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 2012/03/01 17:59:53 UTC

[2/2] TS-1124 moved these three plugins to main repo

http://git-wip-us.apache.org/repos/asf/trafficserver-plugins/blob/77b7d350/regex_remap/regex_remap.cc
----------------------------------------------------------------------
diff --git a/regex_remap/regex_remap.cc b/regex_remap/regex_remap.cc
deleted file mode 100644
index 53a9659..0000000
--- a/regex_remap/regex_remap.cc
+++ /dev/null
@@ -1,899 +0,0 @@
-/** @file
-
-    ATS plugin to do (simple) regular expression remap rules
-
-    @section license License
-
-    Licensed to the Apache Software Foundation (ASF) under one
-    or more contributor license agreements.  See the NOTICE file
-    distributed with this work for additional information
-    regarding copyright ownership.  The ASF licenses this file
-    to you under the Apache License, Version 2.0 (the
-    "License"); you may not use this file except in compliance
-    with the License.  You may obtain a copy of the License at
-
-    http://www.apache.org/licenses/LICENSE-2.0
-
-    Unless required by applicable law or agreed to in writing, software
-    distributed under the License is distributed on an "AS IS" BASIS,
-    WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
-    See the License for the specific language governing permissions and
-    limitations under the License.
-*/
-
-#define UNUSED __attribute__ ((unused))
-static char UNUSED rcsId__regex_remap_cc[] = "@(#) $Id$ built on " __DATE__ " " __TIME__;
-
-#include <sys/types.h>
-#include <stdio.h>
-#include <time.h>
-#include <string.h>
-#include <pcre.h>
-#include <ctype.h>
-#include <unistd.h>
-
-#include <ts/ts.h>
-#include <ts/remap.h>
-
-#include <iostream>
-#include <fstream>
-#include <string>
-
-
-static const char* PLUGIN_NAME = "regex_remap";
-
-// This is copied from lib/ts/*.h, only works with gcc 4.x or later (and compatible).
-// TODO: We really ought to expose these data types and atomic functions to the plugin APIs.
-typedef int int32;
-typedef volatile int32 vint32;
-typedef vint32 *pvint32;
-
-static inline int atomic_increment(pvint32 mem, int value)
-{
-  return __sync_fetch_and_add(mem, value);
-}
-
-
-// Constants
-const int OVECCOUNT = 30; // We support $0 - $9 x2 ints, and this needs to be 1.5x that
-const int MAX_SUBS = 32; // No more than 32 substitution variables in the subst string
-
-// TODO: This should be "autoconf'ed" or something ...
-#define DEFAULT_PATH "/usr/local/etc/regex_remap/"
-
-// Substitutions other than regex matches
-enum ExtraSubstitutions {
-  SUB_HOST = 11,
-  SUB_FROM_HOST = 12,
-  SUB_TO_HOST = 13,
-  SUB_PORT = 14,
-  SUB_SCHEME = 15,
-  SUB_PATH = 16,
-  SUB_QUERY = 17,
-  SUB_MATRIX = 18,
-  SUB_CLIENT_IP = 19,
-};
-
-
-///////////////////////////////////////////////////////////////////////////////
-// Class holding one request URL's component, to simplify the code and
-// length calculations (we need all of them).
-//
-struct UrlComponents
-{
-  UrlComponents()
-    : scheme(NULL), host(NULL), path(NULL), query(NULL), matrix(NULL), port(0),
-      scheme_len(0), host_len(0), path_len(0), query_len(0), matrix_len(0), url_len(0)
-  {}
-
-  void populate(TSRemapRequestInfo *rri)
-  {
-    scheme = TSUrlSchemeGet(rri->requestBufp, rri->requestUrl, &scheme_len);
-    host = TSUrlHostGet(rri->requestBufp, rri->requestUrl, &host_len);
-    path = TSUrlPathGet(rri->requestBufp, rri->requestUrl, &path_len);
-    query = TSUrlHttpQueryGet(rri->requestBufp, rri->requestUrl, &query_len);
-    matrix = TSUrlHttpParamsGet(rri->requestBufp, rri->requestUrl, &matrix_len);
-    port = TSUrlPortGet(rri->requestBufp, rri->requestUrl);
-
-    url_len = scheme_len + host_len + path_len + query_len + matrix_len + 32;
-  }
-
-  const char* scheme;
-  const char* host;
-  const char* path;
-  const char* query;
-  const char* matrix;
-  int port;
-
-  int scheme_len;
-  int host_len;
-  int path_len;
-  int query_len;
-  int matrix_len;
-
-  int url_len; // Full length, of all components
-};
-
-
-
-///////////////////////////////////////////////////////////////////////////////
-// Class encapsulating one regular expression (and the linked list).
-//
-class RemapRegex
-{
- public:
-  RemapRegex(const std::string& reg, const std::string& sub, const std::string& opt) :
-    _num_subs(-1), _rex(NULL), _extra(NULL), _order(-1), _simple(false),
-    _active_timeout(-1), _no_activity_timeout(-1), _connect_timeout(-1), _dns_timeout(-1)
-  {
-    TSDebug(PLUGIN_NAME, "Calling constructor");
-
-    _status = static_cast<TSHttpStatus>(0);
-
-    if (!reg.empty()) {
-      if (reg == ".") {
-        TSDebug(PLUGIN_NAME, "Rule is simple, and fast!");
-        _simple = true;
-      }
-      _rex_string = TSstrdup(reg.c_str());
-    } else
-      _rex_string = NULL;
-
-    if (!sub.empty()) {
-      _subst = TSstrdup(sub.c_str());
-      _subst_len = sub.length();
-    } else {
-      _subst = NULL;
-      _subst_len = 0;
-    }
-
-    _hits = 0;
-
-    memset(_sub_pos, 0, sizeof(_sub_pos));
-    memset(_sub_ix, 0, sizeof(_sub_ix));
-    _next = NULL;
-
-    // Parse options
-    std::string::size_type start = opt.find_first_of("@");
-    std::string::size_type pos1, pos2;
-
-    while (start != std::string::npos) {
-      std::string opt_val;
-
-      ++start;
-      pos1 = opt.find_first_of("=", start);
-      if (pos1 == std::string::npos) {
-        TSError("Malformed options: %s", opt.c_str());
-        break;
-      }
-      ++pos1;
-      pos2 = opt.find_first_of(" \t\n", pos1);
-      if (pos2 == std::string::npos)
-        pos2 = opt.length();
-      opt_val = opt.substr(pos1, pos2-pos1);
-
-      if (opt.compare(start, 6, "status") == 0) {
-        _status = static_cast<TSHttpStatus>(atoi(opt_val.c_str()));
-      } else if (opt.compare(start, 14, "active_timeout") == 0) {
-        _active_timeout = atoi(opt_val.c_str());
-      } else if (opt.compare(start, 19, "no_activity_timeout") == 0) {
-        _no_activity_timeout = atoi(opt_val.c_str());
-      } else if (opt.compare(start, 15, "connect_timeout") == 0) {
-        _connect_timeout = atoi(opt_val.c_str());
-      } else if (opt.compare(start, 11, "dns_timeout") == 0) {
-        _dns_timeout = atoi(opt_val.c_str());
-      } else {
-        TSError("Unknown options: %s", opt.c_str());
-      }
-      start = opt.find_first_of("@", pos2);
-    }
-  };
-
-  ~RemapRegex()
-  {
-    TSDebug(PLUGIN_NAME, "Calling destructor");
-    if (_rex_string)
-      TSfree(_rex_string);
-    if (_subst)
-      TSfree(_subst);
-
-    if (_rex)
-      pcre_free(_rex);
-    if (_extra)
-      pcre_free(_extra);
-  };
-
-  // For profiling information
-  inline void
-  print(int ix, int max, const char* now)
-  {
-    fprintf(stderr, "[%s]:\tRegex %d ( %s ): %.2f%%\n", now, ix, _rex_string, 100.0 * _hits / max);
-  }
-
-  inline void
-  increment()
-  {
-    atomic_increment(&(_hits), 1);
-  }
-
-  // Compile and study the regular expression.
-  int
-  compile(const char** error, int* erroffset)
-  {
-    char* str;
-    int ccount;
-
-    _rex = pcre_compile(_rex_string,          // the pattern
-                        0,                    // default options
-                        error,                // for error message
-                        erroffset,            // for error offset
-                        NULL);                // use default character tables
-
-    if (NULL == _rex)
-      return -1;
-
-    _extra = pcre_study(_rex, 0, error);
-    if ((_extra == NULL) && (*error != 0))
-      return -1;
-
-    if (pcre_fullinfo(_rex, _extra, PCRE_INFO_CAPTURECOUNT, &ccount) != 0)
-      return -1;
-
-    // Get some info for the string substitutions
-    str = _subst;
-    _num_subs = 0;
-
-    while (str && *str) {
-      if ((*str == '$')) {
-        int ix = -1;
-
-        if (isdigit(*(str+1))) {
-          ix = *(str + 1) - '0';
-        } else {
-          switch (*(str + 1)) {
-          case 'h':
-            ix = SUB_HOST;
-            break;
-          case 'f':
-            ix = SUB_FROM_HOST;
-            break;
-          case 't':
-            ix = SUB_TO_HOST;
-            break;
-          case 'p':
-            ix = SUB_PORT;
-            break;
-          case 's':
-            ix = SUB_SCHEME;
-            break;
-          case 'P':
-            ix = SUB_PATH;
-            break;
-          case 'q':
-            ix = SUB_QUERY;
-            break;
-          case 'm':
-            ix = SUB_MATRIX;
-            break;
-          case 'i':
-            ix = SUB_CLIENT_IP;
-            break;
-          default:
-            break;
-          }
-        }
-
-        if (ix > -1) {
-          if ((ix < 10) && (ix > ccount)) {
-            TSDebug(PLUGIN_NAME, "Trying to use unavailable substitution, check the regex!");
-            return -1; // No substitutions available other than $0
-          }
-
-          _sub_ix[_num_subs] = ix;
-          _sub_pos[_num_subs] = (str - _subst);
-          str += 2;
-          ++_num_subs;
-        } else { // Not a valid substitution character, so just ignore it
-          ++str;
-        }
-      } else {
-        ++str;
-      }
-    }
-    return 0;
-  };
-
-  // Perform the regular expression matching against a string.
-  int
-  match(const char* str, int len, int ovector[])
-  {
-    return pcre_exec(_rex,                 // the compiled pattern
-                     _extra,               // Extra data from study (maybe)
-                     str,                  // the subject string
-                     len,                  // the length of the subject
-                     0,                    // start at offset 0 in the subject
-                     0,                    // default options
-                     ovector,              // output vector for substring information
-                     OVECCOUNT);           // number of elements in the output vector
-  };
-
-  // Get the lengths of the matching string(s), taking into account variable substitutions.
-  // We also calculate a total length for the new string, which is the max length the
-  // substituted string can have (use it to allocate a buffer before calling substitute() ).
-  int
-  get_lengths(const int ovector[], int lengths[], TSRemapRequestInfo *rri, UrlComponents *req_url)
-  {
-    int len = _subst_len + 1;   // Bigger then necessary
-
-    for (int i=0; i < _num_subs; i++) {
-      int ix = _sub_ix[i];
-
-      if (ix < 10) {
-        lengths[ix] = ovector[2*ix+1] - ovector[2*ix]; // -1 - -1 == 0
-        len += lengths[ix];
-      } else {
-        int tmp_len;
-
-        switch (ix) {
-        case SUB_HOST:
-          len += req_url->host_len;
-          break;
-        case SUB_FROM_HOST:
-          TSUrlHostGet(rri->requestBufp, rri->mapFromUrl, &tmp_len);
-          len += tmp_len;
-          break;
-        case SUB_TO_HOST:
-          TSUrlHostGet(rri->requestBufp, rri->mapToUrl, &tmp_len);
-          len += tmp_len;
-          break;
-        case SUB_PORT:
-          len += 6; // One extra for snprintf()
-          break;
-        case SUB_SCHEME:
-          len += req_url->scheme_len;
-          break;
-        case SUB_PATH:
-          len += req_url->path_len;
-          break;
-        case SUB_QUERY:
-          len += req_url->query_len;
-          break;
-        case SUB_MATRIX:
-          len += req_url->matrix_len;
-          break;
-        case SUB_CLIENT_IP:
-          len += 15; // Allow for 255.255.255.255
-          break;
-        default:
-          break;
-        }
-      }
-    }
-
-    return len;
-  };
-
-  // Perform substitution on the $0 - $9 variables in the "src" string. $0 is the entire
-  // regex that was matches, while $1 - $9 are the corresponding groups. Return the final
-  // length of the string as written to dest (not including the trailing '0').
-  int
-  substitute(char dest[], const char *src, const int ovector[], const int lengths[],
-             TSRemapRequestInfo *rri, UrlComponents *req_url, struct sockaddr const* addr)
-  {
-    if (_num_subs > 0) {
-      char* p1 = dest;
-      char* p2 = _subst;
-      int prev = 0;
-
-      for (int i=0; i < _num_subs; i++) {
-        int ix = _sub_ix[i];
-
-        memcpy(p1, p2, _sub_pos[i] - prev);
-        p1 += (_sub_pos[i] - prev);
-        if (ix < 10) {
-          memcpy(p1, src + ovector[2*ix], lengths[ix]);
-          p1 += lengths[ix];
-        } else {
-          const char* str = NULL;
-          int len = 0;
-
-          switch (ix) {
-          case SUB_HOST:
-            str = req_url->host;
-            len = req_url->host_len;
-            break;
-          case SUB_FROM_HOST:
-            str = TSUrlHostGet(rri->requestBufp, rri->mapFromUrl, &len);
-            break;
-          case SUB_TO_HOST:
-            str = TSUrlHostGet(rri->requestBufp, rri->mapToUrl, &len);
-            break;
-          case SUB_PORT:
-            p1 += snprintf(p1, 6, "%u", req_url->port);
-            break;
-          case SUB_SCHEME:
-            str = req_url->scheme;
-            len = req_url->scheme_len;
-            break;
-          case SUB_PATH:
-            str = req_url->path;
-            len = req_url->path_len;
-            break;
-          case SUB_QUERY:
-            str = req_url->query;
-            len = req_url->query_len;
-            break;
-          case SUB_MATRIX:
-            str = req_url->matrix;
-            len = req_url->matrix_len;
-            break;
-          case SUB_CLIENT_IP:
-            {
-              // TODO: Finish implementing with the addr from above
-              // p1 += snprintf(p1, 15, "%d.%d.%d.%d", ip[0], ip[1], ip[2], ip[3]);
-            }
-            break;
-          default:
-            break;
-          }
-          // If one of the rules fetched a read-only string, copy it in.
-          if (str && len > 0) {
-            memcpy(p1, str, len);
-            p1 += len;
-          }
-        }
-        p2 += (_sub_pos[i] - prev + 2);
-        prev = _sub_pos[i] + 2;
-      }
-      memcpy(p1, p2, _subst_len - (p2 - _subst));
-      p1 += _subst_len - (p2 - _subst);
-      *p1 = 0; // Make sure it's NULL terminated (for safety).
-      return p1 - dest;
-    } else {
-      memcpy(dest, _subst, _subst_len + 1); // No substitutions in the string, copy it all
-      return _subst_len;
-    }
-
-    return 0; // Shouldn't happen.
-  };
-
-  // setter / getters for members the linked list.
-  inline void set_next(RemapRegex* next) { _next = next; };
-  inline RemapRegex* next() const { return _next; };
-
-  // setter / getters for order number within the linked list
-  inline void set_order(int order) { _order = order; };
-  inline int order() { return _order; };
-
-  // Various getters
-  inline const char* regex() const { return _rex_string;  };
-  inline const char* substitution() const { return _subst;  };
-  inline int substitutions_used() const { return _num_subs; }
-
-  inline bool is_simple() const { return _simple; }
-
-  inline TSHttpStatus status_option() const { return _status; };
-  inline int active_timeout_option() const  { return _active_timeout; };
-  inline int no_activity_timeout_option() const  { return _no_activity_timeout; };
-  inline int connect_timeout_option() const  { return _connect_timeout; };
-  inline int dns_timeout_option() const  { return _dns_timeout; };
-
- private:
-  char* _rex_string;
-  char* _subst;
-  int _subst_len;
-  int _num_subs;
-  int _hits;
-
-  pcre* _rex;
-  pcre_extra* _extra;
-  int _sub_pos[MAX_SUBS];
-  int _sub_ix[MAX_SUBS];
-  RemapRegex* _next;
-  int _order;
-  TSHttpStatus _status;
-  bool _simple;
-  int _active_timeout;
-  int _no_activity_timeout;
-  int _connect_timeout;
-  int _dns_timeout;
-};
-
-struct RemapInstance
-{
-  RemapInstance() :
-    first(NULL), last(NULL), profile(false), method(false), query_string(true),
-    matrix_params(false), hits(0), misses(0),
-    filename("unknown")
-  { };
-
-  RemapRegex* first;
-  RemapRegex* last;
-  bool profile;
-  bool method;
-  bool query_string;
-  bool matrix_params;
-  int hits;
-  int misses;
-  std::string filename;
-};
-
-///////////////////////////////////////////////////////////////////////////////
-// Helpers for memory management (to make sure pcre uses the TS APIs).
-//
-inline void*
-ts_malloc(size_t s)
-{
-  return TSmalloc(s);
-}
-
-inline void
-ts_free(void *s)
-{
-  return TSfree(s);
-}
-
-void
-setup_memory_allocation()
-{
-  pcre_malloc = &ts_malloc;
-  pcre_free = &ts_free;
-}
-
-
-///////////////////////////////////////////////////////////////////////////////
-// Initialize the plugin.
-//
-TSReturnCode
-TSRemapInit(TSRemapInterface* api_info, char *errbuf, int errbuf_size)
-{
-  if (!api_info) {
-    strncpy(errbuf, "[tsremap_init] - Invalid TSRemapInterface argument", errbuf_size - 1);
-    return TS_ERROR;
-  }
-
-  if (api_info->tsremap_version < TSREMAP_VERSION) {
-    snprintf(errbuf, errbuf_size - 1, "[TSRemapInit] - Incorrect API version %ld.%ld",
-             api_info->tsremap_version >> 16, (api_info->tsremap_version & 0xffff));
-    return TS_ERROR;
-  }
-
-  setup_memory_allocation();
-  TSDebug(PLUGIN_NAME, "plugin is succesfully initialized");
-  return TS_SUCCESS;
-}
-
-
-///////////////////////////////////////////////////////////////////////////////
-// We don't have any specific "instances" here, at least not yet.
-//
-TSReturnCode
-TSRemapNewInstance(int argc, char* argv[], void** ih, char* errbuf, int errbuf_size)
-{
-  const char* error;
-  int erroffset;
-  RemapInstance* ri = new RemapInstance();
-
-  std::ifstream f;
-  int lineno = 0;
-  int count = 0;
-
-  *ih = (void*)ri;
-  if (ri == NULL) {
-    TSError("Unable to create remap instance");
-    return TS_ERROR;
-  }
-
-  // Really simple (e.g. basic) config parser
-  for (int i=2; i < argc; ++i) {
-    if (strncmp(argv[i], "profile", 7) == 0) {
-      ri->profile = true;
-    } else if (strncmp(argv[i], "no-profile", 10) == 0) {
-      ri->profile = false;
-    } else if (strncmp(argv[i], "method", 6) == 0) {
-      ri->method = true;
-    } else if (strncmp(argv[i], "no-method", 9) == 0) {
-      ri->method = true;
-    } else if (strncmp(argv[i], "query-string", 12) == 0) {
-      ri->query_string = true;
-    } else if (strncmp(argv[i], "no-query-string", 15) == 0) {
-      ri->query_string = false;
-    } else if (strncmp(argv[i], "matrix-parameters", 15) == 0) {
-      ri->matrix_params = true;
-    } else if (strncmp(argv[i], "no-matrix-parameters", 18) == 0) {
-      ri->matrix_params = false;
-    } else {
-      if (0 != access(argv[2], R_OK)) {
-        ri->filename = DEFAULT_PATH;
-        ri->filename += argv[2];
-      } else {
-        ri->filename = argv[2];
-      }
-
-      f.open((ri->filename).c_str(), std::ios::in);
-      if (!f.is_open()) { // Try with the default path instead
-        TSError("unable to open %s", (ri->filename).c_str());
-        return TS_ERROR;
-      }
-      TSDebug(PLUGIN_NAME, "loading regular expression maps from %s", (ri->filename).c_str());
-
-      while (!f.eof()) {
-        std::string line, regex, subst, options;
-        std::string::size_type pos1, pos2;
-
-        getline(f, line);
-        ++lineno;
-        if (line.empty())
-          continue;
-        pos1 = line.find_first_not_of(" \t\n");
-        if (line[pos1] == '#')
-          continue;  // Skip comment lines
-
-        if (pos1 != std::string::npos) {
-          pos2 = line.find_first_of(" \t\n", pos1);
-          if (pos2 != std::string::npos) {
-            regex = line.substr(pos1, pos2-pos1);
-            pos1 = line.find_first_not_of(" \t\n#", pos2);
-            if (pos1 != std::string::npos) {
-              pos2 = line.find_first_of(" \t\n", pos1);
-              if (pos2 == std::string::npos)
-                pos2 = line.length();
-              subst = line.substr(pos1, pos2-pos1);
-              pos1 = line.find_first_not_of(" \t\n#", pos2);
-              if (pos1 != std::string::npos) {
-                pos2 = line.find_first_of("\n#", pos1);
-                if (pos2 == std::string::npos)
-                  pos2 = line.length();
-                options = line.substr(pos1, pos2-pos1);
-              }
-            }
-          }
-        }
-
-        if (regex.empty()) {
-          // No regex found on this line
-          TSError("no regexp found in %s: line %d", (ri->filename).c_str(), lineno);
-          continue;
-        }
-        if (subst.empty() && options.empty()) {
-          // No substitution found on this line (and no options)
-          TSError("no substitution string found in %s: line %d", (ri->filename).c_str(), lineno);
-          continue;
-        }
-
-        // Got a regex and substitution string
-        RemapRegex* cur = new RemapRegex(regex, subst, options);
-
-        if (cur == NULL) {
-          TSError("can't create a new regex remap rule");
-          continue;
-        }
-
-        if (cur->compile(&error, &erroffset) < 0) {
-          TSError("PCRE failed in %s (line %d) at offset %d: %s", (ri->filename).c_str(), lineno, erroffset, error);
-          delete(cur);
-        } else {
-          TSDebug(PLUGIN_NAME, "added regex=%s with substitution=%s and options `%s'",
-                   regex.c_str(), subst.c_str(), options.c_str());
-          cur->set_order(++count);
-          if (ri->first == NULL)
-            ri->first = cur;
-          else
-            ri->last->set_next(cur);
-          ri->last = cur;
-        }
-      }
-    }
-  }
-
-  // Make sure we got something...
-  if (ri->first == NULL) {
-    TSError("Got no regular expressions from the maps");
-    return TS_ERROR;
-  }
-
-  return TS_SUCCESS;
-}
-
-
-void
-TSRemapDeleteInstance(void* ih)
-{
-  RemapInstance* ri = static_cast<RemapInstance*>(ih);
-  RemapRegex* re;
-  RemapRegex* tmp;
-
-  if (ri->profile) {
-    char now[64];
-    time_t tim = time(NULL);
-
-    if (ctime_r(&tim, now))
-      now[strlen(now) - 1] = '\0';
-    else {
-      memcpy(now, "unknown time", 12);
-      *(now + 12) = '\0';
-    }
-
-    fprintf(stderr, "[%s]: Profiling information for regex_remap file `%s':\n", now, (ri->filename).c_str());
-    fprintf(stderr, "[%s]:\tTotal hits (matches): %d\n", now, ri->hits);
-    fprintf(stderr, "[%s]:\tTotal missed (no regex matches): %d\n", now, ri->misses);
-
-    if (ri->hits > 0) { // Avoid divide by zeros...
-      int ix = 1;
-
-      re = ri->first;
-      while (re) {
-        re->print(ix, ri->hits, now);
-        re = re->next();
-        ++ix;
-      }
-    }
-  }
-
-  re = ri->first;
-  while (re) {
-    tmp = re;
-    re = re->next();
-    delete tmp;
-  }
-
-  delete ri;
-}
-
-
-///////////////////////////////////////////////////////////////////////////////
-// This is the main "entry" point for the plugin, called for every request.
-//
-TSRemapStatus
-TSRemapDoRemap(void* ih, TSHttpTxn txnp, TSRemapRequestInfo *rri)
-{
-  if (NULL == ih) {
-    TSDebug(PLUGIN_NAME, "Falling back to default URL on regex remap without rules");
-    return TSREMAP_NO_REMAP;
-  }
-
-  // Populate the request url
-  UrlComponents req_url;
-  req_url.populate(rri);
-
-  RemapInstance* ri = (RemapInstance*)ih;
-  int ovector[OVECCOUNT];
-  int lengths[OVECCOUNT/2 + 1];
-  int dest_len;
-  TSRemapStatus retval = TSREMAP_DID_REMAP;
-  RemapRegex* re = ri->first;
-  char match_buf[req_url.url_len + 32]; // Worst case scenario and padded for /,? and ;
-  int match_len = 0;
-
-  if (ri->method) { // Prepend the URI path or URL with the HTTP method
-    TSMBuffer mBuf;
-    TSMLoc reqHttpHdrLoc;
-    const char *method;
-
-    // Note that Method can not be longer than 16 bytes, or we'll simply truncate it
-    if (TS_SUCCESS == TSHttpTxnClientReqGet(static_cast<TSHttpTxn>(txnp), &mBuf, &reqHttpHdrLoc)) {
-      method = TSHttpHdrMethodGet(mBuf, reqHttpHdrLoc, &match_len);
-      if (method && (match_len > 0)) {
-        if (match_len > 16)
-          match_len = 16;
-        memcpy(match_buf, method, match_len);
-      }
-    }
-  }
-
-  *(match_buf + match_len) = '/';
-  if (req_url.path && req_url.path_len > 0) {
-    memcpy(match_buf + match_len + 1, req_url.path, req_url.path_len);
-    match_len += (req_url.path_len + 1);
-  }
-
-  if (ri->matrix_params && req_url.matrix && req_url.matrix_len > 0) {
-    *(match_buf + match_len) = ';';
-    memcpy(match_buf + match_len + 1 , req_url.matrix, req_url.matrix_len);
-    match_len += (req_url.matrix_len + 1);
-  }
-
-  if (ri->query_string  && req_url.query && req_url.query_len > 0) {
-    *(match_buf + match_len) = '?';
-    memcpy(match_buf + match_len + 1 , req_url.query, req_url.query_len);
-    match_len += (req_url.query_len + 1);
-  }
-  match_buf[match_len] = '\0'; // NULL terminate the match string
-  TSDebug(PLUGIN_NAME, "Target match string is `%s'", match_buf);
-
-  // Apply the regular expressions, in order. First one wins.
-  while (re) {
-    // Since we check substitutions on parse time, we don't need to reset ovector
-    if (re->is_simple() || (re->match(match_buf, match_len, ovector) != -1)) {
-      int new_len = re->get_lengths(ovector, lengths, rri, &req_url);
-
-      // Set timeouts
-      if (re->active_timeout_option() > (-1)) {
-        TSDebug(PLUGIN_NAME, "Setting active timeout to %d", re->active_timeout_option());
-        TSHttpTxnActiveTimeoutSet(txnp, re->active_timeout_option());
-      }
-      if (re->no_activity_timeout_option() > (-1)) {
-        TSDebug(PLUGIN_NAME, "Setting no activity timeout to %d", re->no_activity_timeout_option());
-        TSHttpTxnNoActivityTimeoutSet(txnp, re->no_activity_timeout_option());
-      }
-      if (re->connect_timeout_option() > (-1)) {
-        TSDebug(PLUGIN_NAME, "Setting connect timeout to %d", re->connect_timeout_option());
-        TSHttpTxnConnectTimeoutSet(txnp, re->connect_timeout_option());
-      }
-      if (re->dns_timeout_option() > (-1)) {
-        TSDebug(PLUGIN_NAME, "Setting DNS timeout to %d", re->dns_timeout_option());
-        TSHttpTxnDNSTimeoutSet(txnp, re->dns_timeout_option());
-      }
-
-      // Update profiling if requested
-      if (ri->profile) {
-        re->increment();
-        atomic_increment(&(ri->hits), 1);
-      }
-
-      if (new_len > 0) {
-        char dest[new_len+8];
-        struct sockaddr const* addr = TSHttpTxnClientAddrGet(txnp);
-
-        dest_len = re->substitute(dest, match_buf, ovector, lengths, rri, &req_url, addr);
-
-        TSDebug(PLUGIN_NAME, "New URL is estimated to be %d bytes long, or less", new_len);
-        TSDebug(PLUGIN_NAME, "New URL is %s (length %d)", dest, dest_len);
-        TSDebug(PLUGIN_NAME, "    matched rule %d [%s]", re->order(), re->regex());
-
-        // Check for a quick response, if the status option is set
-        if (re->status_option() > 0) {
-          if (re->status_option() != TS_HTTP_STATUS_MOVED_PERMANENTLY &&
-              re->status_option() != TS_HTTP_STATUS_MOVED_TEMPORARILY) {
-            // Don't set the URL / Location for this.
-            TSHttpTxnSetHttpRetStatus(txnp, re->status_option());
-            break;
-          }
-
-          TSDebug(PLUGIN_NAME, "Redirecting URL, status=%d", re->status_option());
-          TSHttpTxnSetHttpRetStatus(txnp, re->status_option());
-          rri->redirect = 1;
-        }
-
-        // Now parse the new URL, which can also be the redirect URL
-        if (dest_len > 0) {
-          const char *start = dest;
-
-          // Setup the new URL
-          if (TS_PARSE_ERROR == TSUrlParse(rri->requestBufp, rri->requestUrl, &start, start + dest_len)) {
-            TSHttpTxnSetHttpRetStatus(txnp, TS_HTTP_STATUS_INTERNAL_SERVER_ERROR);
-            TSError("can't parse substituted URL string");
-          }
-        }
-        break;
-      }
-    }
-
-    // Try the next regex
-    re = re->next();
-    if (re == NULL) {
-      retval = TSREMAP_NO_REMAP; // No match
-      if (ri->profile)
-        atomic_increment(&(ri->misses), 1);
-    }
-  }
-
-  return retval;
-}
-
-
-
-/*
-  local variables:
-  mode: C++
-  indent-tabs-mode: nil
-  c-basic-offset: 2
-  c-comment-only-line-offset: 0
-  c-file-offsets: ((statement-block-intro . +)
-  (label . 0)
-  (statement-cont . +)
-  (innamespace . 0))
-  end:
-
-  Indent with: /usr/bin/indent -ncs -nut -npcs -l 120 logstats.cc
-*/

