You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@trafficserver.apache.org by zy...@apache.org on 2013/12/07 07:44:19 UTC

[2/2] git commit: TS-2082: remove NON_MODULAR define

TS-2082: remove NON_MODULAR define


Project: http://git-wip-us.apache.org/repos/asf/trafficserver/repo
Commit: http://git-wip-us.apache.org/repos/asf/trafficserver/commit/5140b18d
Tree: http://git-wip-us.apache.org/repos/asf/trafficserver/tree/5140b18d
Diff: http://git-wip-us.apache.org/repos/asf/trafficserver/diff/5140b18d

Branch: refs/heads/master
Commit: 5140b18d0c15be1b532edab8c92b00b7c862324f
Parents: 51ce9ae
Author: Zhao Yongming <mi...@gmail.com>
Authored: Thu Nov 7 18:53:14 2013 +0800
Committer: Zhao Yongming <mi...@gmail.com>
Committed: Sat Dec 7 14:30:19 2013 +0800

----------------------------------------------------------------------
 iocore/cache/Cache.cc                | 11 +---------
 iocore/cache/CachePages.cc           |  2 --
 iocore/cache/CachePagesInternal.cc   |  4 ----
 iocore/cluster/ClusterAPI.cc         |  7 -------
 iocore/cluster/ClusterHandlerBase.cc |  5 +----
 iocore/cluster/ClusterProcessor.cc   |  2 --
 iocore/cluster/P_ClusterCache.h      |  2 --
 iocore/cluster/P_ClusterInternal.h   |  2 --
 iocore/hostdb/HostDB.cc              | 34 -------------------------------
 iocore/hostdb/MultiCache.cc          |  6 ------
 iocore/net/I_Socks.h                 |  3 +--
 iocore/net/UnixNetPages.cc           |  4 ----
 iocore/net/UnixNetProcessor.cc       |  4 ----
 lib/ts/ink_config.h.in               |  1 -
 14 files changed, 3 insertions(+), 84 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/trafficserver/blob/5140b18d/iocore/cache/Cache.cc
----------------------------------------------------------------------
diff --git a/iocore/cache/Cache.cc b/iocore/cache/Cache.cc
index 39688a7..711b7c9 100644
--- a/iocore/cache/Cache.cc
+++ b/iocore/cache/Cache.cc
@@ -25,10 +25,8 @@
 #include "P_Cache.h"
 
 // Cache Inspector and State Pages
-#ifdef NON_MODULAR
 #include "P_CacheTest.h"
 #include "StatPages.h"
-#endif
 
 #include "I_Layout.h"
 
