You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@trafficserver.apache.org by ma...@apache.org on 2018/05/24 07:27:24 UTC

[trafficserver] branch master updated: Remove prepended "_" from public member of VIO

This is an automated email from the ASF dual-hosted git repository.

masaori pushed a commit to branch master
in repository https://gitbox.apache.org/repos/asf/trafficserver.git


The following commit(s) were added to refs/heads/master by this push:
     new 12cd0c1  Remove prepended "_" from public member of VIO
12cd0c1 is described below

commit 12cd0c10c4175a806c33265014b8c350b00ee4b3
Author: Masaori Koshiba <ma...@apache.org>
AuthorDate: Tue May 22 12:18:30 2018 +0900

    Remove prepended "_" from public member of VIO
    
    For consistency of naming convention. This has only name changes.
---
 iocore/cache/CacheWrite.cc       |  2 +-
 iocore/cache/P_CacheInternal.h   |  2 +-
 iocore/eventsystem/I_VIO.h       |  2 +-
 iocore/eventsystem/P_VIO.h       | 10 ++++-----
 iocore/net/SSLNetVConnection.cc  |  2 +-
 iocore/net/UnixNetVConnection.cc | 38 ++++++++++++++++-----------------
 proxy/CoreUtils.cc               |  2 +-
 proxy/InkIOCoreAPI.cc            |  2 +-
 proxy/PluginVC.cc                | 22 +++++++++----------
 proxy/Prefetch.cc                |  6 +++---
 proxy/Transform.cc               | 26 +++++++++++------------
 proxy/http2/Http2Stream.cc       | 46 ++++++++++++++++++++--------------------
 12 files changed, 80 insertions(+), 80 deletions(-)

