You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@trafficserver.apache.org by zw...@apache.org on 2010/05/18 19:46:12 UTC

svn commit: r945786 - in /trafficserver/traffic/trunk: example/query_remap/ libinktomi++/ proxy/api/ts/

Author: zwoop
Date: Tue May 18 17:46:12 2010
New Revision: 945786

URL: http://svn.apache.org/viewvc?rev=945786&view=rev
Log:
TS-356: Make code more -ansi C portable.

This primary makes sure that we don't use C++ comments in C code (.c
files or C files that includes a .h).

Modified:
    trafficserver/traffic/trunk/example/query_remap/query_remap.c
    trafficserver/traffic/trunk/libinktomi++/ink_atomic.h
    trafficserver/traffic/trunk/libinktomi++/ink_config.h
    trafficserver/traffic/trunk/libinktomi++/ink_defs.h
    trafficserver/traffic/trunk/libinktomi++/ink_port.h
    trafficserver/traffic/trunk/libinktomi++/ink_queue.h
    trafficserver/traffic/trunk/libinktomi++/ink_unused.h
    trafficserver/traffic/trunk/proxy/api/ts/remap.h
    trafficserver/traffic/trunk/proxy/api/ts/ts.h

Modified: trafficserver/traffic/trunk/example/query_remap/query_remap.c
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/example/query_remap/query_remap.c?rev=945786&r1=945785&r2=945786&view=diff
==============================================================================
--- trafficserver/traffic/trunk/example/query_remap/query_remap.c (original)
+++ trafficserver/traffic/trunk/example/query_remap/query_remap.c Tue May 18 17:46:12 2010
@@ -29,7 +29,7 @@
 
 #define PLUGIN_NAME "query_remap"
 
