You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@trafficserver.apache.org by so...@apache.org on 2016/05/31 15:54:45 UTC

[trafficserver] branch 6.2.x updated (65734ed -> 48e8693)

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

sorber pushed a change to branch 6.2.x
in repository https://git-dual.apache.org/repos/asf/trafficserver.git.

      from  65734ed   TS-3123: Missing break statement and failing clang-analyzer
       new  07f3de8   Prevent segfault dealocating a NULL buffer_reader.
       new  202051c   TS-4485 schedule HostDBSyncer in ET_TASK threads instead of ET_NET threads
       new  419d1af   TS-4472: Decrement http_current_active_client_connections_stat in HTTP/2
       new  a411800   TS-4477: Decrement http_current_client_transactions_stat in HTTP/2
       new  ccd8e78   TS-4473: Fix ParentProxy API test race condition.
       new  e8adf71   TS-4473: Fix formatting.
       new  14ecf6a   TS-4473: Failed clang-analyzer, dereference null pointer
       new  63c0f14   TS-4473: Reset txnp after restoring the deferred event.
       new  48e8693   TS-4461: SSL Client Connections not closed.

The 9 revisions listed above as "new" are entirely new to this
repository and will be described in separate emails.  The revisions
listed as "adds" were already present in the repository and have only
been added to this reference.


Summary of changes:
 iocore/hostdb/HostDB.cc              |  7 +++---
 iocore/hostdb/MultiCache.cc          |  4 ++--
 iocore/net/P_UnixNetVConnection.h    |  6 ++++-
 proxy/InkAPITest.cc                  | 43 ++++++++++++++++++++++++++++++++++--
 proxy/http/Http1ClientSession.cc     | 13 ++++++-----
 proxy/http/Http1ClientTransaction.cc |  2 +-
 proxy/http/HttpSM.cc                 |  2 +-
 proxy/http/HttpTunnel.cc             |  6 +++--
 proxy/http2/Http2Stream.cc           |  6 +++++
 9 files changed, 71 insertions(+), 18 deletions(-)

-- 
To stop receiving notification emails like this one, please contact
['"commits@trafficserver.apache.org" <co...@trafficserver.apache.org>'].

[trafficserver] 09/09: TS-4461: SSL Client Connections not closed.

Posted by so...@apache.org.
This is an automated email from the ASF dual-hosted git repository.

sorber pushed a commit to branch 6.2.x
in repository https://git-dual.apache.org/repos/asf/trafficserver.git

commit 48e869374b24c8c50e56a740f5bedad7aa5c1d80
Author: Susan Hinrichs <sh...@ieee.org>
AuthorDate: Thu May 26 02:09:48 2016 +0000

    TS-4461: SSL Client Connections not closed.
    
    (cherry picked from commit 456ade9ab35787d39d3414149a0ee04f44008268)
---
 iocore/net/P_UnixNetVConnection.h    |  6 +++++-
 proxy/http/Http1ClientSession.cc     | 13 +++++++------
 proxy/http/Http1ClientTransaction.cc |  2 +-
 proxy/http/HttpSM.cc                 |  2 +-
 4 files changed, 14 insertions(+), 9 deletions(-)

diff --git a/iocore/net/P_UnixNetVConnection.h b/iocore/net/P_UnixNetVConnection.h
index 9b10cbf..bef0191 100644
--- a/iocore/net/P_UnixNetVConnection.h
+++ b/iocore/net/P_UnixNetVConnection.h
@@ -372,7 +372,11 @@ UnixNetVConnection::set_inactivity_timeout(ink_hrtime timeout)
   } else
     inactivity_timeout = 0;
 #else
-  next_inactivity_timeout_at = Thread::get_hrtime() + timeout;
+  if (timeout) {
+    next_inactivity_timeout_at = Thread::get_hrtime() + timeout;
+  } else {
+    next_inactivity_timeout_at = 0;
+  }
 #endif
 }
 
diff --git a/proxy/http/Http1ClientSession.cc b/proxy/http/Http1ClientSession.cc
index 508b593..e31b953 100644
--- a/proxy/http/Http1ClientSession.cc
+++ b/proxy/http/Http1ClientSession.cc
@@ -266,7 +266,7 @@ Http1ClientSession::do_io_close(int alerrno)
       // Set the active timeout to the same as the inactive time so
       //   that this connection does not hang around forever if
       //   the ua hasn't closed