diff --git a/iocore/cache/CacheWrite.cc b/iocore/cache/CacheWrite.cc
index ff8d66e..626b626 100644
--- a/iocore/cache/CacheWrite.cc
+++ b/iocore/cache/CacheWrite.cc
@@ -1149,7 +1149,7 @@ CacheVC::openWriteCloseDir(int /* event ATS_UNUSED */, Event * /* e ATS_UNUSED *
   if (f.close_complete) {
     recursive++;
     ink_assert(!vol || this_ethread() != vol->mutex->thread_holding);
-    vio._cont->handleEvent(VC_EVENT_WRITE_COMPLETE, (void *)&vio);
+    vio.cont->handleEvent(VC_EVENT_WRITE_COMPLETE, (void *)&vio);
     recursive--;
   }
   return free_CacheVC(this);
diff --git a/iocore/cache/P_CacheInternal.h b/iocore/cache/P_CacheInternal.h
index 1b35d56..5199d10 100644
--- a/iocore/cache/P_CacheInternal.h
+++ b/iocore/cache/P_CacheInternal.h
@@ -625,7 +625,7 @@ CacheVC::calluser(int event)
 {
   recursive++;
   ink_assert(!vol || this_ethread() != vol->mutex->thread_holding);
-  vio._cont->handleEvent(event, (void *)&vio);
+  vio.cont->handleEvent(event, (void *)&vio);
   recursive--;
   if (closed) {
     die();
diff --git a/iocore/eventsystem/I_VIO.h b/iocore/eventsystem/I_VIO.h
index 9e51722..e688717 100644
--- a/iocore/eventsystem/I_VIO.h
+++ b/iocore/eventsystem/I_VIO.h
@@ -165,7 +165,7 @@ public:
     call with events for this operation.
 
   */
-  Continuation *_cont;
+  Continuation *cont;
 
   /**
     Number of bytes to be done for this operation.
diff --git a/iocore/eventsystem/P_VIO.h b/iocore/eventsystem/P_VIO.h
index d72a0f9..d8fcb05 100644
--- a/iocore/eventsystem/P_VIO.h
+++ b/iocore/eventsystem/P_VIO.h
@@ -25,7 +25,7 @@
 #include "I_VIO.h"
 
 TS_INLINE
-VIO::VIO(int aop) : _cont(nullptr), nbytes(0), ndone(0), op(aop), buffer(), vc_server(nullptr), mutex(nullptr) {}
+VIO::VIO(int aop) : cont(nullptr), nbytes(0), ndone(0), op(aop), buffer(), vc_server(nullptr), mutex(nullptr) {}
 
 /////////////////////////////////////////////////////////////
 //
@@ -33,12 +33,12 @@ VIO::VIO(int aop) : _cont(nullptr), nbytes(0), ndone(0), op(aop), buffer(), vc_s
 //
 /////////////////////////////////////////////////////////////
 TS_INLINE
-VIO::VIO() : _cont(nullptr), nbytes(0), ndone(0), op(VIO::NONE), buffer(), vc_server(nullptr), mutex(nullptr) {}
+VIO::VIO() : cont(nullptr), nbytes(0), ndone(0), op(VIO::NONE), buffer(), vc_server(nullptr), mutex(nullptr) {}
 
 TS_INLINE Continuation *
 VIO::get_continuation()
 {
-  return _cont;
+  return cont;
 }
 TS_INLINE void
 VIO::set_writer(MIOBuffer *writer)
@@ -88,10 +88,10 @@ VIO::set_continuation(Continuation *acont)
   }
   if (acont) {
     mutex = acont->mutex;
-    _cont = acont;
+    cont  = acont;
   } else {
     mutex = nullptr;
-    _cont = nullptr;
+    cont  = nullptr;
   }
   return;
 }
diff --git a/iocore/net/SSLNetVConnection.cc b/iocore/net/SSLNetVConnection.cc
index 61c0fca..a3881e7 100644
--- a/iocore/net/SSLNetVConnection.cc
+++ b/iocore/net/SSLNetVConnection.cc
@@ -460,7 +460,7 @@ SSLNetVConnection::net_read_io(NetHandler *nh, EThread *lthread)
     return;
   }
 
-  MUTEX_TRY_LOCK_FOR(lock, s->vio.mutex, lthread, s->vio._cont);
+  MUTEX_TRY_LOCK_FOR(lock, s->vio.mutex, lthread, s->vio.cont);
   if (!lock.is_locked()) {
     readReschedule(nh);
     return;
diff --git a/iocore/net/UnixNetVConnection.cc b/iocore/net/UnixNetVConnection.cc
index 49515d3..3b9244e 100644
--- a/iocore/net/UnixNetVConnection.cc
+++ b/iocore/net/UnixNetVConnection.cc
@@ -79,8 +79,8 @@ static inline int
 read_signal_and_update(int event, UnixNetVConnection *vc)
 {
   vc->recursion++;
-  if (vc->read.vio._cont) {
-    vc->read.vio._cont->handleEvent(event, &vc->read.vio);
+  if (vc->read.vio.cont) {
+    vc->read.vio.cont->handleEvent(event, &vc->read.vio);
   } else {
     switch (event) {
     case VC_EVENT_EOS:
@@ -110,8 +110,8 @@ static inline int
 write_signal_and_update(int event, UnixNetVConnection *vc)
 {
   vc->recursion++;
-  if (vc->write.vio._cont) {
-    vc->write.vio._cont->handleEvent(event, &vc->write.vio);
+  if (vc->write.vio.cont) {
+    vc->write.vio.cont->handleEvent(event, &vc->write.vio);
   } else {
     switch (event) {
     case VC_EVENT_EOS:
@@ -186,7 +186,7 @@ read_from_net(NetHandler *nh, UnixNetVConnection *vc, EThread *thread)
   ProxyMutex *mutex = thread->mutex.get();
   int64_t r         = 0;
 
-  MUTEX_TRY_LOCK_FOR(lock, s->vio.mutex, thread, s->vio._cont);
+  MUTEX_TRY_LOCK_FOR(lock, s->vio.mutex, thread, s->vio.cont);
 
   if (!lock.is_locked()) {
     read_reschedule(nh, vc);
@@ -365,7 +365,7 @@ write_to_net_io(NetHandler *nh, UnixNetVConnection *vc, EThread *thread)
   NetState *s       = &vc->write;
   ProxyMutex *mutex = thread->mutex.get();
 
-  MUTEX_TRY_LOCK_FOR(lock, s->vio.mutex, thread, s->vio._cont);
+  MUTEX_TRY_LOCK_FOR(lock, s->vio.mutex, thread, s->vio.cont);
 
   if (!lock.is_locked() || lock.get_mutex() != s->vio.mutex.get()) {
     write_reschedule(nh, vc);
@@ -594,7 +594,7 @@ UnixNetVConnection::do_io_read(Continuation *c, int64_t nbytes, MIOBuffer *buf)
   }
   read.vio.op        = VIO::READ;
   read.vio.mutex     = c ? c->mutex : this->mutex;
-  read.vio._cont     = c;
+  read.vio.cont      = c;
   read.vio.nbytes    = nbytes;
   read.vio.ndone     = 0;
   read.vio.vc_server = (VConnection *)this;
@@ -619,7 +619,7 @@ UnixNetVConnection::do_io_write(Continuation *c, int64_t nbytes, IOBufferReader
   }
   write.vio.op        = VIO::WRITE;
   write.vio.mutex     = c ? c->mutex : this->mutex;
-  write.vio._cont     = c;
+  write.vio.cont      = c;
   write.vio.nbytes    = nbytes;
   write.vio.ndone     = 0;
   write.vio.vc_server = (VConnection *)this;
@@ -646,11 +646,11 @@ UnixNetVConnection::do_io_close(int alerrno /* = -1 */)
   read.vio.buffer.clear();
   read.vio.nbytes = 0;
   read.vio.op     = VIO::NONE;
