You are viewing a plain text version of this content. The canonical link for it is here.
Posted to cvs@httpd.apache.org by gs...@apache.org on 2003/11/17 00:47:07 UTC

cvs commit: httpd-2.0/server/mpm/worker worker.c

gstein      2003/11/16 15:47:07

  Modified:    server/mpm/worker worker.c
  Log:
  Switch over to the new pollset API.
  
  * server/mpm/worker/worker.c:
    (listener_thread): create and add sockets to the pollset using the new
      APIs. rearrange the round-robin a little bit to work with the new
      pollset return values.
      cleaning: get rid of an extraneous status variable. get rid of
        obsoleted round-robin code.
  
  Revision  Changes    Path
  1.140     +52 -30    httpd-2.0/server/mpm/worker/worker.c
  
  Index: worker.c
  ===================================================================
  RCS file: /home/cvs/httpd-2.0/server/mpm/worker/worker.c,v
  retrieving revision 1.139
  retrieving revision 1.140
  diff -u -r1.139 -r1.140
  --- worker.c	5 Sep 2003 19:36:26 -0000	1.139
  +++ worker.c	16 Nov 2003 23:47:07 -0000	1.140
  @@ -620,17 +620,28 @@
       void *csd = NULL;
       apr_pool_t *ptrans;                /* Pool for per-transaction stuff */
       apr_pool_t *recycled_pool = NULL;
  -    int n;
  -    apr_pollfd_t *pollset;
  +    apr_pollset_t *pollset;
       apr_status_t rv;
  -    ap_listen_rec *lr, *last_lr = ap_listeners;
  +    ap_listen_rec *lr;
       int have_idle_worker = 0;
  +    int last_poll_idx = 0;
   
       free(ti);
   
  -    apr_poll_setup(&pollset, num_listensocks, tpool);
  -    for(lr = ap_listeners ; lr != NULL ; lr = lr->next)
  -        apr_poll_socket_add(pollset, lr->sd, APR_POLLIN);
  +    /* ### check the status */
  +    (void) apr_pollset_create(&pollset, num_listensocks, tpool, 0);
  +
  +    for (lr = ap_listeners; lr != NULL; lr = lr->next) {
  +        apr_pollfd_t pfd = { 0 };
  +
  +        pfd.desc_type = APR_POLL_SOCKET;
  +        pfd.desc.s = lr->sd;
  +        pfd.reqevents = APR_POLLIN;
  +        pfd.client_data = lr;
  +
  +        /* ### check the status */
  +        (void) apr_pollset_add(pollset, &pfd);
  +    }
   
       /* Unblock the signal used to wake this thread up, and set a handler for
        * it.
  @@ -690,41 +701,52 @@
           }
           else {
               while (!listener_may_exit) {
  -                apr_status_t ret;
  -                apr_int16_t event;
  +                apr_int32_t numdesc;
  +                const apr_pollfd_t *pdesc;
   
  -                ret = apr_poll(pollset, num_listensocks, &n, -1);
  -                if (ret != APR_SUCCESS) {
  -                    if (APR_STATUS_IS_EINTR(ret)) {
  +                rv = apr_pollset_poll(pollset, -1, &numdesc, &pdesc);
  +                if (rv != APR_SUCCESS) {
  +                    if (APR_STATUS_IS_EINTR(rv)) {
                           continue;
                       }
   
                       /* apr_poll() will only return errors in catastrophic
                        * circumstances. Let's try exiting gracefully, for now. */
  -                    ap_log_error(APLOG_MARK, APLOG_ERR, ret, (const server_rec *)
  -                                 ap_server_conf, "apr_poll: (listen)");
  +                    ap_log_error(APLOG_MARK, APLOG_ERR, rv,
  +                                 (const server_rec *) ap_server_conf,
  +                                 "apr_pollset_poll: (listen)");
                       signal_threads(ST_GRACEFUL);
                   }
   
                   if (listener_may_exit) break;
   
  -                /* find a listener */
  -                lr = last_lr;
  -                do {
  -                    lr = lr->next;
  -                    if (lr == NULL) {
  -                        lr = ap_listeners;
  -                    }
  -                    /* XXX: Should we check for POLLERR? */
  -                    apr_poll_revents_get(&event, lr->sd, pollset);
  -                    if (event & APR_POLLIN) {
  -                        last_lr = lr;
  -                        goto got_fd;
  -                    }
  -                } while (lr != last_lr);
  -            }
  -        }
  -    got_fd:
  +                /* We can always use pdesc[0], but sockets at position N
  +                 * could end up completely starved of attention in a very
  +                 * busy server. Therefore, we round-robin across the
  +                 * returned set of descriptors. While it is possible that
  +                 * the returned set of descriptors might flip around and
  +                 * continue to starve some sockets, we happen to know the
  +                 * internal pollset implementation retains ordering
  +                 * stability of the sockets. Thus, the round-robin should
  +                 * ensure that a socket will eventually be serviced.
  +                 */
  +                if (last_poll_idx >= numdesc)
  +                    last_poll_idx = 0;
  +
  +                /* Grab a listener record from the client_data of the poll
  +                 * descriptor, and advance our saved index to round-robin
  +                 * the next fetch.
  +                 *
  +                 * ### hmm... this descriptor might have POLLERR rather
  +                 * ### than POLLIN
  +                 */
  +                lr = pdesc[last_poll_idx++].client_data;
  +                break;
  +
  +            } /* while */
  +
  +        } /* if/else */
  +
           if (!listener_may_exit) {
               /* create a new transaction pool for each accepted socket */
               if (recycled_pool == NULL) {