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

svn commit: r948906 [2/2] - in /trafficserver/traffic/trunk: iocore/cache/ iocore/cluster/ proxy/ proxy/hdrs/ proxy/http2/ proxy/logging/

Modified: trafficserver/traffic/trunk/proxy/logging/LogAccessTest.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/proxy/logging/LogAccessTest.cc?rev=948906&r1=948905&r2=948906&view=diff
==============================================================================
--- trafficserver/traffic/trunk/proxy/logging/LogAccessTest.cc (original)
+++ trafficserver/traffic/trunk/proxy/logging/LogAccessTest.cc Thu May 27 16:47:00 2010
@@ -68,10 +68,10 @@ int
 LogAccessTest::marshal_client_host_ip(char *buf)
 {
   if (buf) {
-    LOG_INT val = 0;
+    int64 val = 0;
     marshal_int(buf, val);
   }
-  return sizeof(LOG_INT);
+  return sizeof(int64);
 }
 
 /*-------------------------------------------------------------------------
@@ -109,10 +109,10 @@ int
 LogAccessTest::marshal_client_req_http_method(char *buf)
 {
   if (buf) {
-    LOG_INT val = 1;
+    int64 val = 1;
     marshal_int(buf, val);
   }
-  return sizeof(LOG_INT);
+  return sizeof(int64);
 }
 
 /*-------------------------------------------------------------------------
@@ -136,10 +136,10 @@ int
 LogAccessTest::marshal_client_req_http_version(char *buf)
 {
   if (buf) {
-    LOG_INT val = 2;
+    int64 val = 2;
     marshal_int(buf, val);
   }
-  return sizeof(LOG_INT);
+  return sizeof(int64);
 }
 
 /*-------------------------------------------------------------------------
@@ -149,10 +149,10 @@ int
 LogAccessTest::marshal_client_req_header_len(char *buf)
 {
   if (buf) {
-    LOG_INT val = 3;
+    int64 val = 3;
     marshal_int(buf, val);
   }
-  return sizeof(LOG_INT);
+  return sizeof(int64);
 }
 
 /*-------------------------------------------------------------------------
@@ -162,10 +162,10 @@ int
 LogAccessTest::marshal_client_req_body_len(char *buf)
 {
   if (buf) {
-    LOG_INT val = 4;
+    int64 val = 4;
     marshal_int(buf, val);
   }
-  return sizeof(LOG_INT);
+  return sizeof(int64);
 }
 
 /*-------------------------------------------------------------------------
@@ -175,10 +175,10 @@ int
 LogAccessTest::marshal_client_finish_status_code(char *buf)
 {
   if (buf) {
-    LOG_INT val = 5;
+    int64 val = 5;
     marshal_int(buf, val);
   }
-  return sizeof(LOG_INT);
+  return sizeof(int64);
 }
 
 /*-------------------------------------------------------------------------
@@ -202,10 +202,10 @@ int
 LogAccessTest::marshal_proxy_resp_squid_len(char *buf)
 {
   if (buf) {
-    LOG_INT val = 100;
+    int64 val = 100;
     marshal_int(buf, val);
   }
-  return sizeof(LOG_INT);
+  return sizeof(int64);
 }
 
 /*-------------------------------------------------------------------------
@@ -215,10 +215,10 @@ int
 LogAccessTest::marshal_proxy_resp_content_len(char *buf)
 {
   if (buf) {
-    LOG_INT val = 6;
+    int64 val = 6;
     marshal_int(buf, val);
   }
-  return sizeof(LOG_INT);
+  return sizeof(int64);
 }
 
 /*-------------------------------------------------------------------------
@@ -228,10 +228,10 @@ int
 LogAccessTest::marshal_proxy_resp_status_code(char *buf)
 {
   if (buf) {
-    LOG_INT val = 7;
+    int64 val = 7;
     marshal_int(buf, val);
   }
-  return sizeof(LOG_INT);
+  return sizeof(int64);
 }
 
 /*-------------------------------------------------------------------------
@@ -241,10 +241,10 @@ int
 LogAccessTest::marshal_proxy_resp_header_len(char *buf)
 {
   if (buf) {
-    LOG_INT val = 8;
+    int64 val = 8;
     marshal_int(buf, val);
   }
-  return sizeof(LOG_INT);
+  return sizeof(int64);
 }
 
 /*-------------------------------------------------------------------------
@@ -254,10 +254,10 @@ int
 LogAccessTest::marshal_proxy_finish_status_code(char *buf)
 {
   if (buf) {
-    LOG_INT val = 9;
+    int64 val = 9;
     marshal_int(buf, val);
   }
-  return sizeof(LOG_INT);
+  return sizeof(int64);
 }
 
 /*-------------------------------------------------------------------------
@@ -267,10 +267,10 @@ int
 LogAccessTest::marshal_cache_result_code(char *buf)
 {
   if (buf) {
-    LOG_INT val = 10;
+    int64 val = 10;
     marshal_int(buf, val);
   }
-  return sizeof(LOG_INT);
+  return sizeof(int64);
 }
 
 /*-------------------------------------------------------------------------
@@ -280,10 +280,10 @@ int
 LogAccessTest::marshal_proxy_req_header_len(char *buf)
 {
   if (buf) {
-    LOG_INT val = 11;
+    int64 val = 11;
     marshal_int(buf, val);
   }
-  return sizeof(LOG_INT);
+  return sizeof(int64);
 }
 
 /*-------------------------------------------------------------------------
@@ -293,10 +293,10 @@ int
 LogAccessTest::marshal_proxy_req_body_len(char *buf)
 {
   if (buf) {
-    LOG_INT val = 12;
+    int64 val = 12;
     marshal_int(buf, val);
   }
-  return sizeof(LOG_INT);
+  return sizeof(int64);
 }
 
 /*-------------------------------------------------------------------------
@@ -306,10 +306,10 @@ int
 LogAccessTest::marshal_proxy_hierarchy_route(char *buf)
 {
   if (buf) {
-    LOG_INT val = 13;
+    int64 val = 13;
     marshal_int(buf, val);
   }
-  return sizeof(LOG_INT);
+  return sizeof(int64);
 }
 
 /*-------------------------------------------------------------------------
@@ -319,10 +319,10 @@ int
 LogAccessTest::marshal_server_host_ip(char *buf)
 {
   if (buf) {
-    LOG_INT val = 14;
+    int64 val = 14;
     marshal_int(buf, val);
   }
-  return sizeof(LOG_INT);
+  return sizeof(int64);
 }
 
 /*-------------------------------------------------------------------------
@@ -346,10 +346,10 @@ int
 LogAccessTest::marshal_server_resp_status_code(char *buf)
 {
   if (buf) {
-    LOG_INT val = 15;
+    int64 val = 15;
     marshal_int(buf, val);
   }
-  return sizeof(LOG_INT);
+  return sizeof(int64);
 }
 
 /*-------------------------------------------------------------------------
@@ -359,10 +359,10 @@ int
 LogAccessTest::marshal_server_resp_content_len(char *buf)
 {
   if (buf) {
-    LOG_INT val = 16;
+    int64 val = 16;
     marshal_int(buf, val);
   }
-  return sizeof(LOG_INT);
+  return sizeof(int64);
 }
 
 /*-------------------------------------------------------------------------
@@ -372,10 +372,10 @@ int
 LogAccessTest::marshal_server_resp_header_len(char *buf)
 {
   if (buf) {
-    LOG_INT val = 17;
+    int64 val = 17;
     marshal_int(buf, val);
   }
-  return sizeof(LOG_INT);
+  return sizeof(int64);
 }
 
 /*-------------------------------------------------------------------------
@@ -385,10 +385,10 @@ int
 LogAccessTest::marshal_transfer_time_ms(char *buf)
 {
   if (buf) {
-    LOG_INT val = 18;
+    int64 val = 18;
     marshal_int(buf, val);
   }
-  return sizeof(LOG_INT);
+  return sizeof(int64);
 }
 
 /*-------------------------------------------------------------------------

Modified: trafficserver/traffic/trunk/proxy/logging/LogCollationHostSM.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/proxy/logging/LogCollationHostSM.cc?rev=948906&r1=948905&r2=948906&view=diff
==============================================================================
--- trafficserver/traffic/trunk/proxy/logging/LogCollationHostSM.cc (original)
+++ trafficserver/traffic/trunk/proxy/logging/LogCollationHostSM.cc Thu May 27 16:47:00 2010
@@ -297,7 +297,7 @@ LogCollationHostSM::host_recv(int event,
       unsigned version;
 
       ink_assert(m_read_buffer != NULL);
-      ink_assert(m_read_bytes_received >= sizeof(LogBufferHeader));
+      ink_assert(m_read_bytes_received >= (int64)sizeof(LogBufferHeader));
       log_buffer_header = (LogBufferHeader *) m_read_buffer;
 
       // convert the buffer we just received to host order

Modified: trafficserver/traffic/trunk/proxy/logging/LogCollationHostSM.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/proxy/logging/LogCollationHostSM.h?rev=948906&r1=948905&r2=948906&view=diff
==============================================================================
--- trafficserver/traffic/trunk/proxy/logging/LogCollationHostSM.h (original)
+++ trafficserver/traffic/trunk/proxy/logging/LogCollationHostSM.h Thu May 27 16:47:00 2010
@@ -99,8 +99,8 @@ private:
   // read_state stuff
   NetMsgHeader m_net_msg_header;
   char *m_read_buffer;
-  unsigned int m_read_bytes_wanted;
-  unsigned int m_read_bytes_received;
+  int64 m_read_bytes_wanted;
+  int64 m_read_bytes_received;
 
   // client info
   int m_client_ip;

Modified: trafficserver/traffic/trunk/proxy/logging/LogConfig.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/proxy/logging/LogConfig.cc?rev=948906&r1=948905&r2=948906&view=diff
==============================================================================
--- trafficserver/traffic/trunk/proxy/logging/LogConfig.cc (original)
+++ trafficserver/traffic/trunk/proxy/logging/LogConfig.cc Thu May 27 16:47:00 2010
@@ -1062,7 +1062,7 @@ LogConfig::split_by_protocol(const PreDe
   };
   const char *name[] = { "icp", "mixt", "http" };
   const char *filter_name[] = { "__icp__", "__mixt__", "__http__" };
-  unsigned filter_val[http];    // protocols to reject
+  int64 filter_val[http];    // protocols to reject
   size_t n = 0;
 
   LogFilter *filter[1];
@@ -2573,7 +2573,7 @@ LogConfig::read_xml_log_config(int from_
         size_t n = tok.getNumTokensRemaining();
 
         if (n) {
-          unsigned *val_array = NEW(new unsigned[n]);
+          int64 *val_array = NEW(new int64[n]);
           size_t numValid = 0;
           char *t;
           while (t = tok.getNext(), t != NULL) {

Modified: trafficserver/traffic/trunk/proxy/logging/LogField.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/proxy/logging/LogField.cc?rev=948906&r1=948905&r2=948906&view=diff
==============================================================================
--- trafficserver/traffic/trunk/proxy/logging/LogField.cc (original)
+++ trafficserver/traffic/trunk/proxy/logging/LogField.cc Thu May 27 16:47:00 2010
@@ -305,7 +305,7 @@ unsigned
 LogField::marshal_agg(char *buf)
 {
   ink_assert(buf != NULL);
-  LOG_INT avg = 0;
+  int64 avg = 0;
 
   switch (m_agg_op) {
 
@@ -388,7 +388,7 @@ LogField::set_aggregate_op(LogField::Agg
   -------------------------------------------------------------------------*/
 
 void