-  read.vio._cont  = nullptr;
+  read.vio.cont   = nullptr;
   write.vio.buffer.clear();
   write.vio.nbytes = 0;
   write.vio.op     = VIO::NONE;
-  write.vio._cont  = nullptr;
+  write.vio.cont   = nullptr;
 
   EThread *t        = this_ethread();
   bool close_inline = !recursion && (!nh || nh->mutex->thread_holding == t);
@@ -683,7 +683,7 @@ UnixNetVConnection::do_io_shutdown(ShutdownHowTo_t howto)
     read.enabled = 0;
     read.vio.buffer.clear();
     read.vio.nbytes = 0;
-    read.vio._cont  = nullptr;
+    read.vio.cont   = nullptr;
     f.shutdown |= NET_VC_SHUTDOWN_READ;
     break;
   case IO_SHUTDOWN_WRITE:
@@ -691,7 +691,7 @@ UnixNetVConnection::do_io_shutdown(ShutdownHowTo_t howto)
     write.enabled = 0;
     write.vio.buffer.clear();
     write.vio.nbytes = 0;
-    write.vio._cont  = nullptr;
+    write.vio.cont   = nullptr;
     f.shutdown |= NET_VC_SHUTDOWN_WRITE;
     break;
   case IO_SHUTDOWN_READWRITE:
@@ -702,8 +702,8 @@ UnixNetVConnection::do_io_shutdown(ShutdownHowTo_t howto)
     read.vio.nbytes = 0;
     write.vio.buffer.clear();
     write.vio.nbytes = 0;
-    read.vio._cont   = nullptr;
-    write.vio._cont  = nullptr;
+    read.vio.cont    = nullptr;
+    write.vio.cont   = nullptr;
     f.shutdown       = NET_VC_SHUTDOWN_READ | NET_VC_SHUTDOWN_WRITE;
     break;
   default:
@@ -1177,7 +1177,7 @@ UnixNetVConnection::mainEvent(int event, Event *e)
 
   *signal_timeout    = nullptr;
   *signal_timeout_at = 0;