http://git-wip-us.apache.org/repos/asf/trafficserver-plugins/blob/77b7d350/stats_over_http/.gitignore
----------------------------------------------------------------------
diff --git a/stats_over_http/.gitignore b/stats_over_http/.gitignore
deleted file mode 100644
index c1c0bc2..0000000
--- a/stats_over_http/.gitignore
+++ /dev/null
@@ -1,9 +0,0 @@
-*.o
-*.a
-*.so
-*.in
-*~
-*.tar.gz
-*.lo
-*.la
-.deps

http://git-wip-us.apache.org/repos/asf/trafficserver-plugins/blob/77b7d350/stats_over_http/CHANGES
----------------------------------------------------------------------
diff --git a/stats_over_http/CHANGES b/stats_over_http/CHANGES
deleted file mode 100644
index 638d151..0000000
--- a/stats_over_http/CHANGES
+++ /dev/null
@@ -1,5 +0,0 @@
-                                                         -*- coding: utf-8 -*-
-
-Changes with Apache Traffic Server header_filter 1.0
-
-  *) This is a basic plugin for doing header_filtering.

http://git-wip-us.apache.org/repos/asf/trafficserver-plugins/blob/77b7d350/stats_over_http/LICENSE
----------------------------------------------------------------------
diff --git a/stats_over_http/LICENSE b/stats_over_http/LICENSE
deleted file mode 100644
index bed90de..0000000
--- a/stats_over_http/LICENSE
+++ /dev/null
@@ -1,404 +0,0 @@
-
-                                 Apache License
-                           Version 2.0, January 2004
-                        http://www.apache.org/licenses/
-
-   TERMS AND CONDITIONS FOR USE, REPRODUCTION, AND DISTRIBUTION
-
-   1. Definitions.
-
-      "License" shall mean the terms and conditions for use, reproduction,
-      and distribution as defined by Sections 1 through 9 of this document.
-
-      "Licensor" shall mean the copyright owner or entity authorized by
-      the copyright owner that is granting the License.
-
-      "Legal Entity" shall mean the union of the acting entity and all
-      other entities that control, are controlled by, or are under common
-      control with that entity. For the purposes of this definition,
-      "control" means (i) the power, direct or indirect, to cause the
-      direction or management of such entity, whether by contract or
-      otherwise, or (ii) ownership of fifty percent (50%) or more of the
-      outstanding shares, or (iii) beneficial ownership of such entity.
-
-      "You" (or "Your") shall mean an individual or Legal Entity
-      exercising permissions granted by this License.
-
-      "Source" form shall mean the preferred form for making modifications,
-      including but not limited to software source code, documentation
-      source, and configuration files.
-
-      "Object" form shall mean any form resulting from mechanical
-      transformation or translation of a Source form, including but
-      not limited to compiled object code, generated documentation,
-      and conversions to other media types.
-
-      "Work" shall mean the work of authorship, whether in Source or
-      Object form, made available under the License, as indicated by a
-      copyright notice that is included in or attached to the work
-      (an example is provided in the Appendix below).
-
-      "Derivative Works" shall mean any work, whether in Source or Object
-      form, that is based on (or derived from) the Work and for which the
-      editorial revisions, annotations, elaborations, or other modifications
-      represent, as a whole, an original work of authorship. For the purposes
-      of this License, Derivative Works shall not include works that remain
-      separable from, or merely link (or bind by name) to the interfaces of,
-      the Work and Derivative Works thereof.
-
-      "Contribution" shall mean any work of authorship, including
-      the original version of the Work and any modifications or additions
-      to that Work or Derivative Works thereof, that is intentionally
-      submitted to Licensor for inclusion in the Work by the copyright owner
-      or by an individual or Legal Entity authorized to submit on behalf of
-      the copyright owner. For the purposes of this definition, "submitted"
-      means any form of electronic, verbal, or written communication sent
-      to the Licensor or its representatives, including but not limited to
-      communication on electronic mailing lists, source code control systems,
-      and issue tracking systems that are managed by, or on behalf of, the
-      Licensor for the purpose of discussing and improving the Work, but
-      excluding communication that is conspicuously marked or otherwise
-      designated in writing by the copyright owner as "Not a Contribution."
-
-      "Contributor" shall mean Licensor and any individual or Legal Entity
-      on behalf of whom a Contribution has been received by Licensor and
-      subsequently incorporated within the Work.
-
-   2. Grant of Copyright License. Subject to the terms and conditions of
-      this License, each Contributor hereby grants to You a perpetual,
-      worldwide, non-exclusive, no-charge, royalty-free, irrevocable
-      copyright license to reproduce, prepare Derivative Works of,
-      publicly display, publicly perform, sublicense, and distribute the
-      Work and such Derivative Works in Source or Object form.
-
-   3. Grant of Patent License. Subject to the terms and conditions of
-      this License, each Contributor hereby grants to You a perpetual,
-      worldwide, non-exclusive, no-charge, royalty-free, irrevocable
-      (except as stated in this section) patent license to make, have made,
-      use, offer to sell, sell, import, and otherwise transfer the Work,
-      where such license applies only to those patent claims licensable
-      by such Contributor that are necessarily infringed by their
-      Contribution(s) alone or by combination of their Contribution(s)
-      with the Work to which such Contribution(s) was submitted. If You
-      institute patent litigation against any entity (including a
-      cross-claim or counterclaim in a lawsuit) alleging that the Work
-      or a Contribution incorporated within the Work constitutes direct
-      or contributory patent infringement, then any patent licenses
-      granted to You under this License for that Work shall terminate
-      as of the date such litigation is filed.
-
-   4. Redistribution. You may reproduce and distribute copies of the
-      Work or Derivative Works thereof in any medium, with or without
-      modifications, and in Source or Object form, provided that You
-      meet the following conditions:
-
-      (a) You must give any other recipients of the Work or
-          Derivative Works a copy of this License; and
-
-      (b) You must cause any modified files to carry prominent notices
-          stating that You changed the files; and
-
-      (c) You must retain, in the Source form of any Derivative Works
-          that You distribute, all copyright, patent, trademark, and
-          attribution notices from the Source form of the Work,
-          excluding those notices that do not pertain to any part of
-          the Derivative Works; and
-
-      (d) If the Work includes a "NOTICE" text file as part of its
-          distribution, then any Derivative Works that You distribute must
-          include a readable copy of the attribution notices contained
-          within such NOTICE file, excluding those notices that do not
-          pertain to any part of the Derivative Works, in at least one
-          of the following places: within a NOTICE text file distributed
-          as part of the Derivative Works; within the Source form or
-          documentation, if provided along with the Derivative Works; or,
-          within a display generated by the Derivative Works, if and
-          wherever such third-party notices normally appear. The contents
-          of the NOTICE file are for informational purposes only and
-          do not modify the License. You may add Your own attribution
-          notices within Derivative Works that You distribute, alongside
-          or as an addendum to the NOTICE text from the Work, provided
-          that such additional attribution notices cannot be construed
-          as modifying the License.
-
-      You may add Your own copyright statement to Your modifications and
-      may provide additional or different license terms and conditions
-      for use, reproduction, or distribution of Your modifications, or
-      for any such Derivative Works as a whole, provided Your use,
-      reproduction, and distribution of the Work otherwise complies with
-      the conditions stated in this License.
-
-   5. Submission of Contributions. Unless You explicitly state otherwise,
-      any Contribution intentionally submitted for inclusion in the Work
-      by You to the Licensor shall be under the terms and conditions of
-      this License, without any additional terms or conditions.
-      Notwithstanding the above, nothing herein shall supersede or modify
-      the terms of any separate license agreement you may have executed
-      with Licensor regarding such Contributions.
-
-   6. Trademarks. This License does not grant permission to use the trade
-      names, trademarks, service marks, or product names of the Licensor,
-      except as required for reasonable and customary use in describing the
-      origin of the Work and reproducing the content of the NOTICE file.
-
-   7. Disclaimer of Warranty. Unless required by applicable law or
-      agreed to in writing, Licensor provides the Work (and each
-      Contributor provides its Contributions) on an "AS IS" BASIS,
-      WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or
-      implied, including, without limitation, any warranties or conditions
-      of TITLE, NON-INFRINGEMENT, MERCHANTABILITY, or FITNESS FOR A
-      PARTICULAR PURPOSE. You are solely responsible for determining the
-      appropriateness of using or redistributing the Work and assume any
-      risks associated with Your exercise of permissions under this License.
-
-   8. Limitation of Liability. In no event and under no legal theory,
-      whether in tort (including negligence), contract, or otherwise,
-      unless required by applicable law (such as deliberate and grossly
-      negligent acts) or agreed to in writing, shall any Contributor be
-      liable to You for damages, including any direct, indirect, special,
-      incidental, or consequential damages of any character arising as a
-      result of this License or out of the use or inability to use the
-      Work (including but not limited to damages for loss of goodwill,
-      work stoppage, computer failure or malfunction, or any and all
-      other commercial damages or losses), even if such Contributor
-      has been advised of the possibility of such damages.
-
-   9. Accepting Warranty or Additional Liability. While redistributing
-      the Work or Derivative Works thereof, You may choose to offer,
-      and charge a fee for, acceptance of support, warranty, indemnity,
-      or other liability obligations and/or rights consistent with this
-      License. However, in accepting such obligations, You may act only
-      on Your own behalf and on Your sole responsibility, not on behalf
-      of any other Contributor, and only if You agree to indemnify,
-      defend, and hold each Contributor harmless for any liability
-      incurred by, or claims asserted against, such Contributor by reason
-      of your accepting any such warranty or additional liability.
-
-   END OF TERMS AND CONDITIONS
-
-   APPENDIX: How to apply the Apache License to your work.
-
-      To apply the Apache License to your work, attach the following
-      boilerplate notice, with the fields enclosed by brackets "[]"
-      replaced with your own identifying information. (Don't include
-      the brackets!)  The text should be enclosed in the appropriate
-      comment syntax for the file format. We also recommend that a
-      file or class name and description of purpose be included on the
-      same "printed page" as the copyright notice for easier
-      identification within third-party archives.
-
-   Copyright [yyyy] [name of copyright owner]
-
-   Licensed under the Apache License, Version 2.0 (the "License");
-   you may not use this file except in compliance with the License.
-   You may obtain a copy of the License at
-
-       http://www.apache.org/licenses/LICENSE-2.0
-
-   Unless required by applicable law or agreed to in writing, software
-   distributed under the License is distributed on an "AS IS" BASIS,
-   WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
-   See the License for the specific language governing permissions and
-   limitations under the License.
-
-~~~
-
-Copyright (C) 2009 Yahoo! Inc.
-
-Licensed under the Apache License, Version 2.0 (the "License");
-you may not use this file except in compliance with the License.
-You may obtain a copy of the License at
-
-   http://www.apache.org/licenses/LICENSE-2.0
-
-~~~
-
-Mersenne Twister License
-
-Copyright (C) 1997 - 2002, Makoto Matsumoto and Takuji Nishimura,
-All rights reserved.
-
-Redistribution and use in source and binary forms, with or without
-modification, are permitted provided that the following conditions
-are met:
-
- 1. Redistributions of source code must retain the above copyright
-    notice, this list of conditions and the following disclaimer.
-
- 2. Redistributions in binary form must reproduce the above copyright
-    notice, this list of conditions and the following disclaimer in the
-    documentation and/or other materials provided with the distribution.
-
- 3. The names of its contributors may not be used to endorse or promote
-    products derived from this software without specific prior written
-    permission.
-
-THIS SOFTWARE IS PROVIDED BY THE COPYRIGHT HOLDERS AND CONTRIBUTORS
-"AS IS" AND ANY EXPRESS OR IMPLIED WARRANTIES, INCLUDING, BUT NOT
-LIMITED TO, THE IMPLIED WARRANTIES OF MERCHANTABILITY AND FITNESS FOR
-A PARTICULAR PURPOSE ARE DISCLAIMED.  IN NO EVENT SHALL THE COPYRIGHT OWNER OR
-CONTRIBUTORS BE LIABLE FOR ANY DIRECT, INDIRECT, INCIDENTAL, SPECIAL,
-EXEMPLARY, OR CONSEQUENTIAL DAMAGES (INCLUDING, BUT NOT LIMITED TO,
-PROCUREMENT OF SUBSTITUTE GOODS OR SERVICES; LOSS OF USE, DATA, OR
-PROFITS; OR BUSINESS INTERRUPTION) HOWEVER CAUSED AND ON ANY THEORY OF
-LIABILITY, WHETHER IN CONTRACT, STRICT LIABILITY, OR TORT (INCLUDING
-NEGLIGENCE OR OTHERWISE) ARISING IN ANY WAY OUT OF THE USE OF THIS
-SOFTWARE, EVEN IF ADVISED OF THE POSSIBILITY OF SUCH DAMAGE.
-
-Any feedback is very welcome.
-http://www.math.sci.hiroshima-u.ac.jp/~m-mat/MT/emt.html
-email: m-mat @ math.sci.hiroshima-u.ac.jp (remove space)
-
-~~~
-
-TK 8.3 License
-
-This software is copyrighted by the Regents of the University of
-California, Sun Microsystems, Inc., and other parties.  The following
-terms apply to all files associated with the software unless explicitly
-disclaimed in individual files.
-
-The authors hereby grant permission to use, copy, modify, distribute,
-and license this software and its documentation for any purpose, provided
-that existing copyright notices are retained in all copies and that this
-notice is included verbatim in any distributions. No written agreement,
-license, or royalty fee is required for any of the authorized uses.
-Modifications to this software may be copyrighted by their authors
-and need not follow the licensing terms described here, provided that
-the new terms are clearly indicated on the first page of each file where
-they apply.
-
-IN NO EVENT SHALL THE AUTHORS OR DISTRIBUTORS BE LIABLE TO ANY PARTY
-FOR DIRECT, INDIRECT, SPECIAL, INCIDENTAL, OR CONSEQUENTIAL DAMAGES
-ARISING OUT OF THE USE OF THIS SOFTWARE, ITS DOCUMENTATION, OR ANY
-DERIVATIVES THEREOF, EVEN IF THE AUTHORS HAVE BEEN ADVISED OF THE
-POSSIBILITY OF SUCH DAMAGE.
-
-THE AUTHORS AND DISTRIBUTORS SPECIFICALLY DISCLAIM ANY WARRANTIES,
-INCLUDING, BUT NOT LIMITED TO, THE IMPLIED WARRANTIES OF MERCHANTABILITY,
-FITNESS FOR A PARTICULAR PURPOSE, AND NON-INFRINGEMENT.  THIS SOFTWARE
-IS PROVIDED ON AN "AS IS" BASIS, AND THE AUTHORS AND DISTRIBUTORS HAVE
-NO OBLIGATION TO PROVIDE MAINTENANCE, SUPPORT, UPDATES, ENHANCEMENTS, OR
-MODIFICATIONS.
-
-GOVERNMENT USE: If you are acquiring this software on behalf of the
-U.S. government, the Government shall have only "Restricted Rights"
-in the software and related documentation as defined in the Federal
-Acquisition Regulations (FARs) in Clause 52.227.19 (c) (2).  If you
-are acquiring the software on behalf of the Department of Defense, the
-software shall be classified as "Commercial Computer Software" and the
-Government shall have only "Restricted Rights" as defined in Clause
-252.227-7013 (c) (1) of DFARs.  Notwithstanding the foregoing, the
-authors grant the U.S. Government and others acting in its behalf
-permission to use and distribute the software in accordance with the
-terms specified in this license.
-
-~~~
-
-BIND license
-
-Copyright (c) 1985, 1989, 1993
-   The Regents of the University of California.  All rights reserved.
-
-Redistribution and use in source and binary forms, with or without
-modification, are permitted provided that the following conditions
-are met:
-1. Redistributions of source code must retain the above copyright
-   notice, this list of conditions and the following disclaimer.
-2. Redistributions in binary form must reproduce the above copyright
-   notice, this list of conditions and the following disclaimer in the
-   documentation and/or other materials provided with the distribution.
-3. Neither the name of the University nor the names of its contributors
-   may be used to endorse or promote products derived from this software
-   without specific prior written permission.
-
-THIS SOFTWARE IS PROVIDED BY THE REGENTS AND CONTRIBUTORS ``AS IS'' AND
-ANY EXPRESS OR IMPLIED WARRANTIES, INCLUDING, BUT NOT LIMITED TO, THE
-IMPLIED WARRANTIES OF MERCHANTABILITY AND FITNESS FOR A PARTICULAR PURPOSE
-ARE DISCLAIMED.  IN NO EVENT SHALL THE REGENTS OR CONTRIBUTORS BE LIABLE
-FOR ANY DIRECT, INDIRECT, INCIDENTAL, SPECIAL, EXEMPLARY, OR CONSEQUENTIAL
-DAMAGES (INCLUDING, BUT NOT LIMITED TO, PROCUREMENT OF SUBSTITUTE GOODS
-OR SERVICES; LOSS OF USE, DATA, OR PROFITS; OR BUSINESS INTERRUPTION)
-HOWEVER CAUSED AND ON ANY THEORY OF LIABILITY, WHETHER IN CONTRACT, STRICT
-LIABILITY, OR TORT (INCLUDING NEGLIGENCE OR OTHERWISE) ARISING IN ANY WAY
-OUT OF THE USE OF THIS SOFTWARE, EVEN IF ADVISED OF THE POSSIBILITY OF
-SUCH DAMAGE.
-
-
-
-Portions Copyright (c) 1993 by Digital Equipment Corporation.
-
-Permission to use, copy, modify, and distribute this software for any
-purpose with or without fee is hereby granted, provided that the above
-copyright notice and this permission notice appear in all copies, and that
-the name of Digital Equipment Corporation not be used in advertising or
-publicity pertaining to distribution of the document or software without
-specific, written prior permission.
-
-THE SOFTWARE IS PROVIDED "AS IS" AND DIGITAL EQUIPMENT CORP. DISCLAIMS ALL
-WARRANTIES WITH REGARD TO THIS SOFTWARE, INCLUDING ALL IMPLIED WARRANTIES
-OF MERCHANTABILITY AND FITNESS.   IN NO EVENT SHALL DIGITAL EQUIPMENT
-CORPORATION BE LIABLE FOR ANY SPECIAL, DIRECT, INDIRECT, OR CONSEQUENTIAL
-DAMAGES OR ANY DAMAGES WHATSOEVER RESULTING FROM LOSS OF USE, DATA OR
-PROFITS, WHETHER IN AN ACTION OF CONTRACT, NEGLIGENCE OR OTHER TORTIOUS
-ACTION, ARISING OUT OF OR IN CONNECTION WITH THE USE OR PERFORMANCE OF THIS
-SOFTWARE.
-
-
-
-Copyright (c) 2004 by Internet Systems Consortium, Inc. ("ISC")
-Portions Copyright (c) 1996-1999 by Internet Software Consortium.
-
-Permission to use, copy, modify, and distribute this software for any
-purpose with or without fee is hereby granted, provided that the above
-copyright notice and this permission notice appear in all copies.
-
-THE SOFTWARE IS PROVIDED "AS IS" AND ISC DISCLAIMS ALL WARRANTIES
-WITH REGARD TO THIS SOFTWARE INCLUDING ALL IMPLIED WARRANTIES OF
-MERCHANTABILITY AND FITNESS.  IN NO EVENT SHALL ISC BE LIABLE FOR
-ANY SPECIAL, DIRECT, INDIRECT, OR CONSEQUENTIAL DAMAGES OR ANY DAMAGES
-WHATSOEVER RESULTING FROM LOSS OF USE, DATA OR PROFITS, WHETHER IN AN
-ACTION OF CONTRACT, NEGLIGENCE OR OTHER TORTIOUS ACTION, ARISING OUT
-OF OR IN CONNECTION WITH THE USE OR PERFORMANCE OF THIS SOFTWARE.
-
-~~~
-
-Copyright (C) 2007 Ariya Hidayat (ariya@kde.org)
-Copyright (C) 2006 Ariya Hidayat (ariya@kde.org)
-Copyright (C) 2005 Ariya Hidayat (ariya@kde.org)
-
-Permission is hereby granted, free of charge, to any person obtaining a copy
-of this software and associated documentation files (the "Software"), to deal
-in the Software without restriction, including without limitation the rights
-to use, copy, modify, merge, publish, distribute, sublicense, and/or sell
-copies of the Software, and to permit persons to whom the Software is
-furnished to do so, subject to the following conditions:
-
-The above copyright notice and this permission notice shall be included in
-all copies or substantial portions of the Software.
-
-THE SOFTWARE IS PROVIDED "AS IS", WITHOUT WARRANTY OF ANY KIND, EXPRESS OR
-IMPLIED, INCLUDING BUT NOT LIMITED TO THE WARRANTIES OF MERCHANTABILITY,
-FITNESS FOR A PARTICULAR PURPOSE AND NONINFRINGEMENT. IN NO EVENT SHALL THE
-AUTHORS OR COPYRIGHT HOLDERS BE LIABLE FOR ANY CLAIM, DAMAGES OR OTHER
-LIABILITY, WHETHER IN AN ACTION OF CONTRACT, TORT OR OTHERWISE, ARISING FROM,
-OUT OF OR IN CONNECTION WITH THE SOFTWARE OR THE USE OR OTHER DEALINGS IN
-THE SOFTWARE.
-
-
-For the strlcat, strlcpy in inktomi++/ink_string.cc:
-
-Copyright (c) 1998 Todd C. Miller <To...@courtesan.com>
-
-Permission to use, copy, modify, and distribute this software for any
-purpose with or without fee is hereby granted, provided that the above
-copyright notice and this permission notice appear in all copies.
-
-THE SOFTWARE IS PROVIDED "AS IS" AND THE AUTHOR DISCLAIMS ALL WARRANTIES
-WITH REGARD TO THIS SOFTWARE INCLUDING ALL IMPLIED WARRANTIES OF
-MERCHANTABILITY AND FITNESS. IN NO EVENT SHALL THE AUTHOR BE LIABLE FOR
-ANY SPECIAL, DIRECT, INDIRECT, OR CONSEQUENTIAL DAMAGES OR ANY DAMAGES
-WHATSOEVER RESULTING FROM LOSS OF USE, DATA OR PROFITS, WHETHER IN AN
-ACTION OF CONTRACT, NEGLIGENCE OR OTHER TORTIOUS ACTION, ARISING OUT OF
-OR IN CONNECTION WITH THE USE OR PERFORMANCE OF THIS SOFTWARE.
-

