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/11/16 21:22:08 UTC

svn commit: r1035782 [13/29] - in /trafficserver/traffic/trunk: example/add-header/ example/append-transform/ example/basic-auth/ example/blacklist-0/ example/blacklist-1/ example/bnull-transform/ example/cache_plugin/ example/cache_scan/ example/file-...

Modified: trafficserver/traffic/trunk/proxy/hdrs/MIME.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/proxy/hdrs/MIME.cc?rev=1035782&r1=1035781&r2=1035782&view=diff
==============================================================================
--- trafficserver/traffic/trunk/proxy/hdrs/MIME.cc (original)
+++ trafficserver/traffic/trunk/proxy/hdrs/MIME.cc Tue Nov 16 20:22:02 2010
@@ -1090,9 +1090,9 @@ mime_hdr_destroy(HdrHeap * heap, MIMEHdr
 {
   mime_hdr_destroy_field_block_list(heap, mh->m_first_fblock.m_next);
 
-  // INKqa11458: if we deallocate mh here and call INKMLocRelease
+  // INKqa11458: if we deallocate mh here and call TSMLocRelease
   // again, the plugin fails in assert. We leave deallocating to
-  // the plugin using INKMLocRelease
+  // the plugin using TSMLocRelease
 
   //heap->deallocate_obj(mh);
 }

Modified: trafficserver/traffic/trunk/proxy/http2/HttpClientSession.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/proxy/http2/HttpClientSession.cc?rev=1035782&r1=1035781&r2=1035782&view=diff
==============================================================================
--- trafficserver/traffic/trunk/proxy/http2/HttpClientSession.cc (original)
+++ trafficserver/traffic/trunk/proxy/http2/HttpClientSession.cc Tue Nov 16 20:22:02 2010
@@ -63,7 +63,7 @@ con_id(0), client_vc(NULL), magic(HTTP_C
 transact_count(0), half_close(false), conn_decrease(false), bound_ss(NULL),
 read_buffer(NULL), current_reader(NULL), read_state(HCS_INIT),
 ka_vio(NULL), slave_ka_vio(NULL),
-cur_hook_id(INK_HTTP_LAST_HOOK), cur_hook(NULL),
+cur_hook_id(TS_HTTP_LAST_HOOK), cur_hook(NULL),
 cur_hooks(0), backdoor_connect(false), hooks_set(0),
 //session_based_auth(false), m_bAuthComplete(false), secCtx(NULL), m_active(false)
 session_based_auth(false), m_bAuthComplete(false), m_active(false)
@@ -122,7 +122,7 @@ HttpClientSession::allocate()
 }
 
 void
-HttpClientSession::ssn_hook_append(INKHttpHookID id, INKContInternal * cont)
+HttpClientSession::ssn_hook_append(TSHttpHookID id, INKContInternal * cont)
 {
   api_hooks.append(id, cont);
   hooks_set = 1;
@@ -133,7 +133,7 @@ HttpClientSession::ssn_hook_append(INKHt
 }
 
 void
-HttpClientSession::ssn_hook_prepend(INKHttpHookID id, INKContInternal * cont)
+HttpClientSession::ssn_hook_prepend(TSHttpHookID id, INKContInternal * cont)
 {
   api_hooks.prepend(id, cont);
   hooks_set = 1;
@@ -169,11 +169,11 @@ HttpClientSession::new_transaction()
 }
 
 inline void
-HttpClientSession::do_api_callout(INKHttpHookID id)
+HttpClientSession::do_api_callout(TSHttpHookID id)
 {
 
   cur_hook_id = id;
-  ink_assert(cur_hook_id == INK_HTTP_SSN_START_HOOK || cur_hook_id == INK_HTTP_SSN_CLOSE_HOOK);
+  ink_assert(cur_hook_id == TS_HTTP_SSN_START_HOOK || cur_hook_id == TS_HTTP_SSN_CLOSE_HOOK);
 
   if (hooks_set && backdoor_connect == 0) {
     SET_HANDLER(&HttpClientSession::state_api_callout);
@@ -227,7 +227,7 @@ HttpClientSession::new_connection(NetVCo
   EThread *ethis = this_ethread();
   ProxyMutexPtr lmutex = this->mutex;
   MUTEX_TAKE_LOCK(lmutex, ethis);
-  do_api_callout(INK_HTTP_SSN_START_HOOK);
+  do_api_callout(TS_HTTP_SSN_START_HOOK);
   MUTEX_UNTAKE_LOCK(lmutex, ethis);
   lmutex.clear();
 }
@@ -306,7 +306,7 @@ HttpClientSession::do_io_close(int alerr
     HTTP_SUM_DYN_STAT(http_transactions_per_client_con, transact_count);
     HTTP_DECREMENT_DYN_STAT(http_current_client_connections_stat);
     conn_decrease = false;
-    do_api_callout(INK_HTTP_SSN_CLOSE_HOOK);
+    do_api_callout(TS_HTTP_SSN_CLOSE_HOOK);
   }
 }
 
@@ -431,7 +431,7 @@ HttpClientSession::state_api_callout(int
   case EVENT_NONE:
   case EVENT_INTERVAL:
   case HTTP_API_CONTINUE:
-    if ((cur_hook_id >= 0) && (cur_hook_id < INK_HTTP_LAST_HOOK)) {
+    if ((cur_hook_id >= 0) && (cur_hook_id < TS_HTTP_LAST_HOOK)) {
       if (!cur_hook) {
         if (cur_hooks == 0) {
           cur_hook = http_global_hooks->get(cur_hook_id);
@@ -463,7 +463,7 @@ HttpClientSession::state_api_callout(int
         APIHook *hook = cur_hook;
         cur_hook = cur_hook->next();
 
-        hook->invoke(INK_EVENT_HTTP_READ_REQUEST_HDR + cur_hook_id, this);
+        hook->invoke(TS_EVENT_HTTP_READ_REQUEST_HDR + cur_hook_id, this);
 
         if (plugin_lock) {
           // BZ 51246
@@ -496,14 +496,14 @@ HttpClientSession::handle_api_return(int
   cur_hooks = 0;
 
   switch (cur_hook_id) {
-  case INK_HTTP_SSN_START_HOOK:
+  case TS_HTTP_SSN_START_HOOK:
     if (event != HTTP_API_ERROR) {
       new_transaction();
     } else {
       do_io_close();
     }
     break;
-  case INK_HTTP_SSN_CLOSE_HOOK:
+  case TS_HTTP_SSN_CLOSE_HOOK:
     destroy();
     break;
   default:

Modified: trafficserver/traffic/trunk/proxy/http2/HttpClientSession.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/proxy/http2/HttpClientSession.h?rev=1035782&r1=1035781&r2=1035782&view=diff
==============================================================================
--- trafficserver/traffic/trunk/proxy/http2/HttpClientSession.h (original)
+++ trafficserver/traffic/trunk/proxy/http2/HttpClientSession.h Tue Nov 16 20:22:02 2010
@@ -86,9 +86,9 @@ public:
   HttpServerSession *get_bound_ss();
 
   // Functions for manipulating api hooks
-  void ssn_hook_append(INKHttpHookID id, INKContInternal * cont);
-  void ssn_hook_prepend(INKHttpHookID id, INKContInternal * cont);
-  APIHook *ssn_hook_get(INKHttpHookID id);
+  void ssn_hook_append(TSHttpHookID id, INKContInternal * cont);
+  void ssn_hook_prepend(TSHttpHookID id, INKContInternal * cont);
+  APIHook *ssn_hook_get(TSHttpHookID id);
 
   // Used to verify we are recording the current
   //   client transaction stat properly
@@ -108,7 +108,7 @@ private:
 
   void handle_api_return(int event);
   int state_api_callout(int event, void *data);
-  void do_api_callout(INKHttpHookID id);
+  void do_api_callout(TSHttpHookID id);
 
   virtual void new_transaction();
 
@@ -139,7 +139,7 @@ private:
 
   Link<HttpClientSession> debug_link;
 
-  INKHttpHookID cur_hook_id;
+  TSHttpHookID cur_hook_id;
   APIHook *cur_hook;
   int cur_hooks;
 
@@ -165,7 +165,7 @@ public:
 };
 
 inline APIHook *
-HttpClientSession::ssn_hook_get(INKHttpHookID id)
+HttpClientSession::ssn_hook_get(TSHttpHookID id)
 {
   return api_hooks.get(id);
 }

Modified: trafficserver/traffic/trunk/proxy/http2/HttpDebugNames.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/proxy/http2/HttpDebugNames.cc?rev=1035782&r1=1035781&r2=1035782&view=diff
==============================================================================
--- trafficserver/traffic/trunk/proxy/http2/HttpDebugNames.cc (original)
+++ trafficserver/traffic/trunk/proxy/http2/HttpDebugNames.cc Tue Nov 16 20:22:02 2010
@@ -452,44 +452,43 @@ HttpDebugNames::get_cache_action_name(Ht
 //
 //////////////////////////////////////////////////////////////////
 const char *
-HttpDebugNames::get_api_hook_name(INKHttpHookID t)
+HttpDebugNames::get_api_hook_name(TSHttpHookID t)
 {
-
   switch (t) {
-  case INK_HTTP_READ_REQUEST_HDR_HOOK:
-    return "INK_HTTP_READ_REQUEST_HDR_HOOK";
-  case INK_HTTP_OS_DNS_HOOK:
-    return "INK_HTTP_OS_DNS_HOOK";
-  case INK_HTTP_SEND_REQUEST_HDR_HOOK:
-    return "INK_HTTP_SEND_REQUEST_HDR_HOOK";
-  case INK_HTTP_READ_CACHE_HDR_HOOK:
-    return "INK_HTTP_READ_CACHE_HDR_HOOK";
-  case INK_HTTP_CACHE_LOOKUP_COMPLETE_HOOK:
-    return "INK_HTTP_CACHE_LOOKUP_COMPLETE_HOOK";
-  case INK_HTTP_READ_RESPONSE_HDR_HOOK:
-    return "INK_HTTP_READ_RESPONSE_HDR_HOOK";
-  case INK_HTTP_SEND_RESPONSE_HDR_HOOK:
-    return "INK_HTTP_SEND_RESPONSE_HDR_HOOK";
-  case INK_HTTP_REQUEST_TRANSFORM_HOOK:
-    return "INK_HTTP_REQUEST_TRANSFORM_HOOK";
-  case INK_HTTP_RESPONSE_TRANSFORM_HOOK:
-    return "INK_HTTP_RESPONSE_TRANSFORM_HOOK";
-  case INK_HTTP_SELECT_ALT_HOOK:
-    return "INK_HTTP_SELECT_ALT_HOOK";
-  case INK_HTTP_TXN_START_HOOK:
-    return "INK_HTTP_TXN_START_HOOK";
-  case INK_HTTP_TXN_CLOSE_HOOK:
-    return "INK_HTTP_TXN_CLOSE_HOOK";
-  case INK_HTTP_SSN_START_HOOK:
-    return "INK_HTTP_SSN_START_HOOK";
-  case INK_HTTP_SSN_CLOSE_HOOK:
-    return "INK_HTTP_SSN_CLOSE_HOOK";
-  case INK_HTTP_PRE_REMAP_HOOK:
-    return "INK_HTTP_PRE_REMAP_HOOK";
-  case INK_HTTP_POST_REMAP_HOOK:
-    return "INK_HTTP_POST_REMAP_HOOK";
-  case INK_HTTP_LAST_HOOK:
-    return "INK_HTTP_LAST_HOOK";
+  case TS_HTTP_READ_REQUEST_HDR_HOOK:
+    return "TS_HTTP_READ_REQUEST_HDR_HOOK";
+  case TS_HTTP_OS_DNS_HOOK:
+    return "TS_HTTP_OS_DNS_HOOK";
+  case TS_HTTP_SEND_REQUEST_HDR_HOOK:
+    return "TS_HTTP_SEND_REQUEST_HDR_HOOK";
+  case TS_HTTP_READ_CACHE_HDR_HOOK:
+    return "TS_HTTP_READ_CACHE_HDR_HOOK";
+  case TS_HTTP_CACHE_LOOKUP_COMPLETE_HOOK:
+    return "TS_HTTP_CACHE_LOOKUP_COMPLETE_HOOK";
+  case TS_HTTP_READ_RESPONSE_HDR_HOOK:
+    return "TS_HTTP_READ_RESPONSE_HDR_HOOK";
+  case TS_HTTP_SEND_RESPONSE_HDR_HOOK:
+    return "TS_HTTP_SEND_RESPONSE_HDR_HOOK";
+  case TS_HTTP_REQUEST_TRANSFORM_HOOK:
+    return "TS_HTTP_REQUEST_TRANSFORM_HOOK";
+  case TS_HTTP_RESPONSE_TRANSFORM_HOOK:
+    return "TS_HTTP_RESPONSE_TRANSFORM_HOOK";
+  case TS_HTTP_SELECT_ALT_HOOK:
+    return "TS_HTTP_SELECT_ALT_HOOK";
+  case TS_HTTP_TXN_START_HOOK:
+    return "TS_HTTP_TXN_START_HOOK";
+  case TS_HTTP_TXN_CLOSE_HOOK:
+    return "TS_HTTP_TXN_CLOSE_HOOK";
+  case TS_HTTP_SSN_START_HOOK:
+    return "TS_HTTP_SSN_START_HOOK";
+  case TS_HTTP_SSN_CLOSE_HOOK:
+    return "TS_HTTP_SSN_CLOSE_HOOK";
+  case TS_HTTP_PRE_REMAP_HOOK:
+    return "TS_HTTP_PRE_REMAP_HOOK";
+  case TS_HTTP_POST_REMAP_HOOK:
+    return "TS_HTTP_POST_REMAP_HOOK";
+  case TS_HTTP_LAST_HOOK:
+    return "TS_HTTP_LAST_HOOK";
   }
 
   return "unknown hook";

Modified: trafficserver/traffic/trunk/proxy/http2/HttpDebugNames.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/proxy/http2/HttpDebugNames.h?rev=1035782&r1=1035781&r2=1035782&view=diff
==============================================================================
--- trafficserver/traffic/trunk/proxy/http2/HttpDebugNames.h (original)
+++ trafficserver/traffic/trunk/proxy/http2/HttpDebugNames.h Tue Nov 16 20:22:02 2010
@@ -34,7 +34,7 @@ public:
   static const char *get_action_name(HttpTransact::StateMachineAction_t e);
   static const char *get_method_name(const char *method);
   static const char *get_cache_action_name(HttpTransact::CacheAction_t t);
-  static const char *get_api_hook_name(INKHttpHookID t);
+  static const char *get_api_hook_name(TSHttpHookID t);
   static const char *get_server_state_name(HttpTransact::ServerState_t state);
 };
 

Modified: trafficserver/traffic/trunk/proxy/http2/HttpProxyServerMain.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/proxy/http2/HttpProxyServerMain.cc?rev=1035782&r1=1035781&r2=1035782&view=diff
==============================================================================
--- trafficserver/traffic/trunk/proxy/http2/HttpProxyServerMain.cc (original)
+++ trafficserver/traffic/trunk/proxy/http2/HttpProxyServerMain.cc Tue Nov 16 20:22:02 2010
@@ -222,7 +222,7 @@ init_HttpProxyServer(void)
   // INKqa11918
   init_max_chunk_buf();
 
-#ifndef INK_NO_API
+#ifndef TS_NO_API
   // Used to give plugins the ability to create http requests
   //   The equivalent of the connecting to localhost on the  proxy
   //   port but without going through the operating system

Modified: trafficserver/traffic/trunk/proxy/http2/HttpSM.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/proxy/http2/HttpSM.cc?rev=1035782&r1=1035781&r2=1035782&view=diff
==============================================================================
--- trafficserver/traffic/trunk/proxy/http2/HttpSM.cc (original)
+++ trafficserver/traffic/trunk/proxy/http2/HttpSM.cc Tue Nov 16 20:22:02 2010
@@ -336,7 +336,7 @@ HttpSM::HttpSM()
     server_response_hdr_bytes(0), server_response_body_bytes(0),
     client_response_hdr_bytes(0), client_response_body_bytes(0),
     pushed_response_hdr_bytes(0), pushed_response_body_bytes(0),
-    hooks_set(0), cur_hook_id(INK_HTTP_LAST_HOOK), cur_hook(NULL),
+    hooks_set(0), cur_hook_id(TS_HTTP_LAST_HOOK), cur_hook(NULL),
     // TODO: This needs to be supported with non-V2 APIs as well.
 #if TS_HAS_V2STATS
     prev_hook_start_time(0),
@@ -1352,7 +1352,7 @@ HttpSM::state_api_callout(int event, voi
     // FALLTHROUGH
   case EVENT_NONE:
   case HTTP_API_CONTINUE:
-    if ((cur_hook_id >= 0) && (cur_hook_id < INK_HTTP_LAST_HOOK)) {
+    if ((cur_hook_id >= 0) && (cur_hook_id < TS_HTTP_LAST_HOOK)) {
       if (!cur_hook) {
         if (cur_hooks == 0) {
           cur_hook = http_global_hooks->get(cur_hook_id);
@@ -1416,7 +1416,7 @@ HttpSM::state_api_callout(int event, voi
         hook->m_cont->statCallsMade(cur_hook_id);
 
         // Stat time spent in previous plugin
-        int64 curr_time = INKhrtime();
+        int64 curr_time = ink_get_based_hrtime();
         // TODO: This needs to be supported with non-V2 APIs as well.
         if(prev_hook_stats_enabled && prev_hook_start_time) {
           int64 time_in_plugin_ms = (curr_time - prev_hook_start_time)/1000000;
@@ -1434,7 +1434,7 @@ HttpSM::state_api_callout(int event, voi
           prev_hook_stats = hook->m_cont->cont_time_stats[cur_hook_id];
 #endif
 
-        hook->invoke(INK_EVENT_HTTP_READ_REQUEST_HDR + cur_hook_id, this);
+        hook->invoke(TS_EVENT_HTTP_READ_REQUEST_HDR + cur_hook_id, this);
 
         if (plugin_lock) {
           Mutex_unlock(plugin_mutex, mutex->thread_holding);
@@ -1467,7 +1467,7 @@ HttpSM::state_api_callout(int event, voi
   case HTTP_API_ERROR:
     if (callout_state == HTTP_API_DEFERED_CLOSE) {
       api_next = API_RETURN_DEFERED_CLOSE;
-    } else if (cur_hook_id == INK_HTTP_TXN_CLOSE_HOOK) {
+    } else if (cur_hook_id == TS_HTTP_TXN_CLOSE_HOOK) {
       // If we are closing the state machine, we can't
       //   jump to an error state so just continue
       api_next = API_RETURN_CONTINUE;
@@ -1514,7 +1514,7 @@ HttpSM::state_api_callout(int event, voi
     // TODO: This needs to be supported with non-V2 APIs as well.
 #if TS_HAS_V2STATS
     if(prev_hook_stats_enabled && prev_hook_start_time) {
-      int64 time_in_plugin_ms = (INKhrtime() - prev_hook_start_time)/1000000;
+      int64 time_in_plugin_ms = (ink_get_based_hrtime() - prev_hook_start_time)/1000000;
       Debug("http", "[%lld] Last plugin : Time spent : %s %lld", 
             sm_id, HttpDebugNames::get_api_hook_name(cur_hook_id), time_in_plugin_ms);
       prev_hook_stats.inc(time_in_plugin_ms);
@@ -3940,7 +3940,7 @@ HttpSM::do_hostdb_update_if_necessary()
 
 // this function first checks if cached response has Accept-Ranges and
 // Content-Length header and is HTTP/1.1. && There is no other plugins
-// hooked to INK_HTTP_RESPONSE_TRANSFORM_HOOK.
+// hooked to TS_HTTP_RESPONSE_TRANSFORM_HOOK.
 // Then setup Range transformation if necessary
 void
 HttpSM::do_range_setup_if_necessary()
@@ -3956,13 +3956,13 @@ HttpSM::do_range_setup_if_necessary()
 
   t_state.range_setup = HttpTransact::RANGE_NONE;
   if (t_state.method == HTTP_WKSIDX_GET && t_state.hdr_info.client_request.version_get() == HTTPVersion(1, 1)) {
-    if (api_hooks.get(INK_HTTP_RESPONSE_TRANSFORM_HOOK) == NULL) {
+    if (api_hooks.get(TS_HTTP_RESPONSE_TRANSFORM_HOOK) == NULL) {
       // We may still not do Range if it is out of order Range.
       range_trans = transformProcessor.range_transform(mutex, field,
                                                        t_state.cache_info.object_read,
                                                        &t_state.hdr_info.transform_response, res);
       if (range_trans != NULL) {
-        api_hooks.append(INK_HTTP_RESPONSE_TRANSFORM_HOOK, range_trans);
+        api_hooks.append(TS_HTTP_RESPONSE_TRANSFORM_HOOK, range_trans);
         t_state.range_setup = HttpTransact::RANGE_TRANSFORM;
       } else if (res)
         t_state.range_setup = HttpTransact::RANGE_NOT_SATISFIABLE;
@@ -4037,7 +4037,7 @@ HttpSM::do_cache_delete_all_alts(Continu
 
   Action *cache_action_handle = NULL;
 
-  if (!cont && cache_global_hooks->get(INK_CACHE_PLUGIN_HOOK)) {
+  if (!cont && cache_global_hooks->get(TS_CACHE_PLUGIN_HOOK)) {
     // cache plugin, must pass a continuation
     cacheProcessor.remove(&cache_sm, t_state.cache_info.lookup_url);
   } else {
@@ -4415,46 +4415,46 @@ HttpSM::do_api_callout_internal()
 
   switch (t_state.api_next_action) {
   case HttpTransact::HTTP_API_SM_START:
-    cur_hook_id = INK_HTTP_TXN_START_HOOK;
+    cur_hook_id = TS_HTTP_TXN_START_HOOK;
     break;
   case HttpTransact::HTTP_API_PRE_REMAP:
-    cur_hook_id = INK_HTTP_PRE_REMAP_HOOK;
+    cur_hook_id = TS_HTTP_PRE_REMAP_HOOK;
     break;
   case HttpTransact::HTTP_API_POST_REMAP:
-    cur_hook_id = INK_HTTP_POST_REMAP_HOOK;
+    cur_hook_id = TS_HTTP_POST_REMAP_HOOK;
     break;
   case HttpTransact::HTTP_API_READ_REQUEST_HDR:
-    cur_hook_id = INK_HTTP_READ_REQUEST_HDR_HOOK;
+    cur_hook_id = TS_HTTP_READ_REQUEST_HDR_HOOK;
     break;
   case HttpTransact::HTTP_API_OS_DNS:
-    cur_hook_id = INK_HTTP_OS_DNS_HOOK;
+    cur_hook_id = TS_HTTP_OS_DNS_HOOK;
     break;
   case HttpTransact::HTTP_API_SEND_REQUEST_HDR:
-    cur_hook_id = INK_HTTP_SEND_REQUEST_HDR_HOOK;
+    cur_hook_id = TS_HTTP_SEND_REQUEST_HDR_HOOK;
     break;
   case HttpTransact::HTTP_API_READ_CACHE_HDR:
-    cur_hook_id = INK_HTTP_READ_CACHE_HDR_HOOK;
+    cur_hook_id = TS_HTTP_READ_CACHE_HDR_HOOK;
     break;
   case HttpTransact::HTTP_API_CACHE_LOOKUP_COMPLETE:
-    cur_hook_id = INK_HTTP_CACHE_LOOKUP_COMPLETE_HOOK;
+    cur_hook_id = TS_HTTP_CACHE_LOOKUP_COMPLETE_HOOK;
     break;
   case HttpTransact::HTTP_API_READ_REPONSE_HDR:
-    cur_hook_id = INK_HTTP_READ_RESPONSE_HDR_HOOK;
+    cur_hook_id = TS_HTTP_READ_RESPONSE_HDR_HOOK;
     break;
   case HttpTransact::HTTP_API_SEND_REPONSE_HDR:
-    cur_hook_id = INK_HTTP_SEND_RESPONSE_HDR_HOOK;
+    cur_hook_id = TS_HTTP_SEND_RESPONSE_HDR_HOOK;
     break;
   case HttpTransact::HTTP_API_SM_SHUTDOWN:
     if (callout_state == HTTP_API_IN_CALLOUT || callout_state == HTTP_API_DEFERED_SERVER_ERROR) {
       callout_state = HTTP_API_DEFERED_CLOSE;
       return;
     } else {
-      cur_hook_id = INK_HTTP_TXN_CLOSE_HOOK;
+      cur_hook_id = TS_HTTP_TXN_CLOSE_HOOK;
     }
 
     break;
   default:
-    cur_hook_id = (INKHttpHookID) - 1;
+    cur_hook_id = (TSHttpHookID) - 1;
     ink_assert(!"not reached");
   }
 
@@ -4469,10 +4469,10 @@ HttpSM::do_post_transform_open()
   ink_assert(post_transform_info.vc == NULL);
 
   if (is_action_tag_set("http_post_nullt")) {
-    txn_hook_prepend(INK_HTTP_REQUEST_TRANSFORM_HOOK, transformProcessor.null_transform(mutex));
+    txn_hook_prepend(TS_HTTP_REQUEST_TRANSFORM_HOOK, transformProcessor.null_transform(mutex));
   }
 
-  post_transform_info.vc = transformProcessor.open(this, api_hooks.get(INK_HTTP_REQUEST_TRANSFORM_HOOK));
+  post_transform_info.vc = transformProcessor.open(this, api_hooks.get(TS_HTTP_REQUEST_TRANSFORM_HOOK));
   if (post_transform_info.vc) {
     // Record the transform VC in our table
     post_transform_info.entry = vc_table.new_entry();
@@ -4490,10 +4490,10 @@ HttpSM::do_transform_open()
   APIHook *hooks;
 
   if (is_action_tag_set("http_nullt")) {
-    txn_hook_prepend(INK_HTTP_RESPONSE_TRANSFORM_HOOK, transformProcessor.null_transform(mutex));
+    txn_hook_prepend(TS_HTTP_RESPONSE_TRANSFORM_HOOK, transformProcessor.null_transform(mutex));
   }
 
-  hooks = api_hooks.get(INK_HTTP_RESPONSE_TRANSFORM_HOOK);
+  hooks = api_hooks.get(TS_HTTP_RESPONSE_TRANSFORM_HOOK);
   if (hooks) {
     transform_info.vc = transformProcessor.open(this, hooks);
 
@@ -6053,7 +6053,7 @@ HttpSM::setup_blind_tunnel(bool send_res
 }
 
 inline void
-HttpSM::transform_cleanup(INKHttpHookID hook, HttpTransformInfo * info)
+HttpSM::transform_cleanup(TSHttpHookID hook, HttpTransformInfo * info)
 {
   APIHook *t_hook = api_hooks.get(hook);
   if (t_hook && info->vc == NULL) {
@@ -6127,8 +6127,8 @@ HttpSM::kill_this()
     //   In that case, we need to manually close all the
     //   transforms to prevent memory leaks (INKqa06147)
     if (hooks_set) {
-      transform_cleanup(INK_HTTP_RESPONSE_TRANSFORM_HOOK, &transform_info);
-      transform_cleanup(INK_HTTP_REQUEST_TRANSFORM_HOOK, &post_transform_info);
+      transform_cleanup(TS_HTTP_RESPONSE_TRANSFORM_HOOK, &transform_info);
+      transform_cleanup(TS_HTTP_REQUEST_TRANSFORM_HOOK, &post_transform_info);
     }
     // It's also possible that the plugin_tunnel vc was never
     //   executed due to not contacting the server

Modified: trafficserver/traffic/trunk/proxy/http2/HttpSM.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/proxy/http2/HttpSM.h?rev=1035782&r1=1035781&r2=1035782&view=diff
==============================================================================
--- trafficserver/traffic/trunk/proxy/http2/HttpSM.h (original)
+++ trafficserver/traffic/trunk/proxy/http2/HttpSM.h Tue Nov 16 20:22:02 2010
@@ -255,9 +255,9 @@ public:
   void dump_state_hdr(HTTPHdr *h, const char *s);
 
   // Functions for manipulating api hooks
-  void txn_hook_append(INKHttpHookID id, INKContInternal * cont);
-  void txn_hook_prepend(INKHttpHookID id, INKContInternal * cont);
-  APIHook *txn_hook_get(INKHttpHookID id);
+  void txn_hook_append(TSHttpHookID id, INKContInternal * cont);
+  void txn_hook_prepend(TSHttpHookID id, INKContInternal * cont);
+  APIHook *txn_hook_get(TSHttpHookID id);
 
   void add_history_entry(const char *fileline, int event, int reentrant);
   void add_cache_sm();
@@ -495,7 +495,7 @@ public:
   int hooks_set;
 
 protected:
-  INKHttpHookID cur_hook_id;
+  TSHttpHookID cur_hook_id;
   APIHook *cur_hook;
 
   //
@@ -524,7 +524,7 @@ protected:
   virtual int kill_this_async_hook(int event, void *data);
   void kill_this();
   void update_stats();
-  void transform_cleanup(INKHttpHookID hook, HttpTransformInfo * info);
+  void transform_cleanup(TSHttpHookID hook, HttpTransformInfo * info);
 
 public:
   LINK(HttpSM, debug_link);
@@ -593,21 +593,21 @@ HttpSM::find_server_buffer_size()
 }
 
 inline void
-HttpSM::txn_hook_append(INKHttpHookID id, INKContInternal * cont)
+HttpSM::txn_hook_append(TSHttpHookID id, INKContInternal * cont)
 {
   api_hooks.append(id, cont);
   hooks_set = 1;
 }
 
 inline void
-HttpSM::txn_hook_prepend(INKHttpHookID id, INKContInternal * cont)
+HttpSM::txn_hook_prepend(TSHttpHookID id, INKContInternal * cont)
 {
   api_hooks.prepend(id, cont);
   hooks_set = 1;
 }
 
 inline APIHook *
-HttpSM::txn_hook_get(INKHttpHookID id)
+HttpSM::txn_hook_get(TSHttpHookID id)
 {
   return api_hooks.get(id);
 }

Modified: trafficserver/traffic/trunk/proxy/http2/HttpTransact.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/proxy/http2/HttpTransact.cc?rev=1035782&r1=1035781&r2=1035782&view=diff
==============================================================================
--- trafficserver/traffic/trunk/proxy/http2/HttpTransact.cc (original)
+++ trafficserver/traffic/trunk/proxy/http2/HttpTransact.cc Tue Nov 16 20:22:02 2010
@@ -1304,7 +1304,7 @@ HttpTransact::HandleApiErrorJump(State *
   Debug("http_trans", "[HttpTransact::HandleApiErrorJump]");
 
   // since the READ_REQUEST_HDR_HOOK is processed before
-  //   we examine the request, returning INK_EVENT_ERROR will cause
+  //   we examine the request, returning TS_EVENT_ERROR will cause
   //   the protocol in the via string to be "?"  Set it here
   //   since we know it has to be http
   // For CONNECT method, next_hop_scheme is NULL
@@ -4927,7 +4927,7 @@ HttpTransact::handle_transform_ready(Sta
 void
 HttpTransact::set_header_for_transform(State * s, HTTPHdr * base_header)
 {
-#ifndef INK_NO_TRANSFORM
+#ifndef TS_NO_TRANSFORM
   s->hdr_info.transform_response.create(HTTP_TYPE_RESPONSE);
   s->hdr_info.transform_response.copy(base_header);
 
@@ -4940,7 +4940,7 @@ HttpTransact::set_header_for_transform(S
     DUMP_HEADER("http_hdrs", &s->hdr_info.transform_response, s->state_machine_id, "Header To Transform");
 #else
   ink_assert(!"transformation not supported\n");
-#endif //INK_NO_TRANSFORM
+#endif // TS_NO_TRANSFORM
 }
 
 void

Modified: trafficserver/traffic/trunk/proxy/http2/HttpTransact.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/proxy/http2/HttpTransact.h?rev=1035782&r1=1035781&r2=1035782&view=diff
==============================================================================
--- trafficserver/traffic/trunk/proxy/http2/HttpTransact.h (original)
+++ trafficserver/traffic/trunk/proxy/http2/HttpTransact.h Tue Nov 16 20:22:02 2010
@@ -486,7 +486,7 @@ public:
     TOTAL_RESPONSE_ERROR_TYPES
   };
 
-  // Please do not forget to fix INKServerState (ts/ts.h)
+  // Please do not forget to fix TSServerState (ts/ts.h)
   // in case of any modifications in ServerState_t
   enum ServerState_t
   {

Modified: trafficserver/traffic/trunk/proxy/http2/HttpTransactCache.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/proxy/http2/HttpTransactCache.cc?rev=1035782&r1=1035781&r2=1035782&view=diff
==============================================================================
--- trafficserver/traffic/trunk/proxy/http2/HttpTransactCache.cc (original)
+++ trafficserver/traffic/trunk/proxy/http2/HttpTransactCache.cc Tue Nov 16 20:22:02 2010
@@ -415,7 +415,7 @@ HttpTransactCache::calculate_quality_of_
     HttpAltInfo info;
     float qvalue;
 
-    hook = http_global_hooks->get(INK_HTTP_SELECT_ALT_HOOK);
+    hook = http_global_hooks->get(TS_HTTP_SELECT_ALT_HOOK);
     if (hook) {
       info.m_client_req.copy_shallow(client_request);
       info.m_cached_req.copy_shallow(obj_client_request);
@@ -424,7 +424,7 @@ HttpTransactCache::calculate_quality_of_
 
       while (hook) {
         info.m_qvalue = 1.0;
-        hook->invoke(INK_EVENT_HTTP_SELECT_ALT, &info);
+        hook->invoke(TS_EVENT_HTTP_SELECT_ALT, &info);
         hook = hook->m_link.next;
         if (info.m_qvalue < 0.0) {
           info.m_qvalue = 0.0;

Modified: trafficserver/traffic/trunk/proxy/http2/HttpUpdateSM.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/proxy/http2/HttpUpdateSM.cc?rev=1035782&r1=1035781&r2=1035782&view=diff
==============================================================================
--- trafficserver/traffic/trunk/proxy/http2/HttpUpdateSM.cc (original)
+++ trafficserver/traffic/trunk/proxy/http2/HttpUpdateSM.cc Tue Nov 16 20:22:02 2010
@@ -117,7 +117,7 @@ HttpUpdateSM::handle_api_return()
   }
 
   switch (t_state.next_action) {
-#ifndef INK_NO_TRANSFORM
+#ifndef TS_NO_TRANSFORM
   case HttpTransact::TRANSFORM_READ:
     {
       if (t_state.cache_info.transform_action == HttpTransact::CACHE_DO_WRITE) {
@@ -155,7 +155,7 @@ HttpUpdateSM::handle_api_return()
       }
       break;
     }
-#endif //INK_NO_TRANSFORM
+#endif //TS_NO_TRANSFORM
   case HttpTransact::PROXY_INTERNAL_CACHE_WRITE:
   case HttpTransact::SERVER_READ:
   case HttpTransact::PROXY_INTERNAL_CACHE_NOOP:

Modified: trafficserver/traffic/trunk/proxy/mgmt2/api2/MgmtPlugin.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/proxy/mgmt2/api2/MgmtPlugin.cc?rev=1035782&r1=1035781&r2=1035782&view=diff
==============================================================================
--- trafficserver/traffic/trunk/proxy/mgmt2/api2/MgmtPlugin.cc (original)
+++ trafficserver/traffic/trunk/proxy/mgmt2/api2/MgmtPlugin.cc Tue Nov 16 20:22:02 2010
@@ -150,21 +150,21 @@ mgmt_plugin_load(int argc, char *argv[])
   handles.regist(handle);
 
   // coverity[noescape]
-  init_func_w_handle_t inith = (init_func_w_handle_t) dll_findsym(handle, "INKPluginInitwDLLHandle");
+  init_func_w_handle_t inith = (init_func_w_handle_t) dll_findsym(handle, "TSPluginInitwDLLHandle");
   if (inith) {
     inith(handle, argc, argv);
     return;
   }
 
-  init = (init_func_t) dll_findsym(handle, "INKPluginInit");
+  init = (init_func_t) dll_findsym(handle, "TSPluginInit");
   if (!init) {
-    Warning("[mgmt_plugin_load] unable to find INKPluginInit function '%s': %s", path, dll_error(handle));
+    Warning("[mgmt_plugin_load] unable to find TSPluginInit function '%s': %s", path, dll_error(handle));
     dll_close(handle);
     return;
   }
   // coverity[noescape]
   // coverity[leaked_storage]
-  init(argc, argv);             // call plug-in's INKPluginInit
+  init(argc, argv);             // call plug-in's TSPluginInit
 }
 
 //

Modified: trafficserver/traffic/trunk/test/SDKtest/client/ClientAPI.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/test/SDKtest/client/ClientAPI.h?rev=1035782&r1=1035781&r2=1035782&view=diff
==============================================================================
--- trafficserver/traffic/trunk/test/SDKtest/client/ClientAPI.h (original)
+++ trafficserver/traffic/trunk/test/SDKtest/client/ClientAPI.h Tue Nov 16 20:22:02 2010
@@ -30,45 +30,45 @@
 
 typedef enum
 {
-  INK_FID_OPTIONS_PROCESS,
-  INK_FID_OPTIONS_PROCESS_FINISH,
-  INK_FID_CONNECTION_FINISH,
-  INK_FID_PLUGIN_FINISH,
-  INK_FID_REQUEST_CREATE,
-  INK_FID_HEADER_PROCESS,
-  INK_FID_PARTIAL_BODY_PROCESS,
-  INK_FID_REPORT
-} INKPluginFuncId;
+  TS_FID_OPTIONS_PROCESS,
+  TS_FID_OPTIONS_PROCESS_FINISH,
+  TS_FID_CONNECTION_FINISH,
+  TS_FID_PLUGIN_FINISH,
+  TS_FID_REQUEST_CREATE,
+  TS_FID_HEADER_PROCESS,
+  TS_FID_PARTIAL_BODY_PROCESS,
+  TS_FID_REPORT
+} TSPluginFuncId;
 
 typedef enum
 {
-  INK_CONN_COMPLETE,
-  INK_CONN_ERR,
-  INK_READ_ERR,
-  INK_WRITE_ERR,
-  INK_TIME_EXPIRE
-} INKConnectionStatus;
+  TS_CONN_COMPLETE,
+  TS_CONN_ERR,
+  TS_READ_ERR,
+  TS_WRITE_ERR,
+  TS_TIME_EXPIRE
+} TSConnectionStatus;
 
 typedef enum
 {
-  INK_STOP_SUCCESS,
-  INK_STOP_FAIL,
-  INK_KEEP_GOING
-} INKRequestAction;
+  TS_STOP_SUCCESS,
+  TS_STOP_FAIL,
+  TS_KEEP_GOING
+} TSRequestAction;
 
 typedef enum
 {
-  INK_SUM,
-  INK_MAX,
-  INK_MIN,
-  INK_AVE
-} INKReportCombiner;
+  TS_SUM,
+  TS_MAX,
+  TS_MIN,
+  TS_AVE
+} TSReportCombiner;
 
 extern "C"
 {
-  extern void INKReportSingleData(char *metric, char *unit, INKReportCombiner combiner, double value);
+  extern void TSReportSingleData(char *metric, char *unit, TSReportCombiner combiner, double value);
 
-  extern void INKFuncRegister(INKPluginFuncId fid);
+  extern void TSFuncRegister(TSPluginFuncId fid);
 }
 
 

Modified: trafficserver/traffic/trunk/test/SDKtest/client/Config.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/test/SDKtest/client/Config.cc?rev=1035782&r1=1035781&r2=1035782&view=diff
==============================================================================
--- trafficserver/traffic/trunk/test/SDKtest/client/Config.cc (original)
+++ trafficserver/traffic/trunk/test/SDKtest/client/Config.cc Tue Nov 16 20:22:02 2010
@@ -214,7 +214,7 @@ Config::read_target_byterate_dist()
   }
   printf("\n");
 }
-Config::Config(long warmup, char *config_file, INKPlugin * aplug_in, int aread_timeout)
+Config::Config(long warmup, char *config_file, TSPlugin * aplug_in, int aread_timeout)
 {
   char line[MAX_LINE_SIZE], lhs[MAX_LINE_SIZE], rhs[MAX_LINE_SIZE];
   int c;
@@ -286,7 +286,7 @@ Config::Config(long warmup, char *config
 
 #ifdef _PLUG_IN
       // target_host, target_port, and document_base
-      // will be passed to the INKOptionProcess() later, and
+      // will be passed to the TSOptionProcess() later, and
       // comments are skipped.
       if ((strcmp(lhs, "target_host") || strcmp(lhs, "target_port") || strcmp(lhs, "document_base")) && strcmp(lhs, "")) {
         if (plug_in->options_process_fcn) {

Modified: trafficserver/traffic/trunk/test/SDKtest/client/Config.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/test/SDKtest/client/Config.h?rev=1035782&r1=1035781&r2=1035782&view=diff
==============================================================================
--- trafficserver/traffic/trunk/test/SDKtest/client/Config.h (original)
+++ trafficserver/traffic/trunk/test/SDKtest/client/Config.h Tue Nov 16 20:22:02 2010
@@ -59,7 +59,7 @@ struct Config
   char target_byterate_dist_file[MAX_FILENAME_SIZE];
   /* File that has target_byterate distribution */
   FILE *conf_file, *log_file_p, *docsize_dist_file_p, *thinktime_dist_file_p, *target_byterate_dist_file_p;
-  INKPlugin *plug_in;
+  TSPlugin *plug_in;
   int direct;
   int synthetic;
   int execution_interval;
@@ -86,14 +86,14 @@ struct Config
   double cumulative_size_prob[MAX_SIZES];
   void read_docsize_dist(long warmup);
   int num_thinktimes;
-  long thinktimes[MAX_THINKTIMES];
-  double cumulative_thinktime_prob[MAX_THINKTIMES];
+  long thinktimes[MAX_THTSTIMES];
+  double cumulative_thinktime_prob[MAX_THTSTIMES];
   int num_target_byterates;
   long target_byterates[MAX_TARGET_BYTERATES];
   double cumulative_target_byterate_prob[MAX_TARGET_BYTERATES];
   void read_thinktime_dist();
   void read_target_byterate_dist();
-    Config(long warmup, char *config_file, INKPlugin * aplug_in, int rd_tout);
+    Config(long warmup, char *config_file, TSPlugin * aplug_in, int rd_tout);
 };
 
 #endif // #ifndef _Config_h_

Modified: trafficserver/traffic/trunk/test/SDKtest/client/Defines.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/test/SDKtest/client/Defines.h?rev=1035782&r1=1035781&r2=1035782&view=diff
==============================================================================
--- trafficserver/traffic/trunk/test/SDKtest/client/Defines.h (original)
+++ trafficserver/traffic/trunk/test/SDKtest/client/Defines.h Tue Nov 16 20:22:02 2010
@@ -31,7 +31,7 @@
 #define MAX_ORIGIN_SERVERS 10   /* Max Origin Servers */
 #define MAX_STATUS_LEN 1024     /* Max Status Line Len */
 #define MAX_SIZES 1000          /* Max number of synthetic doc sizes */
-#define MAX_THINKTIMES 1000     /* Max number of think times */
+#define MAX_THTSTIMES 1000     /* Max number of think times */
 #define MAX_TARGET_BYTERATES 1000       /* Max number of byterates */
 #define MAX_SIZESTR_SIZE 20     /* sizestr looks like "size120 */
 #define MAX_SERIALNUMBERSTR_SIZE 20
@@ -45,6 +45,6 @@
 #define MAX_PORTNAME_SIZE 64
 #define MAX_LINE_SIZE 1000
 #define MAX_FILENAME_SIZE 80
-#define MAX_WARMUP_USERS 120    // See INKqa04115: Warmup causes x86 linux to hang
+#define MAX_WARMUP_USERS 120    // See TSqa04115: Warmup causes x86 linux to hang
 
 #endif // #define _Defines_h_

Modified: trafficserver/traffic/trunk/test/SDKtest/client/DoTest.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/test/SDKtest/client/DoTest.cc?rev=1035782&r1=1035781&r2=1035782&view=diff
==============================================================================
--- trafficserver/traffic/trunk/test/SDKtest/client/DoTest.cc (original)
+++ trafficserver/traffic/trunk/test/SDKtest/client/DoTest.cc Tue Nov 16 20:22:02 2010
@@ -69,7 +69,7 @@ DoTest::initialize_stats()
   above_connect_time_cutoff = 0;        /* Reqs above connect cutoff */
   generated_thinktime = 0;      /* Total number of reqs generated */
 
-  for (i = 0; i < MAX_THINKTIMES; i++) {
+  for (i = 0; i < MAX_THTSTIMES; i++) {
     thinktime_generated[i] = 0; /* Number of reqs with each thinktime */
   }
 
@@ -139,7 +139,7 @@ DoTest::create_new_connection_and_send_r
     perror(err);
 
 #ifdef _PLUG_IN
-    user_info[user].conn_status = INK_CONN_ERR;
+    user_info[user].conn_status = TS_CONN_ERR;
 #endif
 
     return 0;
@@ -158,7 +158,7 @@ DoTest::create_new_connection_and_send_r
     perror("Error: connect");
 
 #ifdef _PLUG_IN
-    user_info[user].conn_status = INK_CONN_ERR;
+    user_info[user].conn_status = TS_CONN_ERR;
 #endif
 
     return 0;
@@ -258,7 +258,7 @@ DoTest::create_new_connection_and_send_r
       perror("Error: write");
 
 #ifdef _PLUG_IN
-      user_info[user].conn_status = INK_WRITE_ERR;
+      user_info[user].conn_status = TS_WRITE_ERR;
 #endif
 
       return 0;
@@ -372,7 +372,7 @@ DoTest::compute_bytes_to_read(int user, 
   long should_have_read, to_read;
   long user_elapsed_time;
 
-  // INKqa04029 tripped this
+  // TSqa04029 tripped this
   assert(user_info[user].target_byterate != -2);        // Illegal value
 
   if (user_info[user].target_byterate == -1) {
@@ -489,7 +489,7 @@ DoTest::DoTest(int adebug,
                double ahistogram_resolution,
                long around_trip_time_cutoff,
                long afirst_byte_latency_cutoff,
-               long aconnect_time_cutoff, int aQOS_docsize, INKPlugin * aplug_in, int arequest_rate)
+               long aconnect_time_cutoff, int aQOS_docsize, TSPlugin * aplug_in, int arequest_rate)
 {
 
   debug = adebug;
@@ -595,8 +595,8 @@ DoTest::actual_test(int rr_flag)
     user_info[i].request_id = NULL;
     user_info[i].target_addr = &(user_info[i].dynamic_target_addr);
     user_info[i].content_count = 0;
-    user_info[i].action = INK_KEEP_GOING;
-    user_info[i].conn_status = INK_CONN_COMPLETE;
+    user_info[i].action = TS_KEEP_GOING;
+    user_info[i].conn_status = TS_CONN_COMPLETE;
 #endif
   }
 
@@ -757,7 +757,7 @@ DoTest::actual_test(int rr_flag)
           perror("Error: read");
 
 #ifdef _PLUG_IN
-          user_info[i].conn_status = INK_READ_ERR;
+          user_info[i].conn_status = TS_READ_ERR;
 #endif
 
           // Equivalent to closing the connection, as far as we r concerned
@@ -787,7 +787,7 @@ DoTest::actual_test(int rr_flag)
 #ifdef _PLUG_IN
           // for indicating to plugin that no more content is returned
           if ((user_info[i].status_line_info.status_code == 200 ||
-               user_info[i].status_line_info.status_code == 0) && user_info[i].action == INK_KEEP_GOING) {
+               user_info[i].status_line_info.status_code == 0) && user_info[i].action == TS_KEEP_GOING) {
             if (plug_in->partial_body_process_fcn) {
               (plug_in->partial_body_process_fcn) (user_info[i].request_id, (void *) "", 0, user_info[i].content_count);
             }
@@ -795,7 +795,7 @@ DoTest::actual_test(int rr_flag)
           if (plug_in->connection_finish_fcn) {
             (plug_in->connection_finish_fcn) (user_info[i].request_id, user_info[i].conn_status);
           }
-          user_info[i].conn_status = INK_CONN_COMPLETE;
+          user_info[i].conn_status = TS_CONN_COMPLETE;
           user_info[i].request_id = NULL;
           user_info[i].internal_rid = 0;
 #endif
@@ -815,12 +815,12 @@ DoTest::actual_test(int rr_flag)
 #endif
 
 #ifdef _PLUG_IN
-          if (user_info[i].action == INK_STOP_SUCCESS) {
+          if (user_info[i].action == TS_STOP_SUCCESS) {
             finished_requests += keepalive;
             update_completion_stats(i);
             // doesn't support keepalive yet... => keepalive == 1
             // 200 response but not an error: close connection requested from plugins
-          } else if (user_info[i].action == INK_STOP_FAIL) {
+          } else if (user_info[i].action == TS_STOP_FAIL) {
             failed_requests += keepalive;
           } else if (user_info[i].status_line_info.status_code != 200 && user_info[i].status_line_info.status_code != 0) {
             failed_requests += keepalive;
@@ -869,7 +869,7 @@ DoTest::actual_test(int rr_flag)
 #ifdef _PLUG_IN
           user_info[i].target_addr = &(user_info[i].dynamic_target_addr);
           user_info[i].content_count = 0;
-          user_info[i].action = INK_KEEP_GOING;
+          user_info[i].action = TS_KEEP_GOING;
 #endif
 
           if (user_info[i].think_time > 0) {
@@ -987,7 +987,7 @@ DoTest::actual_test(int rr_flag)
                     }
 
                     sli->status_line_complete = DONE_READING_HEADERS;
-                    if (user_info[i].action == INK_STOP_SUCCESS || user_info[i].action == INK_STOP_FAIL) {
+                    if (user_info[i].action == TS_STOP_SUCCESS || user_info[i].action == TS_STOP_FAIL) {
                       goto CONN_FINISH;
                     }
                     break;
@@ -1011,7 +1011,7 @@ DoTest::actual_test(int rr_flag)
             partial_length = s;
           }
 
-          if (sli->status_line_complete == DONE_READING_HEADERS && user_info[i].action == INK_KEEP_GOING) {
+          if (sli->status_line_complete == DONE_READING_HEADERS && user_info[i].action == TS_KEEP_GOING) {
             if ((sli->status_code == 200 || sli->status_code == 0)
                 && partial_length > 0) {
               user_info[i].content_count += partial_length;
@@ -1021,7 +1021,7 @@ DoTest::actual_test(int rr_flag)
                                                        (void *) partial_body,
                                                        partial_length, user_info[i].content_count);
               }
-              if (user_info[i].action == INK_STOP_SUCCESS || user_info[i].action == INK_STOP_FAIL) {
+              if (user_info[i].action == TS_STOP_SUCCESS || user_info[i].action == TS_STOP_FAIL) {
                 goto CONN_FINISH;
               }
             }
@@ -1131,7 +1131,7 @@ DoTest::actual_test(int rr_flag)
   for (i = 0; i < do_test->users; i++) {
     if (do_test->user_info[i].internal_rid) {
       if (plug_in->connection_finish_fcn) {
-        (plug_in->connection_finish_fcn) (do_test->user_info[i].request_id, INK_TIME_EXPIRE);
+        (plug_in->connection_finish_fcn) (do_test->user_info[i].request_id, TS_TIME_EXPIRE);
       }
     }
   }
@@ -1285,17 +1285,17 @@ DoTest::print_stats(int all)
 
 extern "C"
 {
-  void INKReportSingleData(char *metric, char *unit, INKReportCombiner combiner, double value)
+  void TSReportSingleData(char *metric, char *unit, TSReportCombiner combiner, double value)
   {
     switch (combiner) {
-    case INK_SUM:
+    case TS_SUM:
       do_test->report(metric, unit, "sum", value);
       break;
-      case INK_MAX:do_test->report(metric, unit, "max", value);
+      case TS_MAX:do_test->report(metric, unit, "max", value);
       break;
-      case INK_MIN:do_test->report(metric, unit, "min", value);
+      case TS_MIN:do_test->report(metric, unit, "min", value);
       break;
-      case INK_AVE:do_test->report(metric, unit, "ave Requests", value);
+      case TS_AVE:do_test->report(metric, unit, "ave Requests", value);
       break;
       default:fprintf(stderr, "Error: Illegal combiner in report");
     };

Modified: trafficserver/traffic/trunk/test/SDKtest/client/DoTest.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/test/SDKtest/client/DoTest.h?rev=1035782&r1=1035781&r2=1035782&view=diff
==============================================================================
--- trafficserver/traffic/trunk/test/SDKtest/client/DoTest.h (original)
+++ trafficserver/traffic/trunk/test/SDKtest/client/DoTest.h Tue Nov 16 20:22:02 2010
@@ -107,8 +107,8 @@ struct UserInfo
 #ifdef _PLUG_IN
   struct sockaddr_in dynamic_target_addr;
   long content_count;
-  INKRequestAction action;
-  INKConnectionStatus conn_status;
+  TSRequestAction action;
+  TSConnectionStatus conn_status;
 #endif
   /////////////////////
 
@@ -166,7 +166,7 @@ struct DoTest
   histogram connect_histogram;
 
   long generated_thinktime;     /* Total number of reqs generated */
-  long thinktime_generated[MAX_THINKTIMES];     /* Number of reqs with
+  long thinktime_generated[MAX_THTSTIMES];     /* Number of reqs with
                                                    each thinktime */
   double total_actual_thinktime;
 
@@ -206,7 +206,7 @@ struct DoTest
   int client_id;                /* Among all the client processes running what
                                    is my Id */
   LoadGenerator *load_generator;
-  INKPlugin *plug_in;
+  TSPlugin *plug_in;
   long warmup;
   // =0: real test, > 0 : warmup; create only warmup number of
   // requests
@@ -265,7 +265,7 @@ struct DoTest
            double ahistogram_resolution,
            long around_trip_time_cutoff,
            long afirst_byte_latency_cutoff,
-           long aconnect_time_cutoff, int aQOS_docsize, INKPlugin * aplug_in, int arequest_rate);
+           long aconnect_time_cutoff, int aQOS_docsize, TSPlugin * aplug_in, int arequest_rate);
   void report(char *metric, char *units, char *combiner, double value);
 
    ~DoTest()

Modified: trafficserver/traffic/trunk/test/SDKtest/client/LoadGenerator.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/test/SDKtest/client/LoadGenerator.h?rev=1035782&r1=1035781&r2=1035782&view=diff
==============================================================================
--- trafficserver/traffic/trunk/test/SDKtest/client/LoadGenerator.h (original)
+++ trafficserver/traffic/trunk/test/SDKtest/client/LoadGenerator.h Tue Nov 16 20:22:02 2010
@@ -75,7 +75,7 @@ struct LoadGenerator
   int num_sizes;                /* Number of sizes in the docsize distribution */
   long *sizes;                  /* actual sizes */
   int direct;
-  INKPlugin *plug_in;
+  TSPlugin *plug_in;
   double *cumulative_size_prob;
   /* Cumulative probability of selecting different sizes
      cumulative_size_prob[num_sizes-1] must be 1.0 */
@@ -104,7 +104,7 @@ struct LoadGenerator
 
     LoadGenerator(FILE * aurl_file,     /* only valid for if synthetic = 0 */
                   int akeepalive,       /* how many requests per connection */
-                  INKPlugin * aplug_in)
+                  TSPlugin * aplug_in)
   {
     warmup = 0;
     synthetic = 0;
@@ -129,7 +129,7 @@ struct LoadGenerator
                 double *acumulative_size_prob,
                 /* Cumulative probability of selecting different sizes
                    cumulative_size_prob[num_sizes-1] must be 1.0 */
-                int adirect, INKPlugin * aplug_in)
+                int adirect, TSPlugin * aplug_in)
   {
     plug_in = aplug_in;
     synthetic = 1;

Modified: trafficserver/traffic/trunk/test/SDKtest/client/Main.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/test/SDKtest/client/Main.cc?rev=1035782&r1=1035781&r2=1035782&view=diff
==============================================================================
--- trafficserver/traffic/trunk/test/SDKtest/client/Main.cc (original)
+++ trafficserver/traffic/trunk/test/SDKtest/client/Main.cc Tue Nov 16 20:22:02 2010
@@ -40,7 +40,7 @@
 Config *config;
 LoadGenerator *load_generator;
 DoTest *do_test;
-INKPlugin *plug_in;
+TSPlugin *plug_in;
 
 #if defined(__linux__) || defined(__FreeBSD__)
 static void
@@ -65,7 +65,7 @@ signal_handler(int sig, siginfo_t * sinf
         if (plug_in->connection_finish_fcn) {
           for (int i = 0; i < do_test->users; i++) {
             if (do_test->user_info[i].internal_rid) {
-              (plug_in->connection_finish_fcn) (do_test->user_info[i].request_id, INK_TIME_EXPIRE);
+              (plug_in->connection_finish_fcn) (do_test->user_info[i].request_id, TS_TIME_EXPIRE);
 
             }
           }
@@ -85,7 +85,7 @@ signal_handler(int sig, siginfo_t * sinf
       if (plug_in->connection_finish_fcn) {
         for (int i = 0; i < do_test->users; i++) {
           if (do_test->user_info[i].internal_rid) {
-            (plug_in->connection_finish_fcn) (do_test->user_info[i].request_id, INK_TIME_EXPIRE);
+            (plug_in->connection_finish_fcn) (do_test->user_info[i].request_id, TS_TIME_EXPIRE);
           }
         }
       }
@@ -186,7 +186,7 @@ main(int argc, char *argv[])
     }
   }
 
-  plug_in = new INKPlugin(client_id, api);
+  plug_in = new TSPlugin(client_id, api);
 #ifdef _PLUG_IN
   plug_in->load_plugin();
 #endif

Modified: trafficserver/traffic/trunk/test/SDKtest/client/Plugin.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/test/SDKtest/client/Plugin.cc?rev=1035782&r1=1035781&r2=1035782&view=diff
==============================================================================
--- trafficserver/traffic/trunk/test/SDKtest/client/Plugin.cc (original)
+++ trafficserver/traffic/trunk/test/SDKtest/client/Plugin.cc Tue Nov 16 20:22:02 2010
@@ -58,7 +58,7 @@ dlerror(void)
 }
 #endif
 
-INKPlugin::INKPlugin(int cid, char *api)
+TSPlugin::TSPlugin(int cid, char *api)
 {
   client_id = cid;
   handle = NULL;
@@ -77,7 +77,7 @@ INKPlugin::INKPlugin(int cid, char *api)
 
 
 void
-INKPlugin::load_plugin()
+TSPlugin::load_plugin()
 {
   if (strcmp(path, "")) {
     char *plugin_path = (char *) malloc(strlen(path) + 3);
@@ -92,10 +92,10 @@ INKPlugin::load_plugin()
       perror("client plugin");
       exit(1);
     }
-    plugin_init_fcn = (PluginInit) dlsym(handle, "INKPluginInit");
+    plugin_init_fcn = (PluginInit) dlsym(handle, "TSPluginInit");
 
     if (!plugin_init_fcn) {
-      fprintf(stderr, "unable to find INKPluginInit function: %s", dlerror());
+      fprintf(stderr, "unable to find TSPluginInit function: %s", dlerror());
       dlclose(handle);
       exit(1);
     }
@@ -107,50 +107,50 @@ INKPlugin::load_plugin()
 
 extern "C"
 {
-  void INKFuncRegister(INKPluginFuncId fid)
+  void TSFuncRegister(TSPluginFuncId fid)
   {
     plug_in->register_funct(fid);
   }
 }
 
 void
-INKPlugin::register_funct(INKPluginFuncId fid)
+TSPlugin::register_funct(TSPluginFuncId fid)
 {
   switch (fid) {
-  case INK_FID_OPTIONS_PROCESS:
-    options_process_fcn = (OptionsProcess) dlsym(handle, "INKOptionsProcess");
+  case TS_FID_OPTIONS_PROCESS:
+    options_process_fcn = (OptionsProcess) dlsym(handle, "TSOptionsProcess");
     break;
 
-  case INK_FID_OPTIONS_PROCESS_FINISH:
-    options_process_finish_fcn = (OptionsProcessFinish) dlsym(handle, "INKOptionsProcessFinish");
+  case TS_FID_OPTIONS_PROCESS_FINISH:
+    options_process_finish_fcn = (OptionsProcessFinish) dlsym(handle, "TSOptionsProcessFinish");
     break;
 
-  case INK_FID_CONNECTION_FINISH:
-    connection_finish_fcn = (ConnectionFinish) dlsym(handle, "INKConnectionFinish");
+  case TS_FID_CONNECTION_FINISH:
+    connection_finish_fcn = (ConnectionFinish) dlsym(handle, "TSConnectionFinish");
     break;
 
-  case INK_FID_PLUGIN_FINISH:
-    plugin_finish_fcn = (PluginFinish) dlsym(handle, "INKPluginFinish");
+  case TS_FID_PLUGIN_FINISH:
+    plugin_finish_fcn = (PluginFinish) dlsym(handle, "TSPluginFinish");
     break;
 
-  case INK_FID_REQUEST_CREATE:
-    request_create_fcn = (RequestCreate) dlsym(handle, "INKRequestCreate");
+  case TS_FID_REQUEST_CREATE:
+    request_create_fcn = (RequestCreate) dlsym(handle, "TSRequestCreate");
     break;
 
-  case INK_FID_HEADER_PROCESS:
-    header_process_fcn = (HeaderProcess) dlsym(handle, "INKHeaderProcess");
+  case TS_FID_HEADER_PROCESS:
+    header_process_fcn = (HeaderProcess) dlsym(handle, "TSHeaderProcess");
     break;
 
-  case INK_FID_PARTIAL_BODY_PROCESS:
-    partial_body_process_fcn = (PartialBodyProcess) dlsym(handle, "INKPartialBodyProcess");
+  case TS_FID_PARTIAL_BODY_PROCESS:
+    partial_body_process_fcn = (PartialBodyProcess) dlsym(handle, "TSPartialBodyProcess");
     break;
 
-  case INK_FID_REPORT:
-    report_fcn = (Report) dlsym(handle, "INKReport");
+  case TS_FID_REPORT:
+    report_fcn = (Report) dlsym(handle, "TSReport");
     break;
 
   default:
-    fprintf(stderr, "Can't register function: unknown type of INKPluginFuncId");
+    fprintf(stderr, "Can't register function: unknown type of TSPluginFuncId");
     break;
   }
 }

Modified: trafficserver/traffic/trunk/test/SDKtest/client/Plugin.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/test/SDKtest/client/Plugin.h?rev=1035782&r1=1035781&r2=1035782&view=diff
==============================================================================
--- trafficserver/traffic/trunk/test/SDKtest/client/Plugin.h (original)
+++ trafficserver/traffic/trunk/test/SDKtest/client/Plugin.h Tue Nov 16 20:22:02 2010
@@ -39,14 +39,14 @@
 typedef void (*PluginInit) (int);
 typedef void (*OptionsProcess) (char *, char *);
 typedef void (*OptionsProcessFinish) ();
-typedef void (*ConnectionFinish) (void *, INKConnectionStatus);
+typedef void (*ConnectionFinish) (void *, TSConnectionStatus);
 typedef void (*PluginFinish) ();
 typedef int (*RequestCreate) (char *, int, char *, int, char *, int, void **);
-typedef INKRequestAction(*HeaderProcess) (void *, char *, int, char *);
-typedef INKRequestAction(*PartialBodyProcess) (void *, void *, int, int);
+typedef TSRequestAction(*HeaderProcess) (void *, char *, int, char *);
+typedef TSRequestAction(*PartialBodyProcess) (void *, void *, int, int);
 typedef void (*Report) ();
 
-class INKPlugin
+class TSPlugin
 {
 public:
   int client_id;
@@ -63,11 +63,11 @@ public:
   PartialBodyProcess partial_body_process_fcn;
   Report report_fcn;
 
-    INKPlugin(int cid, char *api);
+    TSPlugin(int cid, char *api);
   void load_plugin();
-  void register_funct(INKPluginFuncId fid);
+  void register_funct(TSPluginFuncId fid);
 };
 
-extern INKPlugin *plug_in;
+extern TSPlugin *plug_in;
 
 #endif // _Plugin_h_

Modified: trafficserver/traffic/trunk/test/SDKtest/client/api/BlackList.c
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/test/SDKtest/client/api/BlackList.c?rev=1035782&r1=1035781&r2=1035782&view=diff
==============================================================================
--- trafficserver/traffic/trunk/test/SDKtest/client/api/BlackList.c (original)
+++ trafficserver/traffic/trunk/test/SDKtest/client/api/BlackList.c Tue Nov 16 20:22:02 2010
@@ -92,7 +92,7 @@ typedef struct
 BlackListPlugin my_plugin;
 
 void
-INKPluginInit(int client_id)
+TSPluginInit(int client_id)
 {
   my_plugin.requests = 0;
   my_plugin.allowed_requests = 0;
@@ -105,19 +105,19 @@ INKPluginInit(int client_id)
   my_plugin.total_bytes_received = 0;
 
   /* setup the callbacks */
-  INKFuncRegister(INK_FID_OPTIONS_PROCESS);
-  INKFuncRegister(INK_FID_OPTIONS_PROCESS_FINISH);
-  INKFuncRegister(INK_FID_CONNECTION_FINISH);
-  INKFuncRegister(INK_FID_PLUGIN_FINISH);
-  INKFuncRegister(INK_FID_REQUEST_CREATE);
-  INKFuncRegister(INK_FID_HEADER_PROCESS);
-  INKFuncRegister(INK_FID_PARTIAL_BODY_PROCESS);
-  INKFuncRegister(INK_FID_REPORT);
+  TSFuncRegister(TS_FID_OPTIONS_PROCESS);
+  TSFuncRegister(TS_FID_OPTIONS_PROCESS_FINISH);
+  TSFuncRegister(TS_FID_CONNECTION_FINISH);
+  TSFuncRegister(TS_FID_PLUGIN_FINISH);
+  TSFuncRegister(TS_FID_REQUEST_CREATE);
+  TSFuncRegister(TS_FID_HEADER_PROCESS);
+  TSFuncRegister(TS_FID_PARTIAL_BODY_PROCESS);
+  TSFuncRegister(TS_FID_REPORT);
 }
 
 
 void
-INKOptionsProcess(char *option, char *value)
+TSOptionsProcess(char *option, char *value)
 {
   if (strcmp(option, "target_host") == 0) {
     my_plugin.target_host = strdup(value);
@@ -140,7 +140,7 @@ INKOptionsProcess(char *option, char *va
 
 
 void
-INKOptionsProcessFinish()
+TSOptionsProcessFinish()
 {
   if ((strlen(my_plugin.target_host) == 0) || (strlen(my_plugin.target_port) == 0)) {
     my_plugin.direct = 1;
@@ -150,9 +150,9 @@ INKOptionsProcessFinish()
 }
 
 void
-INKConnectionFinish(void *req_id, INKConnectionStatus conn_status)
+TSConnectionFinish(void *req_id, TSConnectionStatus conn_status)
 {
-  if (conn_status == INK_TIME_EXPIRE) {
+  if (conn_status == TS_TIME_EXPIRE) {
     my_plugin.unfinished_documents++;
   }
   free(req_id);
@@ -160,7 +160,7 @@ INKConnectionFinish(void *req_id, INKCon
 
 
 void
-INKPluginFinish()
+TSPluginFinish()
 {
   /* do all cleanup here */
   free(my_plugin.target_host);
@@ -171,7 +171,7 @@ INKPluginFinish()
 
 
 int
-INKRequestCreate(char *origin_server_host /* return */ , int max_hostname_size,
+TSRequestCreate(char *origin_server_host /* return */ , int max_hostname_size,
                  char *origin_server_port /* return */ , int max_portname_size,
                  char *request_buf /* return */ , int max_request_size,
                  void **req_id /* return */ )
@@ -205,12 +205,12 @@ INKRequestCreate(char *origin_server_hos
 }
 
 
-INKRequestAction
-INKHeaderProcess(void *req_id, char *header, int length, char *request_str)
+TSRequestAction
+TSHeaderProcess(void *req_id, char *header, int length, char *request_str)
 {
   ((User *) req_id)->header_bytes = length;
   if (strstr(header, "200 OK")) {
-    return INK_KEEP_GOING;
+    return TS_KEEP_GOING;
   }
 
   /* we consider the request to the blacklisted
@@ -218,42 +218,42 @@ INKHeaderProcess(void *req_id, char *hea
   else if (strstr(header, "403 Forbidden")) {
     my_plugin.forbidden_documents++;
     my_plugin.total_bytes_received += length;
-    return INK_STOP_SUCCESS;
+    return TS_STOP_SUCCESS;
   } else if (strstr(header, "302 Moved Temprarily")) {
     my_plugin.redirect_documents++;
     my_plugin.total_bytes_received += length;
-    return INK_STOP_SUCCESS;
+    return TS_STOP_SUCCESS;
   } else {
     my_plugin.other_failed_documents++;
-    return INK_STOP_FAIL;
+    return TS_STOP_FAIL;
   }
 }
 
 
-INKRequestAction
-INKPartialBodyProcess(void *req_id, void *partial_content, int partial_length, int accum_length)
+TSRequestAction
+TSPartialBodyProcess(void *req_id, void *partial_content, int partial_length, int accum_length)
 {
   if (partial_length == 0) {
     my_plugin.successful_documents++;
     my_plugin.total_bytes_received += (accum_length + ((User *) req_id)->header_bytes);
   }
-  return INK_KEEP_GOING;
+  return TS_KEEP_GOING;
 }
 
 
 void
-INKReport()
+TSReport()
 {
 
-  INKReportSingleData("Total Requests", "count", INK_SUM, (double) my_plugin.requests);
-  INKReportSingleData("Allowed Requests", "count", INK_SUM, (double) my_plugin.allowed_requests);
-  INKReportSingleData("Forbidden Requests", "count", INK_SUM, (double) my_plugin.forbidden_requests);
-  INKReportSingleData("Successful Documents", "count", INK_SUM, (double) my_plugin.successful_documents);
-  INKReportSingleData("Forbidden Documents", "count", INK_SUM, (double) my_plugin.forbidden_documents);
-  INKReportSingleData("Redirect Documents", "count", INK_SUM, (double) my_plugin.redirect_documents);
-  INKReportSingleData("Unfinished Documents", "count", INK_SUM, (double) my_plugin.unfinished_documents);
-  INKReportSingleData("Other Fail Documents", "count", INK_SUM, (double) my_plugin.other_failed_documents);
-  INKReportSingleData("Total Bytes Received", "count", INK_SUM, (double) my_plugin.total_bytes_received);
+  TSReportSingleData("Total Requests", "count", TS_SUM, (double) my_plugin.requests);
+  TSReportSingleData("Allowed Requests", "count", TS_SUM, (double) my_plugin.allowed_requests);
+  TSReportSingleData("Forbidden Requests", "count", TS_SUM, (double) my_plugin.forbidden_requests);
+  TSReportSingleData("Successful Documents", "count", TS_SUM, (double) my_plugin.successful_documents);
+  TSReportSingleData("Forbidden Documents", "count", TS_SUM, (double) my_plugin.forbidden_documents);
+  TSReportSingleData("Redirect Documents", "count", TS_SUM, (double) my_plugin.redirect_documents);
+  TSReportSingleData("Unfinished Documents", "count", TS_SUM, (double) my_plugin.unfinished_documents);
+  TSReportSingleData("Other Fail Documents", "count", TS_SUM, (double) my_plugin.other_failed_documents);
+  TSReportSingleData("Total Bytes Received", "count", TS_SUM, (double) my_plugin.total_bytes_received);
 }
 
 

Modified: trafficserver/traffic/trunk/test/SDKtest/client/api/CheckAppend-1.c
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/test/SDKtest/client/api/CheckAppend-1.c?rev=1035782&r1=1035781&r2=1035782&view=diff
==============================================================================
--- trafficserver/traffic/trunk/test/SDKtest/client/api/CheckAppend-1.c (original)
+++ trafficserver/traffic/trunk/test/SDKtest/client/api/CheckAppend-1.c Tue Nov 16 20:22:02 2010
@@ -94,7 +94,7 @@ typedef struct
 CheckAppendPlugin my_plugin;
 
 void
-INKPluginInit(int client_id)
+TSPluginInit(int client_id)
 {
   my_plugin.requests = 0;
   my_plugin.successful_requests = 0;
@@ -103,21 +103,21 @@ INKPluginInit(int client_id)
   fprintf(stderr, "*** CheckAppend-1 Test for append-transform-plugin v1.0***\n");
   /* register the plugin functions that are called back
    * later in the program */
-  INKFuncRegister(INK_FID_OPTIONS_PROCESS);
-  INKFuncRegister(INK_FID_OPTIONS_PROCESS_FINISH);
-  INKFuncRegister(INK_FID_CONNECTION_FINISH);
-  INKFuncRegister(INK_FID_PLUGIN_FINISH);
-  INKFuncRegister(INK_FID_REQUEST_CREATE);
-  INKFuncRegister(INK_FID_HEADER_PROCESS);
-  INKFuncRegister(INK_FID_PARTIAL_BODY_PROCESS);
-  INKFuncRegister(INK_FID_REPORT);
+  TSFuncRegister(TS_FID_OPTIONS_PROCESS);
+  TSFuncRegister(TS_FID_OPTIONS_PROCESS_FINISH);
+  TSFuncRegister(TS_FID_CONNECTION_FINISH);
+  TSFuncRegister(TS_FID_PLUGIN_FINISH);
+  TSFuncRegister(TS_FID_REQUEST_CREATE);
+  TSFuncRegister(TS_FID_HEADER_PROCESS);
+  TSFuncRegister(TS_FID_PARTIAL_BODY_PROCESS);
+  TSFuncRegister(TS_FID_REPORT);
 
 }
 
 void
-INKConnectionFinish(void *req_id, INKConnectionStatus conn_status)
+TSConnectionFinish(void *req_id, TSConnectionStatus conn_status)
 {
-  if (conn_status == INK_TIME_EXPIRE)
+  if (conn_status == TS_TIME_EXPIRE)
     my_plugin.unfinished_requests++;
   free(((CONN_DATA *) req_id)->tail_of_resp);
   free(req_id);
@@ -125,7 +125,7 @@ INKConnectionFinish(void *req_id, INKCon
 
 /* process options specified in SDKtest_client.config */
 void
-INKOptionsProcess(char *option, char *value)
+TSOptionsProcess(char *option, char *value)
 {
   if (strcmp(option, "url_file") == 0) {        /* get the live URL file here */
     if (!(my_plugin.url_file = fopen(value, "r"))) {
@@ -148,7 +148,7 @@ INKOptionsProcess(char *option, char *va
 }
 
 void
-INKOptionsProcessFinish()
+TSOptionsProcessFinish()
 {
   int n;
 
@@ -205,7 +205,7 @@ INKOptionsProcessFinish()
 }
 
 void
-INKPluginFinish()
+TSPluginFinish()
 {
   int i;
 
@@ -220,7 +220,7 @@ INKPluginFinish()
  *     i.e. GET URL HTTP/1.0 ....
  */
 int
-INKRequestCreate(char *origin_server_host /* return */ , int max_hostname_size,
+TSRequestCreate(char *origin_server_host /* return */ , int max_hostname_size,
                  char *origin_server_port /* return */ , int max_portname_size,
                  char *request_buf /* return */ , int max_request_size,
                  void **req_id /* return */ )
@@ -266,15 +266,15 @@ INKRequestCreate(char *origin_server_hos
 /* process response header returned either from synthetic
  * server or from proxy server
  */
-INKRequestAction
-INKHeaderProcess(void *req_id, char *header, int length, char *request_str)
+TSRequestAction
+TSHeaderProcess(void *req_id, char *header, int length, char *request_str)
 {
-  return INK_KEEP_GOING;
+  return TS_KEEP_GOING;
 }
 
 
-INKRequestAction
-INKPartialBodyProcess(void *request_id, void *partial_content, int partial_length, int accum_length)
+TSRequestAction
+TSPartialBodyProcess(void *request_id, void *partial_content, int partial_length, int accum_length)
 {
   char *src;
   int room, bytes_to_move;
@@ -283,7 +283,7 @@ INKPartialBodyProcess(void *request_id, 
 
   req_id = (CONN_DATA *) request_id;
   if (req_id == NULL)
-    return INK_STOP_FAIL;
+    return TS_STOP_FAIL;
 
   /*print_debug((stderr, "req_id %x accum_length %d", req_id, accum_length));
      print_debug((stderr, "Rx response %d bytes\n", partial_length)); */
@@ -292,12 +292,12 @@ INKPartialBodyProcess(void *request_id, 
 
     if (memcmp(req_id->tail_of_resp, my_plugin.append_content, my_plugin.append_len) == 0) {
 
-      return INK_STOP_SUCCESS;
+      return TS_STOP_SUCCESS;
     }
 
     fprintf(stdout, "TEST_FAILED: appended content doesn't match for req_id %x\n", req_id);
     print_debug((stderr, "append: [%s] tail_of_resp [%s]\n", my_plugin.append_content, req_id->tail_of_resp));
-    return INK_STOP_FAIL;
+    return TS_STOP_FAIL;
   }
 
 /* Response not complete. Copy last _useful_ bytes to tail_of_file buffer */
@@ -327,17 +327,17 @@ INKPartialBodyProcess(void *request_id, 
   req_id->tail_of_resp_index += partial_length;
   req_id->tail_of_resp[req_id->tail_of_resp_index + 1] = '\0';
 
-  return INK_KEEP_GOING;
+  return TS_KEEP_GOING;
 
 }
 
 
 /* output report data after the SDKtest report */
 void
-INKReport()
+TSReport()
 {
-  INKReportSingleData("Total Requests", "count", INK_SUM, (double) my_plugin.requests);
-  INKReportSingleData("Successful Documents", "count", INK_SUM, (double) my_plugin.successful_requests);
-  INKReportSingleData("Unfinished Documents", "count", INK_SUM, (double) my_plugin.unfinished_requests);
-  INKReportSingleData("Total Bytes Received", "count", INK_SUM, (double) my_plugin.total_bytes_received);
+  TSReportSingleData("Total Requests", "count", TS_SUM, (double) my_plugin.requests);
+  TSReportSingleData("Successful Documents", "count", TS_SUM, (double) my_plugin.successful_requests);
+  TSReportSingleData("Unfinished Documents", "count", TS_SUM, (double) my_plugin.unfinished_requests);
+  TSReportSingleData("Total Bytes Received", "count", TS_SUM, (double) my_plugin.total_bytes_received);
 }

Modified: trafficserver/traffic/trunk/test/SDKtest/client/api/CheckAppend.c
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/test/SDKtest/client/api/CheckAppend.c?rev=1035782&r1=1035781&r2=1035782&view=diff
==============================================================================
--- trafficserver/traffic/trunk/test/SDKtest/client/api/CheckAppend.c (original)
+++ trafficserver/traffic/trunk/test/SDKtest/client/api/CheckAppend.c Tue Nov 16 20:22:02 2010
@@ -97,7 +97,7 @@ typedef struct
 CheckAppendPlugin my_plugin;
 
 void
-INKPluginInit(int client_id)
+TSPluginInit(int client_id)
 {
   my_plugin.requests = 0;
   my_plugin.successful_requests = 0;
@@ -107,21 +107,21 @@ INKPluginInit(int client_id)
   fprintf(stderr, "*** CheckAppend Test for append-transform-plugin v1.0***\n");
   /* register the plugin functions that are called back
    * later in the program */
-  INKFuncRegister(INK_FID_OPTIONS_PROCESS);
-  INKFuncRegister(INK_FID_OPTIONS_PROCESS_FINISH);
-  INKFuncRegister(INK_FID_CONNECTION_FINISH);
-  INKFuncRegister(INK_FID_PLUGIN_FINISH);
-  INKFuncRegister(INK_FID_REQUEST_CREATE);
-  INKFuncRegister(INK_FID_HEADER_PROCESS);
-  INKFuncRegister(INK_FID_PARTIAL_BODY_PROCESS);
-  INKFuncRegister(INK_FID_REPORT);
+  TSFuncRegister(TS_FID_OPTIONS_PROCESS);
+  TSFuncRegister(TS_FID_OPTIONS_PROCESS_FINISH);
+  TSFuncRegister(TS_FID_CONNECTION_FINISH);
+  TSFuncRegister(TS_FID_PLUGIN_FINISH);
+  TSFuncRegister(TS_FID_REQUEST_CREATE);
+  TSFuncRegister(TS_FID_HEADER_PROCESS);
+  TSFuncRegister(TS_FID_PARTIAL_BODY_PROCESS);
+  TSFuncRegister(TS_FID_REPORT);
 
 }
 
 void
-INKConnectionFinish(void *req_id, INKConnectionStatus conn_status)
+TSConnectionFinish(void *req_id, TSConnectionStatus conn_status)
 {
-  if (conn_status == INK_TIME_EXPIRE)
+  if (conn_status == TS_TIME_EXPIRE)
     my_plugin.unfinished_requests++;
   free(((CONN_DATA *) req_id)->tail_of_resp);
   free(req_id);
@@ -129,7 +129,7 @@ INKConnectionFinish(void *req_id, INKCon
 
 /* process options specified in SDKtest_client.config */
 void
-INKOptionsProcess(char *option, char *value)
+TSOptionsProcess(char *option, char *value)
 {
   if (strcmp(option, "url_file") == 0) {        /* get the live URL file here */
     if (!(my_plugin.url_file = fopen(value, "r"))) {
@@ -154,7 +154,7 @@ INKOptionsProcess(char *option, char *va
 }
 
 void
-INKOptionsProcessFinish()
+TSOptionsProcessFinish()
 {
   int n;
 
@@ -211,7 +211,7 @@ INKOptionsProcessFinish()
 }
 
 void
-INKPluginFinish()
+TSPluginFinish()
 {
   int i;
 
@@ -228,7 +228,7 @@ INKPluginFinish()
  *     i.e. GET URL HTTP/1.0 ....
  */
 int
-INKRequestCreate(char *origin_server_host /* return */ , int max_hostname_size,
+TSRequestCreate(char *origin_server_host /* return */ , int max_hostname_size,
                  char *origin_server_port /* return */ , int max_portname_size,
                  char *request_buf /* return */ , int max_request_size,
                  void **req_id /* return */ )
@@ -280,8 +280,8 @@ INKRequestCreate(char *origin_server_hos
 /* process response header returned either from synthetic
  * server or from proxy server
  */
-INKRequestAction
-INKHeaderProcess(void *req_id, char *header, int length, char *request_str)
+TSRequestAction
+TSHeaderProcess(void *req_id, char *header, int length, char *request_str)
 {
   char *content_type;
   CONN_DATA *p_conn = (CONN_DATA *) req_id;
@@ -311,12 +311,12 @@ INKHeaderProcess(void *req_id, char *hea
     p_conn->check_this_response = 0;
   }
 
-  return INK_KEEP_GOING;
+  return TS_KEEP_GOING;
 }
 
 
-INKRequestAction
-INKPartialBodyProcess(void *request_id, void *partial_content, int partial_length, int accum_length)
+TSRequestAction
+TSPartialBodyProcess(void *request_id, void *partial_content, int partial_length, int accum_length)
 {
   char *src;
   int room, bytes_to_move;
@@ -325,7 +325,7 @@ INKPartialBodyProcess(void *request_id, 
 
   req_id = (CONN_DATA *) request_id;
   if (req_id == NULL || (req_id->check_this_response == 0))
-    return INK_STOP_FAIL;
+    return TS_STOP_FAIL;
 
   /*print_debug((stderr, "req_id %x accum_length %d", req_id, accum_length));
      print_debug((stderr, "Rx response %d bytes\n", partial_length)); */
@@ -334,12 +334,12 @@ INKPartialBodyProcess(void *request_id, 
 
     if (memcmp(req_id->tail_of_resp, my_plugin.append_content, my_plugin.append_len) == 0) {
 
-      return INK_STOP_SUCCESS;
+      return TS_STOP_SUCCESS;
     }
 
     fprintf(stdout, "TEST_FAILED: appended content doesn't match for req_id %x\n", req_id);
     print_debug((stderr, "append: [%s] tail_of_resp [%s]\n", my_plugin.append_content, req_id->tail_of_resp));
-    return INK_STOP_FAIL;
+    return TS_STOP_FAIL;
   }
 
 /* Response not complete. Copy last _useful_ bytes to tail_of_file buffer */
@@ -369,17 +369,17 @@ INKPartialBodyProcess(void *request_id, 
   req_id->tail_of_resp_index += partial_length;
   req_id->tail_of_resp[req_id->tail_of_resp_index + 1] = '\0';
 
-  return INK_KEEP_GOING;
+  return TS_KEEP_GOING;
 
 }
 
 
 /* output report data after the SDKtest report */
 void
-INKReport()
+TSReport()
 {
-  INKReportSingleData("Total Requests", "count", INK_SUM, (double) my_plugin.requests);
-  INKReportSingleData("Successful Documents", "count", INK_SUM, (double) my_plugin.successful_requests);
-  INKReportSingleData("Unfinished Documents", "count", INK_SUM, (double) my_plugin.unfinished_requests);
-  INKReportSingleData("Total Bytes Received", "count", INK_SUM, (double) my_plugin.total_bytes_received);
+  TSReportSingleData("Total Requests", "count", TS_SUM, (double) my_plugin.requests);
+  TSReportSingleData("Successful Documents", "count", TS_SUM, (double) my_plugin.successful_requests);
+  TSReportSingleData("Unfinished Documents", "count", TS_SUM, (double) my_plugin.unfinished_requests);
+  TSReportSingleData("Total Bytes Received", "count", TS_SUM, (double) my_plugin.total_bytes_received);
 }

Modified: trafficserver/traffic/trunk/test/SDKtest/client/api/CheckContentClient.c
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/test/SDKtest/client/api/CheckContentClient.c?rev=1035782&r1=1035781&r2=1035782&view=diff
==============================================================================
--- trafficserver/traffic/trunk/test/SDKtest/client/api/CheckContentClient.c (original)
+++ trafficserver/traffic/trunk/test/SDKtest/client/api/CheckContentClient.c Tue Nov 16 20:22:02 2010
@@ -35,24 +35,24 @@
 #include <stdlib.h>
 
 void
-INKPluginInit(int clientid)
+TSPluginInit(int clientid)
 {
   fprintf(stderr, "*** CheckContentClient Test for Client    ***\n");
   fprintf(stderr, "*** needs to work with CheckContentServer *** \n");
-  INKFuncRegister(INK_FID_HEADER_PROCESS);
-  INKFuncRegister(INK_FID_PARTIAL_BODY_PROCESS);
+  TSFuncRegister(TS_FID_HEADER_PROCESS);
+  TSFuncRegister(TS_FID_PARTIAL_BODY_PROCESS);
 }
 
 
-INKRequestAction
-INKHeaderProcess(void *req_id, char *header, int length, char *request_str)
+TSRequestAction
+TSHeaderProcess(void *req_id, char *header, int length, char *request_str)
 {
-  return INK_KEEP_GOING;
+  return TS_KEEP_GOING;
 }
 
 
-INKRequestAction
-INKPartialBodyProcess(void *req_id, void *partial_content, int partial_length, int accum_length)
+TSRequestAction
+TSPartialBodyProcess(void *req_id, void *partial_content, int partial_length, int accum_length)
 {
   int i, code;
 
@@ -68,5 +68,5 @@ INKPartialBodyProcess(void *req_id, void
     }
     i--;
   }
-  return INK_KEEP_GOING;
+  return TS_KEEP_GOING;
 }

Modified: trafficserver/traffic/trunk/test/SDKtest/client/api/CheckReplaceHeader.c
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/test/SDKtest/client/api/CheckReplaceHeader.c?rev=1035782&r1=1035781&r2=1035782&view=diff
==============================================================================
--- trafficserver/traffic/trunk/test/SDKtest/client/api/CheckReplaceHeader.c (original)
+++ trafficserver/traffic/trunk/test/SDKtest/client/api/CheckReplaceHeader.c Tue Nov 16 20:22:02 2010
@@ -48,18 +48,18 @@
 int replace_hdr_test_failed;
 
 void
-INKPluginInit(int clientid)
+TSPluginInit(int clientid)
 {
 
   replace_hdr_test_failed = 0;
 
   fprintf(stderr, "*** CheckReplaceHeader Test for replace-header-plugin ***\n");
-  INKFuncRegister(INK_FID_HEADER_PROCESS);
+  TSFuncRegister(TS_FID_HEADER_PROCESS);
 }
 
 
-INKRequestAction
-INKHeaderProcess(void *req_id, char *header, int length, char *request_str)
+TSRequestAction
+TSHeaderProcess(void *req_id, char *header, int length, char *request_str)
 {
 
   char *accept_ranges_loc;
@@ -72,7 +72,7 @@ INKHeaderProcess(void *req_id, char *hea
       /*fprintf(stdout, "Response header is:\n%s\n", header); */
     }
     replace_hdr_test_failed = (replace_hdr_test_failed + 1) % 200;
-    return INK_KEEP_GOING;
+    return TS_KEEP_GOING;
   }
 
   while (*accept_ranges_loc != ':')
@@ -90,10 +90,10 @@ INKHeaderProcess(void *req_id, char *hea
       /*fprintf(stdout, "Response header is:\n%s\n", header); */
     }
     replace_hdr_test_failed = (replace_hdr_test_failed + 1) % 200;
-    return INK_KEEP_GOING;
+    return TS_KEEP_GOING;
   }
 
   /*fprintf(stdout, "Test PASSED!!!\n"); */
 
-  return INK_STOP_SUCCESS;
+  return TS_STOP_SUCCESS;
 }

Modified: trafficserver/traffic/trunk/test/SDKtest/client/api/ClientAPI.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/test/SDKtest/client/api/ClientAPI.h?rev=1035782&r1=1035781&r2=1035782&view=diff
==============================================================================
--- trafficserver/traffic/trunk/test/SDKtest/client/api/ClientAPI.h (original)
+++ trafficserver/traffic/trunk/test/SDKtest/client/api/ClientAPI.h Tue Nov 16 20:22:02 2010
@@ -30,49 +30,49 @@
 
 typedef enum
 {
-  INK_FID_OPTIONS_PROCESS,
-  INK_FID_OPTIONS_PROCESS_FINISH,
-  INK_FID_CONNECTION_FINISH,
-  INK_FID_PLUGIN_FINISH,
-  INK_FID_REQUEST_CREATE,
-  INK_FID_HEADER_PROCESS,
-  INK_FID_PARTIAL_BODY_PROCESS,
-  INK_FID_REPORT
-} INKPluginFuncId;
+  TS_FID_OPTIONS_PROCESS,
+  TS_FID_OPTIONS_PROCESS_FINISH,
+  TS_FID_CONNECTION_FINISH,
+  TS_FID_PLUGIN_FINISH,
+  TS_FID_REQUEST_CREATE,
+  TS_FID_HEADER_PROCESS,
+  TS_FID_PARTIAL_BODY_PROCESS,
+  TS_FID_REPORT
+} TSPluginFuncId;
 
 typedef enum
 {
-  INK_CONN_COMPLETE,
-  INK_CONN_ERR,
-  INK_READ_ERR,
-  INK_WRITE_ERR,
-  INK_TIME_EXPIRE
-} INKConnectionStatus;
+  TS_CONN_COMPLETE,
+  TS_CONN_ERR,
+  TS_READ_ERR,
+  TS_WRITE_ERR,
+  TS_TIME_EXPIRE
+} TSConnectionStatus;
 
 typedef enum
 {
-  INK_STOP_SUCCESS,
-  INK_STOP_FAIL,
-  INK_KEEP_GOING
-} INKRequestAction;
+  TS_STOP_SUCCESS,
+  TS_STOP_FAIL,
+  TS_KEEP_GOING
+} TSRequestAction;
 
 typedef enum
 {
-  INK_SUM,
-  INK_MAX,
-  INK_MIN,
-  INK_AVE
-} INKReportCombiner;
+  TS_SUM,
+  TS_MAX,
+  TS_MIN,
+  TS_AVE
+} TSReportCombiner;
 
 #ifdef __cplusplus
 extern "C"
 {
 #endif
-  extern void INKPluginInit(int clientID);
+  extern void TSPluginInit(int clientID);
 
-  extern void INKReportSingleData(char *metric, char *unit, INKReportCombiner combiner, double value);
+  extern void TSReportSingleData(char *metric, char *unit, TSReportCombiner combiner, double value);
 
-  extern void INKFuncRegister(INKPluginFuncId fid);
+  extern void TSFuncRegister(TSPluginFuncId fid);
 
 #ifdef __cplusplus
 }

Modified: trafficserver/traffic/trunk/test/SDKtest/client/api/RequestList.c
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/test/SDKtest/client/api/RequestList.c?rev=1035782&r1=1035781&r2=1035782&view=diff
==============================================================================
--- trafficserver/traffic/trunk/test/SDKtest/client/api/RequestList.c (original)
+++ trafficserver/traffic/trunk/test/SDKtest/client/api/RequestList.c Tue Nov 16 20:22:02 2010
@@ -97,7 +97,7 @@ typedef struct
 RequestListPlugin my_plugin;
 
 void
-INKPluginInit(int client_id)
+TSPluginInit(int client_id)
 {
   my_plugin.requests = 0;
   my_plugin.successful_documents = 0;
@@ -106,19 +106,19 @@ INKPluginInit(int client_id)
   my_plugin.total_bytes_received = 0;
 
   /* setup the callbacks */
-  INKFuncRegister(INK_FID_OPTIONS_PROCESS);
-  INKFuncRegister(INK_FID_OPTIONS_PROCESS_FINISH);
-  INKFuncRegister(INK_FID_CONNECTION_FINISH);
-  INKFuncRegister(INK_FID_PLUGIN_FINISH);
-  INKFuncRegister(INK_FID_REQUEST_CREATE);
-  INKFuncRegister(INK_FID_HEADER_PROCESS);
-  INKFuncRegister(INK_FID_PARTIAL_BODY_PROCESS);
-  INKFuncRegister(INK_FID_REPORT);
+  TSFuncRegister(TS_FID_OPTIONS_PROCESS);
+  TSFuncRegister(TS_FID_OPTIONS_PROCESS_FINISH);
+  TSFuncRegister(TS_FID_CONNECTION_FINISH);
+  TSFuncRegister(TS_FID_PLUGIN_FINISH);
+  TSFuncRegister(TS_FID_REQUEST_CREATE);
+  TSFuncRegister(TS_FID_HEADER_PROCESS);
+  TSFuncRegister(TS_FID_PARTIAL_BODY_PROCESS);
+  TSFuncRegister(TS_FID_REPORT);
 }
 
 
 void
-INKOptionsProcess(char *option, char *value)
+TSOptionsProcess(char *option, char *value)
 {
   int i;
   int rsum;
@@ -170,7 +170,7 @@ INKOptionsProcess(char *option, char *va
 
 
 void
-INKOptionsProcessFinish()
+TSOptionsProcessFinish()
 {
   if ((strlen(my_plugin.target_host) == 0) || (strlen(my_plugin.target_port) == 0)) {
     my_plugin.direct = 1;
@@ -180,9 +180,9 @@ INKOptionsProcessFinish()
 }
 
 void
-INKConnectionFinish(void *req_id, INKConnectionStatus conn_status)
+TSConnectionFinish(void *req_id, TSConnectionStatus conn_status)
 {
-  if (conn_status == INK_TIME_EXPIRE) {
+  if (conn_status == TS_TIME_EXPIRE) {
     my_plugin.unfinished_documents++;
   }
   free(req_id);
@@ -190,7 +190,7 @@ INKConnectionFinish(void *req_id, INKCon
 
 
 void
-INKPluginFinish()
+TSPluginFinish()
 {
   /* do all cleanup here */
   int i;
@@ -204,7 +204,7 @@ INKPluginFinish()
 
 
 int
-INKRequestCreate(char *origin_server_host /* return */ , int max_hostname_size,
+TSRequestCreate(char *origin_server_host /* return */ , int max_hostname_size,
                  char *origin_server_port /* return */ , int max_portname_size,
                  char *request_buf /* return */ , int max_request_size,
                  void **req_id /* return */ )
@@ -268,49 +268,49 @@ INKRequestCreate(char *origin_server_hos
 }
 
 
-INKRequestAction
-INKHeaderProcess(void *req_id, char *header, int length, char *request_str)
+TSRequestAction
+TSHeaderProcess(void *req_id, char *header, int length, char *request_str)
 {
   ((User *) req_id)->header_bytes = length;
 
   if (strstr(header, "200 OK")) {
-    return INK_KEEP_GOING;
+    return TS_KEEP_GOING;
   } else {
     my_plugin.other_failed_documents++;
-    return INK_STOP_FAIL;
+    return TS_STOP_FAIL;
   }
 }
 
 
-INKRequestAction
-INKPartialBodyProcess(void *req_id, void *partial_content, int partial_length, int accum_length)
+TSRequestAction
+TSPartialBodyProcess(void *req_id, void *partial_content, int partial_length, int accum_length)
 {
   if (partial_length == 0) {
     my_plugin.successful_documents++;
     my_plugin.total_bytes_received += (accum_length + ((User *) req_id)->header_bytes);
   }
-  return INK_KEEP_GOING;
+  return TS_KEEP_GOING;
 }
 
 
 void
-INKReport()
+TSReport()
 {
 
   int i;
 
-  INKReportSingleData("Total Requests", "count", INK_SUM, (double) my_plugin.requests);
-  INKReportSingleData("Successful Documents", "count", INK_SUM, (double) my_plugin.successful_documents);
-  INKReportSingleData("Unfinished Documents", "count", INK_SUM, (double) my_plugin.unfinished_documents);
-  INKReportSingleData("Other Failed Documents", "count", INK_SUM, (double) my_plugin.other_failed_documents);
+  TSReportSingleData("Total Requests", "count", TS_SUM, (double) my_plugin.requests);
+  TSReportSingleData("Successful Documents", "count", TS_SUM, (double) my_plugin.successful_documents);
+  TSReportSingleData("Unfinished Documents", "count", TS_SUM, (double) my_plugin.unfinished_documents);
+  TSReportSingleData("Other Failed Documents", "count", TS_SUM, (double) my_plugin.other_failed_documents);
 
   for (i = 0; i < my_plugin.nlist; i++) {
     char s[MAX_FILE_NAME_SIZE + 30];
     sprintf(s, "Total Requests from file %d", i);
-    INKReportSingleData(s, "count", INK_SUM, (double) my_plugin.list_requests[i]);
+    TSReportSingleData(s, "count", TS_SUM, (double) my_plugin.list_requests[i]);
   }
 
-  INKReportSingleData("Total Bytes Received", "count", INK_SUM, (double) my_plugin.total_bytes_received);
+  TSReportSingleData("Total Bytes Received", "count", TS_SUM, (double) my_plugin.total_bytes_received);
 }
 
 

Modified: trafficserver/traffic/trunk/test/SDKtest/client/api/SimBasicAuth-0.c
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/test/SDKtest/client/api/SimBasicAuth-0.c?rev=1035782&r1=1035781&r2=1035782&view=diff
==============================================================================
--- trafficserver/traffic/trunk/test/SDKtest/client/api/SimBasicAuth-0.c (original)
+++ trafficserver/traffic/trunk/test/SDKtest/client/api/SimBasicAuth-0.c Tue Nov 16 20:22:02 2010
@@ -86,26 +86,26 @@ typedef struct
 SimSDKtestPlugin my_plugin;
 
 void
-INKPluginInit(int client_id)
+TSPluginInit(int client_id)
 {
   my_plugin.requests = 0;
   my_plugin.successful_requests = 0;
 
   /* register the plugin functions that are called back
    * later in the program */
-  INKFuncRegister(INK_FID_OPTIONS_PROCESS);
-  INKFuncRegister(INK_FID_OPTIONS_PROCESS_FINISH);
-  INKFuncRegister(INK_FID_CONNECTION_FINISH);
-  INKFuncRegister(INK_FID_PLUGIN_FINISH);
-  INKFuncRegister(INK_FID_REQUEST_CREATE);
-  INKFuncRegister(INK_FID_HEADER_PROCESS);
-  INKFuncRegister(INK_FID_PARTIAL_BODY_PROCESS);
-  INKFuncRegister(INK_FID_REPORT);
+  TSFuncRegister(TS_FID_OPTIONS_PROCESS);
+  TSFuncRegister(TS_FID_OPTIONS_PROCESS_FINISH);
+  TSFuncRegister(TS_FID_CONNECTION_FINISH);
+  TSFuncRegister(TS_FID_PLUGIN_FINISH);
+  TSFuncRegister(TS_FID_REQUEST_CREATE);
+  TSFuncRegister(TS_FID_HEADER_PROCESS);
+  TSFuncRegister(TS_FID_PARTIAL_BODY_PROCESS);
+  TSFuncRegister(TS_FID_REPORT);
 }
 
 /* process options specified in SDKtest_client.config */
 void
-INKOptionsProcess(char *option, char *value)
+TSOptionsProcess(char *option, char *value)
 {
   if (strcmp(option, "target_host") == 0) {
     my_plugin.target_host = strdup(value);
@@ -135,7 +135,7 @@ INKOptionsProcess(char *option, char *va
 }
 
 void
-INKOptionsProcessFinish()
+TSOptionsProcessFinish()
 {
   read_docsize_dist();
   ((strlen(my_plugin.target_host) == 0) || (strlen(my_plugin.target_port) == 0)) ?
@@ -143,15 +143,15 @@ INKOptionsProcessFinish()
 }
 
 void
-INKConnectionFinish(void *req_id, INKConnectionStatus conn_status)
+TSConnectionFinish(void *req_id, TSConnectionStatus conn_status)
 {
-  if (conn_status == INK_TIME_EXPIRE)
+  if (conn_status == TS_TIME_EXPIRE)
     my_plugin.unfinished_requests++;
   free(req_id);
 }
 
 void
-INKPluginFinish()
+TSPluginFinish()
 {
   int i;
   free(my_plugin.target_host);
@@ -170,7 +170,7 @@ INKPluginFinish()
  *     i.e. GET URL HTTP/1.0 ....
  */
 int
-INKRequestCreate(char *origin_server_host /* return */ , int max_hostname_size,
+TSRequestCreate(char *origin_server_host /* return */ , int max_hostname_size,
                  char *origin_server_port /* return */ , int max_portname_size,
                  char *request_buf /* return */ , int max_request_size,
                  void **req_id /* return */ )
@@ -207,18 +207,18 @@ INKRequestCreate(char *origin_server_hos
 /* process response header returned either from synthetic
  * server or from proxy server
  */
-INKRequestAction
-INKHeaderProcess(void *req_id, char *header, int length, char *request_str)
+TSRequestAction
+TSHeaderProcess(void *req_id, char *header, int length, char *request_str)
 {
   ((User *) req_id)->header_bytes = length;
-  return INK_KEEP_GOING;
+  return TS_KEEP_GOING;
 }
 
 /* process part of the response returned either from synthetic
  * server or from proxy server
  */
-INKRequestAction
-INKPartialBodyProcess(void *req_id, void *partial_content, int partial_length, int accum_length)
+TSRequestAction
+TSPartialBodyProcess(void *req_id, void *partial_content, int partial_length, int accum_length)
 {
   if (partial_length == 0) {
     if (accum_length >= ((User *) req_id)->doc_size_requested) {
@@ -228,18 +228,18 @@ INKPartialBodyProcess(void *req_id, void
       fprintf(stderr, "ERROR: received bytes < requested bytes");
     }
   }
-  return INK_KEEP_GOING;
+  return TS_KEEP_GOING;
 }
 
 
 /* output report data after the SDKtest report */
 void
-INKReport()
+TSReport()
 {
-  INKReportSingleData("Total Requests", "count", INK_SUM, (double) my_plugin.requests);
-  INKReportSingleData("Successful Documents", "count", INK_SUM, (double) my_plugin.successful_requests);
-  INKReportSingleData("Unfinished Documents", "count", INK_SUM, (double) my_plugin.unfinished_requests);
-  INKReportSingleData("Total Bytes Received", "count", INK_SUM, (double) my_plugin.total_bytes_received);
+  TSReportSingleData("Total Requests", "count", TS_SUM, (double) my_plugin.requests);
+  TSReportSingleData("Successful Documents", "count", TS_SUM, (double) my_plugin.successful_requests);
+  TSReportSingleData("Unfinished Documents", "count", TS_SUM, (double) my_plugin.unfinished_requests);
+  TSReportSingleData("Total Bytes Received", "count", TS_SUM, (double) my_plugin.total_bytes_received);
 }
 
 /******************** ADDED FUNCTIONS ****************************/