-  writer_cont        = write.vio._cont;
+  writer_cont        = write.vio.cont;
 
   if (closed) {
     nh->free_netvc(this);
@@ -1185,14 +1185,14 @@ UnixNetVConnection::mainEvent(int event, Event *e)
   }
 
   if (read.vio.op == VIO::READ && !(f.shutdown & NET_VC_SHUTDOWN_READ)) {
-    reader_cont = read.vio._cont;
+    reader_cont = read.vio.cont;
     if (read_signal_and_update(signal_event, this) == EVENT_DONE) {
       return EVENT_DONE;
     }
   }
 
   if (!*signal_timeout && !*signal_timeout_at && !closed && write.vio.op == VIO::WRITE && !(f.shutdown & NET_VC_SHUTDOWN_WRITE) &&
-      reader_cont != write.vio._cont && writer_cont == write.vio._cont) {
+      reader_cont != write.vio.cont && writer_cont == write.vio.cont) {
     if (write_signal_and_update(signal_event, this) == EVENT_DONE) {
       return EVENT_DONE;
     }
@@ -1336,8 +1336,8 @@ UnixNetVConnection::clear()
   write.triggered     = 0;
   read.enabled        = 0;
   write.enabled       = 0;
-  read.vio._cont      = nullptr;
-  write.vio._cont     = nullptr;
+  read.vio.cont       = nullptr;
+  write.vio.cont      = nullptr;
   read.vio.vc_server  = nullptr;
   write.vio.vc_server = nullptr;
   options.reset();
diff --git a/proxy/CoreUtils.cc b/proxy/CoreUtils.cc
index ff0f09f..0d9853f 100644
--- a/proxy/CoreUtils.cc
+++ b/proxy/CoreUtils.cc
@@ -740,7 +740,7 @@ void
 CoreUtils::print_netstate(NetState *n)
 {
   printf("      enabled: %d\n", n->enabled);
-  printf("      op: %d  _cont: 0x%p\n", n->vio.op, n->vio._cont);
+  printf("      op: %d  cont: 0x%p\n", n->vio.op, n->vio.cont);
   printf("      nbytes: %d  done: %d\n", (int)n->vio.nbytes, (int)n->vio.ndone);
   printf("      vc_server: 0x%p   mutex: 0x%p\n\n", n->vio.vc_server, n->vio.mutex.m_ptr);
 }
diff --git a/proxy/InkIOCoreAPI.cc b/proxy/InkIOCoreAPI.cc
index cb4ef01..cd6c65d 100644
--- a/proxy/InkIOCoreAPI.cc
+++ b/proxy/InkIOCoreAPI.cc
@@ -385,7 +385,7 @@ TSVIOContGet(TSVIO viop)
   sdk_assert(sdk_sanity_check_iocore_structure(viop) == TS_SUCCESS);
 
   VIO *vio = (VIO *)viop;
-  return (TSCont)vio->_cont;
+  return (TSCont)vio->cont;
 }
 
 TSVConn
diff --git a/proxy/PluginVC.cc b/proxy/PluginVC.cc
index 22cc24c..d4e2de5 100644
--- a/proxy/PluginVC.cc
+++ b/proxy/PluginVC.cc
@@ -263,7 +263,7 @@ PluginVC::do_io_read(Continuation *c, int64_t nbytes, MIOBuffer *buf)
   // Note: we set vio.op last because process_read_side looks at it to
   //  tell if the VConnection is active.
   read_state.vio.mutex     = c ? c->mutex : this->mutex;
-  read_state.vio._cont     = c;
+  read_state.vio.cont      = c;
   read_state.vio.nbytes    = nbytes;
   read_state.vio.ndone     = 0;
   read_state.vio.vc_server = (VConnection *)this;
@@ -295,7 +295,7 @@ PluginVC::do_io_write(Continuation *c, int64_t nbytes, IOBufferReader *abuffer,
   // Note: we set vio.op last because process_write_side looks at it to
   //  tell if the VConnection is active.
   write_state.vio.mutex     = c ? c->mutex : this->mutex;
-  write_state.vio._cont     = c;
+  write_state.vio.cont      = c;
   write_state.vio.nbytes    = nbytes;
   write_state.vio.ndone     = 0;
   write_state.vio.vc_server = (VConnection *)this;
@@ -512,7 +512,7 @@ PluginVC::process_write_side(bool other_side_call)
   Debug("pvc", "[%u] %s: process_write_side; act_on %" PRId64 "", core_obj->id, PVC_TYPE, act_on);
 
   if (other_side->closed || other_side->read_state.shutdown) {
-    write_state.vio._cont->handleEvent(VC_EVENT_ERROR, &write_state.vio);
+    write_state.vio.cont->handleEvent(VC_EVENT_ERROR, &write_state.vio);
     return;
   }
 
@@ -520,7 +520,7 @@ PluginVC::process_write_side(bool other_side_call)
     if (ntodo > 0) {
       // Notify the continuation that we are "disabling"
       //  ourselves due to to nothing to write
-      write_state.vio._cont->handleEvent(VC_EVENT_WRITE_READY, &write_state.vio);
+      write_state.vio.cont->handleEvent(VC_EVENT_WRITE_READY, &write_state.vio);
     }
     return;
   }
