[project @ 2002-09-25 14:46:31 by simonmar]
[ghc-hetmet.git] / ghc / rts / Schedule.c
1 /* ---------------------------------------------------------------------------
2  * $Id: Schedule.c,v 1.156 2002/09/25 14:46:31 simonmar Exp $
3  *
4  * (c) The GHC Team, 1998-2000
5  *
6  * Scheduler
7  *
8  * Different GHC ways use this scheduler quite differently (see comments below)
9  * Here is the global picture:
10  *
11  * WAY  Name     CPP flag  What's it for
12  * --------------------------------------
13  * mp   GUM      PAR          Parallel execution on a distributed memory machine
14  * s    SMP      SMP          Parallel execution on a shared memory machine
15  * mg   GranSim  GRAN         Simulation of parallel execution
16  * md   GUM/GdH  DIST         Distributed execution (based on GUM)
17  *
18  * --------------------------------------------------------------------------*/
19
20 //@node Main scheduling code, , ,
21 //@section Main scheduling code
22
23 /* 
24  * Version with scheduler monitor support for SMPs (WAY=s):
25
26    This design provides a high-level API to create and schedule threads etc.
27    as documented in the SMP design document.
28
29    It uses a monitor design controlled by a single mutex to exercise control
30    over accesses to shared data structures, and builds on the Posix threads
31    library.
32
33    The majority of state is shared.  In order to keep essential per-task state,
34    there is a Capability structure, which contains all the information
35    needed to run a thread: its STG registers, a pointer to its TSO, a
36    nursery etc.  During STG execution, a pointer to the capability is
37    kept in a register (BaseReg).
38
39    In a non-SMP build, there is one global capability, namely MainRegTable.
40
41    SDM & KH, 10/99
42
43  * Version with support for distributed memory parallelism aka GUM (WAY=mp):
44
45    The main scheduling loop in GUM iterates until a finish message is received.
46    In that case a global flag @receivedFinish@ is set and this instance of
47    the RTS shuts down. See ghc/rts/parallel/HLComms.c:processMessages()
48    for the handling of incoming messages, such as PP_FINISH.
49    Note that in the parallel case we have a system manager that coordinates
50    different PEs, each of which are running one instance of the RTS.
51    See ghc/rts/parallel/SysMan.c for the main routine of the parallel program.
52    From this routine processes executing ghc/rts/Main.c are spawned. -- HWL
53
54  * Version with support for simulating parallel execution aka GranSim (WAY=mg):
55
56    The main scheduling code in GranSim is quite different from that in std
57    (concurrent) Haskell: while concurrent Haskell just iterates over the
58    threads in the runnable queue, GranSim is event driven, i.e. it iterates
59    over the events in the global event queue.  -- HWL
60 */
61
62 //@menu
63 //* Includes::                  
64 //* Variables and Data structures::  
65 //* Main scheduling loop::      
66 //* Suspend and Resume::        
67 //* Run queue code::            
68 //* Garbage Collextion Routines::  
69 //* Blocking Queue Routines::   
70 //* Exception Handling Routines::  
71 //* Debugging Routines::        
72 //* Index::                     
73 //@end menu
74
75 //@node Includes, Variables and Data structures, Main scheduling code, Main scheduling code
76 //@subsection Includes
77
78 #include "PosixSource.h"
79 #include "Rts.h"
80 #include "SchedAPI.h"
81 #include "RtsUtils.h"
82 #include "RtsFlags.h"
83 #include "Storage.h"
84 #include "StgRun.h"
85 #include "StgStartup.h"
86 #include "Hooks.h"
87 #define COMPILING_SCHEDULER
88 #include "Schedule.h"
89 #include "StgMiscClosures.h"
90 #include "Storage.h"
91 #include "Interpreter.h"
92 #include "Exception.h"
93 #include "Printer.h"
94 #include "Main.h"
95 #include "Signals.h"
96 #include "Sanity.h"
97 #include "Stats.h"
98 #include "Itimer.h"
99 #include "Prelude.h"
100 #include "ThreadLabels.h"
101 #ifdef PROFILING
102 #include "Proftimer.h"
103 #include "ProfHeap.h"
104 #endif
105 #if defined(GRAN) || defined(PAR)
106 # include "GranSimRts.h"
107 # include "GranSim.h"
108 # include "ParallelRts.h"
109 # include "Parallel.h"
110 # include "ParallelDebug.h"
111 # include "FetchMe.h"
112 # include "HLC.h"
113 #endif
114 #include "Sparks.h"
115 #include "Capability.h"
116 #include "OSThreads.h"
117 #include  "Task.h"
118
119 #ifdef HAVE_SYS_TYPES_H
120 #include <sys/types.h>
121 #endif
122 #ifdef HAVE_UNISTD_H
123 #include <unistd.h>
124 #endif
125
126 #include <string.h>
127 #include <stdlib.h>
128 #include <stdarg.h>
129
130 //@node Variables and Data structures, Prototypes, Includes, Main scheduling code
131 //@subsection Variables and Data structures
132
133 /* Main thread queue.
134  * Locks required: sched_mutex.
135  */
136 StgMainThread *main_threads = NULL;
137
138 /* Thread queues.
139  * Locks required: sched_mutex.
140  */
141 #if defined(GRAN)
142
143 StgTSO* ActiveTSO = NULL; /* for assigning system costs; GranSim-Light only */
144 /* rtsTime TimeOfNextEvent, EndOfTimeSlice;            now in GranSim.c */
145
146 /* 
147    In GranSim we have a runnable and a blocked queue for each processor.
148    In order to minimise code changes new arrays run_queue_hds/tls
149    are created. run_queue_hd is then a short cut (macro) for
150    run_queue_hds[CurrentProc] (see GranSim.h).
151    -- HWL
152 */
153 StgTSO *run_queue_hds[MAX_PROC], *run_queue_tls[MAX_PROC];
154 StgTSO *blocked_queue_hds[MAX_PROC], *blocked_queue_tls[MAX_PROC];
155 StgTSO *ccalling_threadss[MAX_PROC];
156 /* We use the same global list of threads (all_threads) in GranSim as in
157    the std RTS (i.e. we are cheating). However, we don't use this list in
158    the GranSim specific code at the moment (so we are only potentially
159    cheating).  */
160
161 #else /* !GRAN */
162
163 StgTSO *run_queue_hd = NULL;
164 StgTSO *run_queue_tl = NULL;
165 StgTSO *blocked_queue_hd = NULL;
166 StgTSO *blocked_queue_tl = NULL;
167 StgTSO *sleeping_queue = NULL;    /* perhaps replace with a hash table? */
168
169 #endif
170
171 /* Linked list of all threads.
172  * Used for detecting garbage collected threads.
173  */
174 StgTSO *all_threads = NULL;
175
176 /* When a thread performs a safe C call (_ccall_GC, using old
177  * terminology), it gets put on the suspended_ccalling_threads
178  * list. Used by the garbage collector.
179  */
180 static StgTSO *suspended_ccalling_threads;
181
182 static StgTSO *threadStackOverflow(StgTSO *tso);
183
184 /* KH: The following two flags are shared memory locations.  There is no need
185        to lock them, since they are only unset at the end of a scheduler
186        operation.
187 */
188
189 /* flag set by signal handler to precipitate a context switch */
190 //@cindex context_switch
191 nat context_switch = 0;
192
193 /* if this flag is set as well, give up execution */
194 //@cindex interrupted
195 rtsBool interrupted = rtsFalse;
196
197 /* Next thread ID to allocate.
198  * Locks required: thread_id_mutex
199  */
200 //@cindex next_thread_id
201 static StgThreadID next_thread_id = 1;
202
203 /*
204  * Pointers to the state of the current thread.
205  * Rule of thumb: if CurrentTSO != NULL, then we're running a Haskell
206  * thread.  If CurrentTSO == NULL, then we're at the scheduler level.
207  */
208  
209 /* The smallest stack size that makes any sense is:
210  *    RESERVED_STACK_WORDS    (so we can get back from the stack overflow)
211  *  + sizeofW(StgStopFrame)   (the stg_stop_thread_info frame)
212  *  + 1                       (the realworld token for an IO thread)
213  *  + 1                       (the closure to enter)
214  *
215  * A thread with this stack will bomb immediately with a stack
216  * overflow, which will increase its stack size.  
217  */
218
219 #define MIN_STACK_WORDS (RESERVED_STACK_WORDS + sizeofW(StgStopFrame) + 2)
220
221
222 #if defined(GRAN)
223 StgTSO *CurrentTSO;
224 #endif
225
226 /*  This is used in `TSO.h' and gcc 2.96 insists that this variable actually 
227  *  exists - earlier gccs apparently didn't.
228  *  -= chak
229  */
230 StgTSO dummy_tso;
231
232 static rtsBool ready_to_gc;
233
234 /*
235  * Set to TRUE when entering a shutdown state (via shutdownHaskellAndExit()) --
236  * in an MT setting, needed to signal that a worker thread shouldn't hang around
237  * in the scheduler when it is out of work.
238  */
239 static rtsBool shutting_down_scheduler = rtsFalse;
240
241 void            addToBlockedQueue ( StgTSO *tso );
242
243 static void     schedule          ( void );
244        void     interruptStgRts   ( void );
245
246 static void     detectBlackHoles  ( void );
247
248 #ifdef DEBUG
249 static void sched_belch(char *s, ...);
250 #endif
251
252 #if defined(RTS_SUPPORTS_THREADS)
253 /* ToDo: carefully document the invariants that go together
254  *       with these synchronisation objects.
255  */
256 Mutex     sched_mutex       = INIT_MUTEX_VAR;
257 Mutex     term_mutex        = INIT_MUTEX_VAR;
258
259 /*
260  * A heavyweight solution to the problem of protecting
261  * the thread_id from concurrent update.
262  */
263 Mutex     thread_id_mutex   = INIT_MUTEX_VAR;
264
265
266 # if defined(SMP)
267 static Condition gc_pending_cond = INIT_COND_VAR;
268 nat await_death;
269 # endif
270
271 #endif /* RTS_SUPPORTS_THREADS */
272
273 #if defined(PAR)
274 StgTSO *LastTSO;
275 rtsTime TimeOfLastYield;
276 rtsBool emitSchedule = rtsTrue;
277 #endif
278
279 #if DEBUG
280 static char *whatNext_strs[] = {
281   "ThreadEnterGHC",
282   "ThreadRunGHC",
283   "ThreadEnterInterp",
284   "ThreadKilled",
285   "ThreadComplete"
286 };
287 #endif
288
289 #if defined(PAR)
290 StgTSO * createSparkThread(rtsSpark spark);
291 StgTSO * activateSpark (rtsSpark spark);  
292 #endif
293
294 /*
295  * The thread state for the main thread.
296 // ToDo: check whether not needed any more
297 StgTSO   *MainTSO;
298  */
299
300 #if defined(PAR) || defined(RTS_SUPPORTS_THREADS)
301 static void taskStart(void);
302 static void
303 taskStart(void)
304 {
305   schedule();
306 }
307 #endif
308
309
310
311
312 //@node Main scheduling loop, Suspend and Resume, Prototypes, Main scheduling code
313 //@subsection Main scheduling loop
314
315 /* ---------------------------------------------------------------------------
316    Main scheduling loop.
317
318    We use round-robin scheduling, each thread returning to the
319    scheduler loop when one of these conditions is detected:
320
321       * out of heap space
322       * timer expires (thread yields)
323       * thread blocks
324       * thread ends
325       * stack overflow
326
327    Locking notes:  we acquire the scheduler lock once at the beginning
328    of the scheduler loop, and release it when
329     
330       * running a thread, or
331       * waiting for work, or
332       * waiting for a GC to complete.
333
334    GRAN version:
335      In a GranSim setup this loop iterates over the global event queue.
336      This revolves around the global event queue, which determines what 
337      to do next. Therefore, it's more complicated than either the 
338      concurrent or the parallel (GUM) setup.
339
340    GUM version:
341      GUM iterates over incoming messages.
342      It starts with nothing to do (thus CurrentTSO == END_TSO_QUEUE),
343      and sends out a fish whenever it has nothing to do; in-between
344      doing the actual reductions (shared code below) it processes the
345      incoming messages and deals with delayed operations 
346      (see PendingFetches).
347      This is not the ugliest code you could imagine, but it's bloody close.
348
349    ------------------------------------------------------------------------ */
350 //@cindex schedule
351 static void
352 schedule( void )
353 {
354   StgTSO *t;
355   Capability *cap;
356   StgThreadReturnCode ret;
357 #if defined(GRAN)
358   rtsEvent *event;
359 #elif defined(PAR)
360   StgSparkPool *pool;
361   rtsSpark spark;
362   StgTSO *tso;
363   GlobalTaskId pe;
364   rtsBool receivedFinish = rtsFalse;
365 # if defined(DEBUG)
366   nat tp_size, sp_size; // stats only
367 # endif
368 #endif
369   rtsBool was_interrupted = rtsFalse;
370   
371   ACQUIRE_LOCK(&sched_mutex);
372  
373 #if defined(RTS_SUPPORTS_THREADS)
374   waitForWorkCapability(&sched_mutex, &cap, rtsFalse);
375 #else
376   /* simply initialise it in the non-threaded case */
377   grabCapability(&cap);
378 #endif
379
380 #if defined(GRAN)
381   /* set up first event to get things going */
382   /* ToDo: assign costs for system setup and init MainTSO ! */
383   new_event(CurrentProc, CurrentProc, CurrentTime[CurrentProc],
384             ContinueThread, 
385             CurrentTSO, (StgClosure*)NULL, (rtsSpark*)NULL);
386
387   IF_DEBUG(gran,
388            fprintf(stderr, "GRAN: Init CurrentTSO (in schedule) = %p\n", CurrentTSO);
389            G_TSO(CurrentTSO, 5));
390
391   if (RtsFlags.GranFlags.Light) {
392     /* Save current time; GranSim Light only */
393     CurrentTSO->gran.clock = CurrentTime[CurrentProc];
394   }      
395
396   event = get_next_event();
397
398   while (event!=(rtsEvent*)NULL) {
399     /* Choose the processor with the next event */
400     CurrentProc = event->proc;
401     CurrentTSO = event->tso;
402
403 #elif defined(PAR)
404
405   while (!receivedFinish) {    /* set by processMessages */
406                                /* when receiving PP_FINISH message         */ 
407 #else
408
409   while (1) {
410
411 #endif
412
413     IF_DEBUG(scheduler, printAllThreads());
414
415 #if defined(RTS_SUPPORTS_THREADS)
416     /* Check to see whether there are any worker threads
417        waiting to deposit external call results. If so,
418        yield our capability */
419     yieldToReturningWorker(&sched_mutex, &cap);
420 #endif
421
422     /* If we're interrupted (the user pressed ^C, or some other
423      * termination condition occurred), kill all the currently running
424      * threads.
425      */
426     if (interrupted) {
427       IF_DEBUG(scheduler, sched_belch("interrupted"));
428       deleteAllThreads();
429       interrupted = rtsFalse;
430       was_interrupted = rtsTrue;
431     }
432
433     /* Go through the list of main threads and wake up any
434      * clients whose computations have finished.  ToDo: this
435      * should be done more efficiently without a linear scan
436      * of the main threads list, somehow...
437      */
438 #if defined(RTS_SUPPORTS_THREADS)
439     { 
440       StgMainThread *m, **prev;
441       prev = &main_threads;
442       for (m = main_threads; m != NULL; m = m->link) {
443         switch (m->tso->what_next) {
444         case ThreadComplete:
445           if (m->ret) {
446             *(m->ret) = (StgClosure *)m->tso->sp[0];
447           }
448           *prev = m->link;
449           m->stat = Success;
450           broadcastCondition(&m->wakeup);
451 #ifdef DEBUG
452           removeThreadLabel((StgWord)m->tso);
453 #endif
454           break;
455         case ThreadKilled:
456           if (m->ret) *(m->ret) = NULL;
457           *prev = m->link;
458           if (was_interrupted) {
459             m->stat = Interrupted;
460           } else {
461             m->stat = Killed;
462           }
463           broadcastCondition(&m->wakeup);
464 #ifdef DEBUG
465           removeThreadLabel((StgWord)m->tso);
466 #endif
467           break;
468         default:
469           break;
470         }
471       }
472     }
473
474 #else /* not threaded */
475
476 # if defined(PAR)
477     /* in GUM do this only on the Main PE */
478     if (IAmMainThread)
479 # endif
480     /* If our main thread has finished or been killed, return.
481      */
482     {
483       StgMainThread *m = main_threads;
484       if (m->tso->what_next == ThreadComplete
485           || m->tso->what_next == ThreadKilled) {
486 #ifdef DEBUG
487         removeThreadLabel((StgWord)m->tso);
488 #endif
489         main_threads = main_threads->link;
490         if (m->tso->what_next == ThreadComplete) {
491           /* we finished successfully, fill in the return value */
492           if (m->ret) { *(m->ret) = (StgClosure *)m->tso->sp[0]; };
493           m->stat = Success;
494           return;
495         } else {
496           if (m->ret) { *(m->ret) = NULL; };
497           if (was_interrupted) {
498             m->stat = Interrupted;
499           } else {
500             m->stat = Killed;
501           }
502           return;
503         }
504       }
505     }
506 #endif
507
508     /* Top up the run queue from our spark pool.  We try to make the
509      * number of threads in the run queue equal to the number of
510      * free capabilities.
511      *
512      * Disable spark support in SMP for now, non-essential & requires
513      * a little bit of work to make it compile cleanly. -- sof 1/02.
514      */
515 #if 0 /* defined(SMP) */
516     {
517       nat n = getFreeCapabilities();
518       StgTSO *tso = run_queue_hd;
519
520       /* Count the run queue */
521       while (n > 0 && tso != END_TSO_QUEUE) {
522         tso = tso->link;
523         n--;
524       }
525
526       for (; n > 0; n--) {
527         StgClosure *spark;
528         spark = findSpark(rtsFalse);
529         if (spark == NULL) {
530           break; /* no more sparks in the pool */
531         } else {
532           /* I'd prefer this to be done in activateSpark -- HWL */
533           /* tricky - it needs to hold the scheduler lock and
534            * not try to re-acquire it -- SDM */
535           createSparkThread(spark);       
536           IF_DEBUG(scheduler,
537                    sched_belch("==^^ turning spark of closure %p into a thread",
538                                (StgClosure *)spark));
539         }
540       }
541       /* We need to wake up the other tasks if we just created some
542        * work for them.
543        */
544       if (getFreeCapabilities() - n > 1) {
545           signalCondition( &thread_ready_cond );
546       }
547     }
548 #endif // SMP
549
550     /* check for signals each time around the scheduler */
551 #ifndef mingw32_TARGET_OS
552     if (signals_pending()) {
553       RELEASE_LOCK(&sched_mutex); /* ToDo: kill */
554       startSignalHandlers();
555       ACQUIRE_LOCK(&sched_mutex);
556     }
557 #endif
558
559     /* Check whether any waiting threads need to be woken up.  If the
560      * run queue is empty, and there are no other tasks running, we
561      * can wait indefinitely for something to happen.
562      * ToDo: what if another client comes along & requests another
563      * main thread?
564      */
565     if ( !EMPTY_QUEUE(blocked_queue_hd) || !EMPTY_QUEUE(sleeping_queue) ) {
566       awaitEvent( EMPTY_RUN_QUEUE()
567 #if defined(SMP)
568         && allFreeCapabilities()
569 #endif
570         );
571     }
572     /* we can be interrupted while waiting for I/O... */
573     if (interrupted) continue;
574
575     /* 
576      * Detect deadlock: when we have no threads to run, there are no
577      * threads waiting on I/O or sleeping, and all the other tasks are
578      * waiting for work, we must have a deadlock of some description.
579      *
580      * We first try to find threads blocked on themselves (ie. black
581      * holes), and generate NonTermination exceptions where necessary.
582      *
583      * If no threads are black holed, we have a deadlock situation, so
584      * inform all the main threads.
585      */
586 #ifndef PAR
587     if (   EMPTY_THREAD_QUEUES()
588 #if defined(RTS_SUPPORTS_THREADS)
589         && EMPTY_QUEUE(suspended_ccalling_threads)
590 #endif
591 #ifdef SMP
592         && allFreeCapabilities()
593 #endif
594         )
595     {
596         IF_DEBUG(scheduler, sched_belch("deadlocked, forcing major GC..."));
597 #if defined(THREADED_RTS)
598         /* and SMP mode ..? */
599         releaseCapability(cap);
600 #endif
601         // Garbage collection can release some new threads due to
602         // either (a) finalizers or (b) threads resurrected because
603         // they are about to be send BlockedOnDeadMVar.  Any threads
604         // thus released will be immediately runnable.
605         GarbageCollect(GetRoots,rtsTrue);
606
607         if ( !EMPTY_RUN_QUEUE() ) { goto not_deadlocked; }
608
609         IF_DEBUG(scheduler, 
610                  sched_belch("still deadlocked, checking for black holes..."));
611         detectBlackHoles();
612
613         if ( !EMPTY_RUN_QUEUE() ) { goto not_deadlocked; }
614
615 #ifndef mingw32_TARGET_OS
616         /* If we have user-installed signal handlers, then wait
617          * for signals to arrive rather then bombing out with a
618          * deadlock.
619          */
620 #if defined(RTS_SUPPORTS_THREADS)
621         if ( 0 ) { /* hmm..what to do? Simply stop waiting for
622                       a signal with no runnable threads (or I/O
623                       suspended ones) leads nowhere quick.
624                       For now, simply shut down when we reach this
625                       condition.
626                       
627                       ToDo: define precisely under what conditions
628                       the Scheduler should shut down in an MT setting.
629                    */
630 #else
631         if ( anyUserHandlers() ) {
632 #endif
633             IF_DEBUG(scheduler, 
634                      sched_belch("still deadlocked, waiting for signals..."));
635
636             awaitUserSignals();
637
638             // we might be interrupted...
639             if (interrupted) { continue; }
640
641             if (signals_pending()) {
642                 RELEASE_LOCK(&sched_mutex);
643                 startSignalHandlers();
644                 ACQUIRE_LOCK(&sched_mutex);
645             }
646             ASSERT(!EMPTY_RUN_QUEUE());
647             goto not_deadlocked;
648         }
649 #endif
650
651         /* Probably a real deadlock.  Send the current main thread the
652          * Deadlock exception (or in the SMP build, send *all* main
653          * threads the deadlock exception, since none of them can make
654          * progress).
655          */
656         {
657             StgMainThread *m;
658 #if defined(RTS_SUPPORTS_THREADS)
659             for (m = main_threads; m != NULL; m = m->link) {
660                 switch (m->tso->why_blocked) {
661                 case BlockedOnBlackHole:
662                     raiseAsync(m->tso, (StgClosure *)NonTermination_closure);
663                     break;
664                 case BlockedOnException:
665                 case BlockedOnMVar:
666                     raiseAsync(m->tso, (StgClosure *)Deadlock_closure);
667                     break;
668                 default:
669                     barf("deadlock: main thread blocked in a strange way");
670                 }
671             }
672 #else
673             m = main_threads;
674             switch (m->tso->why_blocked) {
675             case BlockedOnBlackHole:
676                 raiseAsync(m->tso, (StgClosure *)NonTermination_closure);
677                 break;
678             case BlockedOnException:
679             case BlockedOnMVar:
680                 raiseAsync(m->tso, (StgClosure *)Deadlock_closure);
681                 break;
682             default:
683                 barf("deadlock: main thread blocked in a strange way");
684             }
685 #endif
686         }
687
688 #if defined(RTS_SUPPORTS_THREADS)
689         /* ToDo: revisit conditions (and mechanism) for shutting
690            down a multi-threaded world  */
691         IF_DEBUG(scheduler, sched_belch("all done, i think...shutting down."));
692         RELEASE_LOCK(&sched_mutex);
693         shutdownHaskell();
694         return;
695 #endif
696     }
697   not_deadlocked:
698
699 #elif defined(PAR)
700     /* ToDo: add deadlock detection in GUM (similar to SMP) -- HWL */
701 #endif
702
703 #if defined(SMP)
704     /* If there's a GC pending, don't do anything until it has
705      * completed.
706      */
707     if (ready_to_gc) {
708       IF_DEBUG(scheduler,sched_belch("waiting for GC"));
709       waitCondition( &gc_pending_cond, &sched_mutex );
710     }
711 #endif    
712
713 #if defined(RTS_SUPPORTS_THREADS)
714     /* block until we've got a thread on the run queue and a free
715      * capability.
716      *
717      */
718     if ( EMPTY_RUN_QUEUE() ) {
719       /* Give up our capability */
720       releaseCapability(cap);
721
722       /* If we're in the process of shutting down (& running the
723        * a batch of finalisers), don't wait around.
724        */
725       if ( shutting_down_scheduler ) {
726         RELEASE_LOCK(&sched_mutex);
727         return;
728       }
729       IF_DEBUG(scheduler, sched_belch("thread %d: waiting for work", osThreadId()));
730       waitForWorkCapability(&sched_mutex, &cap, rtsTrue);
731       IF_DEBUG(scheduler, sched_belch("thread %d: work now available", osThreadId()));
732     }
733 #endif
734
735 #if defined(GRAN)
736     if (RtsFlags.GranFlags.Light)
737       GranSimLight_enter_system(event, &ActiveTSO); // adjust ActiveTSO etc
738
739     /* adjust time based on time-stamp */
740     if (event->time > CurrentTime[CurrentProc] &&
741         event->evttype != ContinueThread)
742       CurrentTime[CurrentProc] = event->time;
743     
744     /* Deal with the idle PEs (may issue FindWork or MoveSpark events) */
745     if (!RtsFlags.GranFlags.Light)
746       handleIdlePEs();
747
748     IF_DEBUG(gran, fprintf(stderr, "GRAN: switch by event-type\n"));
749
750     /* main event dispatcher in GranSim */
751     switch (event->evttype) {
752       /* Should just be continuing execution */
753     case ContinueThread:
754       IF_DEBUG(gran, fprintf(stderr, "GRAN: doing ContinueThread\n"));
755       /* ToDo: check assertion
756       ASSERT(run_queue_hd != (StgTSO*)NULL &&
757              run_queue_hd != END_TSO_QUEUE);
758       */
759       /* Ignore ContinueThreads for fetching threads (if synchr comm) */
760       if (!RtsFlags.GranFlags.DoAsyncFetch &&
761           procStatus[CurrentProc]==Fetching) {
762         belch("ghuH: Spurious ContinueThread while Fetching ignored; TSO %d (%p) [PE %d]",
763               CurrentTSO->id, CurrentTSO, CurrentProc);
764         goto next_thread;
765       } 
766       /* Ignore ContinueThreads for completed threads */
767       if (CurrentTSO->what_next == ThreadComplete) {
768         belch("ghuH: found a ContinueThread event for completed thread %d (%p) [PE %d] (ignoring ContinueThread)", 
769               CurrentTSO->id, CurrentTSO, CurrentProc);
770         goto next_thread;
771       } 
772       /* Ignore ContinueThreads for threads that are being migrated */
773       if (PROCS(CurrentTSO)==Nowhere) { 
774         belch("ghuH: trying to run the migrating TSO %d (%p) [PE %d] (ignoring ContinueThread)",
775               CurrentTSO->id, CurrentTSO, CurrentProc);
776         goto next_thread;
777       }
778       /* The thread should be at the beginning of the run queue */
779       if (CurrentTSO!=run_queue_hds[CurrentProc]) { 
780         belch("ghuH: TSO %d (%p) [PE %d] is not at the start of the run_queue when doing a ContinueThread",
781               CurrentTSO->id, CurrentTSO, CurrentProc);
782         break; // run the thread anyway
783       }
784       /*
785       new_event(proc, proc, CurrentTime[proc],
786                 FindWork,
787                 (StgTSO*)NULL, (StgClosure*)NULL, (rtsSpark*)NULL);
788       goto next_thread; 
789       */ /* Catches superfluous CONTINUEs -- should be unnecessary */
790       break; // now actually run the thread; DaH Qu'vam yImuHbej 
791
792     case FetchNode:
793       do_the_fetchnode(event);
794       goto next_thread;             /* handle next event in event queue  */
795       
796     case GlobalBlock:
797       do_the_globalblock(event);
798       goto next_thread;             /* handle next event in event queue  */
799       
800     case FetchReply:
801       do_the_fetchreply(event);
802       goto next_thread;             /* handle next event in event queue  */
803       
804     case UnblockThread:   /* Move from the blocked queue to the tail of */
805       do_the_unblock(event);
806       goto next_thread;             /* handle next event in event queue  */
807       
808     case ResumeThread:  /* Move from the blocked queue to the tail of */
809       /* the runnable queue ( i.e. Qu' SImqa'lu') */ 
810       event->tso->gran.blocktime += 
811         CurrentTime[CurrentProc] - event->tso->gran.blockedat;
812       do_the_startthread(event);
813       goto next_thread;             /* handle next event in event queue  */
814       
815     case StartThread:
816       do_the_startthread(event);
817       goto next_thread;             /* handle next event in event queue  */
818       
819     case MoveThread:
820       do_the_movethread(event);
821       goto next_thread;             /* handle next event in event queue  */
822       
823     case MoveSpark:
824       do_the_movespark(event);
825       goto next_thread;             /* handle next event in event queue  */
826       
827     case FindWork:
828       do_the_findwork(event);
829       goto next_thread;             /* handle next event in event queue  */
830       
831     default:
832       barf("Illegal event type %u\n", event->evttype);
833     }  /* switch */
834     
835     /* This point was scheduler_loop in the old RTS */
836
837     IF_DEBUG(gran, belch("GRAN: after main switch"));
838
839     TimeOfLastEvent = CurrentTime[CurrentProc];
840     TimeOfNextEvent = get_time_of_next_event();
841     IgnoreEvents=(TimeOfNextEvent==0); // HWL HACK
842     // CurrentTSO = ThreadQueueHd;
843
844     IF_DEBUG(gran, belch("GRAN: time of next event is: %ld", 
845                          TimeOfNextEvent));
846
847     if (RtsFlags.GranFlags.Light) 
848       GranSimLight_leave_system(event, &ActiveTSO); 
849
850     EndOfTimeSlice = CurrentTime[CurrentProc]+RtsFlags.GranFlags.time_slice;
851
852     IF_DEBUG(gran, 
853              belch("GRAN: end of time-slice is %#lx", EndOfTimeSlice));
854
855     /* in a GranSim setup the TSO stays on the run queue */
856     t = CurrentTSO;
857     /* Take a thread from the run queue. */
858     t = POP_RUN_QUEUE(); // take_off_run_queue(t);
859
860     IF_DEBUG(gran, 
861              fprintf(stderr, "GRAN: About to run current thread, which is\n");
862              G_TSO(t,5));
863
864     context_switch = 0; // turned on via GranYield, checking events and time slice
865
866     IF_DEBUG(gran, 
867              DumpGranEvent(GR_SCHEDULE, t));
868
869     procStatus[CurrentProc] = Busy;
870
871 #elif defined(PAR)
872     if (PendingFetches != END_BF_QUEUE) {
873         processFetches();
874     }
875
876     /* ToDo: phps merge with spark activation above */
877     /* check whether we have local work and send requests if we have none */
878     if (EMPTY_RUN_QUEUE()) {  /* no runnable threads */
879       /* :-[  no local threads => look out for local sparks */
880       /* the spark pool for the current PE */
881       pool = &(MainRegTable.rSparks); // generalise to cap = &MainRegTable
882       if (advisory_thread_count < RtsFlags.ParFlags.maxThreads &&
883           pool->hd < pool->tl) {
884         /* 
885          * ToDo: add GC code check that we really have enough heap afterwards!!
886          * Old comment:
887          * If we're here (no runnable threads) and we have pending
888          * sparks, we must have a space problem.  Get enough space
889          * to turn one of those pending sparks into a
890          * thread... 
891          */
892
893         spark = findSpark(rtsFalse);                /* get a spark */
894         if (spark != (rtsSpark) NULL) {
895           tso = activateSpark(spark);       /* turn the spark into a thread */
896           IF_PAR_DEBUG(schedule,
897                        belch("==== schedule: Created TSO %d (%p); %d threads active",
898                              tso->id, tso, advisory_thread_count));
899
900           if (tso==END_TSO_QUEUE) { /* failed to activate spark->back to loop */
901             belch("==^^ failed to activate spark");
902             goto next_thread;
903           }               /* otherwise fall through & pick-up new tso */
904         } else {
905           IF_PAR_DEBUG(verbose,
906                        belch("==^^ no local sparks (spark pool contains only NFs: %d)", 
907                              spark_queue_len(pool)));
908           goto next_thread;
909         }
910       }
911
912       /* If we still have no work we need to send a FISH to get a spark
913          from another PE 
914       */
915       if (EMPTY_RUN_QUEUE()) {
916       /* =8-[  no local sparks => look for work on other PEs */
917         /*
918          * We really have absolutely no work.  Send out a fish
919          * (there may be some out there already), and wait for
920          * something to arrive.  We clearly can't run any threads
921          * until a SCHEDULE or RESUME arrives, and so that's what
922          * we're hoping to see.  (Of course, we still have to
923          * respond to other types of messages.)
924          */
925         TIME now = msTime() /*CURRENT_TIME*/;
926         IF_PAR_DEBUG(verbose, 
927                      belch("--  now=%ld", now));
928         IF_PAR_DEBUG(verbose,
929                      if (outstandingFishes < RtsFlags.ParFlags.maxFishes &&
930                          (last_fish_arrived_at!=0 &&
931                           last_fish_arrived_at+RtsFlags.ParFlags.fishDelay > now)) {
932                        belch("--$$ delaying FISH until %ld (last fish %ld, delay %ld, now %ld)",
933                              last_fish_arrived_at+RtsFlags.ParFlags.fishDelay,
934                              last_fish_arrived_at,
935                              RtsFlags.ParFlags.fishDelay, now);
936                      });
937         
938         if (outstandingFishes < RtsFlags.ParFlags.maxFishes &&
939             (last_fish_arrived_at==0 ||
940              (last_fish_arrived_at+RtsFlags.ParFlags.fishDelay <= now))) {
941           /* outstandingFishes is set in sendFish, processFish;
942              avoid flooding system with fishes via delay */
943           pe = choosePE();
944           sendFish(pe, mytid, NEW_FISH_AGE, NEW_FISH_HISTORY, 
945                    NEW_FISH_HUNGER);
946
947           // Global statistics: count no. of fishes
948           if (RtsFlags.ParFlags.ParStats.Global &&
949               RtsFlags.GcFlags.giveStats > NO_GC_STATS) {
950             globalParStats.tot_fish_mess++;
951           }
952         }
953       
954         receivedFinish = processMessages();
955         goto next_thread;
956       }
957     } else if (PacketsWaiting()) {  /* Look for incoming messages */
958       receivedFinish = processMessages();
959     }
960
961     /* Now we are sure that we have some work available */
962     ASSERT(run_queue_hd != END_TSO_QUEUE);
963
964     /* Take a thread from the run queue, if we have work */
965     t = POP_RUN_QUEUE();  // take_off_run_queue(END_TSO_QUEUE);
966     IF_DEBUG(sanity,checkTSO(t));
967
968     /* ToDo: write something to the log-file
969     if (RTSflags.ParFlags.granSimStats && !sameThread)
970         DumpGranEvent(GR_SCHEDULE, RunnableThreadsHd);
971
972     CurrentTSO = t;
973     */
974     /* the spark pool for the current PE */
975     pool = &(MainRegTable.rSparks); // generalise to cap = &MainRegTable
976
977     IF_DEBUG(scheduler, 
978              belch("--=^ %d threads, %d sparks on [%#x]", 
979                    run_queue_len(), spark_queue_len(pool), CURRENT_PROC));
980
981 # if 1
982     if (0 && RtsFlags.ParFlags.ParStats.Full && 
983         t && LastTSO && t->id != LastTSO->id && 
984         LastTSO->why_blocked == NotBlocked && 
985         LastTSO->what_next != ThreadComplete) {
986       // if previously scheduled TSO not blocked we have to record the context switch
987       DumpVeryRawGranEvent(TimeOfLastYield, CURRENT_PROC, CURRENT_PROC,
988                            GR_DESCHEDULE, LastTSO, (StgClosure *)NULL, 0, 0);
989     }
990
991     if (RtsFlags.ParFlags.ParStats.Full && 
992         (emitSchedule /* forced emit */ ||
993         (t && LastTSO && t->id != LastTSO->id))) {
994       /* 
995          we are running a different TSO, so write a schedule event to log file
996          NB: If we use fair scheduling we also have to write  a deschedule 
997              event for LastTSO; with unfair scheduling we know that the
998              previous tso has blocked whenever we switch to another tso, so
999              we don't need it in GUM for now
1000       */
1001       DumpRawGranEvent(CURRENT_PROC, CURRENT_PROC,
1002                        GR_SCHEDULE, t, (StgClosure *)NULL, 0, 0);
1003       emitSchedule = rtsFalse;
1004     }
1005      
1006 # endif
1007 #else /* !GRAN && !PAR */
1008   
1009     /* grab a thread from the run queue */
1010     ASSERT(run_queue_hd != END_TSO_QUEUE);
1011     t = POP_RUN_QUEUE();
1012     // Sanity check the thread we're about to run.  This can be
1013     // expensive if there is lots of thread switching going on...
1014     IF_DEBUG(sanity,checkTSO(t));
1015 #endif
1016     
1017     cap->r.rCurrentTSO = t;
1018     
1019     /* context switches are now initiated by the timer signal, unless
1020      * the user specified "context switch as often as possible", with
1021      * +RTS -C0
1022      */
1023     if (
1024 #ifdef PROFILING
1025         RtsFlags.ProfFlags.profileInterval == 0 ||
1026 #endif
1027         (RtsFlags.ConcFlags.ctxtSwitchTicks == 0
1028          && (run_queue_hd != END_TSO_QUEUE
1029              || blocked_queue_hd != END_TSO_QUEUE
1030              || sleeping_queue != END_TSO_QUEUE)))
1031         context_switch = 1;
1032     else
1033         context_switch = 0;
1034
1035     RELEASE_LOCK(&sched_mutex);
1036
1037     IF_DEBUG(scheduler, sched_belch("-->> Running TSO %ld (%p) %s ...", 
1038                               t->id, t, whatNext_strs[t->what_next]));
1039
1040 #ifdef PROFILING
1041     startHeapProfTimer();
1042 #endif
1043
1044     /* +++++++++++++++++++++++++++++++++++++++++++++++++++++++++++++++++++++ */
1045     /* Run the current thread 
1046      */
1047     switch (cap->r.rCurrentTSO->what_next) {
1048     case ThreadKilled:
1049     case ThreadComplete:
1050         /* Thread already finished, return to scheduler. */
1051         ret = ThreadFinished;
1052         break;
1053     case ThreadEnterGHC:
1054         ret = StgRun((StgFunPtr) stg_enterStackTop, &cap->r);
1055         break;
1056     case ThreadRunGHC:
1057         ret = StgRun((StgFunPtr) stg_returnToStackTop, &cap->r);
1058         break;
1059     case ThreadEnterInterp:
1060         ret = interpretBCO(cap);
1061         break;
1062     default:
1063       barf("schedule: invalid what_next field");
1064     }
1065     /* +++++++++++++++++++++++++++++++++++++++++++++++++++++++++++++++++++++ */
1066     
1067     /* Costs for the scheduler are assigned to CCS_SYSTEM */
1068 #ifdef PROFILING
1069     stopHeapProfTimer();
1070     CCCS = CCS_SYSTEM;
1071 #endif
1072     
1073     ACQUIRE_LOCK(&sched_mutex);
1074
1075 #ifdef SMP
1076     IF_DEBUG(scheduler,fprintf(stderr,"scheduler (task %ld): ", osThreadId()););
1077 #elif !defined(GRAN) && !defined(PAR)
1078     IF_DEBUG(scheduler,fprintf(stderr,"scheduler: "););
1079 #endif
1080     t = cap->r.rCurrentTSO;
1081     
1082 #if defined(PAR)
1083     /* HACK 675: if the last thread didn't yield, make sure to print a 
1084        SCHEDULE event to the log file when StgRunning the next thread, even
1085        if it is the same one as before */
1086     LastTSO = t; 
1087     TimeOfLastYield = CURRENT_TIME;
1088 #endif
1089
1090     switch (ret) {
1091     case HeapOverflow:
1092 #if defined(GRAN)
1093       IF_DEBUG(gran, DumpGranEvent(GR_DESCHEDULE, t));
1094       globalGranStats.tot_heapover++;
1095 #elif defined(PAR)
1096       globalParStats.tot_heapover++;
1097 #endif
1098
1099       // did the task ask for a large block?
1100       if (cap->r.rHpAlloc > BLOCK_SIZE_W) {
1101           // if so, get one and push it on the front of the nursery.
1102           bdescr *bd;
1103           nat blocks;
1104           
1105           blocks = (nat)BLOCK_ROUND_UP(cap->r.rHpAlloc * sizeof(W_)) / BLOCK_SIZE;
1106
1107           IF_DEBUG(scheduler,belch("--<< thread %ld (%p; %s) stopped: requesting a large block (size %d)", 
1108                                    t->id, t,
1109                                    whatNext_strs[t->what_next], blocks));
1110
1111           // don't do this if it would push us over the
1112           // alloc_blocks_lim limit; we'll GC first.
1113           if (alloc_blocks + blocks < alloc_blocks_lim) {
1114
1115               alloc_blocks += blocks;
1116               bd = allocGroup( blocks );
1117
1118               // link the new group into the list
1119               bd->link = cap->r.rCurrentNursery;
1120               bd->u.back = cap->r.rCurrentNursery->u.back;
1121               if (cap->r.rCurrentNursery->u.back != NULL) {
1122                   cap->r.rCurrentNursery->u.back->link = bd;
1123               } else {
1124                   ASSERT(g0s0->blocks == cap->r.rCurrentNursery &&
1125                          g0s0->blocks == cap->r.rNursery);
1126                   cap->r.rNursery = g0s0->blocks = bd;
1127               }           
1128               cap->r.rCurrentNursery->u.back = bd;
1129
1130               // initialise it as a nursery block.  We initialise the
1131               // step, gen_no, and flags field of *every* sub-block in
1132               // this large block, because this is easier than making
1133               // sure that we always find the block head of a large
1134               // block whenever we call Bdescr() (eg. evacuate() and
1135               // isAlive() in the GC would both have to do this, at
1136               // least).
1137               { 
1138                   bdescr *x;
1139                   for (x = bd; x < bd + blocks; x++) {
1140                       x->step = g0s0;
1141                       x->gen_no = 0;
1142                       x->flags = 0;
1143                       x->free = x->start;
1144                   }
1145               }
1146
1147               // don't forget to update the block count in g0s0.
1148               g0s0->n_blocks += blocks;
1149               ASSERT(countBlocks(g0s0->blocks) == g0s0->n_blocks);
1150
1151               // now update the nursery to point to the new block
1152               cap->r.rCurrentNursery = bd;
1153
1154               // we might be unlucky and have another thread get on the
1155               // run queue before us and steal the large block, but in that
1156               // case the thread will just end up requesting another large
1157               // block.
1158               PUSH_ON_RUN_QUEUE(t);
1159               break;
1160           }
1161       }
1162
1163       /* make all the running tasks block on a condition variable,
1164        * maybe set context_switch and wait till they all pile in,
1165        * then have them wait on a GC condition variable.
1166        */
1167       IF_DEBUG(scheduler,belch("--<< thread %ld (%p; %s) stopped: HeapOverflow", 
1168                                t->id, t, whatNext_strs[t->what_next]));
1169       threadPaused(t);
1170 #if defined(GRAN)
1171       ASSERT(!is_on_queue(t,CurrentProc));
1172 #elif defined(PAR)
1173       /* Currently we emit a DESCHEDULE event before GC in GUM.
1174          ToDo: either add separate event to distinguish SYSTEM time from rest
1175                or just nuke this DESCHEDULE (and the following SCHEDULE) */
1176       if (0 && RtsFlags.ParFlags.ParStats.Full) {
1177         DumpRawGranEvent(CURRENT_PROC, CURRENT_PROC,
1178                          GR_DESCHEDULE, t, (StgClosure *)NULL, 0, 0);
1179         emitSchedule = rtsTrue;
1180       }
1181 #endif
1182       
1183       ready_to_gc = rtsTrue;
1184       context_switch = 1;               /* stop other threads ASAP */
1185       PUSH_ON_RUN_QUEUE(t);
1186       /* actual GC is done at the end of the while loop */
1187       break;
1188       
1189     case StackOverflow:
1190 #if defined(GRAN)
1191       IF_DEBUG(gran, 
1192                DumpGranEvent(GR_DESCHEDULE, t));
1193       globalGranStats.tot_stackover++;
1194 #elif defined(PAR)
1195       // IF_DEBUG(par, 
1196       // DumpGranEvent(GR_DESCHEDULE, t);
1197       globalParStats.tot_stackover++;
1198 #endif
1199       IF_DEBUG(scheduler,belch("--<< thread %ld (%p; %s) stopped, StackOverflow", 
1200                                t->id, t, whatNext_strs[t->what_next]));
1201       /* just adjust the stack for this thread, then pop it back
1202        * on the run queue.
1203        */
1204       threadPaused(t);
1205       { 
1206         StgMainThread *m;
1207         /* enlarge the stack */
1208         StgTSO *new_t = threadStackOverflow(t);
1209         
1210         /* This TSO has moved, so update any pointers to it from the
1211          * main thread stack.  It better not be on any other queues...
1212          * (it shouldn't be).
1213          */
1214         for (m = main_threads; m != NULL; m = m->link) {
1215           if (m->tso == t) {
1216             m->tso = new_t;
1217           }
1218         }
1219         threadPaused(new_t);
1220         PUSH_ON_RUN_QUEUE(new_t);
1221       }
1222       break;
1223
1224     case ThreadYielding:
1225 #if defined(GRAN)
1226       IF_DEBUG(gran, 
1227                DumpGranEvent(GR_DESCHEDULE, t));
1228       globalGranStats.tot_yields++;
1229 #elif defined(PAR)
1230       // IF_DEBUG(par, 
1231       // DumpGranEvent(GR_DESCHEDULE, t);
1232       globalParStats.tot_yields++;
1233 #endif
1234       /* put the thread back on the run queue.  Then, if we're ready to
1235        * GC, check whether this is the last task to stop.  If so, wake
1236        * up the GC thread.  getThread will block during a GC until the
1237        * GC is finished.
1238        */
1239       IF_DEBUG(scheduler,
1240                if (t->what_next == ThreadEnterInterp) {
1241                    /* ToDo: or maybe a timer expired when we were in Hugs?
1242                     * or maybe someone hit ctrl-C
1243                     */
1244                    belch("--<< thread %ld (%p; %s) stopped to switch to Hugs", 
1245                          t->id, t, whatNext_strs[t->what_next]);
1246                } else {
1247                    belch("--<< thread %ld (%p; %s) stopped, yielding", 
1248                          t->id, t, whatNext_strs[t->what_next]);
1249                }
1250                );
1251
1252       threadPaused(t);
1253
1254       IF_DEBUG(sanity,
1255                //belch("&& Doing sanity check on yielding TSO %ld.", t->id);
1256                checkTSO(t));
1257       ASSERT(t->link == END_TSO_QUEUE);
1258 #if defined(GRAN)
1259       ASSERT(!is_on_queue(t,CurrentProc));
1260
1261       IF_DEBUG(sanity,
1262                //belch("&& Doing sanity check on all ThreadQueues (and their TSOs).");
1263                checkThreadQsSanity(rtsTrue));
1264 #endif
1265 #if defined(PAR)
1266       if (RtsFlags.ParFlags.doFairScheduling) { 
1267         /* this does round-robin scheduling; good for concurrency */
1268         APPEND_TO_RUN_QUEUE(t);
1269       } else {
1270         /* this does unfair scheduling; good for parallelism */
1271         PUSH_ON_RUN_QUEUE(t);
1272       }
1273 #else
1274       /* this does round-robin scheduling; good for concurrency */
1275       APPEND_TO_RUN_QUEUE(t);
1276 #endif
1277 #if defined(GRAN)
1278       /* add a ContinueThread event to actually process the thread */
1279       new_event(CurrentProc, CurrentProc, CurrentTime[CurrentProc],
1280                 ContinueThread,
1281                 t, (StgClosure*)NULL, (rtsSpark*)NULL);
1282       IF_GRAN_DEBUG(bq, 
1283                belch("GRAN: eventq and runnableq after adding yielded thread to queue again:");
1284                G_EVENTQ(0);
1285                G_CURR_THREADQ(0));
1286 #endif /* GRAN */
1287       break;
1288       
1289     case ThreadBlocked:
1290 #if defined(GRAN)
1291       IF_DEBUG(scheduler,
1292                belch("--<< thread %ld (%p; %s) stopped, blocking on node %p [PE %d] with BQ: ", 
1293                                t->id, t, whatNext_strs[t->what_next], t->block_info.closure, (t->block_info.closure==(StgClosure*)NULL ? 99 : where_is(t->block_info.closure)));
1294                if (t->block_info.closure!=(StgClosure*)NULL) print_bq(t->block_info.closure));
1295
1296       // ??? needed; should emit block before
1297       IF_DEBUG(gran, 
1298                DumpGranEvent(GR_DESCHEDULE, t)); 
1299       prune_eventq(t, (StgClosure *)NULL); // prune ContinueThreads for t
1300       /*
1301         ngoq Dogh!
1302       ASSERT(procStatus[CurrentProc]==Busy || 
1303               ((procStatus[CurrentProc]==Fetching) && 
1304               (t->block_info.closure!=(StgClosure*)NULL)));
1305       if (run_queue_hds[CurrentProc] == END_TSO_QUEUE &&
1306           !(!RtsFlags.GranFlags.DoAsyncFetch &&
1307             procStatus[CurrentProc]==Fetching)) 
1308         procStatus[CurrentProc] = Idle;
1309       */
1310 #elif defined(PAR)
1311       IF_DEBUG(scheduler,
1312                belch("--<< thread %ld (%p; %s) stopped, blocking on node %p with BQ: ", 
1313                      t->id, t, whatNext_strs[t->what_next], t->block_info.closure));
1314       IF_PAR_DEBUG(bq,
1315
1316                    if (t->block_info.closure!=(StgClosure*)NULL) 
1317                      print_bq(t->block_info.closure));
1318
1319       /* Send a fetch (if BlockedOnGA) and dump event to log file */
1320       blockThread(t);
1321
1322       /* whatever we schedule next, we must log that schedule */
1323       emitSchedule = rtsTrue;
1324
1325 #else /* !GRAN */
1326       /* don't need to do anything.  Either the thread is blocked on
1327        * I/O, in which case we'll have called addToBlockedQueue
1328        * previously, or it's blocked on an MVar or Blackhole, in which
1329        * case it'll be on the relevant queue already.
1330        */
1331       IF_DEBUG(scheduler,
1332                fprintf(stderr, "--<< thread %d (%p) stopped: ", t->id, t);
1333                printThreadBlockage(t);
1334                fprintf(stderr, "\n"));
1335
1336       /* Only for dumping event to log file 
1337          ToDo: do I need this in GranSim, too?
1338       blockThread(t);
1339       */
1340 #endif
1341       threadPaused(t);
1342       break;
1343       
1344     case ThreadFinished:
1345       /* Need to check whether this was a main thread, and if so, signal
1346        * the task that started it with the return value.  If we have no
1347        * more main threads, we probably need to stop all the tasks until
1348        * we get a new one.
1349        */
1350       /* We also end up here if the thread kills itself with an
1351        * uncaught exception, see Exception.hc.
1352        */
1353       IF_DEBUG(scheduler,belch("--++ thread %d (%p) finished", t->id, t));
1354 #if defined(GRAN)
1355       endThread(t, CurrentProc); // clean-up the thread
1356 #elif defined(PAR)
1357       /* For now all are advisory -- HWL */
1358       //if(t->priority==AdvisoryPriority) ??
1359       advisory_thread_count--;
1360       
1361 # ifdef DIST
1362       if(t->dist.priority==RevalPriority)
1363         FinishReval(t);
1364 # endif
1365       
1366       if (RtsFlags.ParFlags.ParStats.Full &&
1367           !RtsFlags.ParFlags.ParStats.Suppressed) 
1368         DumpEndEvent(CURRENT_PROC, t, rtsFalse /* not mandatory */);
1369 #endif
1370       break;
1371       
1372     default:
1373       barf("schedule: invalid thread return code %d", (int)ret);
1374     }
1375
1376 #ifdef PROFILING
1377     if (RtsFlags.ProfFlags.profileInterval==0 || performHeapProfile) {
1378         GarbageCollect(GetRoots, rtsTrue);
1379         heapCensus();
1380         performHeapProfile = rtsFalse;
1381         ready_to_gc = rtsFalse; // we already GC'd
1382     }
1383 #endif
1384
1385     if (ready_to_gc 
1386 #ifdef SMP
1387         && allFreeCapabilities() 
1388 #endif
1389         ) {
1390       /* everybody back, start the GC.
1391        * Could do it in this thread, or signal a condition var
1392        * to do it in another thread.  Either way, we need to
1393        * broadcast on gc_pending_cond afterward.
1394        */
1395 #if defined(RTS_SUPPORTS_THREADS)
1396       IF_DEBUG(scheduler,sched_belch("doing GC"));
1397 #endif
1398       GarbageCollect(GetRoots,rtsFalse);
1399       ready_to_gc = rtsFalse;
1400 #ifdef SMP
1401       broadcastCondition(&gc_pending_cond);
1402 #endif
1403 #if defined(GRAN)
1404       /* add a ContinueThread event to continue execution of current thread */
1405       new_event(CurrentProc, CurrentProc, CurrentTime[CurrentProc],
1406                 ContinueThread,
1407                 t, (StgClosure*)NULL, (rtsSpark*)NULL);
1408       IF_GRAN_DEBUG(bq, 
1409                fprintf(stderr, "GRAN: eventq and runnableq after Garbage collection:\n");
1410                G_EVENTQ(0);
1411                G_CURR_THREADQ(0));
1412 #endif /* GRAN */
1413     }
1414
1415 #if defined(GRAN)
1416   next_thread:
1417     IF_GRAN_DEBUG(unused,
1418                   print_eventq(EventHd));
1419
1420     event = get_next_event();
1421 #elif defined(PAR)
1422   next_thread:
1423     /* ToDo: wait for next message to arrive rather than busy wait */
1424 #endif /* GRAN */
1425
1426   } /* end of while(1) */
1427
1428   IF_PAR_DEBUG(verbose,
1429                belch("== Leaving schedule() after having received Finish"));
1430 }
1431
1432 /* ---------------------------------------------------------------------------
1433  * Singleton fork(). Do not copy any running threads.
1434  * ------------------------------------------------------------------------- */
1435
1436 StgInt forkProcess(StgTSO* tso) {
1437
1438 #ifndef mingw32_TARGET_OS
1439   pid_t pid;
1440   StgTSO* t,*next;
1441   StgMainThread *m;
1442   rtsBool doKill;
1443
1444   IF_DEBUG(scheduler,sched_belch("forking!"));
1445
1446   pid = fork();
1447   if (pid) { /* parent */
1448
1449   /* just return the pid */
1450     
1451   } else { /* child */
1452   /* wipe all other threads */
1453   run_queue_hd = run_queue_tl = tso;
1454   tso->link = END_TSO_QUEUE;
1455
1456   /* When clearing out the threads, we need to ensure
1457      that a 'main thread' is left behind; if there isn't,
1458      the Scheduler will shutdown next time it is entered.
1459      
1460      ==> we don't kill a thread that's on the main_threads
1461          list (nor the current thread.)
1462     
1463      [ Attempts at implementing the more ambitious scheme of
1464        killing the main_threads also, and then adding the
1465        current thread onto the main_threads list if it wasn't
1466        there already, failed -- waitThread() (for one) wasn't
1467        up to it. If it proves to be desirable to also kill
1468        the main threads, then this scheme will have to be
1469        revisited (and fully debugged!)
1470        
1471        -- sof 7/2002
1472      ]
1473   */
1474   /* DO NOT TOUCH THE QUEUES directly because most of the code around
1475      us is picky about finding the thread still in its queue when
1476      handling the deleteThread() */
1477
1478   for (t = all_threads; t != END_TSO_QUEUE; t = next) {
1479     next = t->link;
1480     
1481     /* Don't kill the current thread.. */
1482     if (t->id == tso->id) continue;
1483     doKill=rtsTrue;
1484     /* ..or a main thread */
1485     for (m = main_threads; m != NULL; m = m->link) {
1486         if (m->tso->id == t->id) {
1487           doKill=rtsFalse;
1488           break;
1489         }
1490     }
1491     if (doKill) {
1492       deleteThread(t);
1493     }
1494   }
1495   }
1496   return pid;
1497 #else /* mingw32 */
1498   barf("forkProcess#: primop not implemented for mingw32, sorry! (%u)\n", tso->id);
1499   /* pointlessly printing out the TSOs 'id' to avoid CC unused warning. */
1500   return -1;
1501 #endif /* mingw32 */
1502 }
1503
1504 /* ---------------------------------------------------------------------------
1505  * deleteAllThreads():  kill all the live threads.
1506  *
1507  * This is used when we catch a user interrupt (^C), before performing
1508  * any necessary cleanups and running finalizers.
1509  *
1510  * Locks: sched_mutex held.
1511  * ------------------------------------------------------------------------- */
1512    
1513 void deleteAllThreads ( void )
1514 {
1515   StgTSO* t, *next;
1516   IF_DEBUG(scheduler,sched_belch("deleting all threads"));
1517   for (t = all_threads; t != END_TSO_QUEUE; t = next) {
1518       next = t->global_link;
1519       deleteThread(t);
1520   }      
1521   run_queue_hd = run_queue_tl = END_TSO_QUEUE;
1522   blocked_queue_hd = blocked_queue_tl = END_TSO_QUEUE;
1523   sleeping_queue = END_TSO_QUEUE;
1524 }
1525
1526 /* startThread and  insertThread are now in GranSim.c -- HWL */
1527
1528
1529 //@node Suspend and Resume, Run queue code, Main scheduling loop, Main scheduling code
1530 //@subsection Suspend and Resume
1531
1532 /* ---------------------------------------------------------------------------
1533  * Suspending & resuming Haskell threads.
1534  * 
1535  * When making a "safe" call to C (aka _ccall_GC), the task gives back
1536  * its capability before calling the C function.  This allows another
1537  * task to pick up the capability and carry on running Haskell
1538  * threads.  It also means that if the C call blocks, it won't lock
1539  * the whole system.
1540  *
1541  * The Haskell thread making the C call is put to sleep for the
1542  * duration of the call, on the susepended_ccalling_threads queue.  We
1543  * give out a token to the task, which it can use to resume the thread
1544  * on return from the C function.
1545  * ------------------------------------------------------------------------- */
1546    
1547 StgInt
1548 suspendThread( StgRegTable *reg, 
1549                rtsBool concCall
1550 #if !defined(RTS_SUPPORTS_THREADS) && !defined(DEBUG)
1551                STG_UNUSED
1552 #endif
1553                )
1554 {
1555   nat tok;
1556   Capability *cap;
1557
1558   /* assume that *reg is a pointer to the StgRegTable part
1559    * of a Capability.
1560    */
1561   cap = (Capability *)((void *)reg - sizeof(StgFunTable));
1562
1563   ACQUIRE_LOCK(&sched_mutex);
1564
1565   IF_DEBUG(scheduler,
1566            sched_belch("thread %d did a _ccall_gc (is_concurrent: %d)", cap->r.rCurrentTSO->id,concCall));
1567
1568   threadPaused(cap->r.rCurrentTSO);
1569   cap->r.rCurrentTSO->link = suspended_ccalling_threads;
1570   suspended_ccalling_threads = cap->r.rCurrentTSO;
1571
1572 #if defined(RTS_SUPPORTS_THREADS)
1573   cap->r.rCurrentTSO->why_blocked  = BlockedOnCCall;
1574 #endif
1575
1576   /* Use the thread ID as the token; it should be unique */
1577   tok = cap->r.rCurrentTSO->id;
1578
1579   /* Hand back capability */
1580   releaseCapability(cap);
1581   
1582 #if defined(RTS_SUPPORTS_THREADS)
1583   /* Preparing to leave the RTS, so ensure there's a native thread/task
1584      waiting to take over.
1585      
1586      ToDo: optimise this and only create a new task if there's a need
1587      for one (i.e., if there's only one Concurrent Haskell thread alive,
1588      there's no need to create a new task).
1589   */
1590   IF_DEBUG(scheduler, sched_belch("worker thread (%d): leaving RTS", tok));
1591   if (concCall) {
1592     startTask(taskStart);
1593   }
1594 #endif
1595
1596   /* Other threads _might_ be available for execution; signal this */
1597   THREAD_RUNNABLE();
1598   RELEASE_LOCK(&sched_mutex);
1599   return tok; 
1600 }
1601
1602 StgRegTable *
1603 resumeThread( StgInt tok,
1604               rtsBool concCall
1605 #if !defined(RTS_SUPPORTS_THREADS)
1606                STG_UNUSED
1607 #endif
1608               )
1609 {
1610   StgTSO *tso, **prev;
1611   Capability *cap;
1612
1613 #if defined(RTS_SUPPORTS_THREADS)
1614   /* Wait for permission to re-enter the RTS with the result. */
1615   if ( concCall ) {
1616     ACQUIRE_LOCK(&sched_mutex);
1617     grabReturnCapability(&sched_mutex, &cap);
1618   } else {
1619     grabCapability(&cap);
1620   }
1621 #else
1622   grabCapability(&cap);
1623 #endif
1624
1625   /* Remove the thread off of the suspended list */
1626   prev = &suspended_ccalling_threads;
1627   for (tso = suspended_ccalling_threads; 
1628        tso != END_TSO_QUEUE; 
1629        prev = &tso->link, tso = tso->link) {
1630     if (tso->id == (StgThreadID)tok) {
1631       *prev = tso->link;
1632       break;
1633     }
1634   }
1635   if (tso == END_TSO_QUEUE) {
1636     barf("resumeThread: thread not found");
1637   }
1638   tso->link = END_TSO_QUEUE;
1639   /* Reset blocking status */
1640   tso->why_blocked  = NotBlocked;
1641
1642   cap->r.rCurrentTSO = tso;
1643   RELEASE_LOCK(&sched_mutex);
1644   return &cap->r;
1645 }
1646
1647
1648 /* ---------------------------------------------------------------------------
1649  * Static functions
1650  * ------------------------------------------------------------------------ */
1651 static void unblockThread(StgTSO *tso);
1652
1653 /* ---------------------------------------------------------------------------
1654  * Comparing Thread ids.
1655  *
1656  * This is used from STG land in the implementation of the
1657  * instances of Eq/Ord for ThreadIds.
1658  * ------------------------------------------------------------------------ */
1659
1660 int cmp_thread(const StgTSO *tso1, const StgTSO *tso2) 
1661
1662   StgThreadID id1 = tso1->id; 
1663   StgThreadID id2 = tso2->id;
1664  
1665   if (id1 < id2) return (-1);
1666   if (id1 > id2) return 1;
1667   return 0;
1668 }
1669
1670 /* ---------------------------------------------------------------------------
1671  * Fetching the ThreadID from an StgTSO.
1672  *
1673  * This is used in the implementation of Show for ThreadIds.
1674  * ------------------------------------------------------------------------ */
1675 int rts_getThreadId(const StgTSO *tso) 
1676 {
1677   return tso->id;
1678 }
1679
1680 #ifdef DEBUG
1681 void labelThread(StgTSO *tso, char *label)
1682 {
1683   int len;
1684   void *buf;
1685
1686   /* Caveat: Once set, you can only set the thread name to "" */
1687   len = strlen(label)+1;
1688   buf = malloc(len);
1689   if (buf == NULL) {
1690     fprintf(stderr,"insufficient memory for labelThread!\n");
1691   } else
1692     strncpy(buf,label,len);
1693   /* Update will free the old memory for us */
1694   updateThreadLabel((StgWord)tso,buf);
1695 }
1696 #endif /* DEBUG */
1697
1698 /* ---------------------------------------------------------------------------
1699    Create a new thread.
1700
1701    The new thread starts with the given stack size.  Before the
1702    scheduler can run, however, this thread needs to have a closure
1703    (and possibly some arguments) pushed on its stack.  See
1704    pushClosure() in Schedule.h.
1705
1706    createGenThread() and createIOThread() (in SchedAPI.h) are
1707    convenient packaged versions of this function.
1708
1709    currently pri (priority) is only used in a GRAN setup -- HWL
1710    ------------------------------------------------------------------------ */
1711 //@cindex createThread
1712 #if defined(GRAN)
1713 /*   currently pri (priority) is only used in a GRAN setup -- HWL */
1714 StgTSO *
1715 createThread(nat size, StgInt pri)
1716 #else
1717 StgTSO *
1718 createThread(nat size)
1719 #endif
1720 {
1721
1722     StgTSO *tso;
1723     nat stack_size;
1724
1725     /* First check whether we should create a thread at all */
1726 #if defined(PAR)
1727   /* check that no more than RtsFlags.ParFlags.maxThreads threads are created */
1728   if (advisory_thread_count >= RtsFlags.ParFlags.maxThreads) {
1729     threadsIgnored++;
1730     belch("{createThread}Daq ghuH: refusing to create another thread; no more than %d threads allowed (currently %d)",
1731           RtsFlags.ParFlags.maxThreads, advisory_thread_count);
1732     return END_TSO_QUEUE;
1733   }
1734   threadsCreated++;
1735 #endif
1736
1737 #if defined(GRAN)
1738   ASSERT(!RtsFlags.GranFlags.Light || CurrentProc==0);
1739 #endif
1740
1741   // ToDo: check whether size = stack_size - TSO_STRUCT_SIZEW
1742
1743   /* catch ridiculously small stack sizes */
1744   if (size < MIN_STACK_WORDS + TSO_STRUCT_SIZEW) {
1745     size = MIN_STACK_WORDS + TSO_STRUCT_SIZEW;
1746   }
1747
1748   stack_size = size - TSO_STRUCT_SIZEW;
1749
1750   tso = (StgTSO *)allocate(size);
1751   TICK_ALLOC_TSO(stack_size, 0);
1752
1753   SET_HDR(tso, &stg_TSO_info, CCS_SYSTEM);
1754 #if defined(GRAN)
1755   SET_GRAN_HDR(tso, ThisPE);
1756 #endif
1757   tso->what_next     = ThreadEnterGHC;
1758
1759   /* tso->id needs to be unique.  For now we use a heavyweight mutex to
1760    * protect the increment operation on next_thread_id.
1761    * In future, we could use an atomic increment instead.
1762    */
1763   ACQUIRE_LOCK(&thread_id_mutex);
1764   tso->id = next_thread_id++; 
1765   RELEASE_LOCK(&thread_id_mutex);
1766
1767   tso->why_blocked  = NotBlocked;
1768   tso->blocked_exceptions = NULL;
1769
1770   tso->stack_size   = stack_size;
1771   tso->max_stack_size = round_to_mblocks(RtsFlags.GcFlags.maxStkSize) 
1772                               - TSO_STRUCT_SIZEW;
1773   tso->sp           = (P_)&(tso->stack) + stack_size;
1774
1775 #ifdef PROFILING
1776   tso->prof.CCCS = CCS_MAIN;
1777 #endif
1778
1779   /* put a stop frame on the stack */
1780   tso->sp -= sizeofW(StgStopFrame);
1781   SET_HDR((StgClosure*)tso->sp,(StgInfoTable *)&stg_stop_thread_info,CCS_SYSTEM);
1782   tso->su = (StgUpdateFrame*)tso->sp;
1783
1784   // ToDo: check this
1785 #if defined(GRAN)
1786   tso->link = END_TSO_QUEUE;
1787   /* uses more flexible routine in GranSim */
1788   insertThread(tso, CurrentProc);
1789 #else
1790   /* In a non-GranSim setup the pushing of a TSO onto the runq is separated
1791    * from its creation
1792    */
1793 #endif
1794
1795 #if defined(GRAN) 
1796   if (RtsFlags.GranFlags.GranSimStats.Full) 
1797     DumpGranEvent(GR_START,tso);
1798 #elif defined(PAR)
1799   if (RtsFlags.ParFlags.ParStats.Full) 
1800     DumpGranEvent(GR_STARTQ,tso);
1801   /* HACk to avoid SCHEDULE 
1802      LastTSO = tso; */
1803 #endif
1804
1805   /* Link the new thread on the global thread list.
1806    */
1807   tso->global_link = all_threads;
1808   all_threads = tso;
1809
1810 #if defined(DIST)
1811   tso->dist.priority = MandatoryPriority; //by default that is...
1812 #endif
1813
1814 #if defined(GRAN)
1815   tso->gran.pri = pri;
1816 # if defined(DEBUG)
1817   tso->gran.magic = TSO_MAGIC; // debugging only
1818 # endif
1819   tso->gran.sparkname   = 0;
1820   tso->gran.startedat   = CURRENT_TIME; 
1821   tso->gran.exported    = 0;
1822   tso->gran.basicblocks = 0;
1823   tso->gran.allocs      = 0;
1824   tso->gran.exectime    = 0;
1825   tso->gran.fetchtime   = 0;
1826   tso->gran.fetchcount  = 0;
1827   tso->gran.blocktime   = 0;
1828   tso->gran.blockcount  = 0;
1829   tso->gran.blockedat   = 0;
1830   tso->gran.globalsparks = 0;
1831   tso->gran.localsparks  = 0;
1832   if (RtsFlags.GranFlags.Light)
1833     tso->gran.clock  = Now; /* local clock */
1834   else
1835     tso->gran.clock  = 0;
1836
1837   IF_DEBUG(gran,printTSO(tso));
1838 #elif defined(PAR)
1839 # if defined(DEBUG)
1840   tso->par.magic = TSO_MAGIC; // debugging only
1841 # endif
1842   tso->par.sparkname   = 0;
1843   tso->par.startedat   = CURRENT_TIME; 
1844   tso->par.exported    = 0;
1845   tso->par.basicblocks = 0;
1846   tso->par.allocs      = 0;
1847   tso->par.exectime    = 0;
1848   tso->par.fetchtime   = 0;
1849   tso->par.fetchcount  = 0;
1850   tso->par.blocktime   = 0;
1851   tso->par.blockcount  = 0;
1852   tso->par.blockedat   = 0;
1853   tso->par.globalsparks = 0;
1854   tso->par.localsparks  = 0;
1855 #endif
1856
1857 #if defined(GRAN)
1858   globalGranStats.tot_threads_created++;
1859   globalGranStats.threads_created_on_PE[CurrentProc]++;
1860   globalGranStats.tot_sq_len += spark_queue_len(CurrentProc);
1861   globalGranStats.tot_sq_probes++;
1862 #elif defined(PAR)
1863   // collect parallel global statistics (currently done together with GC stats)
1864   if (RtsFlags.ParFlags.ParStats.Global &&
1865       RtsFlags.GcFlags.giveStats > NO_GC_STATS) {
1866     //fprintf(stderr, "Creating thread %d @ %11.2f\n", tso->id, usertime()); 
1867     globalParStats.tot_threads_created++;
1868   }
1869 #endif 
1870
1871 #if defined(GRAN)
1872   IF_GRAN_DEBUG(pri,
1873                 belch("==__ schedule: Created TSO %d (%p);",
1874                       CurrentProc, tso, tso->id));
1875 #elif defined(PAR)
1876     IF_PAR_DEBUG(verbose,
1877                  belch("==__ schedule: Created TSO %d (%p); %d threads active",
1878                        tso->id, tso, advisory_thread_count));
1879 #else
1880   IF_DEBUG(scheduler,sched_belch("created thread %ld, stack size = %lx words", 
1881                                  tso->id, tso->stack_size));
1882 #endif    
1883   return tso;
1884 }
1885
1886 #if defined(PAR)
1887 /* RFP:
1888    all parallel thread creation calls should fall through the following routine.
1889 */
1890 StgTSO *
1891 createSparkThread(rtsSpark spark) 
1892 { StgTSO *tso;
1893   ASSERT(spark != (rtsSpark)NULL);
1894   if (advisory_thread_count >= RtsFlags.ParFlags.maxThreads) 
1895   { threadsIgnored++;
1896     barf("{createSparkThread}Daq ghuH: refusing to create another thread; no more than %d threads allowed (currently %d)",
1897           RtsFlags.ParFlags.maxThreads, advisory_thread_count);    
1898     return END_TSO_QUEUE;
1899   }
1900   else
1901   { threadsCreated++;
1902     tso = createThread(RtsFlags.GcFlags.initialStkSize);
1903     if (tso==END_TSO_QUEUE)     
1904       barf("createSparkThread: Cannot create TSO");
1905 #if defined(DIST)
1906     tso->priority = AdvisoryPriority;
1907 #endif
1908     pushClosure(tso,spark);
1909     PUSH_ON_RUN_QUEUE(tso);
1910     advisory_thread_count++;    
1911   }
1912   return tso;
1913 }
1914 #endif
1915
1916 /*
1917   Turn a spark into a thread.
1918   ToDo: fix for SMP (needs to acquire SCHED_MUTEX!)
1919 */
1920 #if defined(PAR)
1921 //@cindex activateSpark
1922 StgTSO *
1923 activateSpark (rtsSpark spark) 
1924 {
1925   StgTSO *tso;
1926
1927   tso = createSparkThread(spark);
1928   if (RtsFlags.ParFlags.ParStats.Full) {   
1929     //ASSERT(run_queue_hd == END_TSO_QUEUE); // I think ...
1930     IF_PAR_DEBUG(verbose,
1931                  belch("==^^ activateSpark: turning spark of closure %p (%s) into a thread",
1932                        (StgClosure *)spark, info_type((StgClosure *)spark)));
1933   }
1934   // ToDo: fwd info on local/global spark to thread -- HWL
1935   // tso->gran.exported =  spark->exported;
1936   // tso->gran.locked =   !spark->global;
1937   // tso->gran.sparkname = spark->name;
1938
1939   return tso;
1940 }
1941 #endif
1942
1943 static SchedulerStatus waitThread_(/*out*/StgMainThread* m
1944 #if defined(THREADED_RTS)
1945                                    , rtsBool blockWaiting
1946 #endif
1947                                    );
1948
1949
1950 /* ---------------------------------------------------------------------------
1951  * scheduleThread()
1952  *
1953  * scheduleThread puts a thread on the head of the runnable queue.
1954  * This will usually be done immediately after a thread is created.
1955  * The caller of scheduleThread must create the thread using e.g.
1956  * createThread and push an appropriate closure
1957  * on this thread's stack before the scheduler is invoked.
1958  * ------------------------------------------------------------------------ */
1959
1960 static void scheduleThread_ (StgTSO* tso, rtsBool createTask);
1961
1962 void
1963 scheduleThread_(StgTSO *tso
1964                , rtsBool createTask
1965 #if !defined(THREADED_RTS)
1966                  STG_UNUSED
1967 #endif
1968               )
1969 {
1970   ACQUIRE_LOCK(&sched_mutex);
1971
1972   /* Put the new thread on the head of the runnable queue.  The caller
1973    * better push an appropriate closure on this thread's stack
1974    * beforehand.  In the SMP case, the thread may start running as
1975    * soon as we release the scheduler lock below.
1976    */
1977   PUSH_ON_RUN_QUEUE(tso);
1978 #if defined(THREADED_RTS)
1979   /* If main() is scheduling a thread, don't bother creating a 
1980    * new task.
1981    */
1982   if ( createTask ) {
1983     startTask(taskStart);
1984   }
1985 #endif
1986   THREAD_RUNNABLE();
1987
1988 #if 0
1989   IF_DEBUG(scheduler,printTSO(tso));
1990 #endif
1991   RELEASE_LOCK(&sched_mutex);
1992 }
1993
1994 void scheduleThread(StgTSO* tso)
1995 {
1996   scheduleThread_(tso, rtsFalse);
1997 }
1998
1999 SchedulerStatus
2000 scheduleWaitThread(StgTSO* tso, /*[out]*/HaskellObj* ret)
2001 {
2002   StgMainThread *m;
2003
2004   m = stgMallocBytes(sizeof(StgMainThread), "waitThread");
2005   m->tso = tso;
2006   m->ret = ret;
2007   m->stat = NoStatus;
2008 #if defined(RTS_SUPPORTS_THREADS)
2009   initCondition(&m->wakeup);
2010 #endif
2011
2012   /* Put the thread on the main-threads list prior to scheduling the TSO.
2013      Failure to do so introduces a race condition in the MT case (as
2014      identified by Wolfgang Thaller), whereby the new task/OS thread 
2015      created by scheduleThread_() would complete prior to the thread
2016      that spawned it managed to put 'itself' on the main-threads list.
2017      The upshot of it all being that the worker thread wouldn't get to
2018      signal the completion of the its work item for the main thread to
2019      see (==> it got stuck waiting.)    -- sof 6/02.
2020   */
2021   ACQUIRE_LOCK(&sched_mutex);
2022   IF_DEBUG(scheduler, sched_belch("== scheduler: waiting for thread (%d)\n", tso->id));
2023   
2024   m->link = main_threads;
2025   main_threads = m;
2026
2027   /* Inefficient (scheduleThread_() acquires it again right away),
2028    * but obviously correct.
2029    */
2030   RELEASE_LOCK(&sched_mutex);
2031
2032   scheduleThread_(tso, rtsTrue);
2033 #if defined(THREADED_RTS)
2034   return waitThread_(m, rtsTrue);
2035 #else
2036   return waitThread_(m);
2037 #endif
2038 }
2039
2040 /* ---------------------------------------------------------------------------
2041  * initScheduler()
2042  *
2043  * Initialise the scheduler.  This resets all the queues - if the
2044  * queues contained any threads, they'll be garbage collected at the
2045  * next pass.
2046  *
2047  * ------------------------------------------------------------------------ */
2048
2049 #ifdef SMP
2050 static void
2051 term_handler(int sig STG_UNUSED)
2052 {
2053   stat_workerStop();
2054   ACQUIRE_LOCK(&term_mutex);
2055   await_death--;
2056   RELEASE_LOCK(&term_mutex);
2057   shutdownThread();
2058 }
2059 #endif
2060
2061 void 
2062 initScheduler(void)
2063 {
2064 #if defined(GRAN)
2065   nat i;
2066
2067   for (i=0; i<=MAX_PROC; i++) {
2068     run_queue_hds[i]      = END_TSO_QUEUE;
2069     run_queue_tls[i]      = END_TSO_QUEUE;
2070     blocked_queue_hds[i]  = END_TSO_QUEUE;
2071     blocked_queue_tls[i]  = END_TSO_QUEUE;
2072     ccalling_threadss[i]  = END_TSO_QUEUE;
2073     sleeping_queue        = END_TSO_QUEUE;
2074   }
2075 #else
2076   run_queue_hd      = END_TSO_QUEUE;
2077   run_queue_tl      = END_TSO_QUEUE;
2078   blocked_queue_hd  = END_TSO_QUEUE;
2079   blocked_queue_tl  = END_TSO_QUEUE;
2080   sleeping_queue    = END_TSO_QUEUE;
2081 #endif 
2082
2083   suspended_ccalling_threads  = END_TSO_QUEUE;
2084
2085   main_threads = NULL;
2086   all_threads  = END_TSO_QUEUE;
2087
2088   context_switch = 0;
2089   interrupted    = 0;
2090
2091   RtsFlags.ConcFlags.ctxtSwitchTicks =
2092       RtsFlags.ConcFlags.ctxtSwitchTime / TICK_MILLISECS;
2093       
2094 #if defined(RTS_SUPPORTS_THREADS)
2095   /* Initialise the mutex and condition variables used by
2096    * the scheduler. */
2097   initMutex(&sched_mutex);
2098   initMutex(&term_mutex);
2099   initMutex(&thread_id_mutex);
2100
2101   initCondition(&thread_ready_cond);
2102 #endif
2103   
2104 #if defined(SMP)
2105   initCondition(&gc_pending_cond);
2106 #endif
2107
2108 #if defined(RTS_SUPPORTS_THREADS)
2109   ACQUIRE_LOCK(&sched_mutex);
2110 #endif
2111
2112   /* Install the SIGHUP handler */
2113 #if defined(SMP)
2114   {
2115     struct sigaction action,oact;
2116
2117     action.sa_handler = term_handler;
2118     sigemptyset(&action.sa_mask);
2119     action.sa_flags = 0;
2120     if (sigaction(SIGTERM, &action, &oact) != 0) {
2121       barf("can't install TERM handler");
2122     }
2123   }
2124 #endif
2125
2126   /* A capability holds the state a native thread needs in
2127    * order to execute STG code. At least one capability is
2128    * floating around (only SMP builds have more than one).
2129    */
2130   initCapabilities();
2131   
2132 #if defined(RTS_SUPPORTS_THREADS)
2133     /* start our haskell execution tasks */
2134 # if defined(SMP)
2135     startTaskManager(RtsFlags.ParFlags.nNodes, taskStart);
2136 # else
2137     startTaskManager(0,taskStart);
2138 # endif
2139 #endif
2140
2141 #if /* defined(SMP) ||*/ defined(PAR)
2142   initSparkPools();
2143 #endif
2144
2145 #if defined(RTS_SUPPORTS_THREADS)
2146   RELEASE_LOCK(&sched_mutex);
2147 #endif
2148
2149 }
2150
2151 void
2152 exitScheduler( void )
2153 {
2154 #if defined(RTS_SUPPORTS_THREADS)
2155   stopTaskManager();
2156 #endif
2157   shutting_down_scheduler = rtsTrue;
2158 }
2159
2160 /* -----------------------------------------------------------------------------
2161    Managing the per-task allocation areas.
2162    
2163    Each capability comes with an allocation area.  These are
2164    fixed-length block lists into which allocation can be done.
2165
2166    ToDo: no support for two-space collection at the moment???
2167    -------------------------------------------------------------------------- */
2168
2169 /* -----------------------------------------------------------------------------
2170  * waitThread is the external interface for running a new computation
2171  * and waiting for the result.
2172  *
2173  * In the non-SMP case, we create a new main thread, push it on the 
2174  * main-thread stack, and invoke the scheduler to run it.  The
2175  * scheduler will return when the top main thread on the stack has
2176  * completed or died, and fill in the necessary fields of the
2177  * main_thread structure.
2178  *
2179  * In the SMP case, we create a main thread as before, but we then
2180  * create a new condition variable and sleep on it.  When our new
2181  * main thread has completed, we'll be woken up and the status/result
2182  * will be in the main_thread struct.
2183  * -------------------------------------------------------------------------- */
2184
2185 int 
2186 howManyThreadsAvail ( void )
2187 {
2188    int i = 0;
2189    StgTSO* q;
2190    for (q = run_queue_hd; q != END_TSO_QUEUE; q = q->link)
2191       i++;
2192    for (q = blocked_queue_hd; q != END_TSO_QUEUE; q = q->link)
2193       i++;
2194    for (q = sleeping_queue; q != END_TSO_QUEUE; q = q->link)
2195       i++;
2196    return i;
2197 }
2198
2199 void
2200 finishAllThreads ( void )
2201 {
2202    do {
2203       while (run_queue_hd != END_TSO_QUEUE) {
2204          waitThread ( run_queue_hd, NULL);
2205       }
2206       while (blocked_queue_hd != END_TSO_QUEUE) {
2207          waitThread ( blocked_queue_hd, NULL);
2208       }
2209       while (sleeping_queue != END_TSO_QUEUE) {
2210          waitThread ( blocked_queue_hd, NULL);
2211       }
2212    } while 
2213       (blocked_queue_hd != END_TSO_QUEUE || 
2214        run_queue_hd     != END_TSO_QUEUE ||
2215        sleeping_queue   != END_TSO_QUEUE);
2216 }
2217
2218 SchedulerStatus
2219 waitThread(StgTSO *tso, /*out*/StgClosure **ret)
2220
2221   StgMainThread *m;
2222
2223   m = stgMallocBytes(sizeof(StgMainThread), "waitThread");
2224   m->tso = tso;
2225   m->ret = ret;
2226   m->stat = NoStatus;
2227 #if defined(RTS_SUPPORTS_THREADS)
2228   initCondition(&m->wakeup);
2229 #endif
2230
2231   /* see scheduleWaitThread() comment */
2232   ACQUIRE_LOCK(&sched_mutex);
2233   IF_DEBUG(scheduler, sched_belch("== scheduler: waiting for thread (%d)\n", tso->id));
2234   m->link = main_threads;
2235   main_threads = m;
2236   RELEASE_LOCK(&sched_mutex);
2237
2238   IF_DEBUG(scheduler, sched_belch("== scheduler: waiting for thread (%d)\n", tso->id));
2239 #if defined(THREADED_RTS)
2240   return waitThread_(m, rtsFalse);
2241 #else
2242   return waitThread_(m);
2243 #endif
2244 }
2245
2246 static
2247 SchedulerStatus
2248 waitThread_(StgMainThread* m
2249 #if defined(THREADED_RTS)
2250             , rtsBool blockWaiting
2251 #endif
2252            )
2253 {
2254   SchedulerStatus stat;
2255
2256   IF_DEBUG(scheduler, sched_belch("== scheduler: new main thread (%d)\n", m->tso->id));
2257
2258 #if defined(RTS_SUPPORTS_THREADS)
2259
2260 # if defined(THREADED_RTS)
2261   if (!blockWaiting) {
2262     /* In the threaded case, the OS thread that called main()
2263      * gets to enter the RTS directly without going via another
2264      * task/thread.
2265      */
2266     schedule();
2267     ASSERT(m->stat != NoStatus);
2268   } else 
2269 # endif
2270   {
2271     ACQUIRE_LOCK(&sched_mutex);
2272     do {
2273       waitCondition(&m->wakeup, &sched_mutex);
2274     } while (m->stat == NoStatus);
2275   }
2276 #elif defined(GRAN)
2277   /* GranSim specific init */
2278   CurrentTSO = m->tso;                // the TSO to run
2279   procStatus[MainProc] = Busy;        // status of main PE
2280   CurrentProc = MainProc;             // PE to run it on
2281
2282   schedule();
2283 #else
2284   RELEASE_LOCK(&sched_mutex);
2285   schedule();
2286   ASSERT(m->stat != NoStatus);
2287 #endif
2288
2289   stat = m->stat;
2290
2291 #if defined(RTS_SUPPORTS_THREADS)
2292   closeCondition(&m->wakeup);
2293 #endif
2294
2295   IF_DEBUG(scheduler, fprintf(stderr, "== scheduler: main thread (%d) finished\n", 
2296                               m->tso->id));
2297   free(m);
2298
2299 #if defined(THREADED_RTS)
2300   if (blockWaiting) 
2301 #endif
2302     RELEASE_LOCK(&sched_mutex);
2303
2304   return stat;
2305 }
2306
2307 //@node Run queue code, Garbage Collextion Routines, Suspend and Resume, Main scheduling code
2308 //@subsection Run queue code 
2309
2310 #if 0
2311 /* 
2312    NB: In GranSim we have many run queues; run_queue_hd is actually a macro
2313        unfolding to run_queue_hds[CurrentProc], thus CurrentProc is an
2314        implicit global variable that has to be correct when calling these
2315        fcts -- HWL 
2316 */
2317
2318 /* Put the new thread on the head of the runnable queue.
2319  * The caller of createThread better push an appropriate closure
2320  * on this thread's stack before the scheduler is invoked.
2321  */
2322 static /* inline */ void
2323 add_to_run_queue(tso)
2324 StgTSO* tso; 
2325 {
2326   ASSERT(tso!=run_queue_hd && tso!=run_queue_tl);
2327   tso->link = run_queue_hd;
2328   run_queue_hd = tso;
2329   if (run_queue_tl == END_TSO_QUEUE) {
2330     run_queue_tl = tso;
2331   }
2332 }
2333
2334 /* Put the new thread at the end of the runnable queue. */
2335 static /* inline */ void
2336 push_on_run_queue(tso)
2337 StgTSO* tso; 
2338 {
2339   ASSERT(get_itbl((StgClosure *)tso)->type == TSO);
2340   ASSERT(run_queue_hd!=NULL && run_queue_tl!=NULL);
2341   ASSERT(tso!=run_queue_hd && tso!=run_queue_tl);
2342   if (run_queue_hd == END_TSO_QUEUE) {
2343     run_queue_hd = tso;
2344   } else {
2345     run_queue_tl->link = tso;
2346   }
2347   run_queue_tl = tso;
2348 }
2349
2350 /* 
2351    Should be inlined because it's used very often in schedule.  The tso
2352    argument is actually only needed in GranSim, where we want to have the
2353    possibility to schedule *any* TSO on the run queue, irrespective of the
2354    actual ordering. Therefore, if tso is not the nil TSO then we traverse
2355    the run queue and dequeue the tso, adjusting the links in the queue. 
2356 */
2357 //@cindex take_off_run_queue
2358 static /* inline */ StgTSO*
2359 take_off_run_queue(StgTSO *tso) {
2360   StgTSO *t, *prev;
2361
2362   /* 
2363      qetlaHbogh Qu' ngaSbogh ghomDaQ {tso} yIteq!
2364
2365      if tso is specified, unlink that tso from the run_queue (doesn't have
2366      to be at the beginning of the queue); GranSim only 
2367   */
2368   if (tso!=END_TSO_QUEUE) {
2369     /* find tso in queue */
2370     for (t=run_queue_hd, prev=END_TSO_QUEUE; 
2371          t!=END_TSO_QUEUE && t!=tso;
2372          prev=t, t=t->link) 
2373       /* nothing */ ;
2374     ASSERT(t==tso);
2375     /* now actually dequeue the tso */
2376     if (prev!=END_TSO_QUEUE) {
2377       ASSERT(run_queue_hd!=t);
2378       prev->link = t->link;
2379     } else {
2380       /* t is at beginning of thread queue */
2381       ASSERT(run_queue_hd==t);
2382       run_queue_hd = t->link;
2383     }
2384     /* t is at end of thread queue */
2385     if (t->link==END_TSO_QUEUE) {
2386       ASSERT(t==run_queue_tl);
2387       run_queue_tl = prev;
2388     } else {
2389       ASSERT(run_queue_tl!=t);
2390     }
2391     t->link = END_TSO_QUEUE;
2392   } else {
2393     /* take tso from the beginning of the queue; std concurrent code */
2394     t = run_queue_hd;
2395     if (t != END_TSO_QUEUE) {
2396       run_queue_hd = t->link;
2397       t->link = END_TSO_QUEUE;
2398       if (run_queue_hd == END_TSO_QUEUE) {
2399         run_queue_tl = END_TSO_QUEUE;
2400       }
2401     }
2402   }
2403   return t;
2404 }
2405
2406 #endif /* 0 */
2407
2408 //@node Garbage Collextion Routines, Blocking Queue Routines, Run queue code, Main scheduling code
2409 //@subsection Garbage Collextion Routines
2410
2411 /* ---------------------------------------------------------------------------
2412    Where are the roots that we know about?
2413
2414         - all the threads on the runnable queue
2415         - all the threads on the blocked queue
2416         - all the threads on the sleeping queue
2417         - all the thread currently executing a _ccall_GC
2418         - all the "main threads"
2419      
2420    ------------------------------------------------------------------------ */
2421
2422 /* This has to be protected either by the scheduler monitor, or by the
2423         garbage collection monitor (probably the latter).
2424         KH @ 25/10/99
2425 */
2426
2427 void
2428 GetRoots(evac_fn evac)
2429 {
2430 #if defined(GRAN)
2431   {
2432     nat i;
2433     for (i=0; i<=RtsFlags.GranFlags.proc; i++) {
2434       if ((run_queue_hds[i] != END_TSO_QUEUE) && ((run_queue_hds[i] != NULL)))
2435           evac((StgClosure **)&run_queue_hds[i]);
2436       if ((run_queue_tls[i] != END_TSO_QUEUE) && ((run_queue_tls[i] != NULL)))
2437           evac((StgClosure **)&run_queue_tls[i]);
2438       
2439       if ((blocked_queue_hds[i] != END_TSO_QUEUE) && ((blocked_queue_hds[i] != NULL)))
2440           evac((StgClosure **)&blocked_queue_hds[i]);
2441       if ((blocked_queue_tls[i] != END_TSO_QUEUE) && ((blocked_queue_tls[i] != NULL)))
2442           evac((StgClosure **)&blocked_queue_tls[i]);
2443       if ((ccalling_threadss[i] != END_TSO_QUEUE) && ((ccalling_threadss[i] != NULL)))
2444           evac((StgClosure **)&ccalling_threads[i]);
2445     }
2446   }
2447
2448   markEventQueue();
2449
2450 #else /* !GRAN */
2451   if (run_queue_hd != END_TSO_QUEUE) {
2452       ASSERT(run_queue_tl != END_TSO_QUEUE);
2453       evac((StgClosure **)&run_queue_hd);
2454       evac((StgClosure **)&run_queue_tl);
2455   }
2456   
2457   if (blocked_queue_hd != END_TSO_QUEUE) {
2458       ASSERT(blocked_queue_tl != END_TSO_QUEUE);
2459       evac((StgClosure **)&blocked_queue_hd);
2460       evac((StgClosure **)&blocked_queue_tl);
2461   }
2462   
2463   if (sleeping_queue != END_TSO_QUEUE) {
2464       evac((StgClosure **)&sleeping_queue);
2465   }
2466 #endif 
2467
2468   if (suspended_ccalling_threads != END_TSO_QUEUE) {
2469       evac((StgClosure **)&suspended_ccalling_threads);
2470   }
2471
2472 #if defined(PAR) || defined(GRAN)
2473   markSparkQueue(evac);
2474 #endif
2475
2476 #ifndef mingw32_TARGET_OS
2477   // mark the signal handlers (signals should be already blocked)
2478   markSignalHandlers(evac);
2479 #endif
2480
2481   // main threads which have completed need to be retained until they
2482   // are dealt with in the main scheduler loop.  They won't be
2483   // retained any other way: the GC will drop them from the
2484   // all_threads list, so we have to be careful to treat them as roots
2485   // here.
2486   { 
2487       StgMainThread *m;
2488       for (m = main_threads; m != NULL; m = m->link) {
2489           switch (m->tso->what_next) {
2490           case ThreadComplete:
2491           case ThreadKilled:
2492               evac((StgClosure **)&m->tso);
2493               break;
2494           default:
2495               break;
2496           }
2497       }
2498   }
2499 }
2500
2501 /* -----------------------------------------------------------------------------
2502    performGC
2503
2504    This is the interface to the garbage collector from Haskell land.
2505    We provide this so that external C code can allocate and garbage
2506    collect when called from Haskell via _ccall_GC.
2507
2508    It might be useful to provide an interface whereby the programmer
2509    can specify more roots (ToDo).
2510    
2511    This needs to be protected by the GC condition variable above.  KH.
2512    -------------------------------------------------------------------------- */
2513
2514 static void (*extra_roots)(evac_fn);
2515
2516 void
2517 performGC(void)
2518 {
2519   /* Obligated to hold this lock upon entry */
2520   ACQUIRE_LOCK(&sched_mutex);
2521   GarbageCollect(GetRoots,rtsFalse);
2522   RELEASE_LOCK(&sched_mutex);
2523 }
2524
2525 void
2526 performMajorGC(void)
2527 {
2528   ACQUIRE_LOCK(&sched_mutex);
2529   GarbageCollect(GetRoots,rtsTrue);
2530   RELEASE_LOCK(&sched_mutex);
2531 }
2532
2533 static void
2534 AllRoots(evac_fn evac)
2535 {
2536     GetRoots(evac);             // the scheduler's roots
2537     extra_roots(evac);          // the user's roots
2538 }
2539
2540 void
2541 performGCWithRoots(void (*get_roots)(evac_fn))
2542 {
2543   ACQUIRE_LOCK(&sched_mutex);
2544   extra_roots = get_roots;
2545   GarbageCollect(AllRoots,rtsFalse);
2546   RELEASE_LOCK(&sched_mutex);
2547 }
2548
2549 /* -----------------------------------------------------------------------------
2550    Stack overflow
2551
2552    If the thread has reached its maximum stack size, then raise the
2553    StackOverflow exception in the offending thread.  Otherwise
2554    relocate the TSO into a larger chunk of memory and adjust its stack
2555    size appropriately.
2556    -------------------------------------------------------------------------- */
2557
2558 static StgTSO *
2559 threadStackOverflow(StgTSO *tso)
2560 {
2561   nat new_stack_size, new_tso_size, diff, stack_words;
2562   StgPtr new_sp;
2563   StgTSO *dest;
2564
2565   IF_DEBUG(sanity,checkTSO(tso));
2566   if (tso->stack_size >= tso->max_stack_size) {
2567
2568     IF_DEBUG(gc,
2569              belch("@@ threadStackOverflow of TSO %d (%p): stack too large (now %ld; max is %ld",
2570                    tso->id, tso, tso->stack_size, tso->max_stack_size);
2571              /* If we're debugging, just print out the top of the stack */
2572              printStackChunk(tso->sp, stg_min(tso->stack+tso->stack_size, 
2573                                               tso->sp+64)));
2574
2575     /* Send this thread the StackOverflow exception */
2576     raiseAsync(tso, (StgClosure *)stackOverflow_closure);
2577     return tso;
2578   }
2579
2580   /* Try to double the current stack size.  If that takes us over the
2581    * maximum stack size for this thread, then use the maximum instead.
2582    * Finally round up so the TSO ends up as a whole number of blocks.
2583    */
2584   new_stack_size = stg_min(tso->stack_size * 2, tso->max_stack_size);
2585   new_tso_size   = (nat)BLOCK_ROUND_UP(new_stack_size * sizeof(W_) + 
2586                                        TSO_STRUCT_SIZE)/sizeof(W_);
2587   new_tso_size = round_to_mblocks(new_tso_size);  /* Be MBLOCK-friendly */
2588   new_stack_size = new_tso_size - TSO_STRUCT_SIZEW;
2589
2590   IF_DEBUG(scheduler, fprintf(stderr,"== scheduler: increasing stack size from %d words to %d.\n", tso->stack_size, new_stack_size));
2591
2592   dest = (StgTSO *)allocate(new_tso_size);
2593   TICK_ALLOC_TSO(new_stack_size,0);
2594
2595   /* copy the TSO block and the old stack into the new area */
2596   memcpy(dest,tso,TSO_STRUCT_SIZE);
2597   stack_words = tso->stack + tso->stack_size - tso->sp;
2598   new_sp = (P_)dest + new_tso_size - stack_words;
2599   memcpy(new_sp, tso->sp, stack_words * sizeof(W_));
2600
2601   /* relocate the stack pointers... */
2602   diff = (P_)new_sp - (P_)tso->sp; /* In *words* */
2603   dest->su    = (StgUpdateFrame *) ((P_)dest->su + diff);
2604   dest->sp    = new_sp;
2605   dest->stack_size = new_stack_size;
2606         
2607   /* and relocate the update frame list */
2608   relocate_stack(dest, diff);
2609
2610   /* Mark the old TSO as relocated.  We have to check for relocated
2611    * TSOs in the garbage collector and any primops that deal with TSOs.
2612    *
2613    * It's important to set the sp and su values to just beyond the end
2614    * of the stack, so we don't attempt to scavenge any part of the
2615    * dead TSO's stack.
2616    */
2617   tso->what_next = ThreadRelocated;
2618   tso->link = dest;
2619   tso->sp = (P_)&(tso->stack[tso->stack_size]);
2620   tso->su = (StgUpdateFrame *)tso->sp;
2621   tso->why_blocked = NotBlocked;
2622   dest->mut_link = NULL;
2623
2624   IF_PAR_DEBUG(verbose,
2625                belch("@@ threadStackOverflow of TSO %d (now at %p): stack size increased to %ld",
2626                      tso->id, tso, tso->stack_size);
2627                /* If we're debugging, just print out the top of the stack */
2628                printStackChunk(tso->sp, stg_min(tso->stack+tso->stack_size, 
2629                                                 tso->sp+64)));
2630   
2631   IF_DEBUG(sanity,checkTSO(tso));
2632 #if 0
2633   IF_DEBUG(scheduler,printTSO(dest));
2634 #endif
2635
2636   return dest;
2637 }
2638
2639 //@node Blocking Queue Routines, Exception Handling Routines, Garbage Collextion Routines, Main scheduling code
2640 //@subsection Blocking Queue Routines
2641
2642 /* ---------------------------------------------------------------------------
2643    Wake up a queue that was blocked on some resource.
2644    ------------------------------------------------------------------------ */
2645
2646 #if defined(GRAN)
2647 static inline void
2648 unblockCount ( StgBlockingQueueElement *bqe, StgClosure *node )
2649 {
2650 }
2651 #elif defined(PAR)
2652 static inline void
2653 unblockCount ( StgBlockingQueueElement *bqe, StgClosure *node )
2654 {
2655   /* write RESUME events to log file and
2656      update blocked and fetch time (depending on type of the orig closure) */
2657   if (RtsFlags.ParFlags.ParStats.Full) {
2658     DumpRawGranEvent(CURRENT_PROC, CURRENT_PROC, 
2659                      GR_RESUMEQ, ((StgTSO *)bqe), ((StgTSO *)bqe)->block_info.closure,
2660                      0, 0 /* spark_queue_len(ADVISORY_POOL) */);
2661     if (EMPTY_RUN_QUEUE())
2662       emitSchedule = rtsTrue;
2663
2664     switch (get_itbl(node)->type) {
2665         case FETCH_ME_BQ:
2666           ((StgTSO *)bqe)->par.fetchtime += CURRENT_TIME-((StgTSO *)bqe)->par.blockedat;
2667           break;
2668         case RBH:
2669         case FETCH_ME:
2670         case BLACKHOLE_BQ:
2671           ((StgTSO *)bqe)->par.blocktime += CURRENT_TIME-((StgTSO *)bqe)->par.blockedat;
2672           break;
2673 #ifdef DIST
2674         case MVAR:
2675           break;
2676 #endif    
2677         default:
2678           barf("{unblockOneLocked}Daq Qagh: unexpected closure in blocking queue");
2679         }
2680       }
2681 }
2682 #endif
2683
2684 #if defined(GRAN)
2685 static StgBlockingQueueElement *
2686 unblockOneLocked(StgBlockingQueueElement *bqe, StgClosure *node)
2687 {
2688     StgTSO *tso;
2689     PEs node_loc, tso_loc;
2690
2691     node_loc = where_is(node); // should be lifted out of loop
2692     tso = (StgTSO *)bqe;  // wastes an assignment to get the type right
2693     tso_loc = where_is((StgClosure *)tso);
2694     if (IS_LOCAL_TO(PROCS(node),tso_loc)) { // TSO is local
2695       /* !fake_fetch => TSO is on CurrentProc is same as IS_LOCAL_TO */
2696       ASSERT(CurrentProc!=node_loc || tso_loc==CurrentProc);
2697       CurrentTime[CurrentProc] += RtsFlags.GranFlags.Costs.lunblocktime;
2698       // insertThread(tso, node_loc);
2699       new_event(tso_loc, tso_loc, CurrentTime[CurrentProc],
2700                 ResumeThread,
2701                 tso, node, (rtsSpark*)NULL);
2702       tso->link = END_TSO_QUEUE; // overwrite link just to be sure 
2703       // len_local++;
2704       // len++;
2705     } else { // TSO is remote (actually should be FMBQ)
2706       CurrentTime[CurrentProc] += RtsFlags.GranFlags.Costs.mpacktime +
2707                                   RtsFlags.GranFlags.Costs.gunblocktime +
2708                                   RtsFlags.GranFlags.Costs.latency;
2709       new_event(tso_loc, CurrentProc, CurrentTime[CurrentProc],
2710                 UnblockThread,
2711                 tso, node, (rtsSpark*)NULL);
2712       tso->link = END_TSO_QUEUE; // overwrite link just to be sure 
2713       // len++;
2714     }
2715     /* the thread-queue-overhead is accounted for in either Resume or UnblockThread */
2716     IF_GRAN_DEBUG(bq,
2717                   fprintf(stderr," %s TSO %d (%p) [PE %d] (block_info.closure=%p) (next=%p) ,",
2718                           (node_loc==tso_loc ? "Local" : "Global"), 
2719                           tso->id, tso, CurrentProc, tso->block_info.closure, tso->link));
2720     tso->block_info.closure = NULL;
2721     IF_DEBUG(scheduler,belch("-- Waking up thread %ld (%p)", 
2722                              tso->id, tso));
2723 }
2724 #elif defined(PAR)
2725 static StgBlockingQueueElement *
2726 unblockOneLocked(StgBlockingQueueElement *bqe, StgClosure *node)
2727 {
2728     StgBlockingQueueElement *next;
2729
2730     switch (get_itbl(bqe)->type) {
2731     case TSO:
2732       ASSERT(((StgTSO *)bqe)->why_blocked != NotBlocked);
2733       /* if it's a TSO just push it onto the run_queue */
2734       next = bqe->link;
2735       // ((StgTSO *)bqe)->link = END_TSO_QUEUE; // debugging?
2736       PUSH_ON_RUN_QUEUE((StgTSO *)bqe); 
2737       THREAD_RUNNABLE();
2738       unblockCount(bqe, node);
2739       /* reset blocking status after dumping event */
2740       ((StgTSO *)bqe)->why_blocked = NotBlocked;
2741       break;
2742
2743     case BLOCKED_FETCH:
2744       /* if it's a BLOCKED_FETCH put it on the PendingFetches list */
2745       next = bqe->link;
2746       bqe->link = (StgBlockingQueueElement *)PendingFetches;
2747       PendingFetches = (StgBlockedFetch *)bqe;
2748       break;
2749
2750 # if defined(DEBUG)
2751       /* can ignore this case in a non-debugging setup; 
2752          see comments on RBHSave closures above */
2753     case CONSTR:
2754       /* check that the closure is an RBHSave closure */
2755       ASSERT(get_itbl((StgClosure *)bqe) == &stg_RBH_Save_0_info ||
2756              get_itbl((StgClosure *)bqe) == &stg_RBH_Save_1_info ||
2757              get_itbl((StgClosure *)bqe) == &stg_RBH_Save_2_info);
2758       break;
2759
2760     default:
2761       barf("{unblockOneLocked}Daq Qagh: Unexpected IP (%#lx; %s) in blocking queue at %#lx\n",
2762            get_itbl((StgClosure *)bqe), info_type((StgClosure *)bqe), 
2763            (StgClosure *)bqe);
2764 # endif
2765     }
2766   IF_PAR_DEBUG(bq, fprintf(stderr, ", %p (%s)", bqe, info_type((StgClosure*)bqe)));
2767   return next;
2768 }
2769
2770 #else /* !GRAN && !PAR */
2771 static StgTSO *
2772 unblockOneLocked(StgTSO *tso)
2773 {
2774   StgTSO *next;
2775
2776   ASSERT(get_itbl(tso)->type == TSO);
2777   ASSERT(tso->why_blocked != NotBlocked);
2778   tso->why_blocked = NotBlocked;
2779   next = tso->link;
2780   PUSH_ON_RUN_QUEUE(tso);
2781   THREAD_RUNNABLE();
2782   IF_DEBUG(scheduler,sched_belch("waking up thread %ld", tso->id));
2783   return next;
2784 }
2785 #endif
2786
2787 #if defined(GRAN) || defined(PAR)
2788 inline StgBlockingQueueElement *
2789 unblockOne(StgBlockingQueueElement *bqe, StgClosure *node)
2790 {
2791   ACQUIRE_LOCK(&sched_mutex);
2792   bqe = unblockOneLocked(bqe, node);
2793   RELEASE_LOCK(&sched_mutex);
2794   return bqe;
2795 }
2796 #else
2797 inline StgTSO *
2798 unblockOne(StgTSO *tso)
2799 {
2800   ACQUIRE_LOCK(&sched_mutex);
2801   tso = unblockOneLocked(tso);
2802   RELEASE_LOCK(&sched_mutex);
2803   return tso;
2804 }
2805 #endif
2806
2807 #if defined(GRAN)
2808 void 
2809 awakenBlockedQueue(StgBlockingQueueElement *q, StgClosure *node)
2810 {
2811   StgBlockingQueueElement *bqe;
2812   PEs node_loc;
2813   nat len = 0; 
2814
2815   IF_GRAN_DEBUG(bq, 
2816                 belch("##-_ AwBQ for node %p on PE %d @ %ld by TSO %d (%p): ", \
2817                       node, CurrentProc, CurrentTime[CurrentProc], 
2818                       CurrentTSO->id, CurrentTSO));
2819
2820   node_loc = where_is(node);
2821
2822   ASSERT(q == END_BQ_QUEUE ||
2823          get_itbl(q)->type == TSO ||   // q is either a TSO or an RBHSave
2824          get_itbl(q)->type == CONSTR); // closure (type constructor)
2825   ASSERT(is_unique(node));
2826
2827   /* FAKE FETCH: magically copy the node to the tso's proc;
2828      no Fetch necessary because in reality the node should not have been 
2829      moved to the other PE in the first place
2830   */
2831   if (CurrentProc!=node_loc) {
2832     IF_GRAN_DEBUG(bq, 
2833                   belch("## node %p is on PE %d but CurrentProc is %d (TSO %d); assuming fake fetch and adjusting bitmask (old: %#x)",
2834                         node, node_loc, CurrentProc, CurrentTSO->id, 
2835                         // CurrentTSO, where_is(CurrentTSO),
2836                         node->header.gran.procs));
2837     node->header.gran.procs = (node->header.gran.procs) | PE_NUMBER(CurrentProc);
2838     IF_GRAN_DEBUG(bq, 
2839                   belch("## new bitmask of node %p is %#x",
2840                         node, node->header.gran.procs));
2841     if (RtsFlags.GranFlags.GranSimStats.Global) {
2842       globalGranStats.tot_fake_fetches++;
2843     }
2844   }
2845
2846   bqe = q;
2847   // ToDo: check: ASSERT(CurrentProc==node_loc);
2848   while (get_itbl(bqe)->type==TSO) { // q != END_TSO_QUEUE) {
2849     //next = bqe->link;
2850     /* 
2851        bqe points to the current element in the queue
2852        next points to the next element in the queue
2853     */
2854     //tso = (StgTSO *)bqe;  // wastes an assignment to get the type right
2855     //tso_loc = where_is(tso);
2856     len++;
2857     bqe = unblockOneLocked(bqe, node);
2858   }
2859
2860   /* if this is the BQ of an RBH, we have to put back the info ripped out of
2861      the closure to make room for the anchor of the BQ */
2862   if (bqe!=END_BQ_QUEUE) {
2863     ASSERT(get_itbl(node)->type == RBH && get_itbl(bqe)->type == CONSTR);
2864     /*
2865     ASSERT((info_ptr==&RBH_Save_0_info) ||
2866            (info_ptr==&RBH_Save_1_info) ||
2867            (info_ptr==&RBH_Save_2_info));
2868     */
2869     /* cf. convertToRBH in RBH.c for writing the RBHSave closure */
2870     ((StgRBH *)node)->blocking_queue = (StgBlockingQueueElement *)((StgRBHSave *)bqe)->payload[0];
2871     ((StgRBH *)node)->mut_link       = (StgMutClosure *)((StgRBHSave *)bqe)->payload[1];
2872
2873     IF_GRAN_DEBUG(bq,
2874                   belch("## Filled in RBH_Save for %p (%s) at end of AwBQ",
2875                         node, info_type(node)));
2876   }
2877
2878   /* statistics gathering */
2879   if (RtsFlags.GranFlags.GranSimStats.Global) {
2880     // globalGranStats.tot_bq_processing_time += bq_processing_time;
2881     globalGranStats.tot_bq_len += len;      // total length of all bqs awakened
2882     // globalGranStats.tot_bq_len_local += len_local;  // same for local TSOs only
2883     globalGranStats.tot_awbq++;             // total no. of bqs awakened
2884   }
2885   IF_GRAN_DEBUG(bq,
2886                 fprintf(stderr,"## BQ Stats of %p: [%d entries] %s\n",
2887                         node, len, (bqe!=END_BQ_QUEUE) ? "RBH" : ""));
2888 }
2889 #elif defined(PAR)
2890 void 
2891 awakenBlockedQueue(StgBlockingQueueElement *q, StgClosure *node)
2892 {
2893   StgBlockingQueueElement *bqe;
2894
2895   ACQUIRE_LOCK(&sched_mutex);
2896
2897   IF_PAR_DEBUG(verbose, 
2898                belch("##-_ AwBQ for node %p on [%x]: ",
2899                      node, mytid));
2900 #ifdef DIST  
2901   //RFP
2902   if(get_itbl(q)->type == CONSTR || q==END_BQ_QUEUE) {
2903     IF_PAR_DEBUG(verbose, belch("## ... nothing to unblock so lets just return. RFP (BUG?)"));
2904     return;
2905   }
2906 #endif
2907   
2908   ASSERT(q == END_BQ_QUEUE ||
2909          get_itbl(q)->type == TSO ||           
2910          get_itbl(q)->type == BLOCKED_FETCH || 
2911          get_itbl(q)->type == CONSTR); 
2912
2913   bqe = q;
2914   while (get_itbl(bqe)->type==TSO || 
2915          get_itbl(bqe)->type==BLOCKED_FETCH) {
2916     bqe = unblockOneLocked(bqe, node);
2917   }
2918   RELEASE_LOCK(&sched_mutex);
2919 }
2920
2921 #else   /* !GRAN && !PAR */
2922 void
2923 awakenBlockedQueue(StgTSO *tso)
2924 {
2925   ACQUIRE_LOCK(&sched_mutex);
2926   while (tso != END_TSO_QUEUE) {
2927     tso = unblockOneLocked(tso);
2928   }
2929   RELEASE_LOCK(&sched_mutex);
2930 }
2931 #endif
2932
2933 //@node Exception Handling Routines, Debugging Routines, Blocking Queue Routines, Main scheduling code
2934 //@subsection Exception Handling Routines
2935
2936 /* ---------------------------------------------------------------------------
2937    Interrupt execution
2938    - usually called inside a signal handler so it mustn't do anything fancy.   
2939    ------------------------------------------------------------------------ */
2940
2941 void
2942 interruptStgRts(void)
2943 {
2944     interrupted    = 1;
2945     context_switch = 1;
2946 }
2947
2948 /* -----------------------------------------------------------------------------
2949    Unblock a thread
2950
2951    This is for use when we raise an exception in another thread, which
2952    may be blocked.
2953    This has nothing to do with the UnblockThread event in GranSim. -- HWL
2954    -------------------------------------------------------------------------- */
2955
2956 #if defined(GRAN) || defined(PAR)
2957 /*
2958   NB: only the type of the blocking queue is different in GranSim and GUM
2959       the operations on the queue-elements are the same
2960       long live polymorphism!
2961
2962   Locks: sched_mutex is held upon entry and exit.
2963
2964 */
2965 static void
2966 unblockThread(StgTSO *tso)
2967 {
2968   StgBlockingQueueElement *t, **last;
2969
2970   switch (tso->why_blocked) {
2971
2972   case NotBlocked:
2973     return;  /* not blocked */
2974
2975   case BlockedOnMVar:
2976     ASSERT(get_itbl(tso->block_info.closure)->type == MVAR);
2977     {
2978       StgBlockingQueueElement *last_tso = END_BQ_QUEUE;
2979       StgMVar *mvar = (StgMVar *)(tso->block_info.closure);
2980
2981       last = (StgBlockingQueueElement **)&mvar->head;
2982       for (t = (StgBlockingQueueElement *)mvar->head; 
2983            t != END_BQ_QUEUE; 
2984            last = &t->link, last_tso = t, t = t->link) {
2985         if (t == (StgBlockingQueueElement *)tso) {
2986           *last = (StgBlockingQueueElement *)tso->link;
2987           if (mvar->tail == tso) {
2988             mvar->tail = (StgTSO *)last_tso;
2989           }
2990           goto done;
2991         }
2992       }
2993       barf("unblockThread (MVAR): TSO not found");
2994     }
2995
2996   case BlockedOnBlackHole:
2997     ASSERT(get_itbl(tso->block_info.closure)->type == BLACKHOLE_BQ);
2998     {
2999       StgBlockingQueue *bq = (StgBlockingQueue *)(tso->block_info.closure);
3000
3001       last = &bq->blocking_queue;
3002       for (t = bq->blocking_queue; 
3003            t != END_BQ_QUEUE; 
3004            last = &t->link, t = t->link) {
3005         if (t == (StgBlockingQueueElement *)tso) {
3006           *last = (StgBlockingQueueElement *)tso->link;
3007           goto done;
3008         }
3009       }
3010       barf("unblockThread (BLACKHOLE): TSO not found");
3011     }
3012
3013   case BlockedOnException:
3014     {
3015       StgTSO *target  = tso->block_info.tso;
3016
3017       ASSERT(get_itbl(target)->type == TSO);
3018
3019       if (target->what_next == ThreadRelocated) {
3020           target = target->link;
3021           ASSERT(get_itbl(target)->type == TSO);
3022       }
3023
3024       ASSERT(target->blocked_exceptions != NULL);
3025
3026       last = (StgBlockingQueueElement **)&target->blocked_exceptions;
3027       for (t = (StgBlockingQueueElement *)target->blocked_exceptions; 
3028            t != END_BQ_QUEUE; 
3029            last = &t->link, t = t->link) {
3030         ASSERT(get_itbl(t)->type == TSO);
3031         if (t == (StgBlockingQueueElement *)tso) {
3032           *last = (StgBlockingQueueElement *)tso->link;
3033           goto done;
3034         }
3035       }
3036       barf("unblockThread (Exception): TSO not found");
3037     }
3038
3039   case BlockedOnRead:
3040   case BlockedOnWrite:
3041     {
3042       /* take TSO off blocked_queue */
3043       StgBlockingQueueElement *prev = NULL;
3044       for (t = (StgBlockingQueueElement *)blocked_queue_hd; t != END_BQ_QUEUE; 
3045            prev = t, t = t->link) {
3046         if (t == (StgBlockingQueueElement *)tso) {
3047           if (prev == NULL) {
3048             blocked_queue_hd = (StgTSO *)t->link;
3049             if ((StgBlockingQueueElement *)blocked_queue_tl == t) {
3050               blocked_queue_tl = END_TSO_QUEUE;
3051             }
3052           } else {
3053             prev->link = t->link;
3054             if ((StgBlockingQueueElement *)blocked_queue_tl == t) {
3055               blocked_queue_tl = (StgTSO *)prev;
3056             }
3057           }
3058           goto done;
3059         }
3060       }
3061       barf("unblockThread (I/O): TSO not found");
3062     }
3063
3064   case BlockedOnDelay:
3065     {
3066       /* take TSO off sleeping_queue */
3067       StgBlockingQueueElement *prev = NULL;
3068       for (t = (StgBlockingQueueElement *)sleeping_queue; t != END_BQ_QUEUE; 
3069            prev = t, t = t->link) {
3070         if (t == (StgBlockingQueueElement *)tso) {
3071           if (prev == NULL) {
3072             sleeping_queue = (StgTSO *)t->link;
3073           } else {
3074             prev->link = t->link;
3075           }
3076           goto done;
3077         }
3078       }
3079       barf("unblockThread (I/O): TSO not found");
3080     }
3081
3082   default:
3083     barf("unblockThread");
3084   }
3085
3086  done:
3087   tso->link = END_TSO_QUEUE;
3088   tso->why_blocked = NotBlocked;
3089   tso->block_info.closure = NULL;
3090   PUSH_ON_RUN_QUEUE(tso);
3091 }
3092 #else
3093 static void
3094 unblockThread(StgTSO *tso)
3095 {
3096   StgTSO *t, **last;
3097   
3098   /* To avoid locking unnecessarily. */
3099   if (tso->why_blocked == NotBlocked) {
3100     return;
3101   }
3102
3103   switch (tso->why_blocked) {
3104
3105   case BlockedOnMVar:
3106     ASSERT(get_itbl(tso->block_info.closure)->type == MVAR);
3107     {
3108       StgTSO *last_tso = END_TSO_QUEUE;
3109       StgMVar *mvar = (StgMVar *)(tso->block_info.closure);
3110
3111       last = &mvar->head;
3112       for (t = mvar->head; t != END_TSO_QUEUE; 
3113            last = &t->link, last_tso = t, t = t->link) {
3114         if (t == tso) {
3115           *last = tso->link;
3116           if (mvar->tail == tso) {
3117             mvar->tail = last_tso;
3118           }
3119           goto done;
3120         }
3121       }
3122       barf("unblockThread (MVAR): TSO not found");
3123     }
3124
3125   case BlockedOnBlackHole:
3126     ASSERT(get_itbl(tso->block_info.closure)->type == BLACKHOLE_BQ);
3127     {
3128       StgBlockingQueue *bq = (StgBlockingQueue *)(tso->block_info.closure);
3129
3130       last = &bq->blocking_queue;
3131       for (t = bq->blocking_queue; t != END_TSO_QUEUE; 
3132            last = &t->link, t = t->link) {
3133         if (t == tso) {
3134           *last = tso->link;
3135           goto done;
3136         }
3137       }
3138       barf("unblockThread (BLACKHOLE): TSO not found");
3139     }
3140
3141   case BlockedOnException:
3142     {
3143       StgTSO *target  = tso->block_info.tso;
3144
3145       ASSERT(get_itbl(target)->type == TSO);
3146
3147       while (target->what_next == ThreadRelocated) {
3148           target = target->link;
3149           ASSERT(get_itbl(target)->type == TSO);
3150       }
3151       
3152       ASSERT(target->blocked_exceptions != NULL);
3153
3154       last = &target->blocked_exceptions;
3155       for (t = target->blocked_exceptions; t != END_TSO_QUEUE; 
3156            last = &t->link, t = t->link) {
3157         ASSERT(get_itbl(t)->type == TSO);
3158         if (t == tso) {
3159           *last = tso->link;
3160           goto done;
3161         }
3162       }
3163       barf("unblockThread (Exception): TSO not found");
3164     }
3165
3166   case BlockedOnRead:
3167   case BlockedOnWrite:
3168     {
3169       StgTSO *prev = NULL;
3170       for (t = blocked_queue_hd; t != END_TSO_QUEUE; 
3171            prev = t, t = t->link) {
3172         if (t == tso) {
3173           if (prev == NULL) {
3174             blocked_queue_hd = t->link;
3175             if (blocked_queue_tl == t) {
3176               blocked_queue_tl = END_TSO_QUEUE;
3177             }
3178           } else {
3179             prev->link = t->link;
3180             if (blocked_queue_tl == t) {
3181               blocked_queue_tl = prev;
3182             }
3183           }
3184           goto done;
3185         }
3186       }
3187       barf("unblockThread (I/O): TSO not found");
3188     }
3189
3190   case BlockedOnDelay:
3191     {
3192       StgTSO *prev = NULL;
3193       for (t = sleeping_queue; t != END_TSO_QUEUE; 
3194            prev = t, t = t->link) {
3195         if (t == tso) {
3196           if (prev == NULL) {
3197             sleeping_queue = t->link;
3198           } else {
3199             prev->link = t->link;
3200           }
3201           goto done;
3202         }
3203       }
3204       barf("unblockThread (I/O): TSO not found");
3205     }
3206
3207   default:
3208     barf("unblockThread");
3209   }
3210
3211  done:
3212   tso->link = END_TSO_QUEUE;
3213   tso->why_blocked = NotBlocked;
3214   tso->block_info.closure = NULL;
3215   PUSH_ON_RUN_QUEUE(tso);
3216 }
3217 #endif
3218
3219 /* -----------------------------------------------------------------------------
3220  * raiseAsync()
3221  *
3222  * The following function implements the magic for raising an
3223  * asynchronous exception in an existing thread.
3224  *
3225  * We first remove the thread from any queue on which it might be
3226  * blocked.  The possible blockages are MVARs and BLACKHOLE_BQs.
3227  *
3228  * We strip the stack down to the innermost CATCH_FRAME, building
3229  * thunks in the heap for all the active computations, so they can 
3230  * be restarted if necessary.  When we reach a CATCH_FRAME, we build
3231  * an application of the handler to the exception, and push it on
3232  * the top of the stack.
3233  * 
3234  * How exactly do we save all the active computations?  We create an
3235  * AP_UPD for every UpdateFrame on the stack.  Entering one of these
3236  * AP_UPDs pushes everything from the corresponding update frame
3237  * upwards onto the stack.  (Actually, it pushes everything up to the
3238  * next update frame plus a pointer to the next AP_UPD object.
3239  * Entering the next AP_UPD object pushes more onto the stack until we
3240  * reach the last AP_UPD object - at which point the stack should look
3241  * exactly as it did when we killed the TSO and we can continue
3242  * execution by entering the closure on top of the stack.
3243  *
3244  * We can also kill a thread entirely - this happens if either (a) the 
3245  * exception passed to raiseAsync is NULL, or (b) there's no
3246  * CATCH_FRAME on the stack.  In either case, we strip the entire
3247  * stack and replace the thread with a zombie.
3248  *
3249  * Locks: sched_mutex held upon entry nor exit.
3250  *
3251  * -------------------------------------------------------------------------- */
3252  
3253 void 
3254 deleteThread(StgTSO *tso)
3255 {
3256   raiseAsync(tso,NULL);
3257 }
3258
3259 void
3260 raiseAsyncWithLock(StgTSO *tso, StgClosure *exception)
3261 {
3262   /* When raising async exs from contexts where sched_mutex isn't held;
3263      use raiseAsyncWithLock(). */
3264   ACQUIRE_LOCK(&sched_mutex);
3265   raiseAsync(tso,exception);
3266   RELEASE_LOCK(&sched_mutex);
3267 }
3268
3269 void
3270 raiseAsync(StgTSO *tso, StgClosure *exception)
3271 {
3272   StgUpdateFrame* su = tso->su;
3273   StgPtr          sp = tso->sp;
3274   
3275   /* Thread already dead? */
3276   if (tso->what_next == ThreadComplete || tso->what_next == ThreadKilled) {
3277     return;
3278   }
3279
3280   IF_DEBUG(scheduler, sched_belch("raising exception in thread %ld.", tso->id));
3281
3282   /* Remove it from any blocking queues */
3283   unblockThread(tso);
3284
3285   /* The stack freezing code assumes there's a closure pointer on
3286    * the top of the stack.  This isn't always the case with compiled
3287    * code, so we have to push a dummy closure on the top which just
3288    * returns to the next return address on the stack.
3289    */
3290   if ( LOOKS_LIKE_GHC_INFO((void*)*sp) ) {
3291     *(--sp) = (W_)&stg_dummy_ret_closure;
3292   }
3293
3294   while (1) {
3295     nat words = ((P_)su - (P_)sp) - 1;
3296     nat i;
3297     StgAP_UPD * ap;
3298
3299     ASSERT((P_)su > (P_)sp);
3300     
3301     /* If we find a CATCH_FRAME, and we've got an exception to raise,
3302      * then build the THUNK raise(exception), and leave it on
3303      * top of the CATCH_FRAME ready to enter.
3304      */
3305     if (get_itbl(su)->type == CATCH_FRAME && exception != NULL) {
3306 #ifdef PROFILING
3307       StgCatchFrame *cf = (StgCatchFrame *)su;
3308 #endif
3309       StgClosure *raise;
3310
3311       /* we've got an exception to raise, so let's pass it to the
3312        * handler in this frame.
3313        */
3314       raise = (StgClosure *)allocate(sizeofW(StgClosure)+1);
3315       TICK_ALLOC_SE_THK(1,0);
3316       SET_HDR(raise,&stg_raise_info,cf->header.prof.ccs);
3317       raise->payload[0] = exception;
3318
3319       /* throw away the stack from Sp up to the CATCH_FRAME.
3320        */
3321       sp = (P_)su - 1;
3322
3323       /* Ensure that async excpetions are blocked now, so we don't get
3324        * a surprise exception before we get around to executing the
3325        * handler.
3326        */
3327       if (tso->blocked_exceptions == NULL) {
3328           tso->blocked_exceptions = END_TSO_QUEUE;
3329       }
3330
3331       /* Put the newly-built THUNK on top of the stack, ready to execute
3332        * when the thread restarts.
3333        */
3334       sp[0] = (W_)raise;
3335       tso->sp = sp;
3336       tso->su = su;
3337       tso->what_next = ThreadEnterGHC;
3338       IF_DEBUG(sanity, checkTSO(tso));
3339       return;
3340     }
3341
3342     /* First build an AP_UPD consisting of the stack chunk above the
3343      * current update frame, with the top word on the stack as the
3344      * fun field.
3345      */
3346     ap = (StgAP_UPD *)allocate(AP_sizeW(words));
3347     
3348     ap->n_args = words;
3349     ap->fun    = (StgClosure *)sp[0];
3350     sp++;
3351     for(i=0; i < (nat)words; ++i) {
3352       ap->payload[i] = (StgClosure *)*sp++;
3353     }
3354     
3355     switch (get_itbl(su)->type) {
3356       
3357     case UPDATE_FRAME:
3358       {
3359         SET_HDR(ap,&stg_AP_UPD_info,su->header.prof.ccs /* ToDo */); 
3360         TICK_ALLOC_UP_THK(words+1,0);
3361         
3362         IF_DEBUG(scheduler,
3363                  fprintf(stderr,  "scheduler: Updating ");
3364                  printPtr((P_)su->updatee); 
3365                  fprintf(stderr,  " with ");
3366                  printObj((StgClosure *)ap);
3367                  );
3368         
3369         /* Replace the updatee with an indirection - happily
3370          * this will also wake up any threads currently
3371          * waiting on the result.
3372          *
3373          * Warning: if we're in a loop, more than one update frame on
3374          * the stack may point to the same object.  Be careful not to
3375          * overwrite an IND_OLDGEN in this case, because we'll screw
3376          * up the mutable lists.  To be on the safe side, don't
3377          * overwrite any kind of indirection at all.  See also
3378          * threadSqueezeStack in GC.c, where we have to make a similar
3379          * check.
3380          */
3381         if (!closure_IND(su->updatee)) {
3382             UPD_IND_NOLOCK(su->updatee,ap);  /* revert the black hole */
3383         }
3384         su = su->link;
3385         sp += sizeofW(StgUpdateFrame) -1;
3386         sp[0] = (W_)ap; /* push onto stack */
3387         break;
3388       }
3389
3390     case CATCH_FRAME:
3391       {
3392         StgCatchFrame *cf = (StgCatchFrame *)su;
3393         StgClosure* o;
3394         
3395         /* We want a PAP, not an AP_UPD.  Fortunately, the
3396          * layout's the same.
3397          */
3398         SET_HDR(ap,&stg_PAP_info,su->header.prof.ccs /* ToDo */);
3399         TICK_ALLOC_UPD_PAP(words+1,0);
3400         
3401         /* now build o = FUN(catch,ap,handler) */
3402         o = (StgClosure *)allocate(sizeofW(StgClosure)+2);
3403         TICK_ALLOC_FUN(2,0);
3404         SET_HDR(o,&stg_catch_info,su->header.prof.ccs /* ToDo */);
3405         o->payload[0] = (StgClosure *)ap;
3406         o->payload[1] = cf->handler;
3407         
3408         IF_DEBUG(scheduler,
3409                  fprintf(stderr,  "scheduler: Built ");
3410                  printObj((StgClosure *)o);
3411                  );
3412         
3413         /* pop the old handler and put o on the stack */
3414         su = cf->link;
3415         sp += sizeofW(StgCatchFrame) - 1;
3416         sp[0] = (W_)o;
3417         break;
3418       }
3419       
3420     case SEQ_FRAME:
3421       {
3422         StgSeqFrame *sf = (StgSeqFrame *)su;
3423         StgClosure* o;
3424         
3425         SET_HDR(ap,&stg_PAP_info,su->header.prof.ccs /* ToDo */);
3426         TICK_ALLOC_UPD_PAP(words+1,0);
3427         
3428         /* now build o = FUN(seq,ap) */
3429         o = (StgClosure *)allocate(sizeofW(StgClosure)+1);
3430         TICK_ALLOC_SE_THK(1,0);
3431         SET_HDR(o,&stg_seq_info,su->header.prof.ccs /* ToDo */);
3432         o->payload[0] = (StgClosure *)ap;
3433         
3434         IF_DEBUG(scheduler,
3435                  fprintf(stderr,  "scheduler: Built ");
3436                  printObj((StgClosure *)o);
3437                  );
3438         
3439         /* pop the old handler and put o on the stack */
3440         su = sf->link;
3441         sp += sizeofW(StgSeqFrame) - 1;
3442         sp[0] = (W_)o;
3443         break;
3444       }
3445       
3446     case STOP_FRAME:
3447       /* We've stripped the entire stack, the thread is now dead. */
3448       sp += sizeofW(StgStopFrame) - 1;
3449       sp[0] = (W_)exception;    /* save the exception */
3450       tso->what_next = ThreadKilled;
3451       tso->su = (StgUpdateFrame *)(sp+1);
3452       tso->sp = sp;
3453       return;
3454
3455     default:
3456       barf("raiseAsync");
3457     }
3458   }
3459   barf("raiseAsync");
3460 }
3461
3462 /* -----------------------------------------------------------------------------
3463    resurrectThreads is called after garbage collection on the list of
3464    threads found to be garbage.  Each of these threads will be woken
3465    up and sent a signal: BlockedOnDeadMVar if the thread was blocked
3466    on an MVar, or NonTermination if the thread was blocked on a Black
3467    Hole.
3468
3469    Locks: sched_mutex isn't held upon entry nor exit.
3470    -------------------------------------------------------------------------- */
3471
3472 void
3473 resurrectThreads( StgTSO *threads )
3474 {
3475   StgTSO *tso, *next;
3476
3477   for (tso = threads; tso != END_TSO_QUEUE; tso = next) {
3478     next = tso->global_link;
3479     tso->global_link = all_threads;
3480     all_threads = tso;
3481     IF_DEBUG(scheduler, sched_belch("resurrecting thread %d", tso->id));
3482
3483     switch (tso->why_blocked) {
3484     case BlockedOnMVar:
3485     case BlockedOnException:
3486       /* Called by GC - sched_mutex lock is currently held. */
3487       raiseAsync(tso,(StgClosure *)BlockedOnDeadMVar_closure);
3488       break;
3489     case BlockedOnBlackHole:
3490       raiseAsync(tso,(StgClosure *)NonTermination_closure);
3491       break;
3492     case NotBlocked:
3493       /* This might happen if the thread was blocked on a black hole
3494        * belonging to a thread that we've just woken up (raiseAsync
3495        * can wake up threads, remember...).
3496        */
3497       continue;
3498     default:
3499       barf("resurrectThreads: thread blocked in a strange way");
3500     }
3501   }
3502 }
3503
3504 /* -----------------------------------------------------------------------------
3505  * Blackhole detection: if we reach a deadlock, test whether any
3506  * threads are blocked on themselves.  Any threads which are found to
3507  * be self-blocked get sent a NonTermination exception.
3508  *
3509  * This is only done in a deadlock situation in order to avoid
3510  * performance overhead in the normal case.
3511  *
3512  * Locks: sched_mutex is held upon entry and exit.
3513  * -------------------------------------------------------------------------- */
3514
3515 static void
3516 detectBlackHoles( void )
3517 {
3518     StgTSO *t = all_threads;
3519     StgUpdateFrame *frame;
3520     StgClosure *blocked_on;
3521
3522     for (t = all_threads; t != END_TSO_QUEUE; t = t->global_link) {
3523
3524         while (t->what_next == ThreadRelocated) {
3525             t = t->link;
3526             ASSERT(get_itbl(t)->type == TSO);
3527         }
3528       
3529         if (t->why_blocked != BlockedOnBlackHole) {
3530             continue;
3531         }
3532
3533         blocked_on = t->block_info.closure;
3534
3535         for (frame = t->su; ; frame = frame->link) {
3536             switch (get_itbl(frame)->type) {
3537
3538             case UPDATE_FRAME:
3539                 if (frame->updatee == blocked_on) {
3540                     /* We are blocking on one of our own computations, so
3541                      * send this thread the NonTermination exception.  
3542                      */
3543                     IF_DEBUG(scheduler, 
3544                              sched_belch("thread %d is blocked on itself", t->id));
3545                     raiseAsync(t, (StgClosure *)NonTermination_closure);
3546                     goto done;
3547                 }
3548                 else {
3549                     continue;
3550                 }
3551
3552             case CATCH_FRAME:
3553             case SEQ_FRAME:
3554                 continue;
3555                 
3556             case STOP_FRAME:
3557                 break;
3558             }
3559             break;
3560         }
3561
3562     done: ;
3563     }   
3564 }
3565
3566 //@node Debugging Routines, Index, Exception Handling Routines, Main scheduling code
3567 //@subsection Debugging Routines
3568
3569 /* -----------------------------------------------------------------------------
3570  * Debugging: why is a thread blocked
3571  * [Also provides useful information when debugging threaded programs
3572  *  at the Haskell source code level, so enable outside of DEBUG. --sof 7/02]
3573    -------------------------------------------------------------------------- */
3574
3575 static
3576 void
3577 printThreadBlockage(StgTSO *tso)
3578 {
3579   switch (tso->why_blocked) {
3580   case BlockedOnRead:
3581     fprintf(stderr,"is blocked on read from fd %d", tso->block_info.fd);
3582     break;
3583   case BlockedOnWrite:
3584     fprintf(stderr,"is blocked on write to fd %d", tso->block_info.fd);
3585     break;
3586   case BlockedOnDelay:
3587     fprintf(stderr,"is blocked until %d", tso->block_info.target);
3588     break;
3589   case BlockedOnMVar:
3590     fprintf(stderr,"is blocked on an MVar");
3591     break;
3592   case BlockedOnException:
3593     fprintf(stderr,"is blocked on delivering an exception to thread %d",
3594             tso->block_info.tso->id);
3595     break;
3596   case BlockedOnBlackHole:
3597     fprintf(stderr,"is blocked on a black hole");
3598     break;
3599   case NotBlocked:
3600     fprintf(stderr,"is not blocked");
3601     break;
3602 #if defined(PAR)
3603   case BlockedOnGA:
3604     fprintf(stderr,"is blocked on global address; local FM_BQ is %p (%s)",
3605             tso->block_info.closure, info_type(tso->block_info.closure));
3606     break;
3607   case BlockedOnGA_NoSend:
3608     fprintf(stderr,"is blocked on global address (no send); local FM_BQ is %p (%s)",
3609             tso->block_info.closure, info_type(tso->block_info.closure));
3610     break;
3611 #endif
3612 #if defined(RTS_SUPPORTS_THREADS)
3613   case BlockedOnCCall:
3614     fprintf(stderr,"is blocked on an external call");
3615     break;
3616 #endif
3617   default:
3618     barf("printThreadBlockage: strange tso->why_blocked: %d for TSO %d (%d)",
3619          tso->why_blocked, tso->id, tso);
3620   }
3621 }
3622
3623 static
3624 void
3625 printThreadStatus(StgTSO *tso)
3626 {
3627   switch (tso->what_next) {
3628   case ThreadKilled:
3629     fprintf(stderr,"has been killed");
3630     break;
3631   case ThreadComplete:
3632     fprintf(stderr,"has completed");
3633     break;
3634   default:
3635     printThreadBlockage(tso);
3636   }
3637 }
3638
3639 void
3640 printAllThreads(void)
3641 {
3642   StgTSO *t;
3643   void *label;
3644
3645 # if defined(GRAN)
3646   char time_string[TIME_STR_LEN], node_str[NODE_STR_LEN];
3647   ullong_format_string(TIME_ON_PROC(CurrentProc), 
3648                        time_string, rtsFalse/*no commas!*/);
3649
3650   fprintf(stderr, "all threads at [%s]:\n", time_string);
3651 # elif defined(PAR)
3652   char time_string[TIME_STR_LEN], node_str[NODE_STR_LEN];
3653   ullong_format_string(CURRENT_TIME,
3654                        time_string, rtsFalse/*no commas!*/);
3655
3656   fprintf(stderr,"all threads at [%s]:\n", time_string);
3657 # else
3658   fprintf(stderr,"all threads:\n");
3659 # endif
3660
3661   for (t = all_threads; t != END_TSO_QUEUE; t = t->global_link) {
3662     fprintf(stderr, "\tthread %d @ %p ", t->id, (void *)t);
3663     label = lookupThreadLabel((StgWord)t);
3664     if (label) fprintf(stderr,"[\"%s\"] ",(char *)label);
3665     printThreadStatus(t);
3666     fprintf(stderr,"\n");
3667   }
3668 }
3669     
3670 #ifdef DEBUG
3671
3672 /* 
3673    Print a whole blocking queue attached to node (debugging only).
3674 */
3675 //@cindex print_bq
3676 # if defined(PAR)
3677 void 
3678 print_bq (StgClosure *node)
3679 {
3680   StgBlockingQueueElement *bqe;
3681   StgTSO *tso;
3682   rtsBool end;
3683
3684   fprintf(stderr,"## BQ of closure %p (%s): ",
3685           node, info_type(node));
3686
3687   /* should cover all closures that may have a blocking queue */
3688   ASSERT(get_itbl(node)->type == BLACKHOLE_BQ ||
3689          get_itbl(node)->type == FETCH_ME_BQ ||
3690          get_itbl(node)->type == RBH ||
3691          get_itbl(node)->type == MVAR);
3692     
3693   ASSERT(node!=(StgClosure*)NULL);         // sanity check
3694
3695   print_bqe(((StgBlockingQueue*)node)->blocking_queue);
3696 }
3697
3698 /* 
3699    Print a whole blocking queue starting with the element bqe.
3700 */
3701 void 
3702 print_bqe (StgBlockingQueueElement *bqe)
3703 {
3704   rtsBool end;
3705
3706   /* 
3707      NB: In a parallel setup a BQ of an RBH must end with an RBH_Save closure;
3708   */
3709   for (end = (bqe==END_BQ_QUEUE);
3710        !end; // iterate until bqe points to a CONSTR
3711        end = (get_itbl(bqe)->type == CONSTR) || (bqe->link==END_BQ_QUEUE), 
3712        bqe = end ? END_BQ_QUEUE : bqe->link) {
3713     ASSERT(bqe != END_BQ_QUEUE);                               // sanity check
3714     ASSERT(bqe != (StgBlockingQueueElement *)NULL);            // sanity check
3715     /* types of closures that may appear in a blocking queue */
3716     ASSERT(get_itbl(bqe)->type == TSO ||           
3717            get_itbl(bqe)->type == BLOCKED_FETCH || 
3718            get_itbl(bqe)->type == CONSTR); 
3719     /* only BQs of an RBH end with an RBH_Save closure */
3720     //ASSERT(get_itbl(bqe)->type != CONSTR || get_itbl(node)->type == RBH);
3721
3722     switch (get_itbl(bqe)->type) {
3723     case TSO:
3724       fprintf(stderr," TSO %u (%x),",
3725               ((StgTSO *)bqe)->id, ((StgTSO *)bqe));
3726       break;
3727     case BLOCKED_FETCH:
3728       fprintf(stderr," BF (node=%p, ga=((%x, %d, %x)),",
3729               ((StgBlockedFetch *)bqe)->node, 
3730               ((StgBlockedFetch *)bqe)->ga.payload.gc.gtid,
3731               ((StgBlockedFetch *)bqe)->ga.payload.gc.slot,
3732               ((StgBlockedFetch *)bqe)->ga.weight);
3733       break;
3734     case CONSTR:
3735       fprintf(stderr," %s (IP %p),",
3736               (get_itbl(bqe) == &stg_RBH_Save_0_info ? "RBH_Save_0" :
3737                get_itbl(bqe) == &stg_RBH_Save_1_info ? "RBH_Save_1" :
3738                get_itbl(bqe) == &stg_RBH_Save_2_info ? "RBH_Save_2" :
3739                "RBH_Save_?"), get_itbl(bqe));
3740       break;
3741     default:
3742       barf("Unexpected closure type %s in blocking queue", // of %p (%s)",
3743            info_type((StgClosure *)bqe)); // , node, info_type(node));
3744       break;
3745     }
3746   } /* for */
3747   fputc('\n', stderr);
3748 }
3749 # elif defined(GRAN)
3750 void 
3751 print_bq (StgClosure *node)
3752 {
3753   StgBlockingQueueElement *bqe;
3754   PEs node_loc, tso_loc;
3755   rtsBool end;
3756
3757   /* should cover all closures that may have a blocking queue */
3758   ASSERT(get_itbl(node)->type == BLACKHOLE_BQ ||
3759          get_itbl(node)->type == FETCH_ME_BQ ||
3760          get_itbl(node)->type == RBH);
3761     
3762   ASSERT(node!=(StgClosure*)NULL);         // sanity check
3763   node_loc = where_is(node);
3764
3765   fprintf(stderr,"## BQ of closure %p (%s) on [PE %d]: ",
3766           node, info_type(node), node_loc);
3767
3768   /* 
3769      NB: In a parallel setup a BQ of an RBH must end with an RBH_Save closure;
3770   */
3771   for (bqe = ((StgBlockingQueue*)node)->blocking_queue, end = (bqe==END_BQ_QUEUE);
3772        !end; // iterate until bqe points to a CONSTR
3773        end = (get_itbl(bqe)->type == CONSTR) || (bqe->link==END_BQ_QUEUE), bqe = end ? END_BQ_QUEUE : bqe->link) {
3774     ASSERT(bqe != END_BQ_QUEUE);             // sanity check
3775     ASSERT(bqe != (StgBlockingQueueElement *)NULL);  // sanity check
3776     /* types of closures that may appear in a blocking queue */
3777     ASSERT(get_itbl(bqe)->type == TSO ||           
3778            get_itbl(bqe)->type == CONSTR); 
3779     /* only BQs of an RBH end with an RBH_Save closure */
3780     ASSERT(get_itbl(bqe)->type != CONSTR || get_itbl(node)->type == RBH);
3781
3782     tso_loc = where_is((StgClosure *)bqe);
3783     switch (get_itbl(bqe)->type) {
3784     case TSO:
3785       fprintf(stderr," TSO %d (%p) on [PE %d],",
3786               ((StgTSO *)bqe)->id, (StgTSO *)bqe, tso_loc);
3787       break;
3788     case CONSTR:
3789       fprintf(stderr," %s (IP %p),",
3790               (get_itbl(bqe) == &stg_RBH_Save_0_info ? "RBH_Save_0" :
3791                get_itbl(bqe) == &stg_RBH_Save_1_info ? "RBH_Save_1" :
3792                get_itbl(bqe) == &stg_RBH_Save_2_info ? "RBH_Save_2" :
3793                "RBH_Save_?"), get_itbl(bqe));
3794       break;
3795     default:
3796       barf("Unexpected closure type %s in blocking queue of %p (%s)",
3797            info_type((StgClosure *)bqe), node, info_type(node));
3798       break;
3799     }
3800   } /* for */
3801   fputc('\n', stderr);
3802 }
3803 #else
3804 /* 
3805    Nice and easy: only TSOs on the blocking queue
3806 */
3807 void 
3808 print_bq (StgClosure *node)
3809 {
3810   StgTSO *tso;
3811
3812   ASSERT(node!=(StgClosure*)NULL);         // sanity check
3813   for (tso = ((StgBlockingQueue*)node)->blocking_queue;
3814        tso != END_TSO_QUEUE; 
3815        tso=tso->link) {
3816     ASSERT(tso!=NULL && tso!=END_TSO_QUEUE);   // sanity check
3817     ASSERT(get_itbl(tso)->type == TSO);  // guess what, sanity check
3818     fprintf(stderr," TSO %d (%p),", tso->id, tso);
3819   }
3820   fputc('\n', stderr);
3821 }
3822 # endif
3823
3824 #if defined(PAR)
3825 static nat
3826 run_queue_len(void)
3827 {
3828   nat i;
3829   StgTSO *tso;
3830
3831   for (i=0, tso=run_queue_hd; 
3832        tso != END_TSO_QUEUE;
3833        i++, tso=tso->link)
3834     /* nothing */
3835
3836   return i;
3837 }
3838 #endif
3839
3840 static void
3841 sched_belch(char *s, ...)
3842 {
3843   va_list ap;
3844   va_start(ap,s);
3845 #ifdef SMP
3846   fprintf(stderr, "scheduler (task %ld): ", osThreadId());
3847 #elif defined(PAR)
3848   fprintf(stderr, "== ");
3849 #else
3850   fprintf(stderr, "scheduler: ");
3851 #endif
3852   vfprintf(stderr, s, ap);
3853   fprintf(stderr, "\n");
3854   va_end(ap);
3855 }
3856
3857 #endif /* DEBUG */
3858
3859
3860 //@node Index,  , Debugging Routines, Main scheduling code
3861 //@subsection Index
3862
3863 //@index
3864 //* StgMainThread::  @cindex\s-+StgMainThread
3865 //* awaken_blocked_queue::  @cindex\s-+awaken_blocked_queue
3866 //* blocked_queue_hd::  @cindex\s-+blocked_queue_hd
3867 //* blocked_queue_tl::  @cindex\s-+blocked_queue_tl
3868 //* context_switch::  @cindex\s-+context_switch
3869 //* createThread::  @cindex\s-+createThread
3870 //* gc_pending_cond::  @cindex\s-+gc_pending_cond
3871 //* initScheduler::  @cindex\s-+initScheduler
3872 //* interrupted::  @cindex\s-+interrupted
3873 //* next_thread_id::  @cindex\s-+next_thread_id
3874 //* print_bq::  @cindex\s-+print_bq
3875 //* run_queue_hd::  @cindex\s-+run_queue_hd
3876 //* run_queue_tl::  @cindex\s-+run_queue_tl
3877 //* sched_mutex::  @cindex\s-+sched_mutex
3878 //* schedule::  @cindex\s-+schedule
3879 //* take_off_run_queue::  @cindex\s-+take_off_run_queue
3880 //* term_mutex::  @cindex\s-+term_mutex
3881 //@end index