-      client_vc->set_active_timeout(HRTIME_SECONDS(trans.get_sm()->t_state.txn_conf->keep_alive_no_activity_timeout_out));
+      client_vc->set_active_timeout(HRTIME_SECONDS(trans.get_sm()->t_state.txn_conf->keep_alive_no_activity_timeout_in));
     }
 
     // [bug 2610799] Drain any data read.
@@ -427,9 +427,10 @@ Http1ClientSession::release(ProxyClientTransaction *trans)
     ka_vio = this->do_io_read(this, INT64_MAX, read_buffer);
     ink_assert(slave_ka_vio != ka_vio);
 
-    // Y!?
-    // client_vc->add_to_keep_alive_lru();
-    client_vc->cancel_active_timeout();
+    if (client_vc) {
+      client_vc->cancel_active_timeout();
+      client_vc->add_to_keep_alive_queue();
+    }
     trans->destroy();
   }
 }
@@ -451,8 +452,8 @@ Http1ClientSession::new_transaction()
 
   trans.set_parent(this);
   transact_count++;
-  // Y!?
-  // client_vc->remove_from_keep_alive_lru();
+
+  client_vc->add_to_active_queue();
   trans.new_transaction();
 }
 
diff --git a/proxy/http/Http1ClientTransaction.cc b/proxy/http/Http1ClientTransaction.cc
index 22fb1d5..074d283 100644
--- a/proxy/http/Http1ClientTransaction.cc
+++ b/proxy/http/Http1ClientTransaction.cc
@@ -31,7 +31,7 @@ Http1ClientTransaction::release(IOBufferReader *r)
   // Must set this inactivity count here rather than in the session because the state machine
   // is not availble then
   MgmtInt ka_in = current_reader->t_state.txn_conf->keep_alive_no_activity_timeout_in;
-  get_netvc()->set_inactivity_timeout(HRTIME_SECONDS(ka_in));
+  set_inactivity_timeout(HRTIME_SECONDS(ka_in));
 
   if (m_active) {
     m_active = false;
diff --git a/proxy/http/HttpSM.cc b/proxy/http/HttpSM.cc
index c8f7cd1..8652597 100644
--- a/proxy/http/HttpSM.cc
+++ b/proxy/http/HttpSM.cc
@@ -5613,7 +5613,7 @@ HttpSM::do_setup_post_tunnel(HttpVC_t to_vc_type)
   if (chunked)
     tunnel.set_producer_chunking_action(p, 0, TCA_PASSTHRU_CHUNKED_CONTENT);
 
-  ua_session->get_netvc()->set_inactivity_timeout(HRTIME_SECONDS(t_state.txn_conf->transaction_no_activity_timeout_in));
+  ua_session->set_inactivity_timeout(HRTIME_SECONDS(t_state.txn_conf->transaction_no_activity_timeout_in));
   server_session->get_netvc()->set_inactivity_timeout(HRTIME_SECONDS(t_state.txn_conf->transaction_no_activity_timeout_out));
 
   tunnel.tunnel_run(p);

-- 
To stop receiving notification emails like this one, please contact
"commits@trafficserver.apache.org" <co...@trafficserver.apache.org>.

[trafficserver] 02/09: TS-4485 schedule HostDBSyncer in ET_TASK threads instead of ET_NET threads

Posted by so...@apache.org.
This is an automated email from the ASF dual-hosted git repository.

sorber pushed a commit to branch 6.2.x
in repository https://git-dual.apache.org/repos/asf/trafficserver.git

commit 202051c8d19516dcafaac6c4152c06e837ea14d7
Author: Thomas Jackson <ja...@gmail.com>
AuthorDate: Wed May 25 22:36:21 2016 -0700

    TS-4485 schedule HostDBSyncer in ET_TASK threads instead of ET_NET threads
    
    (cherry picked from commit be315479d3d33d7452a90ecc1aa2f9f7664d443d)
---
 iocore/hostdb/HostDB.cc     | 7 ++++---
 iocore/hostdb/MultiCache.cc | 4 ++--
 2 files changed, 6 insertions(+), 5 deletions(-)

diff --git a/iocore/hostdb/HostDB.cc b/iocore/hostdb/HostDB.cc
index b83ddff..10c0111 100644
--- a/iocore/hostdb/HostDB.cc
+++ b/iocore/hostdb/HostDB.cc
@@ -394,9 +394,9 @@ HostDBSyncer::wait_event(int, void *)
 
   SET_HANDLER(&HostDBSyncer::sync_event);
   if (next_sync > HRTIME_MSECONDS(100))
-    mutex->thread_holding->schedule_in_local(this, next_sync);
+    eventProcessor.schedule_in(this, next_sync, ET_TASK);
   else
-    mutex->thread_holding->schedule_imm_local(this);
+    eventProcessor.schedule_imm(this, ET_TASK);
   return EVENT_DONE;
 }
 