@@ -580,7 +578,7 @@ static const int DEFAULT_CACHE_OPTIONS = (O_RDWR | _O_ATTRIB_OVERLAPPED);
 int
 CacheProcessor::start_internal(int flags)
 {
-#ifdef NON_MODULAR
+
   ink_assert((int)TS_EVENT_CACHE_OPEN_READ == (int)CACHE_EVENT_OPEN_READ);
   ink_assert((int)TS_EVENT_CACHE_OPEN_READ_FAILED == (int)CACHE_EVENT_OPEN_READ_FAILED);
   ink_assert((int)TS_EVENT_CACHE_OPEN_WRITE == (int)CACHE_EVENT_OPEN_WRITE);
@@ -593,7 +591,6 @@ CacheProcessor::start_internal(int flags)
   ink_assert((int)TS_EVENT_CACHE_SCAN_OPERATION_BLOCKED == (int)CACHE_EVENT_SCAN_OPERATION_BLOCKED);
   ink_assert((int)TS_EVENT_CACHE_SCAN_OPERATION_FAILED == (int)CACHE_EVENT_SCAN_OPERATION_FAILED);
   ink_assert((int)TS_EVENT_CACHE_SCAN_DONE == (int)CACHE_EVENT_SCAN_DONE);
-#endif
 
 #if AIO_MODE == AIO_MODE_NATIVE
   int etype = ET_NET;
@@ -2218,12 +2215,10 @@ AIO_Callback_handler::handle_disk_failure(int /* event ATS_UNUSED */, void *data
 
 int
 Cache::open_done() {
-#ifdef NON_MODULAR
   Action *register_ShowCache(Continuation * c, HTTPHdr * h);
   Action *register_ShowCacheInternal(Continuation *c, HTTPHdr *h);
   statPagesManager.register_http("cache", register_ShowCache);
   statPagesManager.register_http("cache-internal", register_ShowCacheInternal);
-#endif
   if (total_good_nvol == 0) {
     ready = CACHE_INIT_FAILED;
     cacheProcessor.cacheInitialized();
@@ -2645,7 +2640,6 @@ Cache::lookup(Continuation *cont, CacheKey *key, CacheFragType type, char *hostn
     return ACTION_RESULT_DONE;
 }
 
-#ifdef NON_MODULAR
 Action *
 Cache::lookup(Continuation *cont, CacheURL *url, CacheFragType type)
 {
@@ -2656,7 +2650,6 @@ Cache::lookup(Continuation *cont, CacheURL *url, CacheFragType type)
   const char *hostname = url->host_get(&len);
   return lookup(cont, &md5, type, (char *) hostname, len);
 }
-#endif
 
 int
 CacheVC::removeEvent(int /* event ATS_UNUSED */, Event * /* e ATS_UNUSED */)
@@ -3417,7 +3410,6 @@ ink_cache_init(ModuleVersion v)
 #endif
 }
 
-#ifdef NON_MODULAR
 //----------------------------------------------------------------------------
 Action *
 CacheProcessor::open_read(Continuation *cont, URL *url, bool cluster_cache_local, CacheHTTPHdr *request,
@@ -3483,4 +3475,3 @@ CacheProcessor::remove(Continuation *cont, URL *url, bool cluster_cache_local, C
   return caches[frag_type]->remove(cont, &md5, frag_type, true, false, const_cast<char*>(hostname), len);
 }
 
-#endif

http://git-wip-us.apache.org/repos/asf/trafficserver/blob/5140b18d/iocore/cache/CachePages.cc
----------------------------------------------------------------------
diff --git a/iocore/cache/CachePages.cc b/iocore/cache/CachePages.cc
index e30dba0..08ef4b7 100644
--- a/iocore/cache/CachePages.cc
+++ b/iocore/cache/CachePages.cc
@@ -23,7 +23,6 @@
 
 #include "P_Cache.h"
 
-#ifdef NON_MODULAR
 #include "api/ts/ts.h"
 #include "Show.h"
 #include "I_Tasks.h"
@@ -640,4 +639,3 @@ ShowCache::handleCacheScanCallback(int event, Event *e)
   }
 }
 
-#endif // NON_MODULAR

http://git-wip-us.apache.org/repos/asf/trafficserver/blob/5140b18d/iocore/cache/CachePagesInternal.cc
----------------------------------------------------------------------
diff --git a/iocore/cache/CachePagesInternal.cc b/iocore/cache/CachePagesInternal.cc
index 16e822d..adde166 100644
--- a/iocore/cache/CachePagesInternal.cc
+++ b/iocore/cache/CachePagesInternal.cc
@@ -23,7 +23,6 @@
 
 #include "P_Cache.h"
 
-#ifdef NON_MODULAR
 #include "Show.h"
 #include "I_Tasks.h"
 
@@ -339,6 +338,3 @@ ShowCacheInternal::showSegSegment(int event, Event * e)
   return EVENT_CONT;
 }
 
-
-
-#endif // NON_MODULAR

http://git-wip-us.apache.org/repos/asf/trafficserver/blob/5140b18d/iocore/cluster/ClusterAPI.cc
----------------------------------------------------------------------
diff --git a/iocore/cluster/ClusterAPI.cc b/iocore/cluster/ClusterAPI.cc
index fab80dc..3600022 100644
--- a/iocore/cluster/ClusterAPI.cc
+++ b/iocore/cluster/ClusterAPI.cc
@@ -30,7 +30,6 @@
 ****************************************************************************/
 #include "P_Cluster.h"
 
-#ifdef NON_MODULAR
 #include "InkAPIInternal.h"
 
 class ClusterAPIPeriodicSM;
@@ -278,11 +277,6 @@ void
 clusterAPI_init()
 {
   MachineStatusSM *mssmp = 0;
-  // XXX: BIG RED WARNING!!! Direct null pointer dereference
-  //      Either create MachineStatusSM before ose or axe this function.
-  //      It is used only if NON_MODULAR is defined making that
-  //      flag crashing ClusterProcessor::init()
-  //
   ink_atomiclist_init(&status_callout_atomic_q,
                       "cluster API status_callout_q", (char *) &mssmp->link.next - (char *) mssmp);
   ClusterAPI_mutex = new_ProxyMutex();
@@ -580,7 +574,6 @@ TSSendClusterRPC(TSNodeHandle_t * nh, TSClusterRPCMsg_t * msg)
 
   return 0;
 }
-#endif /* NON_MODULAR */
 
 /*
  *  End of ClusterAPI.cc

http://git-wip-us.apache.org/repos/asf/trafficserver/blob/5140b18d/iocore/cluster/ClusterHandlerBase.cc
----------------------------------------------------------------------
diff --git a/iocore/cluster/ClusterHandlerBase.cc b/iocore/cluster/ClusterHandlerBase.cc
index 520e3a3..6022b9f 100644
--- a/iocore/cluster/ClusterHandlerBase.cc
+++ b/iocore/cluster/ClusterHandlerBase.cc
@@ -754,9 +754,7 @@ ClusterHandler::machine_down()
 #else
   Note("machine down %u.%u.%u.%u:%d", DOT_SEPARATED(ip), id);
 #endif
-#ifdef NON_MODULAR
   machine_offline_APIcallout(ip);
-#endif
   snprintf(textbuf, sizeof(textbuf), "%hhu.%hhu.%hhu.%hhu:%d", DOT_SEPARATED(ip), port);
   REC_SignalManager(REC_SIGNAL_MACHINE_DOWN, textbuf);
   if (net_vc) {
@@ -1145,9 +1143,8 @@ failed:
         }
 
         this->needByteSwap = !clusteringVersion.NativeByteOrder();
-#ifdef NON_MODULAR
         machine_online_APIcallout(ip);
-#endif
+
         // Signal the manager
         snprintf(textbuf, sizeof(textbuf), "%hhu.%hhu.%hhu.%hhu:%d", DOT_SEPARATED(ip), port);
         REC_SignalManager(REC_SIGNAL_MACHINE_UP, textbuf);

http://git-wip-us.apache.org/repos/asf/trafficserver/blob/5140b18d/iocore/cluster/ClusterProcessor.cc
----------------------------------------------------------------------
diff --git a/iocore/cluster/ClusterProcessor.cc b/iocore/cluster/ClusterProcessor.cc
index b01e0ff..a16381a 100644
--- a/iocore/cluster/ClusterProcessor.cc
+++ b/iocore/cluster/ClusterProcessor.cc
@@ -699,10 +699,8 @@ ClusterProcessor::init()
   REC_ReadConfigInteger(cluster_type, "proxy.local.cluster.type");
 
   create_this_cluster_machine();
-#ifdef NON_MODULAR
   // Cluster API Initializations
   clusterAPI_init();
-#endif
   // Start global Cluster periodic event
   PeriodicClusterEvent = NEW(new GlobalClusterPeriodicEvent);
   PeriodicClusterEvent->init();

http://git-wip-us.apache.org/repos/asf/trafficserver/blob/5140b18d/iocore/cluster/P_ClusterCache.h
----------------------------------------------------------------------
diff --git a/iocore/cluster/P_ClusterCache.h b/iocore/cluster/P_ClusterCache.h
index 10fc46a..5d6b0b9 100644
--- a/iocore/cluster/P_ClusterCache.h
+++ b/iocore/cluster/P_ClusterCache.h
@@ -828,7 +828,6 @@ ClusterFunctionDescriptor clusterFunction[]
    /*********************************************
     * RESERVED for Cluster RPC API use		*
     *********************************************/
-#ifdef NON_MODULAR
   {true, false, CMSG_LOW_PRI, default_api_ClusterFunction, 0},
   {true, false, CMSG_LOW_PRI, default_api_ClusterFunction, 0},
   {true, false, CMSG_LOW_PRI, default_api_ClusterFunction, 0},
@@ -859,7 +858,6 @@ ClusterFunctionDescriptor clusterFunction[]
   {true, false, CMSG_LOW_PRI, default_api_ClusterFunction, 0},
   {true, false, CMSG_LOW_PRI, default_api_ClusterFunction, 0},
   {true, false, CMSG_LOW_PRI, default_api_ClusterFunction, 0}
-#endif
   // ********** ADD NEW ENTRIES ABOVE THIS LINE ************
 }
 #endif