http://git-wip-us.apache.org/repos/asf/trafficserver-plugins/blob/77b7d350/stats_over_http/Makefile
----------------------------------------------------------------------
diff --git a/stats_over_http/Makefile b/stats_over_http/Makefile
deleted file mode 100644
index d970e1d..0000000
--- a/stats_over_http/Makefile
+++ /dev/null
@@ -1,25 +0,0 @@
-#  Licensed to the Apache Software Foundation (ASF) under one
-#  or more contributor license agreements.  See the NOTICE file
-#  distributed with this work for additional information
-#  regarding copyright ownership.  The ASF licenses this file
-#  to you under the Apache License, Version 2.0 (the
-#  "License"); you may not use this file except in compliance
-#  with the License.  You may obtain a copy of the License at
-#
-#  http://www.apache.org/licenses/LICENSE-2.0
-#
-#  Unless required by applicable law or agreed to in writing, software
-#  distributed under the License is distributed on an "AS IS" BASIS,
-#  WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
-#  See the License for the specific language governing permissions and
-#  limitations under the License.
-
-
-all:	stats_over_http.c
-	tsxs -v -c $? -o stats_over_http.so
-
-install:
-	tsxs -i -o stats_over_http.so
-
-clean:
-	rm -f *.lo *.so

http://git-wip-us.apache.org/repos/asf/trafficserver-plugins/blob/77b7d350/stats_over_http/NOTICE
----------------------------------------------------------------------
diff --git a/stats_over_http/NOTICE b/stats_over_http/NOTICE
deleted file mode 100644
index c19f064..0000000
--- a/stats_over_http/NOTICE
+++ /dev/null
@@ -1,5 +0,0 @@
-Apache Traffic Server
-Copyright 2010 The Apache Software Foundation
-
-This product includes software developed at
-The Apache Software Foundation (http://www.apache.org/).

http://git-wip-us.apache.org/repos/asf/trafficserver-plugins/blob/77b7d350/stats_over_http/README
----------------------------------------------------------------------
diff --git a/stats_over_http/README b/stats_over_http/README
deleted file mode 100644
index 03718af..0000000
--- a/stats_over_http/README
+++ /dev/null
@@ -1,10 +0,0 @@
-Compile:
-  tsxs -c stats_over_http.c -o stats_over_http.so
-Install:
-  sudo tsxs -o stats_over_http.so -i
-
-Add to the plugin.conf:
-
-  stats_over_http.so
-
-start traffic server and visit http://IP:port/_stats

http://git-wip-us.apache.org/repos/asf/trafficserver-plugins/blob/77b7d350/stats_over_http/stats_over_http.c
----------------------------------------------------------------------
diff --git a/stats_over_http/stats_over_http.c b/stats_over_http/stats_over_http.c
deleted file mode 100644
index f6c3f14..0000000
--- a/stats_over_http/stats_over_http.c
+++ /dev/null
@@ -1,290 +0,0 @@
-/** @file
-
-  A brief file description
-
-  @section license License
-
-  Licensed to the Apache Software Foundation (ASF) under one
-  or more contributor license agreements.  See the NOTICE file
-  distributed with this work for additional information
-  regarding copyright ownership.  The ASF licenses this file
-  to you under the Apache License, Version 2.0 (the
-  "License"); you may not use this file except in compliance
-  with the License.  You may obtain a copy of the License at
-
-      http://www.apache.org/licenses/LICENSE-2.0
-
-  Unless required by applicable law or agreed to in writing, software
-  distributed under the License is distributed on an "AS IS" BASIS,
-  WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
-  See the License for the specific language governing permissions and
-  limitations under the License.
- */
-
-/* stats.c:  expose traffic server stats over http
- */
-
-#include <stdio.h>
-#include <stdlib.h>
-#include <ctype.h>
-#include <limits.h>
-#include <ts/ts.h>
-#include <string.h>
-
-#include <inttypes.h>
-
-typedef struct stats_state_t
-{
-  TSVConn net_vc;
-  TSVIO read_vio;
-  TSVIO write_vio;
-
-  TSIOBuffer req_buffer;
-  TSIOBuffer resp_buffer;
-  TSIOBufferReader resp_reader;
-
-  int output_bytes;
-  int body_written;
-} stats_state;
-
-static void
-stats_cleanup(TSCont contp, stats_state * my_state)
-{
-  if (my_state->req_buffer) {
-    TSIOBufferDestroy(my_state->req_buffer);
-    my_state->req_buffer = NULL;
-  }
-
-  if (my_state->resp_buffer) {
-    TSIOBufferDestroy(my_state->resp_buffer);
-    my_state->resp_buffer = NULL;
-  }
-  TSVConnClose(my_state->net_vc);
-  TSfree(my_state);
-  TSContDestroy(contp);
-}
-
-static void
-stats_process_accept(TSCont contp, stats_state * my_state)
-{
-
-  my_state->req_buffer = TSIOBufferCreate();
-  my_state->resp_buffer = TSIOBufferCreate();
-  my_state->resp_reader = TSIOBufferReaderAlloc(my_state->resp_buffer);
-  my_state->read_vio = TSVConnRead(my_state->net_vc, contp, my_state->req_buffer, INT64_MAX);
-}
-
-static int
-stats_add_data_to_resp_buffer(const char *s, stats_state * my_state)
-{
-  int s_len = strlen(s);
-
-  TSIOBufferWrite(my_state->resp_buffer, s, s_len);
-
-  return s_len;
-}
-
-static int
-stats_add_resp_header(stats_state * my_state)
-{
-  char resp[] = "HTTP/1.0 200 Ok\r\n"
-    "Content-Type: text/javascript\r\nCache-Control: no-cache\r\n\r\n";
-  return stats_add_data_to_resp_buffer(resp, my_state);
-}
-
-static void
-stats_process_read(TSCont contp, TSEvent event, stats_state * my_state)
-{
-  TSDebug("istats", "stats_process_read(%d)", event);
-  if (event == TS_EVENT_VCONN_READ_READY) {
-    my_state->output_bytes = stats_add_resp_header(my_state);
-    TSVConnShutdown(my_state->net_vc, 1, 0);
-    my_state->write_vio = TSVConnWrite(my_state->net_vc, contp, my_state->resp_reader, INT_MAX);
-  } else if (event == TS_EVENT_ERROR) {
-    TSError("stats_process_read: Received TS_EVENT_ERROR\n");
-  } else if (event == TS_EVENT_VCONN_EOS) {
-    /* client may end the connection, simply return */
-    return;
-  } else if (event == TS_EVENT_NET_ACCEPT_FAILED) {
-    TSError("stats_process_read: Received TS_EVENT_NET_ACCEPT_FAILED\n");
-  } else {
-    printf("Unexpected Event %d\n", event);
-    TSReleaseAssert(!"Unexpected Event");
-  }
-}
-
-#define APPEND(a) my_state->output_bytes += stats_add_data_to_resp_buffer(a, my_state)
-#define APPEND_STAT(a, fmt, v) do { \
-  char b[256]; \
-  if(snprintf(b, sizeof(b), "\"%s\": \"" fmt "\",\n", a, v) < sizeof(b)) \
-    APPEND(b); \
-} while(0)
-
-static void
-json_out_stat(TSRecordType rec_type, void *edata, int registered,
-              const char *name, TSRecordDataType data_type,
-              TSRecordData *datum) {
-  stats_state *my_state = edata;
-
-  switch(data_type) {
-  case TS_RECORDDATATYPE_COUNTER:
-    APPEND_STAT(name, "%" PRIu64, datum->rec_counter); break;
-  case TS_RECORDDATATYPE_INT:
-    APPEND_STAT(name, "%" PRIu64, datum->rec_int); break;
-  case TS_RECORDDATATYPE_FLOAT:
-    APPEND_STAT(name, "%f", datum->rec_float); break;
-  case TS_RECORDDATATYPE_STRING:
-    APPEND_STAT(name, "%s", datum->rec_string); break;
-  default:
-    TSDebug("istats", "unkown type for %s: %d", name, data_type);
-    break;
-  }
-}
-static void
-json_out_stats(stats_state * my_state)
-{
-  const char *version;
-  APPEND("{ \"global\": {\n");
-
-  TSRecordDump(TS_RECORDTYPE_PROCESS, json_out_stat, my_state);
-  version = TSTrafficServerVersionGet();
-  APPEND("\"server\": \"");
-  APPEND(version);
-  APPEND("\"\n");
-  APPEND("  }\n}\n");
-}
-
-static void
-stats_process_write(TSCont contp, TSEvent event, stats_state * my_state)
-{
-  if (event == TS_EVENT_VCONN_WRITE_READY) {
-    if (my_state->body_written == 0) {
-      TSDebug("istats", "plugin adding response body");
-      my_state->body_written = 1;
-      json_out_stats(my_state);
-      TSVIONBytesSet(my_state->write_vio, my_state->output_bytes);
-    }
-    TSVIOReenable(my_state->write_vio);
-  } else if (TS_EVENT_VCONN_WRITE_COMPLETE) {
-    stats_cleanup(contp, my_state);
-  } else if (event == TS_EVENT_ERROR) {
-    TSError("stats_process_write: Received TS_EVENT_ERROR\n");
-  } else {
-    TSReleaseAssert(!"Unexpected Event");
-  }
-}
-
-static int
-stats_dostuff(TSCont contp, TSEvent event, void *edata)
-{
-  stats_state *my_state = TSContDataGet(contp);
-  if (event == TS_EVENT_NET_ACCEPT) {
-    my_state->net_vc = (TSVConn) edata;
-    stats_process_accept(contp, my_state);
-  } else if (edata == my_state->read_vio) {
-    stats_process_read(contp, event, my_state);
-  } else if (edata == my_state->write_vio) {
-    stats_process_write(contp, event, my_state);
-  } else {
-    TSReleaseAssert(!"Unexpected Event");
-  }
-  return 0;
-}
-static int
-stats_origin(TSCont contp, TSEvent event, void *edata)
-{
-  TSCont icontp;
-  stats_state *my_state;
-  TSHttpTxn txnp = (TSHttpTxn) edata;
-  TSMBuffer reqp;
-  TSMLoc hdr_loc = NULL, url_loc = NULL;
-  TSEvent reenable = TS_EVENT_HTTP_CONTINUE;
-
-  TSDebug("istats", "in the read stuff");
- 
-  if (TSHttpTxnClientReqGet(txnp, &reqp, &hdr_loc) != TS_SUCCESS)
-    goto cleanup;
-  
-  if (TSHttpHdrUrlGet(reqp, hdr_loc, &url_loc) != TS_SUCCESS)
-    goto cleanup;
-  
-  int path_len = 0;
-  const char* path = TSUrlPathGet(reqp,url_loc,&path_len);
-  TSDebug("istats","Path: %.*s",path_len,path);
-  
-  if (! (path_len != 0 && path_len == 6 && !memcmp(path,"_stats",6)) ) {
-    goto notforme;
-  }
-  
-  TSSkipRemappingSet(txnp,1); //not strictly necessary, but speed is everything these days
-
-  /* This is us -- register our intercept */
-  TSDebug("istats", "Intercepting request");
-
-  icontp = TSContCreate(stats_dostuff, TSMutexCreate());
-  my_state = (stats_state *) TSmalloc(sizeof(*my_state));
-  memset(my_state, 0, sizeof(*my_state));
-  TSContDataSet(icontp, my_state);
-  TSHttpTxnIntercept(icontp, txnp);
-  goto cleanup;
-
- notforme:
-
- cleanup:
-#if (TS_VERSION_NUMBER < 2001005)
-  if(path) TSHandleStringRelease(reqp, url_loc, path);
-#endif
-  if(url_loc) TSHandleMLocRelease(reqp, hdr_loc, url_loc);
-  if(hdr_loc) TSHandleMLocRelease(reqp, TS_NULL_MLOC, hdr_loc);
-
-  TSHttpTxnReenable(txnp, reenable);
-  return 0;
-}
-
-int
-check_ts_version()
-{
-
-  const char *ts_version = TSTrafficServerVersionGet();
-  int result = 0;
-
-  if (ts_version) {
-    int major_ts_version = 0;
-    int minor_ts_version = 0;
-    int patch_ts_version = 0;
-
-    if (sscanf(ts_version, "%d.%d.%d", &major_ts_version, &minor_ts_version, &patch_ts_version) != 3) {
-      return 0;
-    }
-
-    /* Need at least TS 2.0 */
-    if (major_ts_version >= 2) {
-      result = 1;
-    }
-  }
-
-  return result;
-}
-
-void
-TSPluginInit(int argc, const char *argv[])
-{
-  TSPluginRegistrationInfo info;
-
-  info.plugin_name = "stats";
-  info.vendor_name = "Apache Software Foundation";
-  info.support_email = "jesus@omniti.com";
-
-  if (TSPluginRegister(TS_SDK_VERSION_2_0, &info) != TS_SUCCESS)
-    TSError("Plugin registration failed. \n");
-
-  if (!check_ts_version()) {
-    TSError("Plugin requires Traffic Server 2.0 or later\n");
-    return;
-  }
-
-  /* Create a continuation with a mutex as there is a shared global structure
-     containing the headers to add */
-  TSHttpHookAdd(TS_HTTP_READ_REQUEST_HDR_HOOK, TSContCreate(stats_origin, NULL));
-  TSDebug("istats", "stats module registered");
-}