You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@trafficserver.apache.org by jp...@apache.org on 2010/02/08 20:02:55 UTC

svn commit: r907756 [1/2] - in /incubator/trafficserver/traffic/trunk: iocore/dns/ libinktomi++/

Author: jplevyak
Date: Mon Feb  8 19:02:45 2010
New Revision: 907756

URL: http://svn.apache.org/viewvc?rev=907756&view=rev
Log:
TS-129: moved to code derived from BIND-9.5.2-P2 which has the apache
compatible license.  Also eliminated the two different code paths
for round-robin and non-round robin code which resulted in partial
sharing of the OS _res structure which seemed dangerous.

Modified:
    incubator/trafficserver/traffic/trunk/iocore/dns/DNS.cc
    incubator/trafficserver/traffic/trunk/iocore/dns/I_DNSProcessor.h
    incubator/trafficserver/traffic/trunk/iocore/dns/P_DNSProcessor.h
    incubator/trafficserver/traffic/trunk/iocore/dns/SplitDNS.cc
    incubator/trafficserver/traffic/trunk/libinktomi++/ink_res_init.cc
    incubator/trafficserver/traffic/trunk/libinktomi++/ink_res_mkquery.cc
    incubator/trafficserver/traffic/trunk/libinktomi++/ink_resolver.h

Modified: incubator/trafficserver/traffic/trunk/iocore/dns/DNS.cc
URL: http://svn.apache.org/viewvc/incubator/trafficserver/traffic/trunk/iocore/dns/DNS.cc?rev=907756&r1=907755&r2=907756&view=diff
==============================================================================
--- incubator/trafficserver/traffic/trunk/iocore/dns/DNS.cc (original)
+++ incubator/trafficserver/traffic/trunk/iocore/dns/DNS.cc Mon Feb  8 19:02:45 2010
@@ -50,7 +50,6 @@
 int dns_ns_rr_init_down = 1;
 char *dns_ns_list = NULL;
 
-
 DNSProcessor dnsProcessor;
 ClassAllocator<DNSEntry> dnsEntryAllocator("dnsEntryAllocator");
 // Users are expected to free these entries in short order!
@@ -67,7 +66,6 @@
 static void dns_result(DNSHandler * h, DNSEntry * e, HostEnt * ent, bool retry);
 static void write_dns(DNSHandler * h);
 static bool write_dns_event(DNSHandler * h, DNSEntry * e);
-//static void dns_init();
 
 // "reliable" name to try. need to build up first.
 static int try_servers = 0;
@@ -76,18 +74,6 @@
 char try_server_names[DEFAULT_NUM_TRY_SERVER][MAXDNAME];
 
 
-/*
-// for HPUX port: 
-// domain_string is defined to store the initial domain fields
-// after calling res_init. The _res global variable somehow gets
-// corrupted when event handled by different threads. For now, 
-// we are using this work-around to get-by the problem. It would
-// be investigated further.
-#if (HOST_OS == hpux)
-char *domain_string[MAXDNSRCH]; 
-#endif
-*/
-
 static inline char *
 strnchr(char *s, char c, int len)
 {
@@ -97,6 +83,13 @@
   return *s == c ? s : (char *) NULL;
 }
 
+static inline inku16
+ink_get16(const inku8 *src) {
+  inku16 dst;
+  
+  NS_GET16(dst, src);
+  return dst;
+}
 
 //
 //  Public functions
@@ -109,7 +102,6 @@
   dnsBufAllocator.free(ent);
 }
 
-
 int
 DNSProcessor::start(int)
 {
@@ -136,7 +128,6 @@
   return 0;
 }
 
-
 void
 DNSProcessor::open(unsigned int aip, int aport, int aoptions)
 {
@@ -144,12 +135,7 @@
 
   h->options = aoptions;
   h->mutex = thread->mutex;
-
-  if (dns_ns_rr)
-    h->m_res = l_res_rr;
-  else
-    h->m_res = l_res;
-
+  h->m_res = &l_res;
   h->ip = aip;
   h->port = aport;
 
@@ -160,7 +146,6 @@
   thread->schedule_imm(h, ET_DNS);
 }
 
-
 //
 // Initialization
 //
@@ -226,25 +211,13 @@
     // Terminate the list for ink_res_init
     nameserver_ip[j] = 0;
 
-    struct __res_state_rr *res_rr = new struct __res_state_rr;
-    memset(res_rr, 0, sizeof(__res_state_rr));
-
     // The default domain (4th param) and search list (5th param) will
     // come from /etc/resolv.conf.
-    if (j == 0 || ink_res_init_rr(*res_rr, &nameserver_ip[0], &nameserver_port[0], NULL, NULL) == -1) {
-      Debug("dns", "Failed to build DNS res records for the servers (%s).  Using resolv.conf.", dns_ns_list);
-      Warning("Failed to build DNS res records for the servers (%s).  Using resolv.conf.", dns_ns_list);
-
-      res_init();
-      dns_ns_rr = 0;
-      l_res = &_res;
-      delete res_rr;
-    } else {
-      l_res_rr = res_rr;
-    }
+    if (ink_res_init(&l_res, &nameserver_ip[0], &nameserver_port[0], NULL, NULL) < 0)
+      MachineFatal("Failed to build DNS res records for the servers (%s).  Using resolv.conf.", dns_ns_list);
   } else {
-    res_init();
-    l_res = &_res;
+    if (ink_res_init(&l_res, 0, 0, 0, 0) < 0)
+      MachineFatal("Failed to build DNS res records for the servers (%s).  Using resolv.conf.", dns_ns_list);
     dns_ns_rr = 0;
   }
 }
@@ -264,9 +237,9 @@
 }
 
 DNSProcessor::DNSProcessor()
-:thread(NULL), handler(NULL), l_res(NULL), l_res_rr(NULL)
+  : thread(NULL), handler(NULL)
 {
-  // no body
+  memset(&l_res, 0, sizeof(l_res));
 }
 
 void