http://git-wip-us.apache.org/repos/asf/trafficserver/blob/5140b18d/iocore/cluster/P_ClusterInternal.h
----------------------------------------------------------------------
diff --git a/iocore/cluster/P_ClusterInternal.h b/iocore/cluster/P_ClusterInternal.h
index b7dd616..679461d 100644
--- a/iocore/cluster/P_ClusterInternal.h
+++ b/iocore/cluster/P_ClusterInternal.h
@@ -514,10 +514,8 @@ extern int cluster_port;
 int machine_config_change(const char *, RecDataT, RecData, void *);
 extern void do_machine_config_change(void *, const char *);
 
-#ifdef NON_MODULAR
 // Cluster API support functions
 extern void clusterAPI_init();
 extern void machine_online_APIcallout(int);
 extern void machine_offline_APIcallout(int);
-#endif
 #endif /* _ClusterInternal_h */

http://git-wip-us.apache.org/repos/asf/trafficserver/blob/5140b18d/iocore/hostdb/HostDB.cc
----------------------------------------------------------------------
diff --git a/iocore/hostdb/HostDB.cc b/iocore/hostdb/HostDB.cc
index e0fe928..d2c5e76 100644
--- a/iocore/hostdb/HostDB.cc
+++ b/iocore/hostdb/HostDB.cc
@@ -25,12 +25,7 @@
 
 #include "P_HostDB.h"
 #include "I_Layout.h"