@@ -548,9 +548,9 @@ PluginVC::process_write_side(bool other_side_call)
   Debug("pvc", "[%u] %s: process_write_side; added %" PRId64 "", core_obj->id, PVC_TYPE, added);
 
   if (write_state.vio.ntodo() == 0) {
-    write_state.vio._cont->handleEvent(VC_EVENT_WRITE_COMPLETE, &write_state.vio);
+    write_state.vio.cont->handleEvent(VC_EVENT_WRITE_COMPLETE, &write_state.vio);
   } else {
-    write_state.vio._cont->handleEvent(VC_EVENT_WRITE_READY, &write_state.vio);
+    write_state.vio.cont->handleEvent(VC_EVENT_WRITE_READY, &write_state.vio);
   }
 
   update_inactive_time();
@@ -631,7 +631,7 @@ PluginVC::process_read_side(bool other_side_call)
 
   if (act_on <= 0) {
     if (other_side->closed || other_side->write_state.shutdown) {
-      read_state.vio._cont->handleEvent(VC_EVENT_EOS, &read_state.vio);
+      read_state.vio.cont->handleEvent(VC_EVENT_EOS, &read_state.vio);
     }
     return;
   }
@@ -663,9 +663,9 @@ PluginVC::process_read_side(bool other_side_call)
   Debug("pvc", "[%u] %s: process_read_side; added %" PRId64 "", core_obj->id, PVC_TYPE, added);
 
   if (read_state.vio.ntodo() == 0) {
-    read_state.vio._cont->handleEvent(VC_EVENT_READ_COMPLETE, &read_state.vio);
+    read_state.vio.cont->handleEvent(VC_EVENT_READ_COMPLETE, &read_state.vio);
   } else {
-    read_state.vio._cont->handleEvent(VC_EVENT_READ_READY, &read_state.vio);
+    read_state.vio.cont->handleEvent(VC_EVENT_READ_READY, &read_state.vio);
   }
 
   update_inactive_time();
@@ -765,7 +765,7 @@ PluginVC::process_timeout(Event **e, int event_to_send)
       return;
     }
     *e = nullptr;
-    read_state.vio._cont->handleEvent(event_to_send, &read_state.vio);
+    read_state.vio.cont->handleEvent(event_to_send, &read_state.vio);
   } else if (write_state.vio.op == VIO::WRITE && !write_state.shutdown && write_state.vio.ntodo() > 0) {
     MUTEX_TRY_LOCK(lock, write_state.vio.mutex, (*e)->ethread);
     if (!lock.is_locked()) {
@@ -776,7 +776,7 @@ PluginVC::process_timeout(Event **e, int event_to_send)
       return;
     }
     *e = nullptr;
-    write_state.vio._cont->handleEvent(event_to_send, &write_state.vio);
+    write_state.vio.cont->handleEvent(event_to_send, &write_state.vio);
   } else {
     *e = nullptr;
   }
