1234567891011121314151617181920212223242526272829303132333435363738394041424344454647484950515253545556575859606162636465666768697071727374757677787980818283848586878889909192939495969798991001011021031041051061071081091101111121131141151161171181191201211221231241251261271281291301311321331341351361371381391401411421431441451461471481491501511521531541551561571581591601611621631641651661671681691701711721731741751761771781791801811821831841851861871881891901911921931941951961971981992002012022032042052062072082092102112122132142152162172182192202212222232242252262272282292302312322332342352362372382392402412422432442452462472482492502512522532542552562572582592602612622632642652662672682692702712722732742752762772782792802812822832842852862872882892902912922932942952962972982993003013023033043053063073083093103113123133143153163173183193203213223233243253263273283293303313323333343353363373383393403413423433443453463473483493503513523533543553563573583593603613623633643653663673683693703713723733743753763773783793803813823833843853863873883893903913923933943953963973983994004014024034044054064074084094104114124134144154164174184194204214224234244254264274284294304314324334344354364374384394404414424434444454464474484494504514524534544554564574584594604614624634644654664674684694704714724734744754764774784794804814824834844854864874884894904914924934944954964974984995005015025035045055065075085095105115125135145155165175185195205215225235245255265275285295305315325335345355365375385395405415425435445455465475485495505515525535545555565575585595605615625635645655665675685695705715725735745755765775785795805815825835845855865875885895905915925935945955965975985996006016026036046056066076086096106116126136146156166176186196206216226236246256266276286296306316326336346356366376386396406416426436446456466476486496506516526536546556566576586596606616626636646656666676686696706716726736746756766776786796806816826836846856866876886896906916926936946956966976986997007017027037047057067077087097107117127137147157167177187197207217227237247257267277287297307317327337347357367377387397407417427437447457467477487497507517527537547557567577587597607617627637647657667677687697707717727737747757767777787797807817827837847857867877887897907917927937947957967977987998008018028038048058068078088098108118128138148158168178188198208218228238248258268278288298308318328338348358368378388398408418428438448458468478488498508518528538548558568578588598608618628638648658668678688698708718728738748758768778788798808818828838848858868878888898908918928938948958968978988999009019029039049059069079089099109119129139149159169179189199209219229239249259269279289299309319329339349359369379389399409419429439449459469479489499509519529539549559569579589599609619629639649659669679689699709719729739749759769779789799809819829839849859869879889899909919929939949959969979989991000 |
- /* Part of Scheme 48 1.9. See file COPYING for notices and license.
- *
- * Authors: Richard Kelsey, Jonathan Rees, Mike Sperber, Marcus Crestani, Martin Gasbichler
- */
- #include <signal.h> /* for sigaction(), pthread_sigmask() / sigprocmask() (POSIX.1) */
- #include <stdlib.h>
- #include <unistd.h>
- #include <stdio.h>
- #include <sys/types.h>
- #include <sys/time.h>
- #include <sys/times.h>
- #include <errno.h> /* for errno, (POSIX?/ANSI) */
- #include <string.h> /* FD_ZERO sometimes needs this */
- #include "sysdep.h"
- #ifdef HAVE_PTHREAD_H
- #include <pthread.h>
- #endif
- #ifdef HAVE_POLL_H
- #include <poll.h>
- #endif
- #ifdef HAVE_GLIB
- #include <glib.h>
- #endif
- #include "c-mods.h"
- #include "scheme48vm.h"
- #include "event.h"
- /* turning interrupts and I/O readiness into events */
- static sigset_t interrupt_mask;
- /*
- * They're basically the same, but the behavior of sigprocmask is
- * undefined in the presence of Pthreads.
- */
- #ifdef HAVE_PTHREAD_H
- #define SIGMASK pthread_sigmask
- #else
- /* sigprocmask can be interrupted, while pthread_sigmask cannot */
- static int
- our_sigmask(int how, const sigset_t *set, sigset_t *oset)
- {
- int retval;
- while ((retval = sigprocmask(how, set, oset))
- && (errno == EINTR))
- ;
- return retval;
- }
- #define SIGMASK our_sigmask
- #endif
- static void
- block_keyboard_n_alarm_interrupts(void)
- {
- if (SIGMASK(SIG_BLOCK, &interrupt_mask, NULL))
- {
- fprintf(stderr,
- "Failed to block SIGINT/SIGALRM, errno = %d\n",
- errno);
- exit(1);
- }
- }
- static void
- allow_keyboard_n_alarm_interrupts(void)
- {
- if (SIGMASK(SIG_UNBLOCK, &interrupt_mask, NULL))
- {
- fprintf(stderr,
- "Failed to unblock SIGINT/SIGALRM, errno = %d\n",
- errno);
- exit(1);
- }
- }
- /*
- * Unless a signal is being ignored, set up the handler.
- * If we return PSFALSE, something went wrong and errno is set to what.
- */
- psbool
- s48_setcatcher(int signum, void (*catcher)(int))
- {
- struct sigaction sa;
- if (sigaction(signum, (struct sigaction *)NULL, &sa) != 0)
- return (PSFALSE);
- if (sa.sa_handler == SIG_IGN)
- return (PSTRUE);
- sa.sa_handler = catcher;
- sigemptyset(&sa.sa_mask);
- #ifdef HAVE_SIGALTSTACK
- sa.sa_flags = SA_ONSTACK;
- #else
- sa.sa_flags = 0;
- #endif
- if (sigaction(signum, &sa, (struct sigaction *)NULL) != 0)
- return (PSFALSE);
- return (PSTRUE);
- }
- static long keyboard_interrupt_count = 0;
- void
- s48_when_keyboard_interrupt(int ign)
- {
- keyboard_interrupt_count += 1;
- NOTE_EVENT;
- return;
- }
- /*
- We turn off SIGPIPE interrupts by installing a handler that does nothing.
- Turning them off affects exec()'ed programs, so we don't want to do that.
- Any actual pipe problems are caught when we try to read or write to them.
- We thank Olin Shivers for this hack.
- */
- static void
- when_sigpipe_interrupt(int ign)
- {
- return;
- }
- /* ticks since last timer-interrupt request */
- long s48_current_time = 0;
- static long alarm_time = -1;
- static long poll_time = -1;
- static long poll_interval = 5;
- void
- s48_when_alarm_interrupt(int ign)
- {
- s48_current_time += 1;
- /* fprintf(stderr, "[tick]"); */
- if ((alarm_time >= 0 && alarm_time <= s48_current_time) ||
- (poll_time >= 0 && poll_time <= s48_current_time)) {
- NOTE_EVENT;
- };
- return;
- }
- #define USEC_PER_POLL (1000000 / POLLS_PER_SECOND)
- /* delta is in ticks, 0 cancels current alarm */
- long
- s48_schedule_alarm_interrupt(long delta)
- {
- long old;
- /*
- fprintf(stderr, "<scheduling alarm for %ld + %ld>\n", s48_current_time,
- delta/TICKS_PER_POLL); */
- /* get remaining time */
- if (alarm_time == -1)
- old = -1;
- else
- old = (alarm_time - s48_current_time) * TICKS_PER_POLL;
- /* decrement poll_time and reset current_time */
- if (poll_time != -1)
- poll_time -= s48_current_time;
- s48_current_time = 0;
- /* set alarm_time */
- if (delta == 0) {
- NOTE_EVENT;
- alarm_time = 0; }
- else
- alarm_time = delta / TICKS_PER_POLL;
- return old;
- }
- /* The next two procedures return times in seconds and ticks */
- long
- s48_real_time(long *ticks)
- {
- struct timeval tv;
- static struct timeval tv_orig;
- static int initp = PSFALSE;
- if (!initp) {
- gettimeofday(&tv_orig, NULL);
- initp = PSTRUE;
- };
- gettimeofday(&tv, NULL);
- *ticks = (tv.tv_usec - tv_orig.tv_usec)/(1000000/TICKS_PER_SECOND);
- return tv.tv_sec - tv_orig.tv_sec;
- }
- long
- s48_run_time(long *ticks)
- {
- struct tms time_buffer;
- static long clock_tick = 0;
- long cpu_time;
- if (clock_tick == 0)
- clock_tick = sysconf(_SC_CLK_TCK); /* POSIX.1, POSIX.2 */
- times(&time_buffer); /* On Sun, getrusage() would be better */
- cpu_time = time_buffer.tms_utime + time_buffer.tms_stime;
- *ticks = (cpu_time % clock_tick) * TICKS_PER_SECOND / clock_tick;
- return cpu_time / clock_tick;
- }
- void
- s48_start_alarm_interrupts(void)
- {
- struct itimerval newv, old;
- newv.it_value.tv_sec = 0;
- newv.it_value.tv_usec = USEC_PER_POLL;
- newv.it_interval.tv_sec = 0;
- newv.it_interval.tv_usec = USEC_PER_POLL;
- if (0 != setitimer(ITIMER_REAL, &newv, &old)) {
- perror("setitimer");
- exit(-1); }
- }
- void
- s48_stop_alarm_interrupts(void)
- {
- struct itimerval newv, old;
- newv.it_value.tv_sec = 0;
- newv.it_value.tv_usec = 0;
- newv.it_interval.tv_sec = 0;
- newv.it_interval.tv_usec = 0;
- if (0 != setitimer(ITIMER_REAL, &newv, &old)) {
- perror("setitimer");
- exit(-1); }
- }
- /*
- * We ensure single-threadedness by sending a signal to the main
- * thread, and doing everthing critical there. This is all probably
- * quite useless without OS threads.
- */
- #ifdef HAVE_PTHREAD_H
- static pthread_mutex_t external_event_mutex = PTHREAD_MUTEX_INITIALIZER;
- static pthread_t main_thread;
- #define LOCK_EXTERNAL_EVENTS pthread_mutex_lock(&external_event_mutex)
- #define UNLOCK_EXTERNAL_EVENTS pthread_mutex_unlock(&external_event_mutex)
- #else
- #define LOCK_EXTERNAL_EVENTS
- #define UNLOCK_EXTERNAL_EVENTS
- #endif
- long
- s48_dequeue_external_event(char* readyp)
- {
- long retval;
- LOCK_EXTERNAL_EVENTS;
- retval = s48_dequeue_external_eventBUunsafe(readyp);
- UNLOCK_EXTERNAL_EVENTS;
- return retval;
- }
- static char
- external_event_pending()
- {
- char retval;
- LOCK_EXTERNAL_EVENTS;
- retval = s48_external_event_pendingPUunsafe();
- UNLOCK_EXTERNAL_EVENTS;
- return retval;
- }
- /* no side effect */
- static char
- external_event_ready()
- {
- char retval;
- LOCK_EXTERNAL_EVENTS;
- retval = s48_external_event_readyPUunsafe();
- UNLOCK_EXTERNAL_EVENTS;
- return retval;
- }
- void
- s48_note_external_event(long uid)
- {
- LOCK_EXTERNAL_EVENTS;
- s48_note_external_eventBUunsafe(uid);
- UNLOCK_EXTERNAL_EVENTS;
- NOTE_EVENT;
- #ifdef HAVE_PTHREAD_H
- pthread_kill(main_thread, SIG_EXTERNAL_EVENT);
- #else
- /* pretty useless probably */
- raise(SIG_EXTERNAL_EVENT);
- #endif
- }
- void
- s48_when_external_event_interrupt(int ign)
- {
- /* do nothing, except possibly interrupt the running select */
- }
- /*
- * ; Scheme version of the get-next-event procedure
- * ;
- * ; 1. If there has been a keyboard interrupt, return it.
- * ; 2. Check for ready ports if enough time has passed since the last check.
- * ; 3. If there is a ready port, return it.
- * ; 4. If an alarm is due, return it.
- * ; 5. If no events are pending, clear the event flags.
- * (define (get-next-event)
- * (cond ((> *keyboard-interrupt-count* 0)
- * (without-interrupts
- * (lambda ()
- * (set! *keyboard-interrupt-count*
- * (- *keyboard-interrupt-count* 1))))
- * (values (enum event-type keyboard-interrupt) #f #f))
- * (else
- * (cond ((>= *current_time* *poll-time*)
- * (queue-ready-ports)
- * (set! *poll-time* (+ *time* *poll-interval*))))
- * (cond ((not (queue-empty? ready-ports))
- * (values (enum event-type i/o-completion)
- * (dequeue! ready-ports)))
- * ((>= *current_time* *alarm-time*)
- * (set! *alarm-time* max-integer)
- * (values (enum event-type alarm-interrupt) #f))
- * (else
- * (without-interrupts
- * (lambda ()
- * (if (and (= *keyboard-interrupt-count* 0)
- * (> *alarm-time* *current_time*)
- * (> *poll-time* *current_time*))
- * (set! *pending-event?* #f))))
- * (values (enum event-type no-event) #f))))))
- */
- static psbool there_are_ready_ports(void);
- static int next_ready_port(void);
- static int queue_ready_ports(psbool wait, long seconds, long ticks);
- int
- s48_get_next_event(long *ready_fd, long *status)
- {
- int io_poll_status;
- /*
- fprintf(stderr, "[poll at %d (waiting for %d)]\n", s48_current_time, alarm_time);
- */
- if (keyboard_interrupt_count > 0) {
- block_keyboard_n_alarm_interrupts();
- --keyboard_interrupt_count;
- allow_keyboard_n_alarm_interrupts();
- /* fprintf(stderr, "[keyboard interrupt]\n"); */
- return (KEYBOARD_INTERRUPT_EVENT);
- }
- if (poll_time != -1 && s48_current_time >= poll_time) {
- io_poll_status = queue_ready_ports(PSFALSE, 0, 0);
- if (io_poll_status == NO_ERRORS)
- poll_time = s48_current_time + poll_interval;
- else {
- *status = io_poll_status;
- return (ERROR_EVENT);
- }
- }
- if (there_are_ready_ports()) {
- *ready_fd = next_ready_port();
- *status = 0; /* chars read or written */
- /* fprintf(stderr, "[i/o completion]\n"); */
- return (IO_COMPLETION_EVENT);
- }
- if (alarm_time != -1 && s48_current_time >= alarm_time) {
- alarm_time = -1;
- /* fprintf(stderr, "[alarm %ld]\n", ticks); */
- return (ALARM_EVENT);
- }
- if (s48_os_signal_pending())
- return (OS_SIGNAL_EVENT);
- if (external_event_pending())
- return (EXTERNAL_EVENT);
- block_keyboard_n_alarm_interrupts();
- if ((keyboard_interrupt_count == 0)
- && (alarm_time == -1 || s48_current_time < alarm_time)
- && (poll_time == -1 || s48_current_time < poll_time))
- s48_Spending_eventsPS = PSFALSE;
- allow_keyboard_n_alarm_interrupts();
- return (NO_EVENT);
- }
- /*
- * We keep two queues of ports: those that have a pending operation, and
- * those whose operation has completed. Periodically, we call select() on
- * the pending ports and move any that are ready onto the other queue and
- * signal an event.
- */
- #define FD_QUIESCENT 0 /* idle */
- #define FD_READY 1 /* I/O ready to be performed */
- #define FD_PENDING 2 /* waiting */
- typedef struct fd_struct {
- int fd, /* file descriptor */
- status; /* one of the FD_* constants */
- psbool is_input; /* iff input */
- struct fd_struct *next; /* next on same queue */
- } fd_struct;
- /*
- * A queue of fd_structs is empty iff the first field is NULL. In
- * that case, lastp points to first.
- */
- typedef struct fdque {
- long count;
- fd_struct *first,
- **lastp;
- } fdque;
- static long fd_setsize;
- static fd_struct **fds;
- static fdque ready = {
- 0,
- NULL,
- &ready.first
- },
- pending = {
- 0,
- NULL,
- &pending.first
- };
- static void findrm(fd_struct *entry, fdque *que);
- static fd_struct *rmque(fd_struct **link, fdque *que);
- static void addque(fd_struct *entry, fdque *que);
- static fd_struct *add_fd(int fd, psbool is_input);
- /*
- * Find a fd_struct in a queue, and remove it.
- */
- static void
- findrm(fd_struct *entry, fdque *que)
- {
- fd_struct **fp,
- *f;
- for (fp = &que->first; (f = *fp) != entry; fp = &f->next)
- if (f == NULL) {
- fprintf(stderr, "ERROR: findrm fd %d, status %d not on queue.\n",
- entry->fd, entry->status);
- return;
- }
- rmque(fp, que);
- }
- /*
- * Given a pointer to the link of a fd_struct, and a pointer to
- * the queue it is on, remove the entry from the queue.
- * The entry removed is returned.
- */
- static fd_struct *
- rmque(fd_struct **link, fdque *que)
- {
- fd_struct *res;
- res = *link;
- *link = res->next;
- if (res->next == NULL)
- que->lastp = link;
- que->count--;
- return (res);
- }
- /*
- * Add a fd_struct to a queue.
- */
- static void
- addque(fd_struct *entry, fdque *que)
- {
- *que->lastp = entry;
- entry->next = NULL;
- que->lastp = &entry->next;
- que->count++;
- }
- static psbool
- there_are_ready_ports(void)
- {
- return (ready.first != NULL);
- }
- static int
- next_ready_port(void)
- {
- fd_struct *p;
- p = rmque(&ready.first, &ready);
- p->status = FD_QUIESCENT;
- return (p->fd);
- }
- /*
- * Put fd on to the queue of ports with pending operations.
- * Return PSTRUE if successful, and PSFALSE otherwise.
- */
- psbool
- s48_add_pending_fd(int fd, psbool is_input)
- {
- fd_struct *data;
- if (! (0 <= fd && fd < fd_setsize)) {
- fd_setsize *= 2;
- fds = (fd_struct **) realloc (fds, sizeof (fd_struct *) * fd_setsize);
- if (fds == NULL)
- fprintf(stderr, "ERROR: realloc of fds to %ld elements failed, errno = %d\n",
- fd_setsize,
- errno);
- return (PSFALSE);
- }
- data = fds[fd];
- if (data == NULL) {
- data = add_fd(fd, is_input);
- if (data == NULL)
- return (PSFALSE); } /* no more memory */
- data->is_input = is_input;
- if (data->status == FD_PENDING)
- return (PSTRUE); /* fd is already pending */
- if (data->status == FD_READY)
- findrm(data, &ready);
- data->status = FD_PENDING;
- addque(data, &pending);
- if (poll_time == -1)
- poll_time = s48_current_time + poll_interval;
- return PSTRUE;
- }
- /*
- * Add a new fd_struct for fd.
- */
- static fd_struct *
- add_fd(int fd, psbool is_input)
- {
- struct fd_struct *new_fd;
- new_fd = (struct fd_struct *)malloc(sizeof(struct fd_struct));
- if (new_fd != NULL) {
- new_fd->fd = fd;
- new_fd->status = FD_QUIESCENT;
- new_fd->is_input = is_input;
- new_fd->next = NULL;
- fds[fd] = new_fd;
- }
- return (new_fd);
- }
- /*
- * Remove fd from any queues it is on. Returns true if the FD was on a queue
- * and false if it wasn't.
- */
- psbool
- s48_remove_fd(int fd)
- {
- struct fd_struct *data;
- if (! (0 <= fd && fd < fd_setsize)) {
- fprintf(stderr, "ERROR: s48_remove_fd fd %d not in [0, %ld)\n",
- fd,
- fd_setsize);
- return PSFALSE;
- }
- data = fds[fd];
- if (data == NULL)
- return PSFALSE;
- if (data->status == FD_PENDING) {
- findrm(data, &pending);
- if (pending.first == NULL)
- poll_time = -1;
- } else if (data->status == FD_READY)
- findrm(data, &ready);
- free((void *)data);
- fds[fd] = NULL;
- return PSTRUE;
- }
- int
- s48_wait_for_event(long max_wait, psbool is_minutes)
- {
- int status;
- long seconds,
- ticks;
- /* fprintf(stderr, "[waiting]\n"); */
- s48_stop_alarm_interrupts();
- ticks = 0;
- if (max_wait == -1)
- seconds = -1;
- else if (is_minutes)
- seconds = max_wait * 60;
- else {
- seconds = max_wait / TICKS_PER_SECOND;
- ticks = max_wait % TICKS_PER_SECOND;
- }
- if (keyboard_interrupt_count > 0)
- status = NO_ERRORS;
- else {
- status = queue_ready_ports(PSTRUE, seconds, ticks);
- if (there_are_ready_ports()
- || external_event_ready())
- NOTE_EVENT;
- }
- s48_start_alarm_interrupts();
- return (status);
- }
- #if defined HAVE_GLIB
- static GMainContext *g_main_context;
- typedef struct S48_GSource {
- GSource g_source;
- psbool wait;
- long seconds;
- long ticks;
- } S48_GSource;
- static S48_GSource *g_source;
- static guint g_source_id;
- static GPollFD *g_pollfds;
- static long g_pollfds_size;
- static gboolean
- s48_g_source_prepare(GSource *source, gint *timeout_) {
- fd_struct *fdp,
- **fdpp;
- int g_npollfds;
- S48_GSource *src = (S48_GSource *) source;
- if ((! src->wait)
- && (pending.first == NULL))
- return TRUE;
- if (pending.count > g_pollfds_size) {
- g_pollfds_size *= 2;
- g_pollfds = (GPollFD *) realloc (g_pollfds,
- sizeof (GPollFD) * g_pollfds_size);
- if (g_pollfds == NULL) {
- fprintf(stderr,
- "Failed to realloc array of file descriptors to poll, errno = %d\n",
- errno);
- exit(1);
- }
- }
- for (fdp = pending.first, g_npollfds = 0;
- fdp != NULL;
- fdp = fdp->next, g_npollfds++) {
- g_pollfds[g_npollfds].fd = fdp->fd;
- g_pollfds[g_npollfds].events = fdp->is_input?
- (G_IO_IN | G_IO_HUP | G_IO_ERR) : (G_IO_OUT | G_IO_ERR);
- g_source_add_poll(source, &g_pollfds[g_npollfds]);
- }
- if (src->wait && timeout_)
- if (src->seconds == -1)
- *timeout_ = -1;
- else
- *timeout_ = (gint) src->seconds;
- else
- *timeout_ = 0;
- return FALSE;
- }
- static gboolean
- s48_g_source_check(GSource *source) {
- fd_struct *fdp,
- **fdpp;
- int g_npollfds;
- fdpp = &pending.first;
- for (fdp = *fdpp, g_npollfds = 0;
- (fdp != NULL);
- fdp = *fdpp, g_npollfds++) {
- if ((g_pollfds[g_npollfds].revents
- & (fdp->is_input? G_IO_IN : G_IO_OUT))
- | G_IO_HUP | G_IO_ERR)
- return TRUE;
- else
- fdpp = &fdp->next;
- }
- return FALSE;
- }
- static gboolean
- s48_g_source_dispatch(GSource *source, GSourceFunc callback, gpointer user_data) {
- fd_struct *fdp,
- **fdpp;
- int g_npollfds;
- fdpp = &pending.first;
- for (fdp = *fdpp, g_npollfds = 0;
- (fdp != NULL);
- fdp = *fdpp, g_npollfds++) {
- if ((g_pollfds[g_npollfds].revents
- & (fdp->is_input? G_IO_IN : G_IO_OUT))
- | G_IO_HUP | G_IO_ERR) {
- g_source_remove_poll(source, &g_pollfds[g_npollfds]);
- rmque(fdpp, &pending);
- fdp->status = FD_READY;
- addque(fdp, &ready);
- }
- else
- fdpp = &fdp->next;
- }
- if (pending.first == NULL)
- poll_time = -1;
- return TRUE;
- }
- static GSourceFuncs s48_g_source_funcs = {
- s48_g_source_prepare,
- s48_g_source_check,
- s48_g_source_dispatch,
- NULL,
- NULL,
- NULL
- };
- /*
- * Use the glib event loop.
- */
- static int
- queue_ready_ports(psbool wait, long seconds, long ticks)
- {
- g_source->wait = wait;
- g_source->seconds = seconds;
- g_source->ticks = ticks;
- g_main_context_iteration(g_main_context, wait);
- return NO_ERRORS;
- }
- #elif defined HAVE_POLL
- static struct pollfd *pollfds;
- static long pollfds_size;
- /*
- * Call poll() on the pending ports and move any ready ones to the ready
- * queue. If wait is true, seconds is either -1 (wait forever) or the
- * maximum number of seconds to wait (with ticks any additional ticks).
- * The returned value is a status code.
- */
- static int
- queue_ready_ports(psbool wait, long seconds, long ticks)
- {
- int npollfds;
- int timeout;
- fd_struct *fdp,
- **fdpp;
- int left;
- if ((! wait)
- && (pending.first == NULL))
- return (NO_ERRORS);
- if (pending.count > pollfds_size) {
- pollfds_size *= 2;
- pollfds = (struct pollfd *) realloc (pollfds,
- sizeof (struct pollfd) * pollfds_size);
- if (pollfds == NULL) {
- fprintf(stderr,
- "Failed to realloc array of file descriptors to poll, errno = %d\n",
- errno);
- exit(1);
- }
- }
- for (fdp = pending.first, npollfds = 0; fdp != NULL; fdp = fdp->next, npollfds++) {
- pollfds[npollfds].fd = fdp->fd;
- pollfds[npollfds].events = fdp->is_input? POLLIN : POLLOUT;
- }
- if (wait)
- if (seconds == -1)
- timeout = -1;
- else
- timeout = (int) seconds;
- else
- timeout = 0;
- while(1) {
- left = poll(pollfds, pending.count, timeout);
- if (left > 0) {
- fdpp = &pending.first;
- for (fdp = *fdpp, npollfds = 0;
- (left > 0) && (fdp != NULL);
- fdp = *fdpp, npollfds++) {
- if (pollfds[npollfds].revents & (fdp->is_input? POLLIN : POLLOUT)
- | POLLHUP | POLLERR) {
- rmque(fdpp, &pending);
- fdp->status = FD_READY;
- addque(fdp, &ready);
- }
- else
- fdpp = &fdp->next;
- }
- if (pending.first == NULL)
- poll_time = -1;
- return NO_ERRORS;
- }
- else if (left == 0)
- return NO_ERRORS;
- else if (errno == EINTR) {
- if (external_event_ready())
- return NO_ERRORS;
- timeout = 0; /* turn off blocking and try again */
- }
- else
- return errno;
- }
- }
- #elif defined HAVE_SELECT
- /*
- * Call select() on the pending ports and move any ready ones to the ready
- * queue. If wait is true, seconds is either -1 (wait forever) or the
- * maximum number of seconds to wait (with ticks any additional ticks).
- * The returned value is a status code.
- */
- static int
- queue_ready_ports(psbool wait, long seconds, long ticks)
- {
- fd_set reads,
- writes,
- alls;
- int limfd;
- fd_struct *fdp,
- **fdpp;
- int left;
- struct timeval tv,
- *tvp;
- if ((! wait)
- && (pending.first == NULL))
- return (NO_ERRORS);
- FD_ZERO(&reads);
- FD_ZERO(&writes);
- FD_ZERO(&alls);
- limfd = 0;
- for (fdp = pending.first; fdp != NULL; fdp = fdp->next) {
- FD_SET(fdp->fd, fdp->is_input ? &reads : &writes);
- FD_SET(fdp->fd, &alls);
- if (limfd <= fdp->fd)
- limfd = fdp->fd + 1;
- }
- tvp = &tv;
- if (wait)
- if (seconds == -1)
- tvp = NULL;
- else {
- tv.tv_sec = seconds;
- tv.tv_usec = ticks * (1000000 / TICKS_PER_SECOND);
- }
- else
- timerclear(&tv);
- while(1) {
- left = select(limfd, &reads, &writes, &alls, tvp);
- if (left > 0) {
- fdpp = &pending.first;
- while (left > 0 && (fdp = *fdpp) != NULL)
- if ((FD_ISSET(fdp->fd, &alls))
- || (FD_ISSET(fdp->fd, fdp->is_input ? &reads : &writes))) {
- --left;
- rmque(fdpp, &pending);
- fdp->status = FD_READY;
- addque(fdp, &ready);
- } else
- fdpp = &fdp->next;
- if (pending.first == NULL)
- poll_time = -1;
- return NO_ERRORS;
- }
- else if (left == 0)
- return NO_ERRORS;
- else if (errno == EINTR) {
- if (external_event_ready())
- return NO_ERRORS;
- tvp = &tv; /* turn off blocking and try again */
- timerclear(tvp);
- }
- else
- return errno;
- }
- }
- #endif /* HAVE_SELECT */
- void
- s48_sysdep_init(void)
- {
- #ifdef HAVE_PTHREAD_H
- main_thread = pthread_self();
- #endif
- #ifdef HAVE_SIGALTSTACK
- stack_t ss;
-
- ss.ss_sp = malloc(SIGSTKSZ);
- if (ss.ss_sp == NULL)
- fprintf(stderr,
- "Failed to malloc alt stack, errno = %d\n",
- errno);
- ss.ss_size = SIGSTKSZ;
- ss.ss_flags = 0;
- if (sigaltstack(&ss, NULL) == -1)
- fprintf(stderr,
- "Failed to sigaltstack, errno = %d\n",
- errno);
- #endif
- #if defined HAVE_GLIB
- g_main_context = g_main_context_default();
- g_main_context_ref(g_main_context);
- g_source = (S48_GSource *) g_source_new(&s48_g_source_funcs, sizeof (S48_GSource));
- g_source_id = g_source_attach((GSource *) g_source, g_main_context);
- g_pollfds_size = FD_SETSIZE;
- g_pollfds = (GPollFD *) calloc (sizeof (GPollFD), g_pollfds_size);
- if (g_pollfds == NULL) {
- fprintf(stderr,
- "Failed to alloc array of file descriptors to poll with %d elements, errno = %d\n",
- g_pollfds_size,
- errno);
- exit(1);
- }
- #elif defined HAVE_POLL
- pollfds_size = FD_SETSIZE;
- pollfds = (struct pollfd *) calloc (sizeof (struct pollfd), pollfds_size);
- if (pollfds == NULL) {
- fprintf(stderr,
- "Failed to alloc array of file descriptors to poll with %ld elements, errno = %d\n",
- pollfds_size,
- errno);
- exit(1);
- }
- #endif /* HAVE_POLL */
- fd_setsize = FD_SETSIZE;
- fds = (fd_struct **) calloc (sizeof (fd_struct *), fd_setsize);
- if (fds == NULL) {
- fprintf(stderr,
- "Failed to alloc fds with %ld elements, errno = %d\n",
- fd_setsize,
- errno);
- exit(1);
- }
- if (!s48_setcatcher(SIGINT, s48_when_keyboard_interrupt)
- || !s48_setcatcher(SIGALRM, s48_when_alarm_interrupt)
- || !s48_setcatcher(SIGPIPE, when_sigpipe_interrupt)
- || !s48_setcatcher(SIG_EXTERNAL_EVENT, s48_when_external_event_interrupt)) {
- fprintf(stderr,
- "Failed to install signal handlers, errno = %d\n",
- errno);
- exit(1);
- }
- sigemptyset(&interrupt_mask);
- sigaddset(&interrupt_mask, SIGINT);
- sigaddset(&interrupt_mask, SIGALRM);
- s48_start_alarm_interrupts();
- }
|