-
-#ifndef NON_MODULAR
-//char system_config_directory[512] = "etc/trafficserver";
-#else
 #include "Show.h"
-#endif
 
 // dxu: turn off all Diags.h 's function.
 //#define Debug
@@ -69,9 +64,7 @@ ClassAllocator<HostDBContinuation> hostDBContAllocator("hostDBContAllocator");
 
 HostDBCache hostDB;
 
-#ifdef NON_MODULAR
 static  Queue <HostDBContinuation > remoteHostDBQueue[MULTI_CACHE_PARTITIONS];
-#endif
 
 char *
 HostDBInfo::srvname(HostDBRoundRobin *rr)
@@ -165,10 +158,8 @@ string_for(HostDBMark mark) {
 //
 // Function Prototypes
 //
-#ifdef NON_MODULAR
 static Action *
 register_ShowHostDB(Continuation * c, HTTPHdr * h);
-#endif
 
 void
 HostDBMD5::refresh() {
@@ -456,16 +447,12 @@ HostDBProcessor::start(int, size_t)
   if (hostDB.start(0) < 0)
     return -1;
 
-#ifdef NON_MODULAR
   if (auto_clear_hostdb_flag)
     hostDB.clear();
-#endif
 
   HOSTDB_SET_DYN_COUNT(hostdb_total_entries_stat, hostDB.totalelements);
 
-#ifdef NON_MODULAR
   statPagesManager.register_http("hostdb", register_ShowHostDB);
-#endif
 
   //
   // Register configuration callback, and establish configuation links
@@ -673,9 +660,7 @@ probe(ProxyMutex *mutex, HostDBMD5 const& md5, bool ignore_timeout)
       // -or-
       // we are beyond our TTL but we choose to serve for another N seconds [hostdb_serve_stale_but_revalidate seconds]
       if ((!ignore_timeout && r->is_ip_stale()
-#ifdef NON_MODULAR
            && !cluster_machine_at_depth(master_hash(md5.hash))
-#endif
            && !r->reverse_dns) || (r->is_ip_timeout() && r->serve_stale_but_revalidate())) {
         Debug("hostdb", "stale %u %u %u, using it and refreshing it", r->ip_interval(),
               r->ip_timestamp, r->ip_timeout_interval);
@@ -1332,10 +1317,8 @@ HostDBContinuation::lookup_done(IpAddr const& ip, char const* aname, bool around
       }
     }
   }
-#ifdef NON_MODULAR
   if (from_cont)
     do_put_response(from, i, from_cont);
-#endif
   ink_assert(!i->round_robin || !i->reverse_dns);
   return i;
 }