diff --git a/proxy/Prefetch.cc b/proxy/Prefetch.cc
index c487021..bed1f33 100644
--- a/proxy/Prefetch.cc
+++ b/proxy/Prefetch.cc
@@ -435,7 +435,7 @@ PrefetchTransform::handle_event(int event, void *edata)
   } else {
     switch (event) {
     case VC_EVENT_ERROR:
-      m_write_vio._cont->handleEvent(VC_EVENT_ERROR, &m_write_vio);
+      m_write_vio.cont->handleEvent(VC_EVENT_ERROR, &m_write_vio);
       break;
 
     case VC_EVENT_WRITE_COMPLETE:
@@ -506,12 +506,12 @@ PrefetchTransform::handle_event(int event, void *edata)
       if (m_write_vio.ntodo() > 0) {
         if (towrite > 0) {
           m_output_vio->reenable();
-          m_write_vio._cont->handleEvent(VC_EVENT_WRITE_READY, &m_write_vio);
+          m_write_vio.cont->handleEvent(VC_EVENT_WRITE_READY, &m_write_vio);
         }
       } else {
         m_output_vio->nbytes = m_write_vio.ndone;
         m_output_vio->reenable();
-        m_write_vio._cont->handleEvent(VC_EVENT_WRITE_COMPLETE, &m_write_vio);
+        m_write_vio.cont->handleEvent(VC_EVENT_WRITE_COMPLETE, &m_write_vio);
       }
 
       break;
diff --git a/proxy/Transform.cc b/proxy/Transform.cc
index 631ab51..d45d2df 100644
--- a/proxy/Transform.cc
+++ b/proxy/Transform.cc
@@ -213,10 +213,10 @@ TransformTerminus::handle_event(int event, void * /* edata ATS_UNUSED */)
 
       if (m_write_vio.ntodo() > 0) {
         if (towrite > 0) {
-          m_write_vio._cont->handleEvent(VC_EVENT_WRITE_READY, &m_write_vio);
+          m_write_vio.cont->handleEvent(VC_EVENT_WRITE_READY, &m_write_vio);
         }
       } else {
-        m_write_vio._cont->handleEvent(VC_EVENT_WRITE_COMPLETE, &m_write_vio);
+        m_write_vio.cont->handleEvent(VC_EVENT_WRITE_COMPLETE, &m_write_vio);
       }
 
       // We could have closed on the write callback
@@ -226,12 +226,12 @@ TransformTerminus::handle_event(int event, void * /* edata ATS_UNUSED */)
 
       if (m_read_vio.ntodo() > 0) {
         if (m_write_vio.ntodo() <= 0) {
-          m_read_vio._cont->handleEvent(VC_EVENT_EOS, &m_read_vio);
+          m_read_vio.cont->handleEvent(VC_EVENT_EOS, &m_read_vio);
         } else if (towrite > 0) {
-          m_read_vio._cont->handleEvent(VC_EVENT_READ_READY, &m_read_vio);
+          m_read_vio.cont->handleEvent(VC_EVENT_READ_READY, &m_read_vio);
         }
       } else {
-        m_read_vio._cont->handleEvent(VC_EVENT_READ_COMPLETE, &m_read_vio);
+        m_read_vio.cont->handleEvent(VC_EVENT_READ_COMPLETE, &m_read_vio);
       }
     }
   } else {
@@ -256,8 +256,8 @@ TransformTerminus::handle_event(int event, void * /* edata ATS_UNUSED */)
           m_called_user = 1;
           m_tvc->m_cont->handleEvent(ev, &m_read_vio);
         } else {
-          ink_assert(m_read_vio._cont != nullptr);
-          m_read_vio._cont->handleEvent(ev, &m_read_vio);
+          ink_assert(m_read_vio.cont != nullptr);
+          m_read_vio.cont->handleEvent(ev, &m_read_vio);
         }
       }
 