-//function prototypes
+/* function prototypes */
 uint32_t hash_fnv32(char *buf, size_t len);
 
 typedef struct _query_remap_info {
@@ -42,7 +42,7 @@ typedef struct _query_remap_info {
 
 int tsremap_init(TSRemapInterface *api_info,char *errbuf,int errbuf_size)
 {
-// Called at TS startup. Nothing needed for this plugin
+  /* Called at TS startup. Nothing needed for this plugin */
   INKDebug(PLUGIN_NAME , "remap plugin initialized");
   return 0;
 }
@@ -50,7 +50,7 @@ int tsremap_init(TSRemapInterface *api_i
 
 int tsremap_new_instance(int argc,char *argv[],ihandle *ih,char *errbuf,int errbuf_size)
 {
-// Called for each remap rule using this plugin. The parameters are parsed here
+  /* Called for each remap rule using this plugin. The parameters are parsed here */
   int i;
   INKDebug(PLUGIN_NAME, "new instance fromURL: %s toURL: %s", argv[0], argv[1]);
 
@@ -59,12 +59,13 @@ int tsremap_new_instance(int argc,char *
     return -1;
   }
 
-  //initialize the struct to store info about this remap instance
-  // the argv parameters are:
-  // 0: fromURL
-  // 1: toURL
-  // 2: query param to hash
-  // 3,4,... : server hostnames
+  /* initialize the struct to store info about this remap instance
+     the argv parameters are:
+       0: fromURL
+       1: toURL
+       2: query param to hash
+       3,4,... : server hostnames
+  */
   query_remap_info *qri = (query_remap_info*) INKmalloc(sizeof(query_remap_info));
 
   qri->param_name = INKstrdup(argv[2]);
@@ -87,7 +88,7 @@ int tsremap_new_instance(int argc,char *
 
 void tsremap_delete_instance(ihandle ih)
 {
-// Release instance memory allocated in tsremap_new_instance
+  /* Release instance memory allocated in tsremap_new_instance */
   int i;
   INKDebug(PLUGIN_NAME, "deleting instance %p", ih);
 
@@ -121,20 +122,20 @@ int tsremap_remap(ihandle ih, rhandle rh
   if (rri && rri->request_query && rri->request_query_size > 0) {
     char *q, *s, *key;
 
-    //make a copy of the query, as it is read only
+    /* make a copy of the query, as it is read only */
     q = (char*) INKmalloc(rri->request_query_size+1);
     strncpy(q, rri->request_query, rri->request_query_size);
     q[rri->request_query_size] = '\0';
 
     s = q;
-    //parse query parameters
+    /* parse query parameters */
     for (key = strsep(&s, "&"); key != NULL; key = strsep(&s, "&")) {
       char *val = strchr(key, '=');
       if (val && (size_t)(val-key) == qri->param_len &&
           !strncmp(key, qri->param_name, qri->param_len)) {
         ++val;
-        //the param key matched the configured param_name
-        //hash the param value to pick a host
+        /* the param key matched the configured param_name
+           hash the param value to pick a host */
         hostidx = hash_fnv32(val, strlen(val)) % (uint32_t)qri->num_hosts;
         INKDebug(PLUGIN_NAME, "modifying host based on %s", key);
         break;
@@ -146,32 +147,32 @@ int tsremap_remap(ihandle ih, rhandle rh
     if (hostidx >= 0) {
       rri->new_host_size = strlen(qri->hosts[hostidx]);
       if (rri->new_host_size <= TSREMAP_RRI_MAX_HOST_SIZE) {
-        //copy the chosen host into rri
+        /* copy the chosen host into rri */
         memcpy(rri->new_host, qri->hosts[hostidx], rri->new_host_size);
 
         INKDebug(PLUGIN_NAME, "host changed from [%.*s] to [%.*s]",
                  rri->request_host_size, rri->request_host,
                  rri->new_host_size, rri->new_host);
-        return 1; //host has been modified
+        return 1; /* host has been modified */
       }
     }
   }
 
-  //the request was not modified, TS will use the toURL from the remap rule
+  /* the request was not modified, TS will use the toURL from the remap rule */
   INKDebug(PLUGIN_NAME, "request not modified");
   return 0;
 }
 
 
-// FNV (Fowler/Noll/Vo) hash
-// (description: http://www.isthe.com/chongo/tech/comp/fnv/index.html)
+/* FNV (Fowler/Noll/Vo) hash
+   (description: http://www.isthe.com/chongo/tech/comp/fnv/index.html) */
 uint32_t
 hash_fnv32(char *buf, size_t len)
 {
-  uint32_t hval = (uint32_t)0x811c9dc5; //FNV1_32_INIT
+  uint32_t hval = (uint32_t)0x811c9dc5; /* FNV1_32_INIT */
 
   for (; len > 0; --len) {
-    hval *= (uint32_t)0x01000193; //FNV_32_PRIME
+    hval *= (uint32_t)0x01000193;  /* FNV_32_PRIME */
     hval ^= (uint32_t)*buf++;
   }
 

Modified: trafficserver/traffic/trunk/libinktomi++/ink_atomic.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/libinktomi%2B%2B/ink_atomic.h?rev=945786&r1=945785&r2=945786&view=diff
==============================================================================
--- trafficserver/traffic/trunk/libinktomi++/ink_atomic.h (original)
+++ trafficserver/traffic/trunk/libinktomi++/ink_atomic.h Tue May 18 17:46:12 2010
@@ -77,7 +77,7 @@ static inline int ink_atomic_increment(p
 static inline ink64 ink_atomic_increment64(pvink64 mem, ink64 value) { return ((inku64_s)atomic_add_64_nv((pvinku64_s)mem, (inku64_s)value)) - value; }
 static inline void *ink_atomic_increment_ptr(pvvoidp mem, intptr_t value) { return (void*)(((char*)atomic_add_ptr_nv((vvoidp)mem, (ssize_t)value)) - value); }
 
-// not used for Intel Processors or Sparc which are mostly sequentally consistent
+/* not used for Intel Processors or Sparc which are mostly sequentally consistent */
 #define INK_WRITE_MEMORY_BARRIER
 #define INK_MEMORY_BARRIER
 
@@ -85,7 +85,7 @@ static inline void *ink_atomic_increment
 
 #if defined(__GNUC__) && (__GNUC__ >= 4) && (__GNUC_MINOR__ >= 1)
 
-// see http://gcc.gnu.org/onlinedocs/gcc-4.1.2/gcc/Atomic-Builtins.html
+/* see http://gcc.gnu.org/onlinedocs/gcc-4.1.2/gcc/Atomic-Builtins.html */
 
 static inline ink32 ink_atomic_swap(pvink32 mem, ink32 value) { return __sync_lock_test_and_set(mem, value); }
 static inline ink64 ink_atomic_swap64(pvink64 mem, ink64 value) { return __sync_lock_test_and_set(mem, value); }
@@ -97,7 +97,7 @@ static inline int ink_atomic_increment(p
 static inline ink64 ink_atomic_increment64(pvink64 mem, ink64 value) { return __sync_fetch_and_add(mem, value); }
 static inline void *ink_atomic_increment_ptr(pvvoidp mem, intptr_t value) { return __sync_fetch_and_add((void**)mem, value); }
 
-// not used for Intel Processors which have sequential(esque) consistency
+/* not used for Intel Processors which have sequential(esque) consistency */
 #define INK_WRITE_MEMORY_BARRIER
 #define INK_MEMORY_BARRIER
 
@@ -150,7 +150,7 @@ extern "C"
   {
     return (void *) ink_atomic_increment((int *) mem, value);
   }
-#else  // non-freebsd for the "else"
+#else  /* non-freebsd for the "else" */
 /* Atomic compare and swap 32-bit.
    if (*mem == old) *mem = new_value;
    Returns TRUE if swap was successful. */
@@ -163,7 +163,7 @@ extern "C"
 
 /* Atomic increment/decrement.  Returns the old value */
   int ink_atomic_increment(pvink32 mem, int value);
-#endif  // freebsd vs not freebsd check
+#endif  /* freebsd vs not freebsd check */
 
 /* Atomic 64-bit compare and swap
    THIS IS NOT DEFINED for x86 */
@@ -192,10 +192,10 @@ extern "C"
     } while (!ink_atomic_cas64(mem, old, old + value));
     return old;
   }
-#else  // non-freebsd for the "else"
+#else  /* non-freebsd for the "else" */
   int ink_atomic_cas64(pvink64 mem, ink64 old, ink64 new_value);
   ink64 ink_atomic_increment64(pvink64 mem, ink64 value);
-#endif  // freebsd vs not freebsd check
+#endif  /* freebsd vs not freebsd check */
 
 #define INK_WRITE_MEMORY_BARRIER
 #define INK_MEMORY_BARRIER

Modified: trafficserver/traffic/trunk/libinktomi++/ink_config.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/libinktomi%2B%2B/ink_config.h?rev=945786&r1=945785&r2=945786&view=diff
==============================================================================
--- trafficserver/traffic/trunk/libinktomi++/ink_config.h (original)
+++ trafficserver/traffic/trunk/libinktomi++/ink_config.h Tue May 18 17:46:12 2010
@@ -24,8 +24,8 @@
 #ifndef _ink_config_h
 #define	_ink_config_h
 
-// This file is autogenerated without multiple include protection
-// which matters e.g. when the manager specifically undef's HTTP_CACHE
+/* This file is autogenerated without multiple include protection
+   which matters e.g. when the manager specifically undef's HTTP_CACHE */
 #include "config.h"
 
 #endif

Modified: trafficserver/traffic/trunk/libinktomi++/ink_defs.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/libinktomi%2B%2B/ink_defs.h?rev=945786&r1=945785&r2=945786&view=diff
==============================================================================
--- trafficserver/traffic/trunk/libinktomi++/ink_defs.h (original)
+++ trafficserver/traffic/trunk/libinktomi++/ink_defs.h Tue May 18 17:46:12 2010
@@ -67,8 +67,8 @@ typedef void (*VI_PFN) (int);
 #define	NOWARN_UNUSED(x)	(void)(x)
 #define	NOWARN_UNUSED_RETURN(x)	if (x) {}
 #ifdef __GNUC__
-// Enable this to get printf() style warnings on the Inktomi functions.
-//#define PRINTFLIKE(IDX, FIRST)  __attribute__((format (printf, IDX, FIRST)))
+/*  Enable this to get printf() style warnings on the Inktomi functions. */
+/* #define PRINTFLIKE(IDX, FIRST)  __attribute__((format (printf, IDX, FIRST))) */
 #define PRINTFLIKE(IDX, FIRST)
 #else
 #define PRINTFLIKE(IDX, FIRST)

Modified: trafficserver/traffic/trunk/libinktomi++/ink_port.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/libinktomi%2B%2B/ink_port.h?rev=945786&r1=945785&r2=945786&view=diff
==============================================================================
--- trafficserver/traffic/trunk/libinktomi++/ink_port.h (original)
+++ trafficserver/traffic/trunk/libinktomi++/ink_port.h Tue May 18 17:46:12 2010
@@ -100,7 +100,7 @@ typedef off_t ink_off_t;
 
 #define NUL '\0'
 
-// copy from ink_ntio.h
+/* copy from ink_ntio.h */
 typedef enum
 {
   keSocket = 0xbad,

Modified: trafficserver/traffic/trunk/libinktomi++/ink_queue.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/libinktomi%2B%2B/ink_queue.h?rev=945786&r1=945785&r2=945786&view=diff
==============================================================================
--- trafficserver/traffic/trunk/libinktomi++/ink_queue.h (original)
+++ trafficserver/traffic/trunk/libinktomi++/ink_queue.h Tue May 18 17:46:12 2010
@@ -50,10 +50,12 @@
   the pointer was required by the standard.
 */
 
-//#if defined(POSIX_THREAD)
-//#include <pthread.h>
-//#include <stdlib.h>
-//#endif
+/*
+#if defined(POSIX_THREAD)
+#include <pthread.h>
+#include <stdlib.h>
+#endif
+*/
 
 /* #define USE_SPINLOCK_FOR_FREELIST */
 /* #define CHECK_FOR_DOUBLE_FREE */
@@ -123,10 +125,10 @@ extern "C"
     ink_mutex inkfreelist_mutex;
 #endif
 #if (defined(USE_SPINLOCK_FOR_FREELIST) || defined(CHECK_FOR_DOUBLE_FREE))
-    //
-    // This assumes  we will never use anything other than Pthreads
-    // on alpha
-    //
+    /*
+      This assumes  we will never use anything other than Pthreads
+      on alpha
+    */
     ink_mutex freelist_mutex;
     volatile void_p *head;
 #ifdef CHECK_FOR_DOUBLE_FREE
@@ -193,7 +195,7 @@ extern "C"
 #if !defined(INK_QUEUE_NT)
 #define INK_ATOMICLIST_EMPTY(_x) (!(TO_PTR(FREELIST_POINTER((_x.head)))))
 #else
-  // ink_queue_nt.c doesn't do the FROM/TO pointer swizzling
+  /* ink_queue_nt.c doesn't do the FROM/TO pointer swizzling */
 #define INK_ATOMICLIST_EMPTY(_x) (!(      (FREELIST_POINTER((_x.head)))))
 #endif
 

Modified: trafficserver/traffic/trunk/libinktomi++/ink_unused.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/libinktomi%2B%2B/ink_unused.h?rev=945786&r1=945785&r2=945786&view=diff
==============================================================================
--- trafficserver/traffic/trunk/libinktomi++/ink_unused.h (original)
+++ trafficserver/traffic/trunk/libinktomi++/ink_unused.h Tue May 18 17:46:12 2010
@@ -39,16 +39,18 @@
 #endif /* #if ((__GNUC__ >= 3) || ((__GNUC__ == 2) && (__GNUC_MINOR__ >= 7))) */
 
 #if __GNUC__ >= 3
-//# define inline               inline __attribute__ ((always_inline))
-//# define __pure               __attribute__ ((pure))
-//# define __const      __attribute__ ((const))
-//# define __noreturn   __attribute__ ((noreturn))
-//# define __malloc     __attribute__ ((malloc))
-//# define __must_check __attribute__ ((warn_unused_result))
-//# define __deprecated __attribute__ ((deprecated))
-//# define __used               __attribute__ ((used))
-//# define __unused     __attribute__ ((unused))
-//# define __packed     __attribute__ ((packed))
+#if 0 /* NOT USED */
+# define inline               inline __attribute__ ((always_inline))
+# define __pure               __attribute__ ((pure))
+# define __const      __attribute__ ((const))
+# define __noreturn   __attribute__ ((noreturn))
+# define __malloc     __attribute__ ((malloc))
+# define __must_check __attribute__ ((warn_unused_result))
+# define __deprecated __attribute__ ((deprecated))
+# define __used               __attribute__ ((used))
+# define __unused     __attribute__ ((unused))
+# define __packed     __attribute__ ((packed))
+#endif
 #ifndef likely
 #define likely(x)	__builtin_expect (!!(x), 1)
 #endif
@@ -56,16 +58,18 @@
 #define unlikely(x)	__builtin_expect (!!(x), 0)
 #endif
 #else
-//# define inline               /* no inline */
-//# define __pure               /* no pure */
-//# define __const      /* no const */
-//# define __noreturn   /* no noreturn */
-//# define __malloc     /* no malloc */
-//# define __must_check /* no warn_unused_result */
-//# define __deprecated /* no deprecated */
-//# define __used               /* no used */
-//# define __unused     /* no unused */
-//# define __packed     /* no packed */
+#if 0 /* NOT USED */
+# define inline               /* no inline */
+# define __pure               /* no pure */
+# define __const      /* no const */
+# define __noreturn   /* no noreturn */
+# define __malloc     /* no malloc */
+# define __must_check /* no warn_unused_result */
+# define __deprecated /* no deprecated */
+# define __used               /* no used */
+# define __unused     /* no unused */
+# define __packed     /* no packed */
+#endif
 #ifndef likely
 #define likely(x)	(x)
 #endif

Modified: trafficserver/traffic/trunk/proxy/api/ts/remap.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/proxy/api/ts/remap.h?rev=945786&r1=945785&r2=945786&view=diff
==============================================================================
--- trafficserver/traffic/trunk/proxy/api/ts/remap.h (original)
+++ trafficserver/traffic/trunk/proxy/api/ts/remap.h Tue May 18 17:46:12 2010
@@ -40,38 +40,40 @@ extern "C"
 
   typedef struct _tsremap_api_info
   {
-    unsigned long size;         // in: sizeof(struct _tsremap_api_info)
-    unsigned long tsremap_version;      // in: TS supported version ((major << 16) | minor)
-    tsremap_interface *fp_tsremap_interface;    // in: TS interface function pointer
+    unsigned long size;         /* in: sizeof(struct _tsremap_api_info) */
+    unsigned long tsremap_version;      /* in: TS supported version ((major << 16) | minor) */
+    tsremap_interface *fp_tsremap_interface;    /* in: TS interface function pointer */
   } TSRemapInterface;
 
-  typedef TSRemapInterface TSREMAP_INTERFACE;   // This is deprecated.
+  typedef TSRemapInterface TSREMAP_INTERFACE;   /* This is deprecated. */
 
   typedef void *base_handle;
-  typedef base_handle ihandle;  // plugin instance handle (per unique remap rule)
-  typedef base_handle rhandle;  // request handle
+  typedef base_handle ihandle;  /* plugin instance handle (per unique remap rule) */
+  typedef base_handle rhandle;  /* request handle */
 
 
-// Plugin initialization - called first.
-// Mandatory interface function.
-// Return: 0 - success
-//         != 0 - error, errbuf can include error message from plugin
+  /* Plugin initialization - called first.
+     Mandatory interface function.
+     Return: 0 - success
+             != 0 - error, errbuf can include error message from plugin
+  */
   int tsremap_init(TSRemapInterface * api_info, char *errbuf, int errbuf_size);
   typedef int _tsremap_init(TSRemapInterface * api_info, char *errbuf, int errbuf_size);
 #define TSREMAP_FUNCNAME_INIT "tsremap_init"
 
 
-// Plugin shutdown
-// Optional function.
+  /* Plugin shutdown
+     Optional function. */
   int tsremap_done(void);
   typedef int _tsremap_done(void);
 #define TSREMAP_FUNCNAME_DONE "tsremap_done"
 
-// Plugin new instance. Create new plugin processing entry for unique remap record.
-// First two arguments in argv vector are - fromURL and toURL from remap record.
-// Please keep in mind that fromURL and toURL will be converted to canonical view.
-// Return: != 0 - instance creation error
-//         0 - success
+  /* Plugin new instance. Create new plugin processing entry for unique remap record.
+     First two arguments in argv vector are - fromURL and toURL from remap record.
+     Please keep in mind that fromURL and toURL will be converted to canonical view.
+     Return: != 0 - instance creation error
+                0 - success
+  */
   int tsremap_new_instance(int argc, char *argv[], ihandle * ih, char *errbuf, int errbuf_size);
   typedef int _tsremap_new_instance(int argc, char *argv[], ihandle * ih, char *errbuf, int errbuf_size);
 #define TSREMAP_FUNCNAME_NEW_INSTANCE "tsremap_new_instance"
@@ -86,7 +88,7 @@ extern "C"
 
   typedef struct _tm_remap_request_info
   {
-    // the following fields are read only
+    /* the following fields are read only */
     unsigned long size;         /* sizeof(TSRemapRequestInfo) */
 
     int request_port;           /* request port number */
@@ -133,7 +135,7 @@ extern "C"
     /* Each of the dotted components is a byte, so: */
     /* 0x25364758 = 0x25.0x36.0x47.0x58 = 37.54.71.88 in decimal. */
 
-    // plugin can change the following fields
+    /* plugin can change the following fields */
     char new_host[TSREMAP_RRI_MAX_HOST_SIZE];   /* new host string */
     int new_host_size;          /* new host string size (if 0 - do not change request host) */
     int new_port;               /* new port number (0 - do not change request port) */
@@ -151,22 +153,22 @@ extern "C"
     /*   -1 (default) -> Don't modify scheme */
   } TSRemapRequestInfo;
 
-  typedef TSRemapRequestInfo REMAP_REQUEST_INFO;        // This is deprecated.
-
-// Remap new request
-// Return: != 0 - request was remapped, TS must look at new_... fields in TSRemapRequestInfo
-//         == 0 - request was not processed. TS must perform default remap
-// Note: rhandle == INKHttpTxn (see ts/ts.h for more details)
-// Remap API plugin can use InkAPI function calls inside tsremap_remap()
+  /* Remap new request
+     Return: != 0 - request was remapped, TS must look at new_... fields in TSRemapRequestInfo
+             == 0 - request was not processed. TS must perform default remap
+     Note: rhandle == INKHttpTxn (see ts/ts.h for more details)
+     Remap API plugin can use InkAPI function calls inside tsremap_remap()
+  */
   int tsremap_remap(ihandle ih, rhandle rh, TSRemapRequestInfo * rri);
   typedef int _tsremap_remap(ihandle ih, rhandle rh, TSRemapRequestInfo * rri);
 #define TSREMAP_FUNCNAME_REMAP "tsremap_remap"
 
-// Check response code from Origin Server
-// Return: none
-// Note: rhandle == INKHttpTxn (see ts/ts.h for more details)
-// os_response_type -> INKServerState
-// Remap API plugin can use InkAPI function calls inside tsremap_remap()
+  /* Check response code from Origin Server
+     Return: none
+     Note: rhandle == INKHttpTxn (see ts/ts.h for more details)
+     os_response_type -> INKServerState
+     Remap API plugin can use InkAPI function calls inside tsremap_remap()
+  */
   void tsremap_os_response(ihandle ih, rhandle rh, int os_response_type);
   typedef void _tsremap_os_response(ihandle ih, rhandle rh, int os_response_type);
 #define TSREMAP_FUNCNAME_OS_RESPONSE "tsremap_os_response"

Modified: trafficserver/traffic/trunk/proxy/api/ts/ts.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/proxy/api/ts/ts.h?rev=945786&r1=945785&r2=945786&view=diff
==============================================================================
--- trafficserver/traffic/trunk/proxy/api/ts/ts.h (original)
+++ trafficserver/traffic/trunk/proxy/api/ts/ts.h Tue May 18 17:46:12 2010
@@ -252,7 +252,7 @@ extern "C"
     INK_EVENT_NET_ACCEPT = 202,
     INK_EVENT_NET_ACCEPT_FAILED = 204,
 
-    // EVENTS 206 - 212 for internal use
+    /* EVENTS 206 - 212 for internal use */
     INK_EVENT_INTERNAL_206 = 206,
     INK_EVENT_INTERNAL_207 = 207,
     INK_EVENT_INTERNAL_208 = 208,
@@ -286,7 +286,7 @@ extern "C"
     INK_EVENT_CACHE_READ_READY = 1134,
     INK_EVENT_CACHE_READ_COMPLETE = 1135,
 
-    // EVENT 1200 for internal use
+    /* EVENT 1200 for internal use */
     INK_EVENT_INTERNAL_1200 = 1200,
 
     INK_EVENT_HTTP_CONTINUE = 60000,
@@ -308,7 +308,7 @@ extern "C"
     INK_EVENT_HTTP_READ_REQUEST_PRE_REMAP = 60016,
     INK_EVENT_MGMT_UPDATE = 60100,
 
-    // EVENTS 60200 - 60202 for internal use
+    /* EVENTS 60200 - 60202 for internal use */
     INK_EVENT_INTERNAL_60200 = 60200,
     INK_EVENT_INTERNAL_60201 = 60201,
     INK_EVENT_INTERNAL_60202 = 60202,
@@ -451,9 +451,9 @@ extern "C"
   typedef long long INK64;
   typedef unsigned long long INKU64;
 
-  // These typedefs are used with the corresponding INKMgmt*Get functions
-  // for storing the values retrieved by those functions. For example,
-  // INKMgmtCounterGet() retrieves an INKMgmtCounter.
+  /* These typedefs are used with the corresponding INKMgmt*Get functions
+     for storing the values retrieved by those functions. For example,
+     INKMgmtCounterGet() retrieves an INKMgmtCounter. */
   typedef INK64 INKMgmtInt;
   typedef INK64 INKMgmtLLong;
   typedef INK64 INKMgmtCounter;
@@ -507,8 +507,8 @@ extern "C"
      struct INKFetchUrlParams *next;
   }INKFetchUrlParams_t;
 
-  // --------------------------------------------------------------------------
-  // Init
+  /* --------------------------------------------------------------------------
+     Init */
 
   /**
       This function must be defined by all plugins. Traffic Server
@@ -527,9 +527,8 @@ extern "C"
    */
   extern inkexp void INKPluginInit(int argc, const char *argv[]);
 
-  // --------------------------------------------------------------------------
-  // License
-
+  /* --------------------------------------------------------------------------
+     License */
   /**
       This function lets Traffic Server know that a license key is
       required for the plugin. You implement this function to return the
@@ -540,13 +539,11 @@ extern "C"
 
       @return Zero if no license is required. Returns 1 if a license
         is required.
-
-   */
+  */
   extern inkexp int INKPluginLicenseRequired(void);
 
-  // --------------------------------------------------------------------------
-  // URL schemes
-
+  /* --------------------------------------------------------------------------
+     URL schemes */
   extern inkapi const char *INK_URL_SCHEME_FILE;
   extern inkapi const char *INK_URL_SCHEME_FTP;
   extern inkapi const char *INK_URL_SCHEME_GOPHER;
@@ -559,9 +556,8 @@ extern "C"
   extern inkapi const char *INK_URL_SCHEME_TELNET;
   extern inkapi const char *INK_URL_SCHEME_WAIS;
 
-  // --------------------------------------------------------------------------
-  // URL scheme string lengths
-
+  /* --------------------------------------------------------------------------
+     URL scheme string lengths */
   extern inkapi int INK_URL_LEN_FILE;
   extern inkapi int INK_URL_LEN_FTP;
   extern inkapi int INK_URL_LEN_GOPHER;
@@ -574,9 +570,8 @@ extern "C"
   extern inkapi int INK_URL_LEN_TELNET;
   extern inkapi int INK_URL_LEN_WAIS;
 
-  // --------------------------------------------------------------------------
-  // MIME fields
-
+  /* --------------------------------------------------------------------------
+     MIME fields */
   extern inkapi const char *INK_MIME_FIELD_ACCEPT;
   extern inkapi const char *INK_MIME_FIELD_ACCEPT_CHARSET;
   extern inkapi const char *INK_MIME_FIELD_ACCEPT_ENCODING;
@@ -649,9 +644,8 @@ extern "C"
   extern inkapi const char *INK_MIME_FIELD_XREF;
   extern inkapi const char *INK_MIME_FIELD_X_FORWARDED_FOR;
 
-  // --------------------------------------------------------------------------
-  // MIME fields string lengths
-
+  /* --------------------------------------------------------------------------
+     MIME fields string lengths */
   extern inkapi int INK_MIME_LEN_ACCEPT;
   extern inkapi int INK_MIME_LEN_ACCEPT_CHARSET;
   extern inkapi int INK_MIME_LEN_ACCEPT_ENCODING;
@@ -724,9 +718,8 @@ extern "C"
   extern inkapi int INK_MIME_LEN_XREF;
   extern inkapi int INK_MIME_LEN_X_FORWARDED_FOR;
 
-  // --------------------------------------------------------------------------
-  // HTTP values
-
+  /* --------------------------------------------------------------------------
+     HTTP values */
   extern inkapi const char *INK_HTTP_VALUE_BYTES;
   extern inkapi const char *INK_HTTP_VALUE_CHUNKED;
   extern inkapi const char *INK_HTTP_VALUE_CLOSE;
@@ -749,9 +742,8 @@ extern "C"
   extern inkapi const char *INK_HTTP_VALUE_PUBLIC;
   extern inkapi const char *INK_HTTP_VALUE_SMAX_AGE;
 
-  // --------------------------------------------------------------------------
-  // HTTP values string lengths
-
+  /* --------------------------------------------------------------------------
+     HTTP values string lengths */
   extern inkapi int INK_HTTP_LEN_BYTES;
   extern inkapi int INK_HTTP_LEN_CHUNKED;
   extern inkapi int INK_HTTP_LEN_CLOSE;
@@ -774,9 +766,8 @@ extern "C"
   extern inkapi int INK_HTTP_LEN_PUBLIC;
   extern inkapi int INK_HTTP_LEN_SMAX_AGE;
 
-  // --------------------------------------------------------------------------
-  // HTTP methods
-
+  /* --------------------------------------------------------------------------
+     HTTP methods */
   extern inkapi const char *INK_HTTP_METHOD_CONNECT;
   extern inkapi const char *INK_HTTP_METHOD_DELETE;
   extern inkapi const char *INK_HTTP_METHOD_GET;
@@ -788,9 +779,8 @@ extern "C"
   extern inkapi const char *INK_HTTP_METHOD_PUT;
   extern inkapi const char *INK_HTTP_METHOD_TRACE;
 
-  // --------------------------------------------------------------------------
-  // HTTP methods string lengths
-
+  /* --------------------------------------------------------------------------
+     HTTP methods string lengths */
   extern inkapi int INK_HTTP_LEN_CONNECT;
   extern inkapi int INK_HTTP_LEN_DELETE;
   extern inkapi int INK_HTTP_LEN_GET;
@@ -802,9 +792,8 @@ extern "C"
   extern inkapi int INK_HTTP_LEN_PUT;
   extern inkapi int INK_HTTP_LEN_TRACE;
 
-  // --------------------------------------------------------------------------
-  // MLoc Constants
-
+  /* --------------------------------------------------------------------------
+     MLoc Constants */
   /**
       Use INK_NULL_MLOC as the parent in calls that require a parent
       when an INKMLoc does not have a parent INKMLoc. For example if
@@ -813,9 +802,8 @@ extern "C"
    */
   extern inkapi const INKMLoc INK_NULL_MLOC;
 
-  // --------------------------------------------------------------------------
-  // Memory
-
+  /* --------------------------------------------------------------------------
+     Memory */
 #define INKmalloc(s)      _INKmalloc ((s), INK_RES_MEM_PATH)
 #define INKrealloc(p,s)   _INKrealloc ((p), (s), INK_RES_MEM_PATH)
 #define INKstrdup(p)      _INKstrdup ((p), -1, INK_RES_MEM_PATH)
@@ -827,9 +815,8 @@ extern "C"
   inkapi char *_INKstrdup(const char *str, int length, const char *path);
   inkapi void _INKfree(void *ptr);
 
-  // --------------------------------------------------------------------------
-  // Component object handles
-
+  /* --------------------------------------------------------------------------
+     Component object handles */
   /**
       Releases the INKMLoc mloc created from the INKMLoc parent.
       If there is no parent INKMLoc, use INK_NULL_MLOC.
@@ -856,9 +843,8 @@ extern "C"
    */
   inkapi INKReturnCode INKHandleStringRelease(INKMBuffer bufp, INKMLoc parent, const char *str);
 
-  // --------------------------------------------------------------------------
-  // Install and plugin locations
-
+  /* --------------------------------------------------------------------------
+     Install and plugin locations */
   /**
       Gets the path of the directory in which Traffic Server is installed.
       Use this function to specify the location of files that the
@@ -884,9 +870,8 @@ extern "C"
    */
   inkapi const char *INKPluginDirGet(void);
 
-  // --------------------------------------------------------------------------
-  // Traffic Server Version
-
+  /* --------------------------------------------------------------------------
+     Traffic Server Version */
   /**
       Gets the version of Traffic Server currently running. Use this
       function to make sure that the plugin version and Traffic Server
@@ -897,8 +882,8 @@ extern "C"
    */
   inkapi const char *INKTrafficServerVersionGet(void);
 
-  // --------------------------------------------------------------------------
-  // Plugin registration
+  /* --------------------------------------------------------------------------
+     Plugin registration */
 
   /**
       This function registers your plugin with a particular version
@@ -914,12 +899,10 @@ extern "C"
 
    */
   inkapi int INKPluginRegister(INKSDKVersion sdk_version, INKPluginRegistrationInfo * plugin_info);
-
   inkapi INKReturnCode INKPluginInfoRegister(INKPluginRegistrationInfo * plugin_info);
 
-  // --------------------------------------------------------------------------
-  // Files
-
+  /* --------------------------------------------------------------------------
+     Files */
   /**
       Opens a file for reading or writing and returns a descriptor for
       accessing the file. The current implementation cannot open a file
@@ -1002,9 +985,8 @@ extern "C"
    */
   inkapi char *INKfgets(INKFile filep, char *buf, int length);
 
-  // --------------------------------------------------------------------------
-  // Error logging
-
+  /* --------------------------------------------------------------------------
+     Error logging */
   /**
       Writes printf-style error messages to the Traffic Server error
       log. One advantage of INKError over printf is that each call is
@@ -1018,9 +1000,8 @@ extern "C"
   */
   inkapi void INKError(const char *fmt, ...);
 
-  // --------------------------------------------------------------------------
-  // Assertions
-
+  /* --------------------------------------------------------------------------
+     Assertions */
   inkapi int _INKReleaseAssert(const char *txt, const char *f, int l);
   inkapi int _INKAssert(const char *txt, const char *f, int l);
 
@@ -1030,9 +1011,8 @@ extern "C"
 #define INKAssert(EX) \
             (void)((EX) || (_INKAssert(#EX, __FILE__, __LINE__)))
 
-  // --------------------------------------------------------------------------
-  // Marshal buffers
-
+  /* --------------------------------------------------------------------------
+     Marshal buffers */
   /**
       Creates a new marshal buffer and initializes the reference count
       to 1.
@@ -1050,9 +1030,8 @@ extern "C"
    */
   inkapi INKReturnCode INKMBufferDestroy(INKMBuffer bufp);
 
-  // --------------------------------------------------------------------------
-  // URLs
-
+  /* --------------------------------------------------------------------------
+     URLs */
   /**
       Creates a new URL within the marshal buffer bufp. Returns a
       location for the URL within the marshal buffer.
@@ -1194,9 +1173,8 @@ extern "C"
    */
   inkapi INKReturnCode INKUrlSchemeSet(INKMBuffer bufp, INKMLoc offset, const char *value, int length);
 
-  // --------------------------------------------------------------------------
-  // Internet specific URLs
-
+  /* --------------------------------------------------------------------------
+     Internet specific URLs */
   /**
       Retrieves the user portion of the URL located at url_loc
       within bufp. Note: the returned string is not guaranteed to
@@ -1306,9 +1284,8 @@ extern "C"
    */
   inkapi INKReturnCode INKUrlPortSet(INKMBuffer bufp, INKMLoc offset, int port);
 
-  // --------------------------------------------------------------------------
-  // HTTP specific URLs
-
+  /* --------------------------------------------------------------------------
+     HTTP specific URLs */
   /**
       Retrieves the path portion of the URL located at url_loc within
       bufp. INKUrlPathGet() places the length of the returned string in
@@ -1338,9 +1315,8 @@ extern "C"
    */
   inkapi INKReturnCode INKUrlPathSet(INKMBuffer bufp, INKMLoc offset, const char *value, int length);
 
-  // --------------------------------------------------------------------------
-  // FTP specific URLs
-
+  /* --------------------------------------------------------------------------
+     FTP specific URLs */
   /**
       Retrieves the FTP type of the URL located at url_loc within bufp.
 
@@ -1362,9 +1338,8 @@ extern "C"
    */
   inkapi INKReturnCode INKUrlFtpTypeSet(INKMBuffer bufp, INKMLoc offset, int type);
 
-  // --------------------------------------------------------------------------
-  // HTTP specific URLs
-
+  /* --------------------------------------------------------------------------
+     HTTP specific URLs */
   /**
       Retrieves the HTTP params portion of the URL located at url_loc
       within bufp. The length of the returned string is in the length
@@ -1454,8 +1429,8 @@ extern "C"
    */
   inkapi INKReturnCode INKUrlHttpFragmentSet(INKMBuffer bufp, INKMLoc offset, const char *value, int length);
 
-  // --------------------------------------------------------------------------
-  // MIME headers
+  /* --------------------------------------------------------------------------
+     MIME headers */
 
   /**
       Creates a MIME parser. The parser's data structure contains
@@ -1748,9 +1723,8 @@ extern "C"
 
   inkapi INKReturnCode INKMimeHdrFieldValueDelete(INKMBuffer bufp, INKMLoc hdr, INKMLoc field, int idx);
 
-  // --------------------------------------------------------------------------
-  // HTTP headers
-
+  /* --------------------------------------------------------------------------
+     HTTP headers */
   inkapi INKHttpParser INKHttpParserCreate(void);
   inkapi INKReturnCode INKHttpParserClear(INKHttpParser parser);
   inkapi INKReturnCode INKHttpParserDestroy(INKHttpParser parser);
@@ -1844,17 +1818,15 @@ extern "C"
   inkapi INKReturnCode INKHttpHdrReasonSet(INKMBuffer bufp, INKMLoc offset, const char *value, int length);
   inkapi const char *INKHttpHdrReasonLookup(INKHttpStatus status);
 
-  // --------------------------------------------------------------------------
-  // Threads
-
+  /* --------------------------------------------------------------------------
+     Threads */
   inkapi INKThread INKThreadCreate(INKThreadFunc func, void *data);
   inkapi INKThread INKThreadInit(void);
   inkapi INKReturnCode INKThreadDestroy(INKThread thread);
   inkapi INKThread INKThreadSelf(void);
 
-  // --------------------------------------------------------------------------
-  // Mutexes
-
+  /* --------------------------------------------------------------------------
+     Mutexes */
   inkapi INKMutex INKMutexCreate(void);
   inkapi INKReturnCode INKMutexLock(INKMutex mutexp);
   inkapi INKReturnCode INKMutexLockTry(INKMutex mutexp, int *lock);
@@ -1864,9 +1836,8 @@ extern "C"
 
   inkapi INKReturnCode INKMutexUnlock(INKMutex mutexp);
 
-  // --------------------------------------------------------------------------
-  // cachekey
-
+  /* --------------------------------------------------------------------------
+     cachekey */
   /**
       Creates (allocates memory for) a new cache key.
 
@@ -1913,39 +1884,34 @@ extern "C"
    */
   inkapi INKReturnCode INKCacheKeyDestroy(INKCacheKey key);
 
-  // --------------------------------------------------------------------------
-  // cache url
-
+  /* --------------------------------------------------------------------------
+     cache url */
   inkapi INKReturnCode INKSetCacheUrl(INKHttpTxn txnp, const char *url);
 
-  // --------------------------------------------------------------------------
-  // cache plugin
-
+  /* --------------------------------------------------------------------------
+     cache plugin */
   inkapi INKReturnCode INKCacheKeyGet(INKCacheTxn txnp, void **key, int *length);
   inkapi INKReturnCode INKCacheHeaderKeyGet(INKCacheTxn txnp, void **key, int *length);
   inkapi INKIOBufferReader INKCacheBufferReaderGet(INKCacheTxn txnp);
   inkapi INKHttpTxn INKCacheGetStateMachine(INKCacheTxn txnp);
 
-  // --------------------------------------------------------------------------
-  // Configuration
-
+  /* --------------------------------------------------------------------------
+     Configuration */
   inkapi unsigned int INKConfigSet(unsigned int id, void *data, INKConfigDestroyFunc funcp);
   inkapi INKConfig INKConfigGet(unsigned int id);
   inkapi void INKConfigRelease(unsigned int id, INKConfig configp);
   inkapi void *INKConfigDataGet(INKConfig configp);
 
-  // --------------------------------------------------------------------------
-  // Management
-
+  /* --------------------------------------------------------------------------
+     Management */
   inkapi INKReturnCode INKMgmtUpdateRegister(INKCont contp, const char *plugin_name, const char *path);
   inkapi int INKMgmtIntGet(const char *var_name, INKMgmtInt * result);
   inkapi int INKMgmtCounterGet(const char *var_name, INKMgmtCounter * result);
   inkapi int INKMgmtFloatGet(const char *var_name, INKMgmtFloat * result);
   inkapi int INKMgmtStringGet(const char *var_name, INKMgmtString * result);
 
-  // --------------------------------------------------------------------------
-  // Continuations
-
+  /* --------------------------------------------------------------------------
+     Continuations */
   inkapi INKCont INKContCreate(INKEventFunc funcp, INKMutex mutexp);
   inkapi INKReturnCode INKContDestroy(INKCont contp);
   inkapi INKReturnCode INKContDataSet(INKCont contp, void *data);
@@ -1955,25 +1921,21 @@ extern "C"
   inkapi int INKContCall(INKCont contp, INKEvent event, void *edata);
   inkapi INKMutex INKContMutexGet(INKCont contp);
 
-  // --------------------------------------------------------------------------
-  // HTTP hooks
-
+  /* --------------------------------------------------------------------------
+     HTTP hooks */
   inkapi INKReturnCode INKHttpHookAdd(INKHttpHookID id, INKCont contp);
 
-  // --------------------------------------------------------------------------
-  // Cache hook
-
+  /* --------------------------------------------------------------------------
+     Cache hook */
   inkapi INKReturnCode INKCacheHookAdd(INKCacheHookID id, INKCont contp);
 
-  // --------------------------------------------------------------------------
-  // HTTP sessions
-
+  /* --------------------------------------------------------------------------
+     HTTP sessions */
   inkapi INKReturnCode INKHttpSsnHookAdd(INKHttpSsn ssnp, INKHttpHookID id, INKCont contp);
   inkapi INKReturnCode INKHttpSsnReenable(INKHttpSsn ssnp, INKEvent event);
 
-  // --------------------------------------------------------------------------
-  // HTTP transactions
-
+  /* --------------------------------------------------------------------------
+     HTTP transactions */
   inkapi INKReturnCode INKHttpTxnHookAdd(INKHttpTxn txnp, INKHttpHookID id, INKCont contp);
   inkapi INKHttpSsn INKHttpTxnSsnGet(INKHttpTxn txnp);
   inkapi int INKHttpTxnClientReqGet(INKHttpTxn txnp, INKMBuffer * bufp, INKMLoc * offset);
@@ -2060,8 +2022,8 @@ extern "C"
 
   inkapi INKServerState INKHttpTxnServerStateGet(INKHttpTxn txnp);
 
-  // --------------------------------------------------------------------------
-  // Intercepting Http Transactions
+  /* --------------------------------------------------------------------------
+     Intercepting Http Transactions */
 
   /**
       Allows a plugin take over the servicing of the request as though
@@ -2121,9 +2083,8 @@ extern "C"
    */
   inkapi INKReturnCode INKHttpTxnServerIntercept(INKCont contp, INKHttpTxn txnp);
 
-  // --------------------------------------------------------------------------
-  // Initiate Http Connection
-
+  /* --------------------------------------------------------------------------
+     Initiate Http Connection */
   /**
       Allows the plugin to initiate an http connection. The INKVConn the
       plugin receives as the result of successful operates identically to
@@ -2149,23 +2110,20 @@ extern "C"
   /* Check if HTTP State machine is internal or not */
   inkapi int INKHttpIsInternalRequest(INKHttpTxn txnp);
 
-  // --------------------------------------------------------------------------
-  // HTTP alternate selection
-
+  /* --------------------------------------------------------------------------
+     HTTP alternate selection */
   inkapi INKReturnCode INKHttpAltInfoClientReqGet(INKHttpAltInfo infop, INKMBuffer * bufp, INKMLoc * offset);
   inkapi INKReturnCode INKHttpAltInfoCachedReqGet(INKHttpAltInfo infop, INKMBuffer * bufp, INKMLoc * offset);
   inkapi INKReturnCode INKHttpAltInfoCachedRespGet(INKHttpAltInfo infop, INKMBuffer * bufp, INKMLoc * offset);
   inkapi INKReturnCode INKHttpAltInfoQualitySet(INKHttpAltInfo infop, float quality);
 
-  // --------------------------------------------------------------------------
-  // Actions
-
+  /* --------------------------------------------------------------------------
+     Actions */
   inkapi INKReturnCode INKActionCancel(INKAction actionp);
   inkapi int INKActionDone(INKAction actionp);
 
-  // --------------------------------------------------------------------------
-  // VConnections
-
+  /* --------------------------------------------------------------------------
+     VConnections */
   inkapi INKVIO INKVConnReadVIOGet(INKVConn connp);
   inkapi INKVIO INKVConnWriteVIOGet(INKVConn connp);
   inkapi int INKVConnClosedGet(INKVConn connp);
@@ -2176,20 +2134,17 @@ extern "C"
   inkapi INKReturnCode INKVConnAbort(INKVConn connp, int error);
   inkapi INKReturnCode INKVConnShutdown(INKVConn connp, int read, int write);
 
-  // --------------------------------------------------------------------------
-  // Cache VConnections
-
+  /* --------------------------------------------------------------------------
+     Cache VConnections */
   inkapi INKReturnCode INKVConnCacheObjectSizeGet(INKVConn connp, int *obj_size);
 
-  // --------------------------------------------------------------------------
-  // Transformations
-
+  /* --------------------------------------------------------------------------
+     Transformations */
   inkapi INKVConn INKTransformCreate(INKEventFunc event_funcp, INKHttpTxn txnp);
   inkapi INKVConn INKTransformOutputVConnGet(INKVConn connp);
 
-  // --------------------------------------------------------------------------
-  // Net VConnections
-
+  /* --------------------------------------------------------------------------
+     Net VConnections */
   /**
       Returns the IP address of the remote host with which Traffic Server
       is connected through the vconnection vc.
@@ -2233,15 +2188,13 @@ extern "C"
 
   inkapi INKAction INKNetAccept(INKCont contp, int port);
 
-  // --------------------------------------------------------------------------
-  // DNS Lookups
-
+  /* --------------------------------------------------------------------------
+     DNS Lookups */
   inkapi INKAction INKHostLookup(INKCont contp, char *hostname, int namelen);
   inkapi INKReturnCode INKHostLookupResultIPGet(INKHostLookupResult lookup_result, unsigned int *ip);
 
-  // --------------------------------------------------------------------------
-  // Cache VConnections
-
+  /* --------------------------------------------------------------------------
+     Cache VConnections */
   /**
       Asks the Traffic Server cache if the object corresponding to key
       exists in the cache and can be read. If the object can be read,
@@ -2319,9 +2272,8 @@ extern "C"
   inkapi INKReturnCode INKCacheReady(int *is_ready);
   inkapi INKAction INKCacheScan(INKCont contp, INKCacheKey key, int KB_per_second);
 
-  // --------------------------------------------------------------------------
-  // VIOs
-
+  /* --------------------------------------------------------------------------
+     VIOs */
   inkapi INKReturnCode INKVIOReenable(INKVIO viop);
   inkapi INKIOBuffer INKVIOBufferGet(INKVIO viop);
   inkapi INKIOBufferReader INKVIOReaderGet(INKVIO viop);
@@ -2334,9 +2286,8 @@ extern "C"
   inkapi INKCont INKVIOContGet(INKVIO viop);
   inkapi INKVConn INKVIOVConnGet(INKVIO viop);
 
-  // --------------------------------------------------------------------------
-  // Buffers
-
+  /* --------------------------------------------------------------------------
+     Buffers */
   inkapi INKIOBuffer INKIOBufferCreate(void);
 
   /**
@@ -2413,9 +2364,8 @@ extern "C"
   inkapi INKReturnCode INKIOBufferReaderConsume(INKIOBufferReader readerp, int nbytes);
   inkapi int INKIOBufferReaderAvail(INKIOBufferReader readerp);
 
-  // --------------------------------------------------------------------------
-  // stats
-
+  /* --------------------------------------------------------------------------
+     stats */
   typedef enum
   {
     INKSTAT_TYPE_INT64,
@@ -2425,9 +2375,8 @@ extern "C"
   typedef void *INKStat;
   typedef void *INKCoupledStat;
 
-  // --------------------------------------------------------------------------
-  // uncoupled stats
-
+  /* --------------------------------------------------------------------------
+     uncoupled stats */
   inkapi INKStat INKStatCreate(const char *the_name, INKStatTypes the_type);
   inkapi INKReturnCode INKStatIntAddTo(INKStat the_stat, INK64 amount);
   inkapi INKReturnCode INKStatFloatAddTo(INKStat the_stat, float amount);
@@ -2445,9 +2394,8 @@ extern "C"
   inkapi INKReturnCode INKStatIntSet(INKStat the_stat, INK64 value);
   inkapi INKReturnCode INKStatFloatSet(INKStat the_stat, float value);
 
-  // --------------------------------------------------------------------------
-  // coupled stats
-
+  /* --------------------------------------------------------------------------
+     coupled stats */
   inkapi INKCoupledStat INKStatCoupledGlobalCategoryCreate(const char *the_name);
   inkapi INKCoupledStat INKStatCoupledLocalCopyCreate(const char *the_name, INKCoupledStat global_copy);
   inkapi INKReturnCode INKStatCoupledLocalCopyDestroy(INKCoupledStat local_copy);
@@ -2466,16 +2414,16 @@ extern "C"
   inkapi INKReturnCode     INKStatGetV2(uint32_t stat_num, INK64 *stat_val);
   inkapi INKReturnCode     INKStatGetByNameV2(const char *stat_name, INK64 *stat_val);
 
-  // --------------------------------------------------------------------------
-  // tracing api
+  /* --------------------------------------------------------------------------
+     tracing api */
 
   inkapi int INKIsDebugTagSet(const char *t);
   inkapi void INKDebug(const char *tag, const char *format_str, ...);
   extern int diags_on_for_plugins;
 #define INKDEBUG if (diags_on_for_plugins) INKDebug
 
-  // --------------------------------------------------------------------------
-  // logging api
+  /* --------------------------------------------------------------------------
+     logging api */
 
   /**
       The following enum values are flags, so they should be powers
@@ -2625,11 +2573,11 @@ extern "C"
    */
   inkapi INKReturnCode INKTextLogObjectRollingOffsetHrSet(INKTextLogObject the_object, int rolling_offset_hr);
 
-  // --------------------------------------------------------------------------
-  // Deprecated Functions
-  // Use of the following functions is strongly discouraged. These
-  // functions may incur performance penalties and may not be supported
-  // in future releases.
+  /* --------------------------------------------------------------------------
+     Deprecated Functions
+     Use of the following functions is strongly discouraged. These
+     functions may incur performance penalties and may not be supported
+     in future releases. */
 
   /** @deprecated
       The reason is even if VConn is created using this API, it is
@@ -2660,8 +2608,8 @@ extern "C"
    */
   inkapi INKVConn INKVConnCreate(INKEventFunc event_funcp, INKMutex mutexp);
 
-  // --------------------------------------------------------------------------
-  // Deprecated Buffer Functions
+  /* --------------------------------------------------------------------------
+     Deprecated Buffer Functions */
 
   /** @deprecated */
   inkapi INKReturnCode INKIOBufferAppend(INKIOBuffer bufp, INKIOBufferBlock blockp);
@@ -2672,8 +2620,8 @@ extern "C"
   /** @deprecated */
   inkapi INKIOBufferBlock INKIOBufferBlockCreate(INKIOBufferData datap, int size, int offset);
 
-  // --------------------------------------------------------------------------
-  // Deprecated MBuffer functions
+  /* --------------------------------------------------------------------------
+     Deprecated MBuffer functions */
 
   /** @deprecated */
   inkapi int INKMBufferDataSet(INKMBuffer bufp, void *data);
@@ -2693,14 +2641,14 @@ extern "C"
   /** @deprecated */
   inkapi void INKMBufferCompress(INKMBuffer bufp);
 
-  // --------------------------------------------------------------------------
-  // YTS Team, yamsat Plugin
+  /* --------------------------------------------------------------------------
+     YTS Team, yamsat Plugin */
 
   /** @deprecated */
   inkapi int INKHttpTxnCreateRequest(INKHttpTxn txnp, const char *, const char *, int);
 
-  // --------------------------------------------------------------------------
-  // Deprecated MIME field functions --- use INKMimeHdrFieldXXX instead
+  /* --------------------------------------------------------------------------
+     Deprecated MIME field functions --- use INKMimeHdrFieldXXX instead */
 
   /** @deprecated */
   inkapi INKMLoc INKMimeFieldCreate(INKMBuffer bufp);
@@ -2775,8 +2723,8 @@ extern "C"
   /** @deprecated */
   inkapi void INKMimeFieldValueDelete(INKMBuffer bufp, INKMLoc offset, int idx);
 
-  // --------------------------------------------------------------------------
-  // Deprecated MIME field functions in SDK3.0
+  /* --------------------------------------------------------------------------
+     Deprecated MIME field functions in SDK3.0 */
 
   /** @deprecated Use INKMimeHdrFieldAppend() instead */
   inkapi INKReturnCode INKMimeHdrFieldInsert(INKMBuffer bufp, INKMLoc hdr, INKMLoc field, int idx);
@@ -2823,8 +2771,8 @@ extern "C"
   /** @deprecated */
   inkapi INKReturnCode INKCacheBufferInfoGet(INKCacheTxn txnp, INKU64 * length, INKU64 * offset);
 
-  // --------------------------------------------------------------------------
-  // cache http info APIs
+  /* --------------------------------------------------------------------------
+     cache http info APIs */
 
   /** @deprecated */
   inkapi INKCacheHttpInfo INKCacheHttpInfoCreate();