@@ -1610,13 +1593,11 @@ HostDBContinuation::dnsEvent(int event, HostEnt * e)
     ink_assert(!r || !r->round_robin || !r->reverse_dns);
     ink_assert(failed || !r->round_robin || r->app.rr.offset);
 
-#ifdef NON_MODULAR
     // if we are not the owner, put on the owner
     //
     ClusterMachine *m = cluster_machine_at_depth(master_hash(md5.hash));
     if (m)
       do_put_response(m, r, NULL);
-#endif
 
     // try to callback the user
     //
@@ -1650,7 +1631,6 @@ HostDBContinuation::dnsEvent(int event, HostEnt * e)
 }
 
 
-#ifdef NON_MODULAR
 //
 // HostDB Get Message
 // Used to lookup host information on a remote node in the cluster
@@ -1802,7 +1782,6 @@ HostDBContinuation::do_put_response(ClusterMachine * m, HostDBInfo * r, Continua
   clusterProcessor.invoke_remote(m->pop_ClusterHandler(), PUT_HOSTINFO_CLUSTER_FUNCTION, (char *) &msg, len);
 
 }
-#endif // NON_MODULAR
 
 
 //
@@ -1828,10 +1807,8 @@ HostDBContinuation::probeEvent(int /* event ATS_UNUSED */, Event * e)
   if (!hostdb_enable || (!*md5.host_name && !md5.ip.isValid())) {
     if (action.continuation)
       action.continuation->handleEvent(EVENT_HOST_DB_LOOKUP, NULL);
-#ifdef NON_MODULAR
     if (from)
       do_put_response(from, 0, from_cont);
-#endif
     hostdb_cont_free(this);
     return EVENT_DONE;
   }
@@ -1845,7 +1822,6 @@ HostDBContinuation::probeEvent(int /* event ATS_UNUSED */, Event * e)
     if (r)
       HOSTDB_INCREMENT_DYN_STAT(hostdb_total_hits_stat);
 
-#ifdef NON_MODULAR
     if (action.continuation && r)
       reply_to_cont(action.continuation, r);
 
@@ -1853,7 +1829,6 @@ HostDBContinuation::probeEvent(int /* event ATS_UNUSED */, Event * e)
     //
     if (from)
       do_put_response(from, r, from_cont);
-#endif
 
     // If it suceeds or it was a remote probe, we are done
     //
@@ -1861,12 +1836,10 @@ HostDBContinuation::probeEvent(int /* event ATS_UNUSED */, Event * e)
       hostdb_cont_free(this);
       return EVENT_DONE;
     }
-#ifdef NON_MODULAR
     // If it failed, do a remote probe
     //
     if (do_get_response(e))
       return EVENT_CONT;
-#endif
   }
   // If there are no remote nodes to probe, do a DNS lookup
   //
@@ -1959,8 +1932,6 @@ HostDBContinuation::do_dns()
   }
 }
 
-#ifdef NON_MODULAR
-
 
 //
 // Handle the response (put message)