-LogField::update_aggregate(LOG_INT val)
+LogField::update_aggregate(int64 val)
 {
   switch (m_agg_op) {
 

Modified: trafficserver/traffic/trunk/proxy/logging/LogField.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/proxy/logging/LogField.h?rev=948906&r1=948905&r2=948906&view=diff
==============================================================================
--- trafficserver/traffic/trunk/proxy/logging/LogField.h (original)
+++ trafficserver/traffic/trunk/proxy/logging/LogField.h Thu May 27 16:47:00 2010
@@ -20,15 +20,15 @@
   See the License for the specific language governing permissions and
   limitations under the License.
  */
-
-
-
 #ifndef LOG_FIELD_H
 #define LOG_FIELD_H
 
 #include "inktomi++.h"
 #include "LogFieldAliasMap.h"
 
+// This is setup for 64-bit log integers
+#define MIN_ALIGN	8
+
 class LogAccess;
 
 /*-------------------------------------------------------------------------
@@ -126,7 +126,7 @@ public:
   }
 
   void set_aggregate_op(Aggregate agg_op);
-  void update_aggregate(unsigned val);  // SAME AS LOG_INT
+  void update_aggregate(int64 val);
 
   static Container valid_container_name(char *name);
   static Aggregate valid_aggregate_name(char *name);
@@ -141,8 +141,8 @@ private:
   UnmarshalFunc m_unmarshal_func;       // create a string of the data
   UnmarshalFuncWithMap m_unmarshal_func_map;
   Aggregate m_agg_op;
-  unsigned m_agg_cnt;           // SAME AS LOG_INT
-  unsigned m_agg_val;           // SAME AS LOG_INT
+  int64 m_agg_cnt;
+  int64 m_agg_val;
   bool m_time_field;
   Ptr<LogFieldAliasMap> m_alias_map; // map sINT <--> string
 

Modified: trafficserver/traffic/trunk/proxy/logging/LogFieldAliasMap.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/proxy/logging/LogFieldAliasMap.h?rev=948906&r1=948905&r2=948906&view=diff
==============================================================================
--- trafficserver/traffic/trunk/proxy/logging/LogFieldAliasMap.h (original)
+++ trafficserver/traffic/trunk/proxy/logging/LogFieldAliasMap.h Thu May 27 16:47:00 2010
@@ -76,7 +76,8 @@ class LogFieldAliasMap:public RefCountOb
 {
 public:
   // the logging system assumes log entries of type sINT are
-  // unsigned integers (LOG_INT type) so we define IntType to be unsigned
+  // unsigned integers (int64 type) so we define IntType to be unsigned
+  // TODO/XXX: B0rken, need to fix this to int64
   typedef unsigned int IntType;
   enum
   { ALL_OK = 0, INVALID_INT, INVALID_STRING, BUFFER_TOO_SMALL };

Modified: trafficserver/traffic/trunk/proxy/logging/LogFilter.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/proxy/logging/LogFilter.cc?rev=948906&r1=948905&r2=948906&view=diff
==============================================================================
--- trafficserver/traffic/trunk/proxy/logging/LogFilter.cc (original)
+++ trafficserver/traffic/trunk/proxy/logging/LogFilter.cc Thu May 27 16:47:00 2010
@@ -375,23 +375,15 @@ bool LogFilterString::toss_this_entry(Lo
     return false;
   }
 
-  static const unsigned
-    BUFSIZE = 1024;
-  char
-    small_buf[BUFSIZE];
-  char
-    small_buf_upper[BUFSIZE];
-  char *
-    big_buf = NULL;
-  char *
-    big_buf_upper = NULL;
-  char *
-    buf = small_buf;
-  char *
-    buf_upper = small_buf_upper;
+  static const unsigned BUFSIZE = 1024;
+  char small_buf[BUFSIZE];
+  char small_buf_upper[BUFSIZE];
+  char *big_buf = NULL;
+  char *big_buf_upper = NULL;
+  char *buf = small_buf;
+  char *buf_upper = small_buf_upper;
+  size_t marsh_len = m_field->marshal_len(lad);      // includes null termination
 
-  size_t
-    marsh_len = m_field->marshal_len(lad);      // includes null termination
   if (marsh_len > BUFSIZE) {
     big_buf = (char *) xmalloc((unsigned int) marsh_len);
     ink_assert(big_buf != NULL);
@@ -495,18 +487,18 @@ LogFilterString::display_as_XML(FILE * f
   -------------------------------------------------------------------------*/
 
 void
-LogFilterInt::_setValues(size_t n, unsigned *value)
+LogFilterInt::_setValues(size_t n, int64 *value)
 {
   m_type = INT_FILTER;
   m_num_values = n;
   if (n) {
-    m_value = NEW(new unsigned[n]);
-    memcpy(m_value, value, n * sizeof(unsigned));
+    m_value = NEW(new int64[n]);
+    memcpy(m_value, value, n * sizeof(int64));
   }
 }
 
 int
-LogFilterInt::_convertStringToInt(char *value, unsigned *ival, LogFieldAliasMap * map)
+LogFilterInt::_convertStringToInt(char *value, int64 *ival, LogFieldAliasMap * map)
 {
   size_t i, l = strlen(value);
   for (i = 0; i < l && ParseRules::is_digit(value[i]); i++);
@@ -516,7 +508,8 @@ LogFilterInt::_convertStringToInt(char *
     // value is an alias and try to get the actual integer value
     // from the log field alias map if field has one
     //
-    if (map == NULL || map->asInt(value, ival) != LogFieldAliasMap::ALL_OK) {
+    // TODO: should not cast
+    if (map == NULL || map->asInt(value, (unsigned int*)ival) != LogFieldAliasMap::ALL_OK) {
       return -1;                // error
     };
   } else {
@@ -529,16 +522,16 @@ LogFilterInt::_convertStringToInt(char *
 }
 
 LogFilterInt::LogFilterInt(const char *name, LogField * field,
-                           LogFilter::Action action, LogFilter::Operator oper, unsigned value)
+                           LogFilter::Action action, LogFilter::Operator oper, int64 value)
 :LogFilter(name, field, action, oper)
 {
-  unsigned v[1];
+  int64  v[1];
   v[0] = value;
   _setValues(1, v);
 }
 
 LogFilterInt::LogFilterInt(const char *name, LogField * field,
-                           LogFilter::Action action, LogFilter::Operator oper, size_t num_values, unsigned *value)
+                           LogFilter::Action action, LogFilter::Operator oper, size_t num_values, int64 *value)
   :
 LogFilter(name, field, action, oper)
 {
@@ -552,15 +545,15 @@ LogFilter(name, field, action, oper)
 {
   // parse the comma-separated list of values and construct array
   //
-  unsigned *val_array = 0;
+  int64 *val_array = 0;
   size_t i = 0;
   SimpleTokenizer tok(values, ',');
   size_t n = tok.getNumTokensRemaining();
   if (n) {
-    val_array = NEW(new unsigned[n]);
+    val_array = NEW(new int64[n]);
     char *t;
     while (t = tok.getNext(), t != NULL) {
-      unsigned ival;
+      int64 ival;
       if (!_convertStringToInt(t, &ival, field->map())) {
         // conversion was successful, add entry to array
         //
@@ -635,10 +628,9 @@ bool LogFilterInt::toss_this_entry(LogAc
     return false;
   }
 
-  bool
-    cond_satisfied = false;
-  unsigned
-    value;
+  bool cond_satisfied = false;
+  int64 value;
+
   m_field->marshal(lad, (char *) &value);
   value = ntohl(value);
 
@@ -675,9 +667,9 @@ LogFilterInt::display(FILE * fd)
   } else {
     fprintf(fd, "Filter \"%s\" %sS records if %s %s ", m_name,
             ACTION_NAME[m_action], m_field->symbol(), OPERATOR_NAME[m_operator]);
-    fprintf(fd, "%u", m_value[0]);
+    fprintf(fd, "%lld", m_value[0]);
     for (size_t i = 1; i < m_num_values; ++i) {
-      fprintf(fd, ", %u", m_value[i]);
+      fprintf(fd, ", %lld", m_value[i]);
     }
     fprintf(fd, "\n");
   }
@@ -696,9 +688,9 @@ LogFilterInt::display_as_XML(FILE * fd)
   if (m_num_values == 0) {
     fprintf(fd, "<no values>\"\n");
   } else {
-    fprintf(fd, "%u", m_value[0]);
+    fprintf(fd, "%lld", m_value[0]);
     for (size_t i = 1; i < m_num_values; ++i) {
-      fprintf(fd, ", %u", m_value[i]);
+      fprintf(fd, ", %lld", m_value[i]);
     }
     fprintf(fd, "\"/>\n");
   }
@@ -851,6 +843,7 @@ unsigned
 LogFilterList::count()
 {
   unsigned cnt = 0;
+
   for (LogFilter * f = first(); f; f = next(f)) {
     cnt++;
   }

Modified: trafficserver/traffic/trunk/proxy/logging/LogFilter.h
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/proxy/logging/LogFilter.h?rev=948906&r1=948905&r2=948906&view=diff
==============================================================================
--- trafficserver/traffic/trunk/proxy/logging/LogFilter.h (original)
+++ trafficserver/traffic/trunk/proxy/logging/LogFilter.h Thu May 27 16:47:00 2010
@@ -183,8 +183,8 @@ private:
 class LogFilterInt:public LogFilter
 {
 public:
-  LogFilterInt(const char *name, LogField * field, Action a, Operator o, unsigned value);
-    LogFilterInt(const char *name, LogField * field, Action a, Operator o, size_t num_values, unsigned *value);
+  LogFilterInt(const char *name, LogField * field, Action a, Operator o, int64 value);
+    LogFilterInt(const char *name, LogField * field, Action a, Operator o, size_t num_values, int64 *value);
     LogFilterInt(const char *name, LogField * field, Action a, Operator o, char *values);
     LogFilterInt(const LogFilterInt & rhs);
    ~LogFilterInt();
@@ -195,10 +195,10 @@ public:
   void display_as_XML(FILE * fd = stdout);
 
 private:
-  unsigned *m_value;            // the array of values
+  int64 *m_value;            // the array of values
 
-  void _setValues(size_t n, unsigned *value);
-  int _convertStringToInt(char *val, unsigned *ival, LogFieldAliasMap * map);
+  void _setValues(size_t n, int64 *value);
+  int _convertStringToInt(char *val, int64 *ival, LogFieldAliasMap * map);
 
   // -- member functions that are not allowed --
     LogFilterInt();

Modified: trafficserver/traffic/trunk/proxy/logging/LogObject.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/proxy/logging/LogObject.cc?rev=948906&r1=948905&r2=948906&view=diff
==============================================================================
--- trafficserver/traffic/trunk/proxy/logging/LogObject.cc (original)
+++ trafficserver/traffic/trunk/proxy/logging/LogObject.cc Thu May 27 16:47:00 2010
@@ -495,10 +495,10 @@ LogObject::log(LogAccess * lad, char *te
     LogFieldList *fl = &m_format->m_field_list;
     char *data_ptr = m_format->m_agg_marshal_space;
     LogField *f;
-    LOG_INT val;
+    int64 val;
     for (f = fl->first(); f; f = fl->next(f)) {
       // convert to host order to do computations
-      val = (f->is_time_field())? time_now : ntohl(*((LOG_INT *) data_ptr));
+      val = (f->is_time_field())? time_now : ntohl(*((int64 *) data_ptr));
       f->update_aggregate(val);
       data_ptr += INK_MIN_ALIGN;
     }

Modified: trafficserver/traffic/trunk/proxy/logstats.cc
URL: http://svn.apache.org/viewvc/trafficserver/traffic/trunk/proxy/logstats.cc?rev=948906&r1=948905&r2=948906&view=diff
==============================================================================
--- trafficserver/traffic/trunk/proxy/logstats.cc (original)
+++ trafficserver/traffic/trunk/proxy/logstats.cc Thu May 27 16:47:00 2010
@@ -698,7 +698,7 @@ parse_log_buff(LogBufferHeader * buf_hea
       switch (state) {
       case P_STATE_ELAPSED:
         state = P_STATE_IP;
-        elapsed = ntohl(*((LOG_INT *) (read_from)));
+        elapsed = ntohl(*((int64 *) (read_from)));
         read_from += INK_MIN_ALIGN;
         break;
 
@@ -713,7 +713,7 @@ parse_log_buff(LogBufferHeader * buf_hea
 
       case P_STATE_RESULT:
         state = P_STATE_CODE;
-        result = ntohl(*((LOG_INT *) (read_from)));
+        result = ntohl(*((int64 *) (read_from)));
         read_from += INK_MIN_ALIGN;
         if ((result<32) || (result> 255)) {
           flag = 1;
@@ -723,7 +723,7 @@ parse_log_buff(LogBufferHeader * buf_hea
 
       case P_STATE_CODE:
         state = P_STATE_SIZE;
-        http_code = ntohl(*((LOG_INT *) (read_from)));
+        http_code = ntohl(*((int64 *) (read_from)));
         read_from += INK_MIN_ALIGN;
         if ((http_code<0) || (http_code> 999)) {
           flag = 1;
@@ -736,7 +736,7 @@ parse_log_buff(LogBufferHeader * buf_hea
         // Warning: This is not 64-bit safe, when converting the log format,
         // this needs to be fixed as well.
         state = P_STATE_METHOD;
-        size = ntohl(*((LOG_INT *) (read_from)));
+        size = ntohl(*((int64 *) (read_from)));
         read_from += INK_MIN_ALIGN;
         //printf("Size == %d\n", size)
         break;
@@ -868,7 +868,7 @@ parse_log_buff(LogBufferHeader * buf_hea
 
       case P_STATE_HIERARCHY:
         state = P_STATE_PEER;
-        hier = ntohl(*((LOG_INT *) (read_from)));
+        hier = ntohl(*((int64 *) (read_from)));
         switch (hier) {
         case SQUID_HIER_NONE:
           update_counter(totals.hierarchies.none, size);