@@ -434,18 +407,9 @@
   Debug("dns", "DNSHandler::startEvent: on thread%d\n", e->ethread->id);
   if (ip == DEFAULT_DOMAIN_NAME_SERVER) {
     // seems that res_init always sets m_res.nscount to at least 1!
-    int nscount = 0;
-    if (!dns_ns_rr)
-      nscount = ((struct __res_state *) m_res)->nscount;
-    else
-      nscount = ((struct __res_state_rr *) m_res)->nscount;
-    if (!nscount)
-      IOCORE_MachineFatal("bad '/etc/resolv.conf': no nameservers given");
-    struct sockaddr_in *sa;
-    if (!dns_ns_rr)
-      sa = &((struct __res_state *) m_res)->nsaddr_list[0];
-    else
-      sa = &((struct __res_state_rr *) m_res)->nsaddr_list[0];
+    if (!m_res->nscount)
+      MachineFatal("bad '/etc/resolv.conf': no nameservers given");
+    struct sockaddr_in *sa = &m_res->nsaddr_list[0];
     ip = sa->sin_addr.s_addr;
     if (!ip)
       ip = ink_inet_addr("127.0.0.1");
@@ -460,12 +424,12 @@
     dns_handler_initialized = 1;
     SET_HANDLER(&DNSHandler::mainEvent);
     if (dns_ns_rr) {
-      int max_nscount = ((struct __res_state_rr *) m_res)->nscount;
+      int max_nscount = m_res->nscount;
       if (max_nscount > MAX_NAMED)
         max_nscount = MAX_NAMED;
       n_con = 0;
       for (int i = 0; i < max_nscount; i++) {
-        struct sockaddr_in *sa = &((struct __res_state_rr *) m_res)->nsaddr_list[i];
+        struct sockaddr_in *sa = &m_res->nsaddr_list[i];
         ip = sa->sin_addr.s_addr;
         if (ip) {
           port = ntohs(sa->sin_port);
@@ -486,93 +450,11 @@
     ink_assert(false);          // I.e. this should never really happen
     return EVENT_DONE;
   }
-
-#ifdef SOMEONE_IS_SMOKING_CRACK_HERE
-}
-
-else {                          //this appears to never happen but i may be wrong /ebalsa
-  // Certainly looks "dead" to me, but it might be that we want to be able to restart the
-  // DNS processor / handler?
-
-  //
-  // If we are re-initializing the connection
-  // close the old one and open the new one.
-  //
-
-  //added by YTS Team, yamsat 
-  Debug("dns", "Reinitializing the connections in DNSHandler::startEvent on thread%d\n", e->ethread->id);
-  struct epoll_event event;
-  PollDescriptor *pd = get_PollDescriptor(e->ethread);
-  memset(&event, 0, sizeof(struct epoll_event));
-  event.events = EPOLLIN | EPOLLET;
-
-  if (dns_ns_rr) {
-    int max_nscount = ((struct __res_state_rr *) m_res)->nscount;
-    if (max_nscount > MAX_NAMED)
-      max_nscount = MAX_NAMED;
-    n_con = 0;
-    for (int i = 0; i < max_nscount; i++) {
-      if (dnsProcessor.handler->con[i].fd != NO_FD) {
-        //added by YTS Team, yamsat 
-        epoll_ctl(pd->epoll_fd, EPOLL_CTL_DEL, dnsProcessor.handler->con[i].fd, &event);
-        dnsProcessor.handler->con[i].close();
-      }
-      struct sockaddr_in *sa = &((struct __res_state_rr *) m_res)->nsaddr_list[i];
-      ip = sa->sin_addr.s_addr;
-      if (ip) {
-        port = ntohs(sa->sin_port);
-        dnsProcessor.handler->options = options;
-        dnsProcessor.handler->open_con(ip, port, false, i);
-        //added by YTS Team, yamsat 
-        dnsProcessor.handler->con[i].num = n_con;
-        if (dnsProcessor.handler->con[i].epoll_ptr == NULL) {
-          struct epoll_data_ptr *eptr;
-          eptr = (struct epoll_data_ptr *) xmalloc(sizeof(struct epoll_data_ptr));
-          eptr->type = 3;
-          eptr->data.dnscon = &dnsProcessor.handler->con[i];
-          dnsProcessor.handler->con[i].epoll_ptr = eptr;
-        }
-        event.data.ptr = dnsProcessor.handler->con[i].epoll_ptr;
-        if (epoll_ctl(pd->epoll_fd, EPOLL_CTL_ADD, dnsProcessor.handler->con[i].fd, &event) < 0) {
-          Debug("iocore_dns", "startEvent : Failed to add %d server to epoll list\n", i);
-        }
-        ++n_con;
-      }
-    }
-  } else {
-    if (dnsProcessor.handler->con[0].fd != NO_FD) {
-      //added by YTS Team, yamsat 
-      epoll_ctl(pd->epoll_fd, EPOLL_CTL_DEL, dnsProcessor.handler->con[0].fd, &event);
-      dnsProcessor.handler->con[0].close();
-    }
-    dnsProcessor.handler->options = options;
-    dnsProcessor.handler->open_con(ip, port);
-
-    //added by YTS Team, yamsat 
-    dnsProcessor.handler->con[0].num = 0;
-    if (dnsProcessor.handler->con[0].epoll_ptr == NULL) {
-      struct epoll_data_ptr *eptr;
-      eptr = (struct epoll_data_ptr *) xmalloc(sizeof(struct epoll_data_ptr));
-      eptr->type = 3;
-      eptr->data.dnscon = &dnsProcessor.handler->con[0];
-      dnsProcessor.handler->con[0].epoll_ptr = eptr;
-    }
-    event.data.ptr = dnsProcessor.handler->con[0].epoll_ptr;
-    if (epoll_ctl(pd->epoll_fd, EPOLL_CTL_ADD, dnsProcessor.handler->con[0].fd, &event) < 0) {
-      Debug("iocore_dns", "startEvent : Failed to add the server to epoll list\n");
-    }
-  }
-  delete this;
-  return EVENT_DONE;
-}
-#endif //Crack
-
 }
 
 /**
   Initial state of the DSNHandler. Can reinitialize the running DNS
   hander to a new nameserver.
-
 */
 int
 DNSHandler::startEvent_sdns(int event, Event * e)
@@ -586,9 +468,9 @@
 
   if (ip == DEFAULT_DOMAIN_NAME_SERVER) {
     // seems that res_init always sets m_res.nscount to at least 1!
-    if (!((struct __res_state *) m_res)->nscount)
-      IOCORE_MachineFatal("bad '/etc/resolv.conf': no nameservers given");
-    struct sockaddr_in *sa = &((struct __res_state *) m_res)->nsaddr_list[0];
+    if (!m_res->nscount)
+      MachineFatal("bad '/etc/resolv.conf': no nameservers given");
+    struct sockaddr_in *sa = &m_res->nsaddr_list[0];
     ip = sa->sin_addr.s_addr;
     if (!ip)
       ip = ink_inet_addr("127.0.0.1");
@@ -603,9 +485,8 @@
   return EVENT_CONT;
 }
 
-
 static inline int
-_ink_res_mkquery(struct __res_state &res, char *qname, int qtype, char *buffer)
+_ink_res_mkquery(ink_res_state res, char *qname, int qtype, char *buffer)
 {
   int r = ink_res_mkquery(res, QUERY, qname, C_IN, qtype,
                           NULL, 0, NULL, (unsigned char *) buffer,
@@ -613,16 +494,6 @@
   return r;
 }
 
-static inline int
-_ink_res_mkquery_rr(struct __res_state_rr &res, char *qname, int qtype, char *buffer)
-{
-  int r = ink_res_mkquery_rr(res, QUERY, qname, C_IN, qtype,
-                             NULL, 0, NULL, (unsigned char *) buffer,
-                             MAX_DNS_PACKET_LEN);
-  return r;
-}
-
-
 void
 DNSHandler::recover()
 {
@@ -631,7 +502,6 @@
   switch_named(name_server);
 }
 
-
 void
 DNSHandler::retry_named(int ndx, ink_hrtime t, bool reopen)
 {
@@ -640,10 +510,7 @@
     last_primary_reopen = t;
     con[ndx].close();
     struct sockaddr_in *sa;
-    if (!dns_ns_rr)
-      sa = &((struct __res_state *) m_res)->nsaddr_list[ndx];
-    else
-      sa = &((struct __res_state_rr *) m_res)->nsaddr_list[ndx];
+    sa = &m_res->nsaddr_list[ndx];
     ip = sa->sin_addr.s_addr;
     port = ntohs(sa->sin_port);
 
@@ -652,14 +519,7 @@
 
   char buffer[MAX_DNS_PACKET_LEN];
   Debug("dns", "trying to resolve '%s' from DNS connection, ndx %d", try_server_names[try_servers], ndx);
-  int r = 0;
-  if (!dns_ns_rr) {
-    struct __res_state *p_res = (struct __res_state *) m_res;
-    r = _ink_res_mkquery(*p_res, try_server_names[try_servers], T_A, buffer);
-  } else {
-    struct __res_state_rr *p_res = (struct __res_state_rr *) m_res;
-    r = _ink_res_mkquery_rr(*p_res, try_server_names[try_servers], T_A, buffer);
-  }
+  int r = _ink_res_mkquery(m_res, try_server_names[try_servers], T_A, buffer);
   try_servers = (try_servers + 1) % SIZE(try_server_names);
   ink_assert(r >= 0);
   if (r >= 0) {                 // looking for a bounce
@@ -668,7 +528,6 @@
   }
 }
 
-
 void
 DNSHandler::try_primary_named(bool reopen)
 {
@@ -680,18 +539,10 @@
   }
   if ((t - last_primary_retry) > DNS_PRIMARY_RETRY_PERIOD) {
     char buffer[MAX_DNS_PACKET_LEN];
-    int r;
 
     last_primary_retry = t;
-    if (!dns_ns_rr) {
-      Debug("dns", "trying to resolve '%s' from primary DNS connection", try_server_names[try_servers]);
-      struct __res_state *p_res = (struct __res_state *) m_res;
-      r = _ink_res_mkquery(*p_res, try_server_names[try_servers], T_A, buffer);
-    } else {
-      Debug("dns", "[rr] trying to resolve '%s' from primary DNS connection", try_server_names[try_servers]);
-      struct __res_state_rr *p_res = (struct __res_state_rr *) m_res;
-      r = _ink_res_mkquery_rr(*p_res, try_server_names[try_servers], T_A, buffer);
-    }
+    Debug("dns", "trying to resolve '%s' from primary DNS connection", try_server_names[try_servers]);
+    int r = _ink_res_mkquery(m_res, try_server_names[try_servers], T_A, buffer);
     // if try_server_names[] is not full, round-robin within the
     // filled entries.
     if (local_num_entries < DEFAULT_NUM_TRY_SERVER)
@@ -725,16 +576,16 @@
 {
   Debug("dns", "failover: initiating failover attempt, current name_server=%d", name_server);
   // no hope, if we have only one server
-  if (((struct __res_state *) m_res)->nscount > 1) {
-    int max_nscount = ((struct __res_state *) m_res)->nscount;
+  if (m_res->nscount > 1) {
+    int max_nscount = m_res->nscount;
 
     if (max_nscount > MAX_NAMED)
       max_nscount = MAX_NAMED;
-    unsigned int old_ip = ((struct __res_state *) m_res)->nsaddr_list[name_server].sin_addr.s_addr;
+    unsigned int old_ip = m_res->nsaddr_list[name_server].sin_addr.s_addr;
     name_server = (name_server + 1) % max_nscount;
     Debug("dns", "failover: failing over to name_server=%d", name_server);
 
-    struct sockaddr_in *sa = &((struct __res_state *) m_res)->nsaddr_list[name_server];
+    struct sockaddr_in *sa = &m_res->nsaddr_list[name_server];
 
     Warning("failover: connection to DNS server %d.%d.%d.%d lost, move to %d.%d.%d.%d",
             DOT_SEPARATED(old_ip), DOT_SEPARATED(sa->sin_addr.s_addr));
@@ -761,19 +612,19 @@
     Debug("dns", "rr_failure: Marking nameserver %d as down", ndx);
     ns_down[ndx] = 1;
 
-    struct sockaddr_in *sa = &((struct __res_state_rr *) m_res)->nsaddr_list[ndx];
+    struct sockaddr_in *sa = &m_res->nsaddr_list[ndx];
     unsigned int tip = sa->sin_addr.s_addr;
     Warning("connection to DNS server %d.%d.%d.%d lost, marking as down", DOT_SEPARATED(tip));
   }
 
-  int nscnt = ((struct __res_state_rr *) m_res)->nscount;
-  if (nscnt > MAX_NAMED)
-    nscnt = MAX_NAMED;
+  int nscount = m_res->nscount;
+  if (nscount > MAX_NAMED)
+    nscount = MAX_NAMED;
 
   // See if all nameservers are down
   int all_down = 1;
 
-  for (int i = 0; i < nscnt && all_down; i++) {
+  for (int i = 0; i < nscount && all_down; i++) {
     Debug("dns", "nsdown[%d]=%d", i, ns_down[i]);
     if (!ns_down[i]) {
       all_down = 0;
@@ -859,7 +710,7 @@
         if (good_rcode(buf->buf)) {
           received_one(dnsc->num);
           if (ns_down[dnsc->num]) {
-            struct sockaddr_in *sa = &((struct __res_state_rr *) m_res)->nsaddr_list[dnsc->num];
+            struct sockaddr_in *sa = &m_res->nsaddr_list[dnsc->num];
             Warning("connection to DNS server %d.%d.%d.%d restored", DOT_SEPARATED(sa->sin_addr.s_addr));
             ns_down[dnsc->num] = 0;
           }
@@ -968,12 +819,7 @@
 {
   ProxyMutex *mutex = h->mutex;
   DNS_INCREMENT_DYN_STAT(dns_total_lookups_stat);
-  int max_nscount;
-
-  if (!dns_ns_rr)
-    max_nscount = ((struct __res_state *) (h->m_res))->nscount;
-  else
-    max_nscount = ((struct __res_state_rr *) (h->m_res))->nscount;
+  int max_nscount = h->m_res->nscount;
   if (max_nscount > MAX_NAMED)
     max_nscount = MAX_NAMED;
 
@@ -1019,14 +865,7 @@
 #ifdef DNS_PROXY
   if (!e->proxy) {
 #endif
-    if (!dns_ns_rr) {
-      struct __res_state *p_res = (struct __res_state *) h->m_res;
-      r = _ink_res_mkquery(*p_res, e->qname, e->qtype, buffer);
-    } else {
-      struct __res_state_rr *p_res = (struct __res_state_rr *) h->m_res;
-      r = _ink_res_mkquery_rr(*p_res, e->qname, e->qtype, buffer);
-    }
-    if (r <= 0) {
+    if ((r = _ink_res_mkquery(h->m_res, e->qname, e->qtype, buffer)) <= 0) {
       Debug("dns", "cannot build query: %s", e->qname);
       dns_result(h, e, NULL, false);
       return true;
@@ -1043,7 +882,6 @@
 
   DNS_SET_DYN_COUNT(dns_sequence_number_stat, dns_sequence_number);
 
-
 #ifdef DNS_PROXY
   if (!e->proxy) {
 #endif
@@ -1127,12 +965,8 @@
       if (!proxy) {
 #endif
         //if (dns_search && !strnchr(qname,'.',MAXDNAME)){
-        if (dns_search) {
-          if (!dns_ns_rr)
-            domains = ((struct __res_state *) dnsH->m_res)->dnsrch;
-          else
-            domains = ((struct __res_state_rr *) dnsH->m_res)->dnsrch;
-        }
+        if (dns_search)
+          domains = dnsH->m_res->dnsrch;
         if (domains && !strnchr(qname, '.', MAXDNAME)) {
           qname[qname_len] = '.';
           ink_strncpy(qname + qname_len + 1, *domains, MAXDNAME - (qname_len + 1));
@@ -1358,7 +1192,6 @@
   return 0;
 }
 
-
 int
 DNSEntry::postEvent(int event, Event * e)
 {
@@ -1590,20 +1423,20 @@
         cp += dn_skipname(cp, eom);
         here = cp;              /* hack */
         char srvname[MAXDNAME];
-        int r = ns_name_ntop(srv[num_srv] + SRV_SERVER, srvname, MAXDNAME);
+        int r = ink_ns_name_ntop(srv[num_srv] + SRV_SERVER, srvname, MAXDNAME);
         if (r <= 0) {
           /* FIXME: is this really an error? or just a continue; */
           ++error;
           goto Lerror;
         }
         Debug("dns_srv", "Discovered SRV record [from NS lookup] with cost:%d weight:%d port:%d with host:%s",
-              ns_get16(srv[num_srv] + SRV_COST),
-              ns_get16(srv[num_srv] + SRV_WEIGHT), ns_get16(srv[num_srv] + SRV_PORT), srvname);
+              ink_get16(srv[num_srv] + SRV_COST),
+              ink_get16(srv[num_srv] + SRV_WEIGHT), ink_get16(srv[num_srv] + SRV_PORT), srvname);
 
         SRV *s = SRVAllocator.alloc();
-        s->setPort(ns_get16(srv[num_srv] + SRV_PORT));
-        s->setPriority(ns_get16(srv[num_srv] + SRV_COST));
-        s->setWeight(ns_get16(srv[num_srv] + SRV_WEIGHT));
+        s->setPort(ink_get16(srv[num_srv] + SRV_PORT));
+        s->setPriority(ink_get16(srv[num_srv] + SRV_COST));
+        s->setWeight(ink_get16(srv[num_srv] + SRV_WEIGHT));
         s->setHost(srvname);
 
         buf->srv_hosts.insert(s);

Modified: incubator/trafficserver/traffic/trunk/iocore/dns/I_DNSProcessor.h
URL: http://svn.apache.org/viewvc/incubator/trafficserver/traffic/trunk/iocore/dns/I_DNSProcessor.h?rev=907756&r1=907755&r2=907756&view=diff
==============================================================================
--- incubator/trafficserver/traffic/trunk/iocore/dns/I_DNSProcessor.h (original)
+++ incubator/trafficserver/traffic/trunk/iocore/dns/I_DNSProcessor.h Mon Feb  8 19:02:45 2010
@@ -109,15 +109,14 @@
   //
   void open(unsigned int ip = DEFAULT_DOMAIN_NAME_SERVER, int port = DOMAIN_SERVICE_PORT, int options = _res.options);
 
-    DNSProcessor();
+  DNSProcessor();
 
   //
   // private:
   //
   EThread *thread;
   DNSHandler *handler;
-  struct __res_state *l_res;
-  struct __res_state_rr *l_res_rr;
+  __ink_res_state l_res;
   Action *getby(char *x, int len, int type, Continuation * cont,
                 HostEnt ** wait, DNSHandler * adnsH = NULL, bool proxy = false, bool proxy_cache = false, int timeout =
                 0);

Modified: incubator/trafficserver/traffic/trunk/iocore/dns/P_DNSProcessor.h
URL: http://svn.apache.org/viewvc/incubator/trafficserver/traffic/trunk/iocore/dns/P_DNSProcessor.h?rev=907756&r1=907755&r2=907756&view=diff
==============================================================================
--- incubator/trafficserver/traffic/trunk/iocore/dns/P_DNSProcessor.h (original)
+++ incubator/trafficserver/traffic/trunk/iocore/dns/P_DNSProcessor.h Mon Feb  8 19:02:45 2010
@@ -61,14 +61,6 @@
 extern int dns_max_dns_in_flight;
 extern unsigned int dns_sequence_number;
 
-//#include "OneWayTunnel.h"
-//#include "HttpTransact.h"
-
-// This is temporily to bypass a bunch of debug and error statements. 
-//#define Warning
-//#define Debug
-//#define IOCORE_MachineFatal
-
 //
 // Constants
 //
@@ -218,11 +210,6 @@
 };
 
 
-//extern ClassAllocator<DNSEntry>;
-// Users are expected to free these entries in short order!
-// We could page align this buffer to enable page flipping for recv...
-//extern ClassAllocator<HostEnt>;
-
 typedef int (DNSEntry::*DNSEntryHandler) (int, void *);
 
 struct DNSEntry;
@@ -240,7 +227,7 @@
   int n_con;
   DNSConnection con[MAX_NAMED];
   int options;
-    Queue<DNSEntry> entries;
+  Queue<DNSEntry> entries;
   int in_flight;
   int name_server;
   int in_write_dns;
@@ -253,7 +240,7 @@
   ink_hrtime last_primary_retry;
   ink_hrtime last_primary_reopen;
 
-  void *m_res;
+  ink_res_state m_res;
   int txn_lookup_timeout;
 
   void received_one(int i)
@@ -304,13 +291,13 @@
 
 
 inline DNSHandler::DNSHandler()
-:Continuation(NULL),
-ip(0),
-port(0),
-n_con(0),
-options(0),
-in_flight(0), name_server(0), in_write_dns(0), hostent_cache(0), last_primary_retry(0), last_primary_reopen(0),
-m_res(0), txn_lookup_timeout(0)
+ :Continuation(NULL),
+  ip(0),
+  port(0),
+  n_con(0),
+  options(0),
+  in_flight(0), name_server(0), in_write_dns(0), hostent_cache(0), last_primary_retry(0), last_primary_reopen(0),
+  m_res(0), txn_lookup_timeout(0)
 {
   for (int i = 0; i < MAX_NAMED; i++) {
     ifd[i] = -1;

Modified: incubator/trafficserver/traffic/trunk/iocore/dns/SplitDNS.cc
URL: http://svn.apache.org/viewvc/incubator/trafficserver/traffic/trunk/iocore/dns/SplitDNS.cc?rev=907756&r1=907755&r2=907756&view=diff
==============================================================================
--- incubator/trafficserver/traffic/trunk/iocore/dns/SplitDNS.cc (original)
+++ incubator/trafficserver/traffic/trunk/iocore/dns/SplitDNS.cc Mon Feb  8 19:02:45 2010
@@ -718,11 +718,10 @@
   }
 
   DNSHandler *dnsH = new DNSHandler;
-  struct __res_state *res = new ResState;
-  memset(res, 0, sizeof(ResState));
+  ink_res_state res = new __ink_res_state;
+  memset(res, 0, sizeof(__ink_res_state));
 
-
-  if ((-1 == ink_res_init(*res,
+  if ((-1 == ink_res_init(res,
                           &m_servers.x_server_ip[0],
                           &m_servers.x_dns_server_port[0],
                           &m_servers.x_def_domain[0], &m_servers.x_domain_srch_list[0]))) {
@@ -733,7 +732,7 @@
 
     return errBuf;
   }
-  dnsH->m_res = (void *) res;
+  dnsH->m_res = res;
 
   dnsH->mutex = SplitDNSConfig::dnsHandler_mutex;
   dnsH->options = res->options;
@@ -821,7 +820,10 @@
 
   SplitDNSRecord *newRec;
 
-  if (-1 == res_init()) {
+  ink_res_state res = new __ink_res_state;
+  memset(res, 0, sizeof(__ink_res_state));
+
+  if (ink_res_init(res, 0, 0, 0, 0) < 0) {
     Warning("no default name server configured!");
     return 0;
   }
@@ -829,14 +831,12 @@
   newRec = NEW(new SplitDNSRecord);
 
   for (int i = 0; i < _res.nscount; i++) {
-
     newRec->m_servers.x_server_ip[i] = _res.nsaddr_list[i].sin_addr.s_addr;
-
     newRec->m_servers.x_dns_server_port[i] = ntohs(_res.nsaddr_list[i].sin_port);
   }
 
   newRec->m_servers.x_dnsH = new DNSHandler;
-  newRec->m_servers.x_dnsH->m_res = &_res;
+  newRec->m_servers.x_dnsH->m_res = res;
 
   newRec->m_servers.x_dnsH->mutex = SplitDNSConfig::dnsHandler_mutex;
   newRec->m_servers.x_dnsH->options = _res.options;

Modified: incubator/trafficserver/traffic/trunk/libinktomi++/ink_res_init.cc
URL: http://svn.apache.org/viewvc/incubator/trafficserver/traffic/trunk/libinktomi%2B%2B/ink_res_init.cc?rev=907756&r1=907755&r2=907756&view=diff
==============================================================================
--- incubator/trafficserver/traffic/trunk/libinktomi++/ink_res_init.cc (original)
+++ incubator/trafficserver/traffic/trunk/libinktomi++/ink_res_init.cc Mon Feb  8 19:02:45 2010
@@ -1,60 +1,95 @@
-/** @file
-
-  A brief file description
-
-  @section license License
-
-  Copyright (c) 1985, 1989, 1993
-     The Regents of the University of California.  All rights reserved.
+/*
+ * Copyright (c) 1985, 1989, 1993
+ *    The Regents of the University of California.  All rights reserved.
+ *
+ * Redistribution and use in source and binary forms, with or without
+ * modification, are permitted provided that the following conditions
+ * are met:
+ * 1. Redistributions of source code must retain the above copyright
+ *    notice, this list of conditions and the following disclaimer.
+ * 2. Redistributions in binary form must reproduce the above copyright
+ *    notice, this list of conditions and the following disclaimer in the
+ *    documentation and/or other materials provided with the distribution.
+ * 3. All advertising materials mentioning features or use of this software
+ *    must display the following acknowledgement:
+ *      This product includes software developed by the University of
+ *      California, Berkeley and its contributors.
+ * 4. Neither the name of the University nor the names of its contributors
+ *    may be used to endorse or promote products derived from this software
+ *    without specific prior written permission.
+ *
+ * THIS SOFTWARE IS PROVIDED BY THE REGENTS AND CONTRIBUTORS ``AS IS'' AND
+ * ANY EXPRESS OR IMPLIED WARRANTIES, INCLUDING, BUT NOT LIMITED TO, THE
+ * IMPLIED WARRANTIES OF MERCHANTABILITY AND FITNESS FOR A PARTICULAR PURPOSE
+ * ARE DISCLAIMED.  IN NO EVENT SHALL THE REGENTS OR CONTRIBUTORS BE LIABLE
+ * FOR ANY DIRECT, INDIRECT, INCIDENTAL, SPECIAL, EXEMPLARY, OR CONSEQUENTIAL
+ * DAMAGES (INCLUDING, BUT NOT LIMITED TO, PROCUREMENT OF SUBSTITUTE GOODS
+ * OR SERVICES; LOSS OF USE, DATA, OR PROFITS; OR BUSINESS INTERRUPTION)
+ * HOWEVER CAUSED AND ON ANY THEORY OF LIABILITY, WHETHER IN CONTRACT, STRICT
+ * LIABILITY, OR TORT (INCLUDING NEGLIGENCE OR OTHERWISE) ARISING IN ANY WAY
+ * OUT OF THE USE OF THIS SOFTWARE, EVEN IF ADVISED OF THE POSSIBILITY OF
+ * SUCH DAMAGE.
+ */
 
-  Redistribution and use in source and binary forms, with or without
-  modification, are permitted provided that the following conditions
-  are met:
-  1. Redistributions of source code must retain the above copyright
-     notice, this list of conditions and the following disclaimer.
-  2. Redistributions in binary form must reproduce the above copyright
-     notice, this list of conditions and the following disclaimer in the
-     documentation and/or other materials provided with the distribution.
-  3. All advertising materials mentioning features or use of this software
-     must display the following acknowledgement:
-     This product includes software developed by the University of
-     California, Berkeley and its contributors.
-  4. Neither the name of the University nor the names of its contributors
-     may be used to endorse or promote products derived from this software
-     without specific prior written permission.
-
-  THIS SOFTWARE IS PROVIDED BY THE REGENTS AND CONTRIBUTORS ``AS IS'' AND
-  ANY EXPRESS OR IMPLIED WARRANTIES, INCLUDING, BUT NOT LIMITED TO, THE
-  IMPLIED WARRANTIES OF MERCHANTABILITY AND FITNESS FOR A PARTICULAR PURPOSE
-  ARE DISCLAIMED.  IN NO EVENT SHALL THE REGENTS OR CONTRIBUTORS BE LIABLE
-  FOR ANY DIRECT, INDIRECT, INCIDENTAL, SPECIAL, EXEMPLARY, OR CONSEQUENTIAL
-  DAMAGES (INCLUDING, BUT NOT LIMITED TO, PROCUREMENT OF SUBSTITUTE GOODS
-  OR SERVICES; LOSS OF USE, DATA, OR PROFITS; OR BUSINESS INTERRUPTION)
-  HOWEVER CAUSED AND ON ANY THEORY OF LIABILITY, WHETHER IN CONTRACT, STRICT
-  LIABILITY, OR TORT (INCLUDING NEGLIGENCE OR OTHERWISE) ARISING IN ANY WAY
-  OUT OF THE USE OF THIS SOFTWARE, EVEN IF ADVISED OF THE POSSIBILITY OF
-  SUCH DAMAGE.
-
-  Portions Copyright (c) 1993 by Digital Equipment Corporation.
-
-  Permission to use, copy, modify, and distribute this software for any
-  purpose with or without fee is hereby granted, provided that the above
-  copyright notice and this permission notice appear in all copies, and that
-  the name of Digital Equipment Corporation not be used in advertising or
-  publicity pertaining to distribution of the document or software without
-  specific, written prior permission.
-
-  THE SOFTWARE IS PROVIDED "AS IS" AND DIGITAL EQUIPMENT CORP. DISCLAIMS ALL
-  WARRANTIES WITH REGARD TO THIS SOFTWARE, INCLUDING ALL IMPLIED WARRANTIES
-  OF MERCHANTABILITY AND FITNESS.   IN NO EVENT SHALL DIGITAL EQUIPMENT
-  CORPORATION BE LIABLE FOR ANY SPECIAL, DIRECT, INDIRECT, OR CONSEQUENTIAL
-  DAMAGES OR ANY DAMAGES WHATSOEVER RESULTING FROM LOSS OF USE, DATA OR
-  PROFITS, WHETHER IN AN ACTION OF CONTRACT, NEGLIGENCE OR OTHER TORTIOUS
-  ACTION, ARISING OUT OF OR IN CONNECTION WITH THE USE OR PERFORMANCE OF THIS
-  SOFTWARE.
+/*
+ * Portions Copyright (c) 1993 by Digital Equipment Corporation.
+ *
+ * Permission to use, copy, modify, and distribute this software for any
+ * purpose with or without fee is hereby granted, provided that the above
+ * copyright notice and this permission notice appear in all copies, and that
+ * the name of Digital Equipment Corporation not be used in advertising or
+ * publicity pertaining to distribution of the document or software without
+ * specific, written prior permission.
+ *
+ * THE SOFTWARE IS PROVIDED "AS IS" AND DIGITAL EQUIPMENT CORP. DISCLAIMS ALL
+ * WARRANTIES WITH REGARD TO THIS SOFTWARE, INCLUDING ALL IMPLIED WARRANTIES
+ * OF MERCHANTABILITY AND FITNESS.   IN NO EVENT SHALL DIGITAL EQUIPMENT
+ * CORPORATION BE LIABLE FOR ANY SPECIAL, DIRECT, INDIRECT, OR CONSEQUENTIAL
+ * DAMAGES OR ANY DAMAGES WHATSOEVER RESULTING FROM LOSS OF USE, DATA OR
+ * PROFITS, WHETHER IN AN ACTION OF CONTRACT, NEGLIGENCE OR OTHER TORTIOUS
+ * ACTION, ARISING OUT OF OR IN CONNECTION WITH THE USE OR PERFORMANCE OF THIS
+ * SOFTWARE.
+ */
 
+/*
+ * Copyright (c) 2004 by Internet Systems Consortium, Inc. ("ISC")
+ * Portions Copyright (c) 1996-1999 by Internet Software Consortium.
+ *
+ * Permission to use, copy, modify, and distribute this software for any
+ * purpose with or without fee is hereby granted, provided that the above
+ * copyright notice and this permission notice appear in all copies.
+ *
+ * THE SOFTWARE IS PROVIDED "AS IS" AND ISC DISCLAIMS ALL WARRANTIES
+ * WITH REGARD TO THIS SOFTWARE INCLUDING ALL IMPLIED WARRANTIES OF
+ * MERCHANTABILITY AND FITNESS.  IN NO EVENT SHALL ISC BE LIABLE FOR
+ * ANY SPECIAL, DIRECT, INDIRECT, OR CONSEQUENTIAL DAMAGES OR ANY DAMAGES
+ * WHATSOEVER RESULTING FROM LOSS OF USE, DATA OR PROFITS, WHETHER IN AN
+ * ACTION OF CONTRACT, NEGLIGENCE OR OTHER TORTIOUS ACTION, ARISING OUT
+ * OF OR IN CONNECTION WITH THE USE OR PERFORMANCE OF THIS SOFTWARE.
  */
 
+/*
+  Imported from Bind-9.5.2-P2
+  
+  Changes:
+
+  Licensed to the Apache Software Foundation (ASF) under one
+  or more contributor license agreements.  See the NOTICE file
+  distributed with this work for additional information
+  regarding copyright ownership.  The ASF licenses this file
+  to you under the Apache License, Version 2.0 (the
+  "License"); you may not use this file except in compliance
+  with the License.  You may obtain a copy of the License at
+
+      http://www.apache.org/licenses/LICENSE-2.0
+
+  Unless required by applicable law or agreed to in writing, software
+  distributed under the License is distributed on an "AS IS" BASIS,
+  WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+  See the License for the specific language governing permissions and
+  limitations under the License.
+*/
+
 #if !defined (_WIN32)
 #if defined(LIBC_SCCS) && !defined(lint)
 static char sccsid[] = "@(#)res_init.c	8.1 (Berkeley) 6/7/93";
@@ -78,32 +113,6 @@
 
 #include "ink_resolver.h"
 
-/*-------------------------------------- info about "sortlist" --------------
- * Marc Majka		1994/04/16
- * Allan Nathanson	1994/10/29 (BIND 4.9.3.x)
- *
- * NetInfo resolver configuration directory support.
- *
- * Allow a NetInfo directory to be created in the hierarchy which
- * contains the same information as the resolver configuration file.
- *
- * - The local domain name is stored as the value of the "domain" property.
- * - The Internet address(es) of the name server(s) are stored as values
- *   of the "nameserver" property.
- * - The name server addresses are stored as values of the "nameserver"
- *   property.
- * - The search list for host-name lookup is stored as values of the
- *   "search" property.
- * - The sortlist comprised of IP address netmask pairs are stored as
- *   values of the "sortlist" property. The IP address and optional netmask
- *   should be seperated by a slash (/) or ampersand (&) character.
- * - Internal resolver variables can be set from the value of the "options"
- *   property.
- */
-
-
-static void res_setoptions(struct __res_state &p_res, char *options, char *source);
-static void res_setoptions_rr(struct __res_state_rr &p_res, char *options, char *source);
 #if (HOST_OS != linux)
 int inet_aton(register const char *cp, struct in_addr *addr);
 #endif
@@ -118,17 +127,304 @@
 # define isascii(c) (!(c & 0200))
 #endif
 
-/*
- * Resolver state default settings.
+/*%
+ * This routine is for closing the socket if a virtual circuit is used and
+ * the program wants to close it.  This provides support for endhostent()
+ * which expects to close the socket.
+ *
+ * This routine is not expected to be user visible.
  */
+static void
+ink_res_nclose(ink_res_state statp) {
+  int ns;
+
+  if (statp->_vcsock >= 0) { 
+    (void) close(statp->_vcsock);
+    statp->_vcsock = -1;
+    statp->_flags &= ~(RES_F_VC | RES_F_CONN);
+  }
+  for (ns = 0; ns < statp->_u._ext.nscount; ns++) {
+    if (statp->_u._ext.nssocks[ns] != -1) {
+      (void) close(statp->_u._ext.nssocks[ns]);
+      statp->_u._ext.nssocks[ns] = -1;
+    }
+  }
+}
 
-# if defined(__BIND_RES_TEXT)
-= {
-RES_TIMEOUT,}                   /* Motorola, et al. */
-# endif
-;
+static void
+ink_res_ndestroy(ink_res_state statp) {
+  ink_res_nclose(statp);
+  if (statp->_u._ext.ext != NULL)
+    free(statp->_u._ext.ext);
+  statp->options &= ~RES_INIT;
+  statp->_u._ext.ext = NULL;
+}
+
+static void
+ink_res_setservers(ink_res_state statp, const union ink_res_sockaddr_union *set, int cnt) {
+  int i, nserv;
+  size_t size;
+
+  /* close open servers */
+  ink_res_nclose(statp);
+
+  /* cause rtt times to be forgotten */
+  statp->_u._ext.nscount = 0;
+
+  nserv = 0;
+  for (i = 0; i < cnt && nserv < MAXNS; i++) {
+    switch (set->sin.sin_family) {
+      case AF_INET:
+        size = sizeof(set->sin);
+        if (statp->_u._ext.ext)
+          memcpy(&statp->_u._ext.ext->nsaddrs[nserv],
+                 &set->sin, size);
+        if (size <= sizeof(statp->nsaddr_list[nserv]))
+          memcpy(&statp->nsaddr_list[nserv],
+                 &set->sin, size);
+        else
+          statp->nsaddr_list[nserv].sin_family = 0;
+        nserv++;
+        break;
 
-/*
+#ifdef HAS_INET6_STRUCTS
+      case AF_INET6:
+        size = sizeof(set->sin6);
+        if (statp->_u._ext.ext)
+          memcpy(&statp->_u._ext.ext->nsaddrs[nserv],
+                 &set->sin6, size);
+        if (size <= sizeof(statp->nsaddr_list[nserv]))
+          memcpy(&statp->nsaddr_list[nserv],
+                 &set->sin6, size);
+        else
+          statp->nsaddr_list[nserv].sin_family = 0;
+        nserv++;
+        break;
+#endif
+
+      default:
+        break;
+    }
+    set++;
+  }
+  statp->nscount = nserv;
+	
+}
+
+int
+ink_res_getservers(ink_res_state statp, union ink_res_sockaddr_union *set, int cnt) {
+  int i;
+  size_t size;
+  u_int16_t family;
+
+  for (i = 0; i < statp->nscount && i < cnt; i++) {
+    if (statp->_u._ext.ext)
+      family = statp->_u._ext.ext->nsaddrs[i].sin.sin_family;
+    else 
+      family = statp->nsaddr_list[i].sin_family;
+
+    switch (family) {
+      case AF_INET:
+        size = sizeof(set->sin);
+        if (statp->_u._ext.ext)
+          memcpy(&set->sin,
+                 &statp->_u._ext.ext->nsaddrs[i],
+                 size);
+        else
+          memcpy(&set->sin, &statp->nsaddr_list[i],
+                 size);
+        break;
+
+#ifdef HAS_INET6_STRUCTS
+      case AF_INET6:
+        size = sizeof(set->sin6);
+        if (statp->_u._ext.ext)
+          memcpy(&set->sin6,
+                 &statp->_u._ext.ext->nsaddrs[i],
+                 size);
+        else
+          memcpy(&set->sin6, &statp->nsaddr_list[i],
+                 size);
+        break;
+#endif
+
+      default:
+        set->sin.sin_family = 0;
+        break;
+    }
+    set++;
+  }
+  return (statp->nscount);
+}
+
+static void
+ink_res_setoptions(ink_res_state statp, const char *options, const char *source)
+{
+  const char *cp = options;
+  int i;
+  struct __ink_res_state_ext *ext = statp->_u._ext.ext;
+
+#ifdef DEBUG
+  if (statp->options & RES_DEBUG)
+    printf(";; res_setoptions(\"%s\", \"%s\")...\n",
+           options, source);
+#endif
+  while (*cp) {
+    /* skip leading and inner runs of spaces */
+    while (*cp == ' ' || *cp == '\t')
+      cp++;
+    /* search for and process individual options */
+    if (!strncmp(cp, "ndots:", sizeof("ndots:") - 1)) {
+      i = atoi(cp + sizeof("ndots:") - 1);
+      if (i <= RES_MAXNDOTS)
+        statp->ndots = i;
+      else
+        statp->ndots = RES_MAXNDOTS;
+#ifdef DEBUG
+      if (statp->options & RES_DEBUG)
+        printf(";;\tndots=%d\n", statp->ndots);
+#endif
+    } else if (!strncmp(cp, "timeout:", sizeof("timeout:") - 1)) {
+      i = atoi(cp + sizeof("timeout:") - 1);
+      if (i <= RES_MAXRETRANS)
+        statp->retrans = i;
+      else
+        statp->retrans = RES_MAXRETRANS;
+#ifdef DEBUG
+      if (statp->options & RES_DEBUG)
+        printf(";;\ttimeout=%d\n", statp->retrans);
+#endif
+#ifdef	SOLARIS2
+    } else if (!strncmp(cp, "retrans:", sizeof("retrans:") - 1)) {
+      /*
+       * For backward compatibility, 'retrans' is
+       * supported as an alias for 'timeout', though
+       * without an imposed maximum.
+       */
+      statp->retrans = atoi(cp + sizeof("retrans:") - 1);
+    } else if (!strncmp(cp, "retry:", sizeof("retry:") - 1)){
+      /*
+       * For backward compatibility, 'retry' is
+       * supported as an alias for 'attempts', though
+       * without an imposed maximum.
+       */
+      statp->retry = atoi(cp + sizeof("retry:") - 1);
+#endif	/* SOLARIS2 */
+    } else if (!strncmp(cp, "attempts:", sizeof("attempts:") - 1)){
+      i = atoi(cp + sizeof("attempts:") - 1);
+      if (i <= RES_MAXRETRY)
+        statp->retry = i;
+      else
+        statp->retry = RES_MAXRETRY;
+#ifdef DEBUG
+      if (statp->options & RES_DEBUG)
+        printf(";;\tattempts=%d\n", statp->retry);
+#endif
+    } else if (!strncmp(cp, "debug", sizeof("debug") - 1)) {
+#ifdef DEBUG
+      if (!(statp->options & RES_DEBUG)) {
+        printf(";; res_setoptions(\"%s\", \"%s\")..\n",
+               options, source);
+        statp->options |= RES_DEBUG;
+      }
+      printf(";;\tdebug\n");
+#endif
+    } else if (!strncmp(cp, "no_tld_query",
+                        sizeof("no_tld_query") - 1) ||
+               !strncmp(cp, "no-tld-query",
+                        sizeof("no-tld-query") - 1)) {
+      statp->options |= RES_NOTLDQUERY;
+    } else if (!strncmp(cp, "inet6", sizeof("inet6") - 1)) {
+      statp->options |= RES_USE_INET6;
+    } else if (!strncmp(cp, "rotate", sizeof("rotate") - 1)) {
+      statp->options |= RES_ROTATE;
+    } else if (!strncmp(cp, "no-check-names",
+                        sizeof("no-check-names") - 1)) {
+      statp->options |= RES_NOCHECKNAME;
+    }
+#ifdef RES_USE_EDNS0
+    else if (!strncmp(cp, "edns0", sizeof("edns0") - 1)) {
+      statp->options |= RES_USE_EDNS0;
+    }
+#endif
+    else if (!strncmp(cp, "dname", sizeof("dname") - 1)) {
+      statp->options |= RES_USE_DNAME;
+    }
+    else if (!strncmp(cp, "nibble:", sizeof("nibble:") - 1)) {
+      if (ext == NULL)
+        goto skip;
+      cp += sizeof("nibble:") - 1;
+      i = MIN(strcspn(cp, " \t"), sizeof(ext->nsuffix) - 1);
+      strncpy(ext->nsuffix, cp, i);
+      ext->nsuffix[i] = '\0';
+    }
+    else if (!strncmp(cp, "nibble2:", sizeof("nibble2:") - 1)) {
+      if (ext == NULL)
+        goto skip;
+      cp += sizeof("nibble2:") - 1;
+      i = MIN(strcspn(cp, " \t"), sizeof(ext->nsuffix2) - 1);
+      strncpy(ext->nsuffix2, cp, i);
+      ext->nsuffix2[i] = '\0';
+    }
+    else if (!strncmp(cp, "v6revmode:", sizeof("v6revmode:") - 1)) {
+      cp += sizeof("v6revmode:") - 1;
+      /* "nibble" and "bitstring" used to be valid */
+      if (!strncmp(cp, "single", sizeof("single") - 1)) {
+        statp->options |= RES_NO_NIBBLE2;
+      } else if (!strncmp(cp, "both", sizeof("both") - 1)) {
+        statp->options &=
+          ~RES_NO_NIBBLE2;
+      }
+    }
+    else {
+      /* XXX - print a warning here? */
+    }
+  skip:
+    /* skip to next run of spaces */
+    while (*cp && *cp != ' ' && *cp != '\t')
+      cp++;
+  }
+}
+
+#ifdef RESOLVSORT
+/* XXX - should really support CIDR which means explicit masks always. */
+static u_int32_t
+ink_net_mask(in)		/*!< XXX - should really use system's version of this  */
+  struct in_addr in;
+{
+  register u_int32_t i = ntohl(in.s_addr);
+
+  if (IN_CLASSA(i))
+    return (htonl(IN_CLASSA_NET));
+  else if (IN_CLASSB(i))
+    return (htonl(IN_CLASSB_NET));
+  return (htonl(IN_CLASSC_NET));
+}
+#endif
+
+static u_int
+ink_res_randomid(void) {
+  struct timeval now;
+
+  gettimeofday(&now, NULL);
+  return (0xffff & (now.tv_sec ^ now.tv_usec ^ getpid()));
+}
+
+const char *
+ink_res_get_nibblesuffix(ink_res_state statp) {
+  if (statp->_u._ext.ext)
+    return (statp->_u._ext.ext->nsuffix);
+  return ("ip6.arpa");
+}
+
+const char *
+ink_res_get_nibblesuffix2(ink_res_state statp) {
+  if (statp->_u._ext.ext)
+    return (statp->_u._ext.ext->nsuffix2);
+  return ("ip6.int");
+}
+
+/*%
  * Set up default settings.  If the configuration file exist, the values
  * there will have precedence.  Otherwise, the server address is set to
  * INADDR_ANY and the default domain name comes from the gethostname().
@@ -138,7 +434,7 @@
  * since it was noted that INADDR_ANY actually meant ``the first interface
  * you "ifconfig"'d at boot time'' and if this was a SLIP or PPP interface,
  * it had to be "up" in order for you to reach your own name server.  It
- * was later decided that since the recommended practice is to always
+ * was later decided that since the recommended practice is to always 
  * install local static routes through 127.0.0.1 for all your network
  * interfaces, that we could solve this problem without a code change.
  *
@@ -149,71 +445,121 @@
  *
  * Return 0 if completes successfully, -1 on error
  */
+/*% This function has to be reachable by res_data.c but not publically. */
 int
-ink_res_init(struct __res_state &p_res, unsigned long *pHostList, int *pPort, char *pDefDomain, char *pSearchList)
-{
+ink_res_init(ink_res_state statp, unsigned long *pHostList, int *pPort, char *pDefDomain, char *pSearchList) {
   register FILE *fp;
   register char *cp, **pp;
   register int n;
-  char buf[MAXDNAME];
-  int nserv = 0;                /* number of nameserver records read from file */
+  char buf[BUFSIZ];
+  int nserv = 0;    /*%< number of nameserver records read from file */
   int haveenv = 0;
   int havesearch = 0;
 #ifdef RESOLVSORT
   int nsort = 0;
   char *net;
 #endif
-#ifndef RFC1535
   int dots;
-#endif
-
-  /*
-   * These three fields used to be statically initialized.  This made
-   * it hard to use this code in a shared library.  It is necessary,
-   * now that we're doing dynamic initialization here, that we preserve
-   * the old semantics: if an application modifies one of these three
-   * fields of p_res before res_init() is called, res_init() will not
-   * alter them.  Of course, if an application is setting them to
-   * _zero_ before calling res_init(), hoping to override what used
-   * to be the static default, we can't detect it and unexpected results
-   * will follow.  Zero for any of these fields would make no sense,
-   * so one can safely assume that the applications were already getting
-   * unexpected results.
-   *
-   * p_res.options is tricky since some apps were known to diddle the bits
-   * before res_init() was first called. We can't replicate that semantic
-   * with dynamic initialization (they may have turned bits off that are
-   * set in RES_DEFAULT).  Our solution is to declare such applications
-   * "broken".  They could fool us by setting RES_INIT but none do (yet).
-   */
-  if (!p_res.retrans)
-    p_res.retrans = RES_TIMEOUT;
-  if (!p_res.retry)
-    p_res.retry = 4;
-  if (!(p_res.options & RES_INIT))
-    p_res.options = RES_DEFAULT;
+  union ink_res_sockaddr_union u[2];
+  int maxns = MAXNS;
 
-  /*
-   * This one used to initialize implicitly to zero, so unless the app
-   * has set it to something in particular, we can randomize it now.
-   */
-  if (!p_res.id)
-    p_res.id = res_randomid();
+  // RES_SET_H_ERRNO(statp, 0);
+  statp->res_h_errno = 0;
+  if (statp->_u._ext.ext != NULL)
+    ink_res_ndestroy(statp);
+
+  statp->retrans = RES_TIMEOUT;
+  statp->retry = RES_DFLRETRY;
+  statp->options = RES_DEFAULT;
+  statp->id = ink_res_randomid();
 
+  memset(u, 0, sizeof(u));
+#ifdef USELOOPBACK
+  u[nserv].sin.sin_addr = inet_makeaddr(IN_LOOPBACKNET, 1);
+#else
+  u[nserv].sin.sin_addr.s_addr = INADDR_ANY;
+#endif
+  u[nserv].sin.sin_family = AF_INET;
+  u[nserv].sin.sin_port = htons(NAMESERVER_PORT);
+#ifdef HAVE_SA_LEN
+  u[nserv].sin.sin_len = sizeof(struct sockaddr_in);
+#endif
+  nserv++;
+#ifdef HAS_INET6_STRUCTS
 #ifdef USELOOPBACK
-  p_res.nsaddr.sin_addr = inet_makeaddr(IN_LOOPBACKNET, 1);
+  u[nserv].sin6.sin6_addr = in6addr_loopback;
 #else
-  p_res.nsaddr.sin_addr.s_addr = INADDR_ANY;
+  u[nserv].sin6.sin6_addr = in6addr_any;
+#endif
+  u[nserv].sin6.sin6_family = AF_INET6;
+  u[nserv].sin6.sin6_port = htons(NAMESERVER_PORT);
+#ifdef HAVE_SA_LEN
+  u[nserv].sin6.sin6_len = sizeof(struct sockaddr_in6);
+#endif
+  nserv++;
+#endif
+  statp->nscount = 0;
+  statp->ndots = 1;
+  statp->pfcode = 0;
+  statp->_vcsock = -1;
+  statp->_flags = 0;
+  statp->qhook = NULL;
+  statp->rhook = NULL;
+  statp->_u._ext.nscount = 0;
+  statp->_u._ext.ext = (struct __ink_res_state_ext*)malloc(sizeof(*statp->_u._ext.ext));
+  if (statp->_u._ext.ext != NULL) {
+    memset(statp->_u._ext.ext, 0, sizeof(*statp->_u._ext.ext));
+    statp->_u._ext.ext->nsaddrs[0].sin = statp->nsaddr;
+    strcpy(statp->_u._ext.ext->nsuffix, "ip6.arpa");
+    strcpy(statp->_u._ext.ext->nsuffix2, "ip6.int");
+  } else {
+    /*
+     * Historically res_init() rarely, if at all, failed.
+     * Examples and applications exist which do not check
+     * our return code.  Furthermore several applications
+     * simply call us to get the systems domainname.  So
+     * rather then immediately fail here we store the
+     * failure, which is returned later, in h_errno.  And
+     * prevent the collection of 'nameserver' information
+     * by setting maxns to 0.  Thus applications that fail
+     * to check our return code wont be able to make
+     * queries anyhow.
+     */
+    // RES_SET_H_ERRNO(statp, NETDB_INTERNAL);
+    statp->res_h_errno = NETDB_INTERNAL;
+    maxns = 0;
+  }
+#ifdef RESOLVSORT
+  statp->nsort = 0;
 #endif
-  p_res.nsaddr.sin_family = AF_INET;
-  p_res.nsaddr.sin_port = htons(NAMESERVER_PORT);
-  p_res.nscount = 1;
-  p_res.ndots = 1;
-  p_res.pfcode = 0;
+  ink_res_setservers(statp, u, nserv);
+
+#ifdef	SOLARIS2
+  /*
+   * The old libresolv derived the defaultdomain from NIS/NIS+.
+   * We want to keep this behaviour
+   */
+  {
+    char buf[sizeof(statp->defdname)], *cp;
+    int ret;
 
-  /* Allow user to override the local domain definition */
+    if ((ret = sysinfo(SI_SRPC_DOMAIN, buf, sizeof(buf))) > 0 &&
+        (unsigned int)ret <= sizeof(buf)) {
+      if (buf[0] == '+')
+        buf[0] = '.';
+      cp = strchr(buf, '.');
+      cp = (cp == NULL) ? buf : (cp + 1);
+      strncpy(statp->defdname, cp,
+              sizeof(statp->defdname) - 1);
+      statp->defdname[sizeof(statp->defdname) - 1] = '\0';
+    }
+  }
+#endif	/* SOLARIS2 */
+
+	/* Allow user to override the local domain definition */
   if ((cp = getenv("LOCALDOMAIN")) != NULL) {
-    (void) strncpy(p_res.defdname, cp, sizeof(p_res.defdname) - 1);
+    (void)strncpy(statp->defdname, cp, sizeof(statp->defdname) - 1);
+    statp->defdname[sizeof(statp->defdname) - 1] = '\0';
     haveenv++;
 
     /*
@@ -223,11 +569,11 @@
      * one that they want to use as an individual (even more
      * important now that the rfc1535 stuff restricts searches)
      */
-    cp = p_res.defdname;
-    pp = p_res.dnsrch;
+    cp = statp->defdname;
+    pp = statp->dnsrch;
     *pp++ = cp;
-    for (n = 0; *cp && pp < p_res.dnsrch + MAXDNSRCH; cp++) {
-      if (*cp == '\n')          /* silly backwards compat */
+    for (n = 0; *cp && pp < statp->dnsrch + MAXDNSRCH; cp++) {
+      if (*cp == '\n')	/*%< silly backwards compat */
         break;
       else if (*cp == ' ' || *cp == '\t') {
         *cp = 0;
@@ -244,8 +590,7 @@
     *cp = '\0';
     *pp++ = 0;
   }
-
-
+        
   /* ---------------------------------------------
      Default domain name and doamin Search list:
 
@@ -259,8 +604,8 @@
   if (pDefDomain && '\0' != *pDefDomain && '\n' != *pDefDomain) {
 
     cp = pDefDomain;
-    strncpy(p_res.defdname, cp, sizeof(p_res.defdname) - 1);
-    if ((cp = strpbrk(p_res.defdname, " \t\n")) != NULL)
+    strncpy(statp->defdname, cp, sizeof(statp->defdname) - 1);
+    if ((cp = strpbrk(statp->defdname, " \t\n")) != NULL)
       *cp = '\0';
 
     havedef_domain = 1;
@@ -269,17 +614,17 @@
   if (pSearchList && '\0' != *pSearchList && '\n' != *pSearchList) {
 
     cp = pSearchList;
-    strncpy(p_res.defdname, cp, sizeof(p_res.defdname) - 1);
-    if ((cp = strchr(p_res.defdname, '\n')) != NULL)
+    strncpy(statp->defdname, cp, sizeof(statp->defdname) - 1);
+    if ((cp = strchr(statp->defdname, '\n')) != NULL)
       *cp = '\0';
     /*
      * Set search list to be blank-separated strings
      * on rest of line.
      */
-    cp = p_res.defdname;
-    pp = p_res.dnsrch;
+    cp = statp->defdname;
+    pp = statp->dnsrch;
     *pp++ = cp;
-    for (n = 0; *cp && pp < p_res.dnsrch + MAXDNSRCH; cp++) {
+    for (n = 0; *cp && pp < statp->dnsrch + MAXDNSRCH; cp++) {
       if (*cp == ' ' || *cp == '\t') {
         *cp = 0;
         n = 1;
@@ -301,76 +646,62 @@
      we must be provided with atleast a named!
      ------------------------------------------- */
 
-  while (pHostList[nserv] != 0 && nserv < MAXNS) {
-
-    p_res.nsaddr_list[nserv].sin_addr.s_addr = pHostList[nserv];
-    p_res.nsaddr_list[nserv].sin_family = AF_INET;
-    p_res.nsaddr_list[nserv].sin_port = htons(pPort[nserv]);
+  while (pHostList && pHostList[nserv] != 0 && nserv < MAXNS) {
+    statp->nsaddr_list[nserv].sin_addr.s_addr = pHostList[nserv];
+    statp->nsaddr_list[nserv].sin_family = AF_INET;
+    statp->nsaddr_list[nserv].sin_port = htons(pPort[nserv]);
     nserv++;
   }
 
-  if (nserv > 1)
-    p_res.nscount = nserv;
-
-
-  if (0 == nserv)
-    return -1;
-
-#define	MATCH(line, name) \
-	(!strncmp(line, name, sizeof(name) - 1) && \
-	(line[sizeof(name) - 1] == ' ' || \
-	 line[sizeof(name) - 1] == '\t'))
+#define	MATCH(line, name)                       \
+  (!strncmp(line, name, sizeof(name) - 1) &&    \
+   (line[sizeof(name) - 1] == ' ' ||            \
+    line[sizeof(name) - 1] == '\t'))
 
+  nserv = 0;
   if ((fp = fopen(_PATH_RESCONF, "r")) != NULL) {
     /* read the config file */
     while (fgets(buf, sizeof(buf), fp) != NULL) {
       /* skip comments */
       if (*buf == ';' || *buf == '#')
         continue;
-
       /* read default domain name */
       if (MATCH(buf, "domain")) {
-
-        if (havedef_domain || haveenv)
+        if (haveenv)	/*%< skip if have from environ */
           continue;
-
         cp = buf + sizeof("domain") - 1;
-
         while (*cp == ' ' || *cp == '\t')
           cp++;
         if ((*cp == '\0') || (*cp == '\n'))
           continue;
-        strncpy(p_res.defdname, cp, sizeof(p_res.defdname) - 1);
-        if ((cp = strpbrk(p_res.defdname, " \t\n")) != NULL)
+        strncpy(statp->defdname, cp, sizeof(statp->defdname) - 1);
+        statp->defdname[sizeof(statp->defdname) - 1] = '\0';
+        if ((cp = strpbrk(statp->defdname, " \t\n")) != NULL)
           *cp = '\0';
         havesearch = 0;
         continue;
       }
-
-
       /* set search list */
       if (MATCH(buf, "search")) {
-
-        if (havedomain_srchlst || haveenv)      /* skip if have from environ */
+        if (haveenv)	/*%< skip if have from environ */
           continue;
-
         cp = buf + sizeof("search") - 1;
-
         while (*cp == ' ' || *cp == '\t')
           cp++;
         if ((*cp == '\0') || (*cp == '\n'))
           continue;
-        strncpy(p_res.defdname, cp, sizeof(p_res.defdname) - 1);
-        if ((cp = strchr(p_res.defdname, '\n')) != NULL)
+        strncpy(statp->defdname, cp, sizeof(statp->defdname) - 1);
+        statp->defdname[sizeof(statp->defdname) - 1] = '\0';
+        if ((cp = strchr(statp->defdname, '\n')) != NULL)
           *cp = '\0';
         /*
          * Set search list to be blank-separated strings
          * on rest of line.
          */
-        cp = p_res.defdname;
-        pp = p_res.dnsrch;
+        cp = statp->defdname;
+        pp = statp->dnsrch;
         *pp++ = cp;
-        for (n = 0; *cp && pp < p_res.dnsrch + MAXDNSRCH; cp++) {
+        for (n = 0; *cp && pp < statp->dnsrch + MAXDNSRCH; cp++) {
           if (*cp == ' ' || *cp == '\t') {
             *cp = 0;
             n = 1;
@@ -387,686 +718,144 @@
         havesearch = 1;
         continue;
       }
-
-      /* we suppy the name servers! */
       /* read nameservers to query */
-      if (MATCH(buf, "nameserver")) {
-#if 0
-        if (MATCH(buf, "nameserver") && nserv < MAXNS) {
-          struct in_addr a;
-          cp = buf + sizeof("nameserver") - 1;
-          while (*cp == ' ' || *cp == '\t')
-            cp++;
-          if ((*cp != '\0') && (*cp != '\n') && inet_aton(cp, &a)) {
-            p_res.nsaddr_list[nserv].sin_addr = a;
-            p_res.nsaddr_list[nserv].sin_family = AF_INET;
-            p_res.nsaddr_list[nserv].sin_port = htons(NAMESERVER_PORT);
-            nserv++;
-          }
-#endif
-          continue;
-        }
-
-#ifdef RESOLVSORT
-        if (MATCH(buf, "sortlist")) {
-          struct in_addr a;
+      if (MATCH(buf, "nameserver") && nserv < maxns) {
+        struct addrinfo hints, *ai;
+        char sbuf[NI_MAXSERV];
+        const size_t minsiz =
+          sizeof(statp->_u._ext.ext->nsaddrs[0]);
 
-          cp = buf + sizeof("sortlist") - 1;
-          while (nsort < MAXRESOLVSORT) {
-            while (*cp == ' ' || *cp == '\t')
-              cp++;
-            if (*cp == '\0' || *cp == '\n' || *cp == ';')
-              break;
-            net = cp;
-            while (*cp && !ISSORTMASK(*cp) && *cp != ';' && isascii(*cp) && !isspace(*cp))
-              cp++;
-            n = *cp;
-            *cp = 0;
-            if (inet_aton(net, &a)) {
-              p_res.sort_list[nsort].addr = a;
-              if (ISSORTMASK(n)) {
-                *cp++ = n;
-                net = cp;
-                while (*cp && *cp != ';' && isascii(*cp) && !isspace(*cp))
-                  cp++;
-                n = *cp;
-                *cp = 0;
-                if (inet_aton(net, &a)) {
-                  p_res.sort_list[nsort].mask = a.s_addr;
-                } else {
-                  p_res.sort_list[nsort].mask = net_mask(p_res.sort_list[nsort].addr);
-                }
-              } else {
-                p_res.sort_list[nsort].mask = net_mask(p_res.sort_list[nsort].addr);
-              }
-              nsort++;
+        cp = buf + sizeof("nameserver") - 1;
+        while (*cp == ' ' || *cp == '\t')
+          cp++;
+        cp[strcspn(cp, ";# \t\n")] = '\0';
+        if ((*cp != '\0') && (*cp != '\n')) {
+          memset(&hints, 0, sizeof(hints));
+          hints.ai_family = PF_UNSPEC;
+          hints.ai_socktype = SOCK_DGRAM;	/*dummy*/
+          hints.ai_flags = AI_NUMERICHOST;
+          sprintf(sbuf, "%u", NAMESERVER_PORT);
+          if (getaddrinfo(cp, sbuf, &hints, &ai) == 0 &&
+              ai->ai_addrlen <= minsiz) {
+            if (statp->_u._ext.ext != NULL) {
+              memcpy(&statp->_u._ext.ext->nsaddrs[nserv],
+                     ai->ai_addr, ai->ai_addrlen);
             }
-            *cp = n;
+            if (ai->ai_addrlen <=
+                sizeof(statp->nsaddr_list[nserv])) {
+              memcpy(&statp->nsaddr_list[nserv],
+                     ai->ai_addr, ai->ai_addrlen);
+            } else
+              statp->nsaddr_list[nserv].sin_family = 0;
+            freeaddrinfo(ai);
+            nserv++;
           }
-          continue;
-        }
-#endif
-        if (MATCH(buf, "options")) {
-          res_setoptions(p_res, buf + sizeof("options") - 1, "conf");
-          continue;
         }
+        continue;
       }
-      if (nserv > 1)
-        p_res.nscount = nserv;
-#ifdef RESOLVSORT
-      p_res.nsort = nsort;
-#endif
-      (void) fclose(fp);
-    }
-
-
-    /* -----------------------------
-       ----------------------------- */
-
-
-    if (p_res.defdname[0] == 0 && gethostname(buf, sizeof(p_res.defdname) - 1) == 0 && (cp = strchr(buf, '.')) != NULL)
-      ink_strncpy(p_res.defdname, cp + 1, sizeof(p_res.defdname));
-
-    /* find components of local domain that might be searched */
-    if (havesearch == 0) {
-      pp = p_res.dnsrch;
-      *pp++ = p_res.defdname;
-      *pp = NULL;
-
-#ifndef RFC1535
-      dots = 0;
-      for (cp = p_res.defdname; *cp; cp++)
-        dots += (*cp == '.');
-
-      cp = p_res.defdname;
-      while (pp < p_res.dnsrch + MAXDFLSRCH) {
-        if (dots < LOCALDOMAINPARTS)
-          break;
-        cp = strchr(cp, '.') + 1;       /* we know there is one */
-        *pp++ = cp;
-        dots--;
-      }
-      *pp = NULL;
-#ifdef DEBUG
-      if (p_res.options & RES_DEBUG) {
-        printf(";; res_init()... default dnsrch list:\n");
-        for (pp = p_res.dnsrch; *pp; pp++)
-          printf(";;\t%s\n", *pp);
-        printf(";;\t..END..\n");
-      }
-#endif /* DEBUG */
-#endif /* !RFC1535 */
-    }
-
-    if ((cp = getenv("RES_OPTIONS")) != NULL)
-      res_setoptions(p_res, cp, "env");
-    p_res.options |= RES_INIT;
-    return (0);
-  }
-
-  static void res_setoptions(struct __res_state &p_res, char *options, char *source)
-  {
-    char *cp = options;
-    int i;
-
-#ifdef DEBUG
-    if (p_res.options & RES_DEBUG)
-      printf(";; res_setoptions(\"%s\", \"%s\")...\n", options, source);
-#endif
-    while (*cp) {
-      /* skip leading and inner runs of spaces */
-      while (*cp == ' ' || *cp == '\t')
-        cp++;
-      /* search for and process individual options */
-      if (!strncmp(cp, "ndots:", sizeof("ndots:") - 1)) {
-        i = atoi(cp + sizeof("ndots:") - 1);
-        if (i <= RES_MAXNDOTS)
-          p_res.ndots = i;
-        else
-          p_res.ndots = RES_MAXNDOTS;
-#ifdef DEBUG
-        if (p_res.options & RES_DEBUG)
-          printf(";;\tndots=%d\n", p_res.ndots);
-#endif
-      } else if (!strncmp(cp, "debug", sizeof("debug") - 1)) {
-#ifdef DEBUG
-        if (!(p_res.options & RES_DEBUG)) {
-          printf(";; res_setoptions(\"%s\", \"%s\")..\n", options, source);
-          p_res.options |= RES_DEBUG;
-        }
-        printf(";;\tdebug\n");
-#endif
-      }
-
-      else if (!strncmp(cp, "inet6", sizeof("inet6") - 1)) {
-        p_res.options |= RES_USE_INET6;
-      }
-
-      else {
-        /* XXX - print a warning here? */
-      }
-      /* skip to next run of spaces */
-      while (*cp && *cp != ' ' && *cp != '\t')
-        cp++;
-    }
-  }
-
-  int ink_res_init_rr(struct __res_state_rr &p_res, unsigned long *pHostList,
-                      int *pPort, char *pDefDomain, char *pSearchList)
-  {
-    register FILE *fp;
-    register char *cp, **pp;
-    register int n;
-    char buf[MAXDNAME];
-    int nserv = 0;              /* number of nameserver records read from file */
-    int haveenv = 0;
-    int havesearch = 0;
 #ifdef RESOLVSORT
-    int nsort = 0;
-    char *net;
-#endif
-#ifndef RFC1535
-    int dots;
-#endif
-
-    /*
-     * These three fields used to be statically initialized.  This made
-     * it hard to use this code in a shared library.  It is necessary,
-     * now that we're doing dynamic initialization here, that we preserve
-     * the old semantics: if an application modifies one of these three
-     * fields of p_res before res_init() is called, res_init() will not
-     * alter them.  Of course, if an application is setting them to
-     * _zero_ before calling res_init(), hoping to override what used
-     * to be the static default, we can't detect it and unexpected results
-     * will follow.  Zero for any of these fields would make no sense,
-     * so one can safely assume that the applications were already getting
-     * unexpected results.
-     *
-     * p_res.options is tricky since some apps were known to diddle the bits
-     * before res_init() was first called. We can't replicate that semantic
-     * with dynamic initialization (they may have turned bits off that are
-     * set in RES_DEFAULT).  Our solution is to declare such applications
-     * "broken".  They could fool us by setting RES_INIT but none do (yet).
-     */
-    if (!p_res.retrans)
-      p_res.retrans = RES_TIMEOUT;
-    if (!p_res.retry)
-      p_res.retry = 4;
-    if (!(p_res.options & RES_INIT))
-      p_res.options = RES_DEFAULT;
-
-    /*
-     * This one used to initialize implicitly to zero, so unless the app
-     * has set it to something in particular, we can randomize it now.
-     */
-    if (!p_res.id)
-      p_res.id = res_randomid();
-
-#ifdef USELOOPBACK
-    p_res.nsaddr.sin_addr = inet_makeaddr(IN_LOOPBACKNET, 1);
-#else
-    p_res.nsaddr.sin_addr.s_addr = INADDR_ANY;
-#endif
-    p_res.nsaddr.sin_family = AF_INET;
-    p_res.nsaddr.sin_port = htons(NAMESERVER_PORT);
-    p_res.nscount = 1;
-    p_res.ndots = 1;
-    p_res.pfcode = 0;
-
-    /* Allow user to override the local domain definition */
-    if ((cp = getenv("LOCALDOMAIN")) != NULL) {
-      (void) strncpy(p_res.defdname, cp, sizeof(p_res.defdname) - 1);
-      haveenv++;
-
-      /*
-       * Set search list to be blank-separated strings
-       * from rest of env value.  Permits users of LOCALDOMAIN
-       * to still have a search list, and anyone to set the
-       * one that they want to use as an individual (even more
-       * important now that the rfc1535 stuff restricts searches)
-       */
-      cp = p_res.defdname;
-      pp = p_res.dnsrch;
-      *pp++ = cp;
-      for (n = 0; *cp && pp < p_res.dnsrch + MAXDNSRCH; cp++) {
-        if (*cp == '\n')        /* silly backwards compat */
-          break;
-        else if (*cp == ' ' || *cp == '\t') {
-          *cp = 0;
-          n = 1;
-        } else if (n) {
-          *pp++ = cp;
-          n = 0;
-          havesearch = 1;
-        }
-      }
-      /* null terminate last domain if there are excess */
-      while (*cp != '\0' && *cp != ' ' && *cp != '\t' && *cp != '\n')
-        cp++;
-      *cp = '\0';
-      *pp++ = 0;
-    }
-
-
-    /* ---------------------------------------------
-       Default domain name and doamin Search list:
-
-       if we are supplied a default domain name,
-       and/or search list we will use it. Otherwise,
-       we will skip to using  what is present in the
-       conf file
-       ---------------------------------------------- */
-
-    int havedef_domain = 0, havedomain_srchlst = 0;
-    if (pDefDomain && '\0' != *pDefDomain && '\n' != *pDefDomain) {
-
-      cp = pDefDomain;
-      strncpy(p_res.defdname, cp, sizeof(p_res.defdname) - 1);
-      if ((cp = strpbrk(p_res.defdname, " \t\n")) != NULL)
-        *cp = '\0';
-
-      havedef_domain = 1;
-
-    }
-    if (pSearchList && '\0' != *pSearchList && '\n' != *pSearchList) {
-
-      cp = pSearchList;
-      strncpy(p_res.defdname, cp, sizeof(p_res.defdname) - 1);
-      if ((cp = strchr(p_res.defdname, '\n')) != NULL)
-        *cp = '\0';
-      /*
-       * Set search list to be blank-separated strings
-       * on rest of line.
-       */
-      cp = p_res.defdname;
-      pp = p_res.dnsrch;
-      *pp++ = cp;
-      for (n = 0; *cp && pp < p_res.dnsrch + MAXDNSRCH; cp++) {
-        if (*cp == ' ' || *cp == '\t') {
-          *cp = 0;
-          n = 1;
-        } else if (n) {
-          *pp++ = cp;
-          n = 0;
-        }
-      }
-      /* null terminate last domain if there are excess */
-      while (*cp != '\0' && *cp != ' ' && *cp != '\t')
-        cp++;
-      *cp = '\0';
-      *pp++ = 0;
-      havesearch = 1;
-      havedomain_srchlst = 1;
-    }
-
-    /* -------------------------------------------
-       we must be provided with atleast a named!
-       ------------------------------------------- */
-
-    while (pHostList[nserv] != 0 && nserv < MAXNSRR) {
-
-      p_res.nsaddr_list[nserv].sin_addr.s_addr = pHostList[nserv];
-      p_res.nsaddr_list[nserv].sin_family = AF_INET;
-      p_res.nsaddr_list[nserv].sin_port = htons(pPort[nserv]);
-      nserv++;
-    }
-
-    if (nserv > 1)
-      p_res.nscount = nserv;
-
-
-    if (0 == nserv)
-      return -1;
-
-#define	MATCH(line, name) \
-	(!strncmp(line, name, sizeof(name) - 1) && \
-	(line[sizeof(name) - 1] == ' ' || \
-	 line[sizeof(name) - 1] == '\t'))
-
-    if ((fp = fopen(_PATH_RESCONF, "r")) != NULL) {
-      /* read the config file */
-      while (fgets(buf, sizeof(buf), fp) != NULL) {
-        /* skip comments */
-        if (*buf == ';' || *buf == '#')
-          continue;
-
-        /* read default domain name */
-        if (MATCH(buf, "domain")) {
-
-          if (havedef_domain || haveenv)
-            continue;
-
-          cp = buf + sizeof("domain") - 1;
+      if (MATCH(buf, "sortlist")) {
+        struct in_addr a;
 
+        cp = buf + sizeof("sortlist") - 1;
+        while (nsort < MAXRESOLVSORT) {
           while (*cp == ' ' || *cp == '\t')
             cp++;
-          if ((*cp == '\0') || (*cp == '\n'))
-            continue;
-          strncpy(p_res.defdname, cp, sizeof(p_res.defdname) - 1);
-          if ((cp = strpbrk(p_res.defdname, " \t\n")) != NULL)
-            *cp = '\0';
-          havesearch = 0;
-          continue;
-        }
-
-
-        /* set search list */
-        if (MATCH(buf, "search")) {
-
-          if (havedomain_srchlst || haveenv)    /* skip if have from environ */
-            continue;
-
-          cp = buf + sizeof("search") - 1;
-
-          while (*cp == ' ' || *cp == '\t')
-            cp++;
-          if ((*cp == '\0') || (*cp == '\n'))
-            continue;
-          strncpy(p_res.defdname, cp, sizeof(p_res.defdname) - 1);
-          if ((cp = strchr(p_res.defdname, '\n')) != NULL)
-            *cp = '\0';
-          /*
-           * Set search list to be blank-separated strings
-           * on rest of line.
-           */
-          cp = p_res.defdname;
-          pp = p_res.dnsrch;
-          *pp++ = cp;
-          for (n = 0; *cp && pp < p_res.dnsrch + MAXDNSRCH; cp++) {
-            if (*cp == ' ' || *cp == '\t') {
-              *cp = 0;
-              n = 1;
-            } else if (n) {
-              *pp++ = cp;
-              n = 0;
-            }
-          }
-          /* null terminate last domain if there are excess */
-          while (*cp != '\0' && *cp != ' ' && *cp != '\t')
+          if (*cp == '\0' || *cp == '\n' || *cp == ';')
+            break;
+          net = cp;
+          while (*cp && !ISSORTMASK(*cp) && *cp != ';' &&
+                 isascii(*cp) && !isspace((unsigned char)*cp))
             cp++;
-          *cp = '\0';
-          *pp++ = 0;
-          havesearch = 1;
-          continue;
-        }
-
-        /* we suppy the name servers! */
-        /* read nameservers to query */
-        if (MATCH(buf, "nameserver")) {
-#if 0
-          if (MATCH(buf, "nameserver") && nserv < MAXNS) {
-            struct in_addr a;
-            cp = buf + sizeof("nameserver") - 1;
-            while (*cp == ' ' || *cp == '\t')
-              cp++;
-            if ((*cp != '\0') && (*cp != '\n') && inet_aton(cp, &a)) {
-              p_res.nsaddr_list[nserv].sin_addr = a;
-              p_res.nsaddr_list[nserv].sin_family = AF_INET;
-              p_res.nsaddr_list[nserv].sin_port = htons(NAMESERVER_PORT);
-              nserv++;
-            }
-#endif
-            continue;
-          }
-
-#ifdef RESOLVSORT
-          if (MATCH(buf, "sortlist")) {
-            struct in_addr a;
-
-            cp = buf + sizeof("sortlist") - 1;
-            while (nsort < MAXRESOLVSORT) {
-              while (*cp == ' ' || *cp == '\t')
-                cp++;
-              if (*cp == '\0' || *cp == '\n' || *cp == ';')
-                break;
+          n = *cp;
+          *cp = 0;
+          if (inet_aton(net, &a)) {
+            statp->sort_list[nsort].addr = a;
+            if (ISSORTMASK(n)) {
+              *cp++ = n;
               net = cp;
-              while (*cp && !ISSORTMASK(*cp) && *cp != ';' && isascii(*cp) && !isspace(*cp))
+              while (*cp && *cp != ';' &&
+                     isascii(*cp) &&
+                     !isspace((unsigned char)*cp))
                 cp++;
               n = *cp;
               *cp = 0;
               if (inet_aton(net, &a)) {
-                p_res.sort_list[nsort].addr = a;
-                if (ISSORTMASK(n)) {
-                  *cp++ = n;
-                  net = cp;
-                  while (*cp && *cp != ';' && isascii(*cp) && !isspace(*cp))
-                    cp++;
-                  n = *cp;
-                  *cp = 0;
-                  if (inet_aton(net, &a)) {
-                    p_res.sort_list[nsort].mask = a.s_addr;
-                  } else {
-                    p_res.sort_list[nsort].mask = net_mask(p_res.sort_list[nsort].addr);
-                  }
-                } else {
-                  p_res.sort_list[nsort].mask = net_mask(p_res.sort_list[nsort].addr);
-                }
-                nsort++;
+                statp->sort_list[nsort].mask = a.s_addr;
+              } else {
+                statp->sort_list[nsort].mask = 
+                  net_mask(statp->sort_list[nsort].addr);
               }
-              *cp = n;
+            } else {
+              statp->sort_list[nsort].mask = 
+                net_mask(statp->sort_list[nsort].addr);
             }
-            continue;
+            nsort++;
           }
-#endif
-          if (MATCH(buf, "options")) {
-            res_setoptions_rr(p_res, buf + sizeof("options") - 1, "conf");
-            continue;
-          }
-        }
-        if (nserv > 1)
-          p_res.nscount = nserv;
-#ifdef RESOLVSORT
-        p_res.nsort = nsort;
-#endif
-        (void) fclose(fp);
-      }
-
-
-      /* -----------------------------
-         ----------------------------- */
-
-
-      if (p_res.defdname[0] == 0 &&
-          gethostname(buf, sizeof(p_res.defdname) - 1) == 0 && (cp = strchr(buf, '.')) != NULL)
-        ink_strncpy(p_res.defdname, cp + 1, sizeof(p_res.defdname));
-
-      /* find components of local domain that might be searched */
-      if (havesearch == 0) {
-        pp = p_res.dnsrch;
-        *pp++ = p_res.defdname;
-        *pp = NULL;
-
-#ifndef RFC1535
-        dots = 0;
-        for (cp = p_res.defdname; *cp; cp++)
-          dots += (*cp == '.');
-
-        cp = p_res.defdname;
-        while (pp < p_res.dnsrch + MAXDFLSRCH) {
-          if (dots < LOCALDOMAINPARTS)
-            break;
-          cp = strchr(cp, '.') + 1;     /* we know there is one */
-          *pp++ = cp;
-          dots--;
+          *cp = n;
         }
-        *pp = NULL;
-#ifdef DEBUG
-        if (p_res.options & RES_DEBUG) {
-          printf(";; res_init()... default dnsrch list:\n");
-          for (pp = p_res.dnsrch; *pp; pp++)
-            printf(";;\t%s\n", *pp);
-          printf(";;\t..END..\n");
-        }
-#endif /* DEBUG */
-#endif /* !RFC1535 */
+        continue;
       }
-
-      if ((cp = getenv("RES_OPTIONS")) != NULL)
-        res_setoptions_rr(p_res, cp, "env");
-      p_res.options |= RES_INIT;
-      return (0);
-    }
-
-    static void res_setoptions_rr(struct __res_state_rr &p_res, char *options, char *source)
-    {
-      char *cp = options;
-      int i;
-
-#ifdef DEBUG
-      if (p_res.options & RES_DEBUG)
-        printf(";; res_setoptions(\"%s\", \"%s\")...\n", options, source);
 #endif
-      while (*cp) {
-        /* skip leading and inner runs of spaces */
-        while (*cp == ' ' || *cp == '\t')
-          cp++;
-        /* search for and process individual options */
-        if (!strncmp(cp, "ndots:", sizeof("ndots:") - 1)) {
-          i = atoi(cp + sizeof("ndots:") - 1);
-          if (i <= RES_MAXNDOTS)
-            p_res.ndots = i;
-          else
-            p_res.ndots = RES_MAXNDOTS;
-#ifdef DEBUG
-          if (p_res.options & RES_DEBUG)
-            printf(";;\tndots=%d\n", p_res.ndots);
-#endif
-        } else if (!strncmp(cp, "debug", sizeof("debug") - 1)) {
-#ifdef DEBUG
-          if (!(p_res.options & RES_DEBUG)) {
-            printf(";; res_setoptions(\"%s\", \"%s\")..\n", options, source);
-            p_res.options |= RES_DEBUG;
-          }
-          printf(";;\tdebug\n");
-#endif
-        }
-
-        else if (!strncmp(cp, "inet6", sizeof("inet6") - 1)) {
-          p_res.options |= RES_USE_INET6;
-        }
-
-        else {
-          /* XXX - print a warning here? */
-        }
-        /* skip to next run of spaces */
-        while (*cp && *cp != ' ' && *cp != '\t')
-          cp++;
+      if (MATCH(buf, "options")) {
+        ink_res_setoptions(statp, buf + sizeof("options") - 1, "conf");
+        continue;
       }
     }
-
+    if (nserv > 0) 
+      statp->nscount = nserv;
 #ifdef RESOLVSORT
-/* XXX - should really support CIDR which means explicit masks always. */
-    static u_int32_t net_mask(in)       /* XXX - should really use system's version of this */
-    struct in_addr in;
-    {
-      register u_int32_t i = ntohl(in.s_addr);
-
-      if (IN_CLASSA(i))
-        return (htonl(IN_CLASSA_NET));
-      else if (IN_CLASSB(i))
-        return (htonl(IN_CLASSB_NET));
-      return (htonl(IN_CLASSC_NET));
-    }
+    statp->nsort = nsort;
 #endif
-
-#if (HOST_OS != linux) && (HOST_OS != freebsd)
-/* 
- * Check whether "cp" is a valid ascii representation
- * of an Internet address and convert to a binary address.
- * Returns 1 if the address is valid, 0 if not.
- * This replaces inet_addr, the return value from which
- * cannot distinguish between failure and a local broadcast address.
+    (void) fclose(fp);
+  }
+/*
+ * Last chance to get a nameserver.  This should not normally
+ * be necessary
  */
-
-    int inet_aton(register const char *cp, struct in_addr *addr)
-    {
-      register u_long val;
-      register int base, n;
-      register char c;
-      u_int parts[4];
-      register u_int *pp = parts;
-
-      c = *cp;
-      for (;;) {
-        /*
-         * Collect number up to ``.''.
-         * Values are specified as for C:
-         * 0x=hex, 0=octal, isdigit=decimal.
-         */
-        if (!isdigit(c))
-          return (0);
-        val = 0;
-        base = 10;
-        if (c == '0') {
-          c = *++cp;
-          if (c == 'x' || c == 'X')
-            base = 16, c = *++cp;
-          else
-            base = 8;
-        }
-        for (;;) {
-          if (isascii(c) && isdigit(c)) {
-            val = (val * base) + (c - '0');
-            c = *++cp;
-          } else if (base == 16 && isascii(c) && isxdigit(c)) {
-            val = (val << 4) | (c + 10 - (islower(c) ? 'a' : 'A'));
-            c = *++cp;
-          } else
-            break;
-        }
-        if (c == '.') {
-          /*
-           * Internet format:
-           *      a.b.c.d
-           *      a.b.c   (with c treated as 16 bits)
-           *      a.b     (with b treated as 24 bits)
-           */
-          if (pp >= parts + 3)
-            return (0);
-          *pp++ = val;
-          c = *++cp;
-        } else
-          break;
-      }
-      /*
-       * Check for trailing characters.
-       */
-      if (c != '\0' && (!isascii(c) || !isspace(c)))
-        return (0);
-      /*
-       * Concoct the address according to
-       * the number of parts specified.
-       */
-      n = pp - parts + 1;
-      switch (n) {
-
-      case 0:
-        return (0);             /* initial nondigit */
-
-      case 1:                  /* a -- 32 bits */
-        break;
-
-      case 2:                  /* a.b -- 8.24 bits */
-        if (val > 0xffffff)
-          return (0);
-        val |= parts[0] << 24;
-        break;
-
-      case 3:                  /* a.b.c -- 8.8.16 bits */
-        if (val > 0xffff)
-          return (0);
-        val |= (parts[0] << 24) | (parts[1] << 16);
+#ifdef NO_RESOLV_CONF
+  if(nserv == 0)
+    nserv = get_nameservers(statp);
+#endif
+
+  if (statp->defdname[0] == 0 &&
+      gethostname(buf, sizeof(statp->defdname) - 1) == 0 &&
+      (cp = strchr(buf, '.')) != NULL)
+    strcpy(statp->defdname, cp + 1);
+
+  /* find components of local domain that might be searched */
+  if (havesearch == 0) {
+    pp = statp->dnsrch;
+    *pp++ = statp->defdname;
+    *pp = NULL;
+
+    dots = 0;
+    for (cp = statp->defdname; *cp; cp++)
+      dots += (*cp == '.');
+
+    cp = statp->defdname;
+    while (pp < statp->dnsrch + MAXDFLSRCH) {
+      if (dots < LOCALDOMAINPARTS)
         break;
-
-      case 4:                  /* a.b.c.d -- 8.8.8.8 bits */
-        if (val > 0xff)
-          return (0);
-        val |= (parts[0] << 24) | (parts[1] << 16) | (parts[2] << 8);
-        break;
-      }
-      if (addr)
-        addr->s_addr = htonl(val);
-      return (1);
+      cp = strchr(cp, '.') + 1;    /*%< we know there is one */
+      *pp++ = cp;
+      dots--;
+    }
+    *pp = NULL;
+#ifdef DEBUG
+    if (statp->options & RES_DEBUG) {
+      printf(";; res_init()... default dnsrch list:\n");
+      for (pp = statp->dnsrch; *pp; pp++)
+        printf(";;\t%s\n", *pp);
+      printf(";;\t..END..\n");
     }
 #endif
+  }
+
+  if ((cp = getenv("RES_OPTIONS")) != NULL)
+    ink_res_setoptions(statp, cp, "env");
+  statp->options |= RES_INIT;
+  return (statp->res_h_errno);
+}
+
 #endif