@@ -2151,7 +2122,6 @@ put_hostinfo_ClusterFunction(ClusterHandler *ch, void *data, int /* len ATS_UNUS
   c->from = ch->machine;
   dnsProcessor.thread->schedule_imm(c);
 }
-#endif // NON_MODULAR
 
 
 //
@@ -2248,15 +2218,12 @@ HostDBInfo::heap_offset_ptr()
 }
 
 
-#ifdef NON_MODULAR
 ClusterMachine *
 HostDBContinuation::master_machine(ClusterConfiguration * cc)
 {
   return cc->machine_hash((int) (md5.hash[1] >> 32));
 }
-#endif // NON_MODULAR
 
-#ifdef NON_MODULAR
 struct ShowHostDB;
 typedef int (ShowHostDB::*ShowHostDBEventHandler) (int event, Event * data);
 struct ShowHostDB: public ShowCont
@@ -2401,7 +2368,6 @@ register_ShowHostDB(Continuation * c, HTTPHdr * h)
   this_ethread()->schedule_imm(s);
   return &s->action;
 }
-#endif // NON_MODULAR
 
 
 #define HOSTDB_TEST_MAX_OUTSTANDING 100

http://git-wip-us.apache.org/repos/asf/trafficserver/blob/5140b18d/iocore/hostdb/MultiCache.cc
----------------------------------------------------------------------
diff --git a/iocore/hostdb/MultiCache.cc b/iocore/hostdb/MultiCache.cc
index b153d75..629f87c 100644
--- a/iocore/hostdb/MultiCache.cc
+++ b/iocore/hostdb/MultiCache.cc
@@ -30,13 +30,7 @@
 
 #include "libts.h"
 #include "I_Layout.h"
-#ifdef NON_MODULAR
 #include "P_HostDB.h"
-#else
-//extern const char *system_config_directory;
-extern int hostdb_sync_frequency;
-#endif
-
 #include "P_MultiCache.h"
 #include "P_EventSystem.h"      // FIXME: need to have this in I_* header files.
 #include "ink_file.h"

http://git-wip-us.apache.org/repos/asf/trafficserver/blob/5140b18d/iocore/net/I_Socks.h
----------------------------------------------------------------------
diff --git a/iocore/net/I_Socks.h b/iocore/net/I_Socks.h
index a8aac85..4dd206e 100644
--- a/iocore/net/I_Socks.h
+++ b/iocore/net/I_Socks.h
@@ -24,13 +24,12 @@
 #ifndef __I_SOCKS_H__
 #define __I_SOCKS_H__
 
-#ifdef NON_MODULAR
 /*When this is being compiled with TS, we enable more features the use
   non modularized stuff. namely:
   ip_ranges and multiple socks server support.
 */
 #define SOCKS_WITH_TS
-#endif
+
 
 #define SOCKS_DEFAULT_VERSION 0 //defined the configuration variable
 #define SOCKS4_VERSION  4

http://git-wip-us.apache.org/repos/asf/trafficserver/blob/5140b18d/iocore/net/UnixNetPages.cc
----------------------------------------------------------------------
diff --git a/iocore/net/UnixNetPages.cc b/iocore/net/UnixNetPages.cc
index dfcc28f..7a19c51 100644
--- a/iocore/net/UnixNetPages.cc
+++ b/iocore/net/UnixNetPages.cc
@@ -22,9 +22,6 @@
  */
 
 #include "libts.h"
-
-#ifdef NON_MODULAR
-
 #include "P_Net.h"
 #include "Show.h"
 #include "I_Tasks.h"
@@ -250,4 +247,3 @@ register_ShowNet(Continuation * c, HTTPHdr * h)
   return &s->action;
 }
 
-#endif

http://git-wip-us.apache.org/repos/asf/trafficserver/blob/5140b18d/iocore/net/UnixNetProcessor.cc
----------------------------------------------------------------------
diff --git a/iocore/net/UnixNetProcessor.cc b/iocore/net/UnixNetProcessor.cc
index b3b121c..eaae439 100644
--- a/iocore/net/UnixNetProcessor.cc
+++ b/iocore/net/UnixNetProcessor.cc
@@ -24,9 +24,7 @@
 #include "P_Net.h"
 
 // For Stat Pages
-#ifdef NON_MODULAR
 #include "StatPages.h"