@@ -639,7 +639,7 @@ NullTransform::handle_event(int event, void *edata)
   } else {
     switch (event) {
     case VC_EVENT_ERROR:
-      m_write_vio._cont->handleEvent(VC_EVENT_ERROR, &m_write_vio);
+      m_write_vio.cont->handleEvent(VC_EVENT_ERROR, &m_write_vio);
       break;
     case VC_EVENT_WRITE_COMPLETE:
       ink_assert(m_output_vio == (VIO *)edata);
@@ -702,12 +702,12 @@ NullTransform::handle_event(int event, void *edata)
       if (m_write_vio.ntodo() > 0) {
         if (towrite > 0) {
           m_output_vio->reenable();
-          m_write_vio._cont->handleEvent(VC_EVENT_WRITE_READY, &m_write_vio);
+          m_write_vio.cont->handleEvent(VC_EVENT_WRITE_READY, &m_write_vio);
         }
       } else {
         m_output_vio->nbytes = m_write_vio.ndone;
         m_output_vio->reenable();
-        m_write_vio._cont->handleEvent(VC_EVENT_WRITE_COMPLETE, &m_write_vio);
+        m_write_vio.cont->handleEvent(VC_EVENT_WRITE_COMPLETE, &m_write_vio);
       }
 
       break;
@@ -794,7 +794,7 @@ RangeTransform::handle_event(int event, void *edata)
   } else {
     switch (event) {
     case VC_EVENT_ERROR:
-      m_write_vio._cont->handleEvent(VC_EVENT_ERROR, &m_write_vio);
+      m_write_vio.cont->handleEvent(VC_EVENT_ERROR, &m_write_vio);
       break;
     case VC_EVENT_WRITE_COMPLETE:
       ink_assert(m_output_vio == (VIO *)edata);
@@ -910,7 +910,7 @@ RangeTransform::transform_to_range()
         //   input data, send VC_EVENT_EOS to let the upstream know
         //   that it can rely on us consuming any more data
         int cb_event = (m_write_vio.ntodo() > 0) ? VC_EVENT_EOS : VC_EVENT_WRITE_COMPLETE;
-        m_write_vio._cont->handleEvent(cb_event, &m_write_vio);
+        m_write_vio.cont->handleEvent(cb_event, &m_write_vio);
         return;
       }
 
@@ -946,7 +946,7 @@ RangeTransform::transform_to_range()
   }
 
   m_output_vio->reenable();
-  m_write_vio._cont->handleEvent(VC_EVENT_WRITE_READY, &m_write_vio);
+  m_write_vio.cont->handleEvent(VC_EVENT_WRITE_READY, &m_write_vio);
 }
 
 /*-------------------------------------------------------------------------
diff --git a/proxy/http2/Http2Stream.cc b/proxy/http2/Http2Stream.cc
index 9232ed8..85453e2 100644
--- a/proxy/http2/Http2Stream.cc
+++ b/proxy/http2/Http2Stream.cc
@@ -71,16 +71,16 @@ Http2Stream::main_event_handler(int event, void *edata)
     if (current_reader && read_vio.ntodo() > 0) {
       MUTEX_TRY_LOCK(lock, read_vio.mutex, this_ethread());
       if (lock.is_locked()) {
-        read_vio._cont->handleEvent(event, &read_vio);
+        read_vio.cont->handleEvent(event, &read_vio);
       } else {
-        this_ethread()->schedule_imm(read_vio._cont, event, &read_vio);
+        this_ethread()->schedule_imm(read_vio.cont, event, &read_vio);
       }
     } else if (current_reader && write_vio.ntodo() > 0) {
       MUTEX_TRY_LOCK(lock, write_vio.mutex, this_ethread());
       if (lock.is_locked()) {
-        write_vio._cont->handleEvent(event, &write_vio);
+        write_vio.cont->handleEvent(event, &write_vio);
       } else {
-        this_ethread()->schedule_imm(write_vio._cont, event, &write_vio);
+        this_ethread()->schedule_imm(write_vio.cont, event, &write_vio);
       }
     }
     break;
@@ -90,10 +90,10 @@ Http2Stream::main_event_handler(int event, void *edata)
     if (e->cookie == &write_vio) {
       if (write_vio.mutex) {
         MUTEX_TRY_LOCK(lock, write_vio.mutex, this_ethread());
-        if (lock.is_locked() && write_vio._cont && this->current_reader) {
-          write_vio._cont->handleEvent(event, &write_vio);
+        if (lock.is_locked() && write_vio.cont && this->current_reader) {
+          write_vio.cont->handleEvent(event, &write_vio);
         } else {
-          this_ethread()->schedule_imm(write_vio._cont, event, &write_vio);
+          this_ethread()->schedule_imm(write_vio.cont, event, &write_vio);
         }
       }
     } else {
@@ -106,10 +106,10 @@ Http2Stream::main_event_handler(int event, void *edata)
     if (e->cookie == &read_vio) {
       if (read_vio.mutex) {
         MUTEX_TRY_LOCK(lock, read_vio.mutex, this_ethread());
-        if (lock.is_locked() && read_vio._cont && this->current_reader) {
-          read_vio._cont->handleEvent(event, &read_vio);
+        if (lock.is_locked() && read_vio.cont && this->current_reader) {
+          read_vio.cont->handleEvent(event, &read_vio);
         } else {
-          this_ethread()->schedule_imm(read_vio._cont, event, &read_vio);
+          this_ethread()->schedule_imm(read_vio.cont, event, &read_vio);
         }
       }
     } else {
@@ -119,10 +119,10 @@ Http2Stream::main_event_handler(int event, void *edata)
   case VC_EVENT_EOS:
     if (e->cookie == &read_vio) {
       SCOPED_MUTEX_LOCK(lock, read_vio.mutex, this_ethread());
-      read_vio._cont->handleEvent(VC_EVENT_EOS, &read_vio);
+      read_vio.cont->handleEvent(VC_EVENT_EOS, &read_vio);
     } else if (e->cookie == &write_vio) {
       SCOPED_MUTEX_LOCK(lock, write_vio.mutex, this_ethread());
-      write_vio._cont->handleEvent(VC_EVENT_EOS, &write_vio);
+      write_vio.cont->handleEvent(VC_EVENT_EOS, &write_vio);
     }
     break;
   }
@@ -281,7 +281,7 @@ Http2Stream::do_io_read(Continuation *c, int64_t nbytes, MIOBuffer *buf)
   }
 
   read_vio.mutex     = c ? c->mutex : this->mutex;
-  read_vio._cont     = c;
+  read_vio.cont      = c;
   read_vio.nbytes    = nbytes;
   read_vio.ndone     = 0;
   read_vio.vc_server = this;
@@ -303,7 +303,7 @@ Http2Stream::do_io_write(Continuation *c, int64_t nbytes, IOBufferReader *abuffe
     write_vio.buffer.clear();
   }
   write_vio.mutex     = c ? c->mutex : this->mutex;
-  write_vio._cont     = c;
+  write_vio.cont      = c;
   write_vio.nbytes    = nbytes;
   write_vio.ndone     = 0;
   write_vio.vc_server = this;
@@ -411,7 +411,7 @@ Http2Stream::initiating_close()
     bool sent_write_complete = false;
     if (current_reader) {
       // Push out any last IO events
-      if (write_vio._cont) {
+      if (write_vio.cont) {
         SCOPED_MUTEX_LOCK(lock, write_vio.mutex, this_ethread());
         // Are we done?
         if (write_vio.nbytes == write_vio.ndone) {
@@ -425,7 +425,7 @@ Http2Stream::initiating_close()
       }
     }
     // Send EOS to let SM know that we aren't sticking around
-    if (current_reader && read_vio._cont) {
+    if (current_reader && read_vio.cont) {
       // Only bother with the EOS if we haven't sent the write complete
       if (!sent_write_complete) {
         SCOPED_MUTEX_LOCK(lock, read_vio.mutex, this_ethread());
@@ -493,8 +493,8 @@ Http2Stream::update_read_request(int64_t read_len, bool call_update, bool check_
           int send_event = (read_vio.nbytes == read_vio.ndone || recv_end_stream) ? VC_EVENT_READ_COMPLETE : VC_EVENT_READ_READY;
           if (call_update) { // Safe to call vio handler directly
             inactive_timeout_at = Thread::get_hrtime() + inactive_timeout;
-            if (read_vio._cont && this->current_reader) {
-              read_vio._cont->handleEvent(send_event, &read_vio);
+            if (read_vio.cont && this->current_reader) {
+              read_vio.cont->handleEvent(send_event, &read_vio);
             }
           } else { // Called from do_io_read.  Still setting things up.  Send event to handle this after the dust settles
             read_event = send_tracked_event(read_event, send_event, &read_vio);
@@ -507,8 +507,8 @@ Http2Stream::update_read_request(int64_t read_len, bool call_update, bool check_
       if (request_reader->read_avail() > 0 || send_event == VC_EVENT_READ_COMPLETE) {
         if (call_update) { // Safe to call vio handler directly
           inactive_timeout_at = Thread::get_hrtime() + inactive_timeout;
-          if (read_vio._cont && this->current_reader) {
-            read_vio._cont->handleEvent(send_event, &read_vio);
+          if (read_vio.cont && this->current_reader) {
+            read_vio.cont->handleEvent(send_event, &read_vio);
           }
         } else { // Called from do_io_read.  Still setting things up.  Send event
                  // to handle this after the dust settles
@@ -646,7 +646,7 @@ Http2Stream::update_write_request(IOBufferReader *buf_reader, int64_t write_len,
 void
 Http2Stream::signal_write_event(bool call_update)
 {
-  if (this->write_vio._cont == nullptr || this->write_vio.op == VIO::NONE) {
+  if (this->write_vio.cont == nullptr || this->write_vio.op == VIO::NONE) {
     return;
   }
 
@@ -658,8 +658,8 @@ Http2Stream::signal_write_event(bool call_update)
 
   if (call_update) {
     // Coming from reenable.  Safe to call the handler directly
-    if (write_vio._cont && this->current_reader) {
-      write_vio._cont->handleEvent(send_event, &write_vio);
+    if (write_vio.cont && this->current_reader) {
+      write_vio.cont->handleEvent(send_event, &write_vio);
     }
   } else {
     // Called from do_io_write. Might still be setting up state. Send an event to let the dust settle

-- 
To stop receiving notification emails like this one, please contact
masaori@apache.org.