@@ -526,7 +526,8 @@ HostDBProcessor::start(int, size_t)
   // Sync HostDB, if we've asked for it.
   //
   if (hostdb_sync_frequency > 0)
-    eventProcessor.schedule_imm(new HostDBSyncer);
+    eventProcessor.schedule_imm(new HostDBSyncer, ET_TASK);
+
   return 0;
 }
 
diff --git a/iocore/hostdb/MultiCache.cc b/iocore/hostdb/MultiCache.cc
index 2e6951a..1105fb0 100644
--- a/iocore/hostdb/MultiCache.cc
+++ b/iocore/hostdb/MultiCache.cc
@@ -1177,9 +1177,9 @@ MultiCacheBase::sync_partitions(Continuation *cont)
   // don't try to sync if we were not correctly initialized
   if (data && mapped_header) {
     if (heap_used[heap_halfspace] > halfspace_size() * MULTI_CACHE_HEAP_HIGH_WATER)
-      eventProcessor.schedule_imm(new MultiCacheHeapGC(cont, this), ET_CALL);
+      eventProcessor.schedule_imm(new MultiCacheHeapGC(cont, this), ET_TASK);
     else
-      eventProcessor.schedule_imm(new MultiCacheSync(cont, this), ET_CALL);
+      eventProcessor.schedule_imm(new MultiCacheSync(cont, this), ET_TASK);
   }
 }
 

-- 
To stop receiving notification emails like this one, please contact
"commits@trafficserver.apache.org" <co...@trafficserver.apache.org>.

[trafficserver] 05/09: TS-4473: Fix ParentProxy API test race condition.

Posted by so...@apache.org.
This is an automated email from the ASF dual-hosted git repository.

sorber pushed a commit to branch 6.2.x
in repository https://git-dual.apache.org/repos/asf/trafficserver.git

commit ccd8e78ed1d2ab64d847a1964ea9671164827aa7
Author: James Peach <jp...@apache.org>
AuthorDate: Mon May 23 16:12:54 2016 -0700

    TS-4473: Fix ParentProxy API test race condition.
    
    The actual configuration change is made an undefined time after
    applying the configuration change, so when we write tests that
    depend on changing the configuration, we need to wait until it is
    applied.
    
    (cherry picked from commit 08b2ed4aa22e67ee77ee8a128154c7e9d4012b6f)
---
 proxy/InkAPITest.cc | 37 ++++++++++++++++++++++++++++++++++++-
 1 file changed, 36 insertions(+), 1 deletion(-)