-#endif
 
 NetProcessor::AcceptOptions const NetProcessor::DEFAULT_ACCEPT_OPTIONS;
 
@@ -439,11 +437,9 @@ UnixNetProcessor::start(int, size_t)
 /*
  * Stat pages
  */
-#ifdef NON_MODULAR
   extern Action *register_ShowNet(Continuation * c, HTTPHdr * h);
   if (etype == ET_NET)
     statPagesManager.register_http("net", register_ShowNet);
-#endif
   return 1;
 }
 

http://git-wip-us.apache.org/repos/asf/trafficserver/blob/5140b18d/lib/ts/ink_config.h.in
----------------------------------------------------------------------
diff --git a/lib/ts/ink_config.h.in b/lib/ts/ink_config.h.in
index 3a31c9f..e158a2d 100644
--- a/lib/ts/ink_config.h.in
+++ b/lib/ts/ink_config.h.in
@@ -94,7 +94,6 @@
 
 # define FIXME_NONMODULAR               1
 # define SPLIT_DNS                      1
-# define NON_MODULAR                    1
 # define HTTP_CACHE                     1
 
 /* Defaults for user / group */


Re: [2/2] git commit: TS-2082: remove NON_MODULAR define

Posted by Igor Galić <i....@brainsware.org>.

----- Original Message -----
> TS-2082: remove NON_MODULAR define
> 
> 
> Project: http://git-wip-us.apache.org/repos/asf/trafficserver/repo
> Commit: http://git-wip-us.apache.org/repos/asf/trafficserver/commit/5140b18d
> Tree: http://git-wip-us.apache.org/repos/asf/trafficserver/tree/5140b18d
> Diff: http://git-wip-us.apache.org/repos/asf/trafficserver/diff/5140b18d
> 
> Branch: refs/heads/master
> Commit: 5140b18d0c15be1b532edab8c92b00b7c862324f
> Parents: 51ce9ae
> Author: Zhao Yongming <mi...@gmail.com>
> Authored: Thu Nov 7 18:53:14 2013 +0800
> Committer: Zhao Yongming <mi...@gmail.com>
> Committed: Sat Dec 7 14:30:19 2013 +0800

[snip]

> http://git-wip-us.apache.org/repos/asf/trafficserver/blob/5140b18d/iocore/cluster/ClusterAPI.cc
> ----------------------------------------------------------------------
> diff --git a/iocore/cluster/ClusterAPI.cc b/iocore/cluster/ClusterAPI.cc
> index fab80dc..3600022 100644
> --- a/iocore/cluster/ClusterAPI.cc
> +++ b/iocore/cluster/ClusterAPI.cc
> @@ -30,7 +30,6 @@
>  ****************************************************************************/
>  #include "P_Cluster.h"
>  
> -#ifdef NON_MODULAR
>  #include "InkAPIInternal.h"
>  
>  class ClusterAPIPeriodicSM;
> @@ -278,11 +277,6 @@ void
>  clusterAPI_init()
>  {
>    MachineStatusSM *mssmp = 0;
> -  // XXX: BIG RED WARNING!!! Direct null pointer dereference
> -  //      Either create MachineStatusSM before ose or axe this function.
> -  //      It is used only if NON_MODULAR is defined making that
> -  //      flag crashing ClusterProcessor::init()
> -  //

This Warning no longer applies?

>    ink_atomiclist_init(&status_callout_atomic_q,
>                        "cluster API status_callout_q", (char *)
>                        &mssmp->link.next - (char *) mssmp);
>    ClusterAPI_mutex = new_ProxyMutex();
> @@ -580,7 +574,6 @@ TSSendClusterRPC(TSNodeHandle_t * nh, TSClusterRPCMsg_t *
> msg)
>  
>    return 0;
>  }
> -#endif /* NON_MODULAR */
>  
>  /*
>   *  End of ClusterAPI.cc
> 

-- 
Igor Galić

Tel: +43 (0) 664 886 22 883
Mail: i.galic@brainsware.org
URL: http://brainsware.org/
GPG: 8716 7A9F 989B ABD5 100F  4008 F266 55D6 2998 1641