diff --git a/proxy/InkAPITest.cc b/proxy/InkAPITest.cc
index 8f87248..51f670e 100644
--- a/proxy/InkAPITest.cc
+++ b/proxy/InkAPITest.cc
@@ -5269,7 +5269,7 @@ REGRESSION_TEST(SDK_API_TSTextLog)(RegressionTest *test, int /* atype ATS_UNUSED
 
 REGRESSION_TEST(SDK_API_TSMgmtGet)(RegressionTest *test, int /* atype ATS_UNUSED */, int *pstatus)
 {
-  const char *CONFIG_PARAM_COUNTER_NAME = "proxy.process.http.total_parent_proxy_connections";
+  const char *CONFIG_PARAM_COUNTER_NAME = "proxy.process.ssl.total_tickets_renewed";
   int CONFIG_PARAM_COUNTER_VALUE = 0;
 
   const char *CONFIG_PARAM_FLOAT_NAME = "proxy.config.http.background_fill_completed_threshold";
@@ -5900,6 +5900,8 @@ struct ParentTest {
     this->regtest = test;
     this->pstatus = pstatus;
     this->magic = MAGIC_ALIVE;
+    this->deferred.event = TS_EVENT_NONE;
+    this->deferred.edata = NULL;
 
     /* If parent proxy routing is not enabled, enable it for the life of the test. */
     RecGetRecordBool("proxy.config.http.parent_proxy_routing_enable", &this->parent_proxy_routing_enable);
@@ -5920,9 +5922,24 @@ struct ParentTest {
     this->magic = MAGIC_DEAD;
   }
 
+  bool parent_routing_enabled() const {
+    RecBool enabled = false;
+
+    ParentConfigParams *params = ParentConfig::acquire();
+    enabled = params->policy.ParentEnable;
+    ParentConfig::release(params);
+
+    return enabled;
+  }
+
   RegressionTest *regtest;
   int *pstatus;
 
+  struct {
+    TSEvent event;
+    void *  edata;
+  } deferred;
+
   const char *testcase;
   SocketServer *os;
   ClientTxn *browser;
@@ -6006,8 +6023,26 @@ parent_proxy_handler(TSCont contp, TSEvent event, void *edata)
   CHECK_SPURIOUS_EVENT(contp, event, edata);
   ptest = (ParentTest *)TSContDataGet(contp);
 
+  if (ptest && ptest->deferred.event != TS_EVENT_NONE) {
+    event = ptest->deferred.event;
+    edata = ptest->deferred.edata;
+    ptest->deferred.event = TS_EVENT_NONE;
+    ptest->deferred.edata = NULL;
+  }
+
   switch (event) {
   case TS_EVENT_HTTP_READ_REQUEST_HDR:
+    // Keep deferring the test start until the parent configuration
+    // has taken effect.
+    if (!ptest->parent_routing_enabled()) {
+      rprintf(ptest->regtest, "waiting for parent proxy configuration\n");
+
+      ptest->deferred.event = event;
+      ptest->deferred.edata = edata;
+      TSContSchedule(contp, 100, TS_THREAD_POOL_NET);
+      break;
+    }
+
     rprintf(ptest->regtest, "setting synserver parent proxy to %s:%d\n", "127.0.0.1", SYNSERVER_LISTEN_PORT);
 
     // Since we chose a request format with a hostname of trafficserver.apache.org, it won't get

-- 
To stop receiving notification emails like this one, please contact
"commits@trafficserver.apache.org" <co...@trafficserver.apache.org>.

[trafficserver] 01/09: Prevent segfault dealocating a NULL buffer_reader.

Posted by so...@apache.org.
This is an automated email from the ASF dual-hosted git repository.

sorber pushed a commit to branch 6.2.x
in repository https://git-dual.apache.org/repos/asf/trafficserver.git

commit 07f3de804b79ba794430ec754175a07f27d40cd6
Author: David Calavera <da...@gmail.com>
AuthorDate: Fri May 13 13:47:14 2016 -0700

    Prevent segfault dealocating a NULL buffer_reader.
    
    Signed-off-by: David Calavera <da...@gmail.com>
    (cherry picked from commit 0f3548015c062def879a1dcb0cb57b38daeea2de)
---
 proxy/http/HttpTunnel.cc | 6 ++++--
 1 file changed, 4 insertions(+), 2 deletions(-)

diff --git a/proxy/http/HttpTunnel.cc b/proxy/http/HttpTunnel.cc
index adc84ae..b96cc4b 100644
--- a/proxy/http/HttpTunnel.cc
+++ b/proxy/http/HttpTunnel.cc
@@ -1386,8 +1386,10 @@ HttpTunnel::consumer_handler(int event, HttpTunnelConsumer *c)
     // Deallocate the reader after calling back the sm
     //  because buffer problems are easier to debug
     //  in the sm when the reader is still valid
-    c->buffer_reader->mbuf->dealloc_reader(c->buffer_reader);
-    c->buffer_reader = NULL;
+    if (c->buffer_reader) {
+      c->buffer_reader->mbuf->dealloc_reader(c->buffer_reader);
+      c->buffer_reader = NULL;
+    }
 
     // Since we removed a consumer, it may now be
     //   possbile to put more stuff in the buffer

-- 
To stop receiving notification emails like this one, please contact
"commits@trafficserver.apache.org" <co...@trafficserver.apache.org>.

[trafficserver] 06/09: TS-4473: Fix formatting.

Posted by so...@apache.org.
This is an automated email from the ASF dual-hosted git repository.

sorber pushed a commit to branch 6.2.x
in repository https://git-dual.apache.org/repos/asf/trafficserver.git

commit e8adf714ff6c5965fea2260dcc35f1446c974581
Author: James Peach <jp...@apache.org>
AuthorDate: Mon May 23 16:50:46 2016 -0700

    TS-4473: Fix formatting.
    
    (cherry picked from commit 523ce000b56f7ce16d4cfe7f2324e52cb528f558)
---
 proxy/InkAPITest.cc | 6 ++++--
 1 file changed, 4 insertions(+), 2 deletions(-)

diff --git a/proxy/InkAPITest.cc b/proxy/InkAPITest.cc
index 51f670e..11122dc 100644
--- a/proxy/InkAPITest.cc
+++ b/proxy/InkAPITest.cc
@@ -5922,7 +5922,9 @@ struct ParentTest {
     this->magic = MAGIC_DEAD;
   }
 
-  bool parent_routing_enabled() const {
+  bool
+  parent_routing_enabled() const
+  {
     RecBool enabled = false;
 
     ParentConfigParams *params = ParentConfig::acquire();
@@ -5937,7 +5939,7 @@ struct ParentTest {
 
   struct {
     TSEvent event;
-    void *  edata;
+    void *edata;
   } deferred;
 
   const char *testcase;

-- 
To stop receiving notification emails like this one, please contact
"commits@trafficserver.apache.org" <co...@trafficserver.apache.org>.

[trafficserver] 04/09: TS-4477: Decrement http_current_client_transactions_stat in HTTP/2

Posted by so...@apache.org.
This is an automated email from the ASF dual-hosted git repository.

sorber pushed a commit to branch 6.2.x
in repository https://git-dual.apache.org/repos/asf/trafficserver.git

commit a41180050741b709cd8ba30d74b5a245bc96e82e
Author: Masaori Koshiba <ma...@apache.org>
AuthorDate: Tue May 24 09:49:21 2016 -0700

    TS-4477: Decrement http_current_client_transactions_stat in HTTP/2
    
    (cherry picked from commit c2fd76b20d3f338fef11de584e891dba177ee338)
---
 proxy/http2/Http2Stream.cc | 1 +
 1 file changed, 1 insertion(+)

diff --git a/proxy/http2/Http2Stream.cc b/proxy/http2/Http2Stream.cc
index 137e9e7..42f6659 100644
--- a/proxy/http2/Http2Stream.cc
+++ b/proxy/http2/Http2Stream.cc
@@ -512,6 +512,7 @@ Http2Stream::destroy()
     m_active = false;
     HTTP_DECREMENT_DYN_STAT(http_current_active_client_connections_stat);
   }
+  HTTP_DECREMENT_DYN_STAT(http_current_client_transactions_stat);
 
   HTTP2_DECREMENT_THREAD_DYN_STAT(HTTP2_STAT_CURRENT_CLIENT_STREAM_COUNT, _thread);
   ink_hrtime end_time = Thread::get_hrtime();

-- 
To stop receiving notification emails like this one, please contact
"commits@trafficserver.apache.org" <co...@trafficserver.apache.org>.

[trafficserver] 08/09: TS-4473: Reset txnp after restoring the deferred event.

Posted by so...@apache.org.
This is an automated email from the ASF dual-hosted git repository.

sorber pushed a commit to branch 6.2.x
in repository https://git-dual.apache.org/repos/asf/trafficserver.git

commit 63c0f147ff73b4545ba471e0082bc7988803b641
Author: James Peach <jp...@apache.org>
AuthorDate: Tue May 24 10:43:21 2016 -0700

    TS-4473: Reset txnp after restoring the deferred event.
    
    (cherry picked from commit 53ab967ba6618227bda103088ba0dbdaf59eb242)
---
 proxy/InkAPITest.cc | 3 ++-
 1 file changed, 2 insertions(+), 1 deletion(-)

diff --git a/proxy/InkAPITest.cc b/proxy/InkAPITest.cc
index a9852ed..68ff2cc 100644
--- a/proxy/InkAPITest.cc
+++ b/proxy/InkAPITest.cc
@@ -6020,7 +6020,6 @@ static int
 parent_proxy_handler(TSCont contp, TSEvent event, void *edata)
 {
   ParentTest *ptest = NULL;
-  TSHttpTxn txnp = (TSHttpTxn)edata;
 
   CHECK_SPURIOUS_EVENT(contp, event, edata);
   ptest = (ParentTest *)TSContDataGet(contp);
@@ -6033,6 +6032,8 @@ parent_proxy_handler(TSCont contp, TSEvent event, void *edata)
     ptest->deferred.edata = NULL;
   }
 
+  TSHttpTxn txnp = (TSHttpTxn)edata;
+
   switch (event) {
   case TS_EVENT_HTTP_READ_REQUEST_HDR:
     // Keep deferring the test start until the parent configuration

-- 
To stop receiving notification emails like this one, please contact
"commits@trafficserver.apache.org" <co...@trafficserver.apache.org>.

[trafficserver] 03/09: TS-4472: Decrement http_current_active_client_connections_stat in HTTP/2

Posted by so...@apache.org.
This is an automated email from the ASF dual-hosted git repository.

sorber pushed a commit to branch 6.2.x
in repository https://git-dual.apache.org/repos/asf/trafficserver.git

commit 419d1af8355674236d6eb4f5e9b7f584acdc3c5f
Author: Masaori Koshiba <ma...@apache.org>
AuthorDate: Mon May 23 15:28:58 2016 -0700

    TS-4472: Decrement http_current_active_client_connections_stat in HTTP/2
    
    `http_current_active_client_connections_stat` is incremented in HttpSM.
    And if client connection is HTTP/1.1, this is decremented in Http1ClientTransaction.
    But if client connection is HTTP/2, this is not decremented anywhere.
    
    (cherry picked from commit 8ed5bf2c76b437903412e3f34c75bda6b8611966)
---
 proxy/http2/Http2Stream.cc | 5 +++++
 1 file changed, 5 insertions(+)

diff --git a/proxy/http2/Http2Stream.cc b/proxy/http2/Http2Stream.cc
index e54ed85..137e9e7 100644
--- a/proxy/http2/Http2Stream.cc
+++ b/proxy/http2/Http2Stream.cc
@@ -508,6 +508,11 @@ Http2Stream::destroy()
   // Clean up the write VIO in case of inactivity timeout
   this->do_io_write(NULL, 0, NULL);
 
+  if (m_active) {
+    m_active = false;
+    HTTP_DECREMENT_DYN_STAT(http_current_active_client_connections_stat);
+  }
+
   HTTP2_DECREMENT_THREAD_DYN_STAT(HTTP2_STAT_CURRENT_CLIENT_STREAM_COUNT, _thread);
   ink_hrtime end_time = Thread::get_hrtime();
   HTTP2_SUM_THREAD_DYN_STAT(HTTP2_STAT_TOTAL_TRANSACTIONS_TIME, _thread, end_time - _start_time);

-- 
To stop receiving notification emails like this one, please contact
"commits@trafficserver.apache.org" <co...@trafficserver.apache.org>.

[trafficserver] 07/09: TS-4473: Failed clang-analyzer, dereference null pointer

Posted by so...@apache.org.
This is an automated email from the ASF dual-hosted git repository.

sorber pushed a commit to branch 6.2.x
in repository https://git-dual.apache.org/repos/asf/trafficserver.git

commit 14ecf6a3c06701a31160d1da942a5a6696617e41
Author: Bryan Call <bc...@apache.org>
AuthorDate: Tue May 24 10:39:31 2016 -0700

    TS-4473: Failed clang-analyzer, dereference null pointer
    
    (cherry picked from commit cd1782d757ea62789292b2d1200eedbf1ed2e53a)
---
 proxy/InkAPITest.cc | 3 ++-
 1 file changed, 2 insertions(+), 1 deletion(-)

diff --git a/proxy/InkAPITest.cc b/proxy/InkAPITest.cc
index 11122dc..a9852ed 100644
--- a/proxy/InkAPITest.cc
+++ b/proxy/InkAPITest.cc
@@ -6024,8 +6024,9 @@ parent_proxy_handler(TSCont contp, TSEvent event, void *edata)
 
   CHECK_SPURIOUS_EVENT(contp, event, edata);
   ptest = (ParentTest *)TSContDataGet(contp);
+  ink_release_assert(ptest);
 
-  if (ptest && ptest->deferred.event != TS_EVENT_NONE) {
+  if (ptest->deferred.event != TS_EVENT_NONE) {
     event = ptest->deferred.event;
     edata = ptest->deferred.edata;
     ptest->deferred.event = TS_EVENT_NONE;

-- 
To stop receiving notification emails like this one, please contact
"commits@trafficserver.apache.org" <co...@trafficserver.apache.org>.