You are viewing a plain text version of this content. The canonical link for it is here.
Posted to modperl-cvs@perl.apache.org by jk...@apache.org on 2013/02/20 08:54:52 UTC

svn commit: r1448022 [2/2] - in /perl/modperl/branches/httpd24: ./ lib/ lib/Apache2/ lib/ModPerl/ src/modules/perl/ t/conf/ t/lib/TestAPRlib/ t/response/TestDirective/ xs/ xs/APR/Brigade/ xs/APR/Bucket/ xs/APR/BucketAlloc/ xs/APR/Error/ xs/APR/Finfo/ x...

Modified: perl/modperl/branches/httpd24/xs/APR/Pool/APR__Pool.h
URL: http://svn.apache.org/viewvc/perl/modperl/branches/httpd24/xs/APR/Pool/APR__Pool.h?rev=1448022&r1=1448021&r2=1448022&view=diff
==============================================================================
--- perl/modperl/branches/httpd24/xs/APR/Pool/APR__Pool.h (original)
+++ perl/modperl/branches/httpd24/xs/APR/Pool/APR__Pool.h Wed Feb 20 07:54:50 2013
@@ -60,7 +60,7 @@ APR_OPTIONAL_FN_TYPE(modperl_thx_interp_
     MAGIC *mg = mg_find(acct->sv, PERL_MAGIC_ext);                  \
     if (mg && mg->mg_obj) {                                         \
         sv_2mortal(mg->mg_obj);                                     \
-        mg->mg_obj = Nullsv;                                        \
+        mg->mg_obj = (SV *)NULL;                                        \
         mg->mg_flags &= ~MGf_REFCOUNTED;                            \
     }                                                               \
     mg_free(acct->sv);                                              \
@@ -87,7 +87,7 @@ APR_OPTIONAL_FN_TYPE(modperl_thx_interp_
     acct->perl = aTHX;                                                  \
     SvIVX(acct_sv) = PTR2IV(pool);                                      \
                                                                         \
-    sv_magic(acct_sv, Nullsv, PERL_MAGIC_ext,                           \
+    sv_magic(acct_sv, (SV *)NULL, PERL_MAGIC_ext,                           \
              MP_APR_POOL_NEW, sizeof(MP_APR_POOL_NEW));                 \
                                                                         \
     apr_pool_cleanup_register(pool, (void *)acct,                       \
@@ -113,7 +113,7 @@ APR_OPTIONAL_FN_TYPE(modperl_thx_interp_
     acct->sv = acct_sv;                                                 \
     SvIVX(acct_sv) = PTR2IV(pool);                                      \
                                                                         \
-    sv_magic(acct_sv, Nullsv, PERL_MAGIC_ext,                           \
+    sv_magic(acct_sv, (SV *)NULL, PERL_MAGIC_ext,                           \
               MP_APR_POOL_NEW, sizeof(MP_APR_POOL_NEW));                \
                                                                         \
     apr_pool_cleanup_register(pool, (void *)acct,                       \
@@ -193,7 +193,7 @@ static MP_INLINE SV *mpxs_apr_pool_creat
 #endif
 
     {
-        SV *rv = sv_setref_pv(NEWSV(0, 0), "APR::Pool", (void*)child_pool);
+        SV *rv = sv_setref_pv(newSV(0), "APR::Pool", (void*)child_pool);
         SV *sv = SvRV(rv);
 
         /* Each newly created pool must be destroyed only once. Calling
@@ -285,6 +285,7 @@ static apr_status_t mpxs_cleanup_run(voi
     }
     PUTBACK;
 
+    save_gp(PL_errgv, 1);       /* local *@ */
     count = call_sv(cdata->cv, G_SCALAR|G_EVAL);
 
     SPAGAIN;
@@ -293,6 +294,11 @@ static apr_status_t mpxs_cleanup_run(voi
         (void)POPs; /* the return value is ignored */
     }
 
+    if (SvTRUE(ERRSV)) {
+        Perl_warn(aTHX_ "APR::Pool: cleanup died: %s", 
+                  SvPV_nolen(ERRSV));
+    }
+
     PUTBACK;
     FREETMPS;LEAVE;
 
@@ -311,10 +317,6 @@ static apr_status_t mpxs_cleanup_run(voi
     }
 #endif
 
-    if (SvTRUE(ERRSV)) {
-        Perl_croak(aTHX_ SvPV_nolen(ERRSV));
-    }
-
     /* the return value is ignored by apr_pool_destroy anyway */
     return APR_SUCCESS;
 }
@@ -332,7 +334,7 @@ static MP_INLINE void mpxs_apr_pool_clea
         (mpxs_cleanup_t *)apr_pcalloc(p, sizeof(*data));
 
     data->cv = SvREFCNT_inc(cv);
-    data->arg = arg ? SvREFCNT_inc(arg) : Nullsv;
+    data->arg = arg ? SvREFCNT_inc(arg) : (SV *)NULL;
     data->p = p;
 #ifdef USE_ITHREADS
     data->perl = aTHX;

Modified: perl/modperl/branches/httpd24/xs/APR/Table/APR__Table.h
URL: http://svn.apache.org/viewvc/perl/modperl/branches/httpd24/xs/APR/Table/APR__Table.h?rev=1448022&r1=1448021&r2=1448022&view=diff
==============================================================================
--- perl/modperl/branches/httpd24/xs/APR/Table/APR__Table.h (original)
+++ perl/modperl/branches/httpd24/xs/APR/Table/APR__Table.h Wed Feb 20 07:54:50 2013
@@ -21,7 +21,7 @@
 #define MPXS_DO_TABLE_N_MAGIC_RETURN(call)                              \
     apr_pool_t *p = mp_xs_sv2_APR__Pool(p_sv);                          \
     apr_table_t *t = call;                                              \
-    SV *t_sv = modperl_hash_tie(aTHX_ "APR::Table", Nullsv, t);         \
+    SV *t_sv = modperl_hash_tie(aTHX_ "APR::Table", (SV *)NULL, t);     \
     mpxs_add_pool_magic(t_sv, p_sv);                                    \
     return t_sv;
 

Modified: perl/modperl/branches/httpd24/xs/APR/ThreadMutex/APR__ThreadMutex.h
URL: http://svn.apache.org/viewvc/perl/modperl/branches/httpd24/xs/APR/ThreadMutex/APR__ThreadMutex.h?rev=1448022&r1=1448021&r2=1448022&view=diff
==============================================================================
--- perl/modperl/branches/httpd24/xs/APR/ThreadMutex/APR__ThreadMutex.h (original)
+++ perl/modperl/branches/httpd24/xs/APR/ThreadMutex/APR__ThreadMutex.h Wed Feb 20 07:54:50 2013
@@ -24,7 +24,7 @@ SV *mpxs_apr_thread_mutex_create(pTHX_ S
     apr_thread_mutex_t *mutex = NULL;
     SV *mutex_sv;
     (void)apr_thread_mutex_create(&mutex, flags, p);
-    mutex_sv = sv_setref_pv(NEWSV(0, 0), "APR::ThreadMutex", (void*)mutex);
+    mutex_sv = sv_setref_pv(newSV(0), "APR::ThreadMutex", (void*)mutex);
     mpxs_add_pool_magic(mutex_sv, p_sv);
     return mutex_sv;
 }

Modified: perl/modperl/branches/httpd24/xs/APR/ThreadRWLock/APR__ThreadRWLock.h
URL: http://svn.apache.org/viewvc/perl/modperl/branches/httpd24/xs/APR/ThreadRWLock/APR__ThreadRWLock.h?rev=1448022&r1=1448021&r2=1448022&view=diff
==============================================================================
--- perl/modperl/branches/httpd24/xs/APR/ThreadRWLock/APR__ThreadRWLock.h (original)
+++ perl/modperl/branches/httpd24/xs/APR/ThreadRWLock/APR__ThreadRWLock.h Wed Feb 20 07:54:50 2013
@@ -23,7 +23,7 @@ SV *mpxs_apr_thread_rwlock_create(pTHX_ 
     apr_thread_rwlock_t *rwlock = NULL;
     SV *rwlock_sv;
     (void)apr_thread_rwlock_create(&rwlock, p);
-    rwlock_sv = sv_setref_pv(NEWSV(0, 0), "APR::ThreadRWLock", (void*)rwlock);
+    rwlock_sv = sv_setref_pv(newSV(0), "APR::ThreadRWLock", (void*)rwlock);
     mpxs_add_pool_magic(rwlock_sv, p_sv);
     return rwlock_sv;
 }

Modified: perl/modperl/branches/httpd24/xs/APR/URI/APR__URI.h
URL: http://svn.apache.org/viewvc/perl/modperl/branches/httpd24/xs/APR/URI/APR__URI.h?rev=1448022&r1=1448021&r2=1448022&view=diff
==============================================================================
--- perl/modperl/branches/httpd24/xs/APR/URI/APR__URI.h (original)
+++ perl/modperl/branches/httpd24/xs/APR/URI/APR__URI.h Wed Feb 20 07:54:50 2013
@@ -45,7 +45,7 @@ SV *mpxs_apr_uri_parse(pTHX_ SV *classna
 
     (void)apr_uri_parse(p, uri_string, &uri->uri);
 
-    uri_sv = sv_setref_pv(NEWSV(0, 0), "APR::URI", (void*)uri);
+    uri_sv = sv_setref_pv(newSV(0), "APR::URI", (void*)uri);
     mpxs_add_pool_magic(uri_sv, p_sv);
 
     return uri_sv;
@@ -91,5 +91,5 @@ SV *mpxs_APR__URI_rpath(pTHX_ apr_uri_t 
             return newSVpv(uri->uri.path, 0);
         }
     }
-    return Nullsv;
+    return (SV *)NULL;
 }

Modified: perl/modperl/branches/httpd24/xs/Apache2/Directive/Apache2__Directive.h
URL: http://svn.apache.org/viewvc/perl/modperl/branches/httpd24/xs/Apache2/Directive/Apache2__Directive.h?rev=1448022&r1=1448021&r2=1448022&view=diff
==============================================================================
--- perl/modperl/branches/httpd24/xs/Apache2/Directive/Apache2__Directive.h (original)
+++ perl/modperl/branches/httpd24/xs/Apache2/Directive/Apache2__Directive.h Wed Feb 20 07:54:50 2013
@@ -109,7 +109,7 @@ static MP_INLINE SV *mpxs_Apache2__Direc
         }
         else {
             hash_insert(aTHX_ hash, directive, directive_len,
-                        args, args_len, Nullsv);
+                        args, args_len, (SV *)NULL);
         }
 
         tree = tree->next;

Modified: perl/modperl/branches/httpd24/xs/Apache2/Filter/Apache2__Filter.h
URL: http://svn.apache.org/viewvc/perl/modperl/branches/httpd24/xs/Apache2/Filter/Apache2__Filter.h?rev=1448022&r1=1448021&r2=1448022&view=diff
==============================================================================
--- perl/modperl/branches/httpd24/xs/Apache2/Filter/Apache2__Filter.h (original)
+++ perl/modperl/branches/httpd24/xs/Apache2/Filter/Apache2__Filter.h Wed Feb 20 07:54:50 2013
@@ -107,10 +107,10 @@ static MP_INLINE U16 *modperl_filter_att
         char *str;                                              \
         len -= 2;           /* s/ \( | \) //x       */          \
         string++;           /* skip the opening '(' */          \
-        New(0, str, len+1, char);                               \
+        Newx(str, len+1, char);                               \
         Copy(string, str, len+1, char);                         \
         str[len] = '\0';    /* remove the closing ')' */        \
-        sv_magic(cv, Nullsv, '~', NULL, -1);                    \
+        sv_magic(cv, (SV *)NULL, '~', NULL, -1);                    \
         SvMAGIC(cv)->mg_ptr = str;                              \
     }
 
@@ -186,7 +186,7 @@ static MP_INLINE SV *mpxs_Apache2__Filte
      * (and it can contain any references)
      */
 
-    if (data != Nullsv) {
+    if (data != (SV *)NULL) {
         if (ctx->data) {
             if (SvOK(ctx->data) && SvREFCNT(ctx->data)) {
                 /* release the previously stored SV so we don't leak

Modified: perl/modperl/branches/httpd24/xs/Apache2/Log/Apache2__Log.h
URL: http://svn.apache.org/viewvc/perl/modperl/branches/httpd24/xs/Apache2/Log/Apache2__Log.h?rev=1448022&r1=1448021&r2=1448022&view=diff
==============================================================================
--- perl/modperl/branches/httpd24/xs/Apache2/Log/Apache2__Log.h (original)
+++ perl/modperl/branches/httpd24/xs/Apache2/Log/Apache2__Log.h Wed Feb 20 07:54:50 2013
@@ -31,7 +31,7 @@ static void mpxs_ap_log_error(pTHX_ int 
     char *file = NULL;
     int line = 0;
     char *str;
-    SV *svstr = Nullsv;
+    SV *svstr = (SV *)NULL;
     STRLEN n_a;
     int lmask = level & APLOG_LEVELMASK;
     server_rec *s;
@@ -219,7 +219,7 @@ MP_STATIC XS(MPXS_Apache2__Log_LOG_MARK)
 MP_STATIC XS(MPXS_Apache2__Log_log_xerror)
 {
     dXSARGS;
-    SV *msgsv = Nullsv;
+    SV *msgsv = (SV *)NULL;
     STRLEN n_a;
     request_rec *r = NULL;
     server_rec *s = NULL;
@@ -288,7 +288,7 @@ MP_STATIC XS(MPXS_Apache2__Log_log_error
     server_rec *s = NULL;
     int i = 0;
     char *errstr = NULL;
-    SV *sv = Nullsv;
+    SV *sv = (SV *)NULL;
     STRLEN n_a;
 
     if (items > 1) {

Modified: perl/modperl/branches/httpd24/xs/Apache2/RequestIO/Apache2__RequestIO.h
URL: http://svn.apache.org/viewvc/perl/modperl/branches/httpd24/xs/Apache2/RequestIO/Apache2__RequestIO.h?rev=1448022&r1=1448021&r2=1448022&view=diff
==============================================================================
--- perl/modperl/branches/httpd24/xs/Apache2/RequestIO/Apache2__RequestIO.h (original)
+++ perl/modperl/branches/httpd24/xs/Apache2/RequestIO/Apache2__RequestIO.h Wed Feb 20 07:54:50 2013
@@ -312,7 +312,7 @@ int mpxs_Apache2__RequestRec_OPEN(pTHX_ 
     }
 
     name = SvPV(arg, len);
-    return do_open(handle, name, len, FALSE, O_RDONLY, 0, Nullfp);
+    return do_open(handle, name, len, FALSE, O_RDONLY, 0, (PerlIO *)NULL);
 }
 
 static MP_INLINE

Modified: perl/modperl/branches/httpd24/xs/Apache2/RequestUtil/Apache2__RequestUtil.h
URL: http://svn.apache.org/viewvc/perl/modperl/branches/httpd24/xs/Apache2/RequestUtil/Apache2__RequestUtil.h?rev=1448022&r1=1448021&r2=1448022&view=diff
==============================================================================
--- perl/modperl/branches/httpd24/xs/Apache2/RequestUtil/Apache2__RequestUtil.h (original)
+++ perl/modperl/branches/httpd24/xs/Apache2/RequestUtil/Apache2__RequestUtil.h Wed Feb 20 07:54:50 2013
@@ -120,7 +120,7 @@ SV *mpxs_Apache2__RequestRec_new(pTHX_ S
     r->assbackwards    = 1;
     r->protocol        = "UNKNOWN";
 
-    r_sv = sv_setref_pv(NEWSV(0, 0), "Apache2::RequestRec", (void*)r);
+    r_sv = sv_setref_pv(newSV(0), "Apache2::RequestRec", (void*)r);
 
     if (base_pool_sv) {
         mpxs_add_pool_magic(r_sv, base_pool_sv);

Modified: perl/modperl/branches/httpd24/xs/Apache2/ServerUtil/Apache2__ServerUtil.h
URL: http://svn.apache.org/viewvc/perl/modperl/branches/httpd24/xs/Apache2/ServerUtil/Apache2__ServerUtil.h?rev=1448022&r1=1448021&r2=1448022&view=diff
==============================================================================
--- perl/modperl/branches/httpd24/xs/Apache2/ServerUtil/Apache2__ServerUtil.h (original)
+++ perl/modperl/branches/httpd24/xs/Apache2/ServerUtil/Apache2__ServerUtil.h Wed Feb 20 07:54:50 2013
@@ -55,6 +55,9 @@ static apr_status_t mpxs_cleanup_run(voi
     dTHXa(cdata->perl);
 #endif
     dSP;
+#ifdef USE_ITHREADS
+    PERL_SET_CONTEXT(aTHX);
+#endif
 
     ENTER;SAVETMPS;
     PUSHMARK(SP);
@@ -63,6 +66,7 @@ static apr_status_t mpxs_cleanup_run(voi
     }
     PUTBACK;
 
+    save_gp(PL_errgv, 1);       /* local *@ */
     count = call_sv(cdata->cv, G_SCALAR|G_EVAL);
 
     SPAGAIN;
@@ -71,6 +75,11 @@ static apr_status_t mpxs_cleanup_run(voi
         (void)POPs; /* the return value is ignored */
     }
 
+    if (SvTRUE(ERRSV)) {
+        Perl_warn(aTHX_ "Apache2::ServerUtil: cleanup died: %s",
+                  SvPV_nolen(ERRSV));
+    }
+
     PUTBACK;
     FREETMPS;LEAVE;
 
@@ -79,10 +88,6 @@ static apr_status_t mpxs_cleanup_run(voi
         SvREFCNT_dec(cdata->arg);
     }
 
-    if (SvTRUE(ERRSV)) {
-        Perl_croak(aTHX_ SvPV_nolen(ERRSV));
-    }
-
     /* the return value is ignored by apr_pool_destroy anyway */
     return APR_SUCCESS;
 }
@@ -103,7 +108,7 @@ void mpxs_Apache2__ServerUtil_server_shu
      * before parent perl is destroyed */
     data = (mpxs_cleanup2_t *)apr_pcalloc(p, sizeof(*data));
     data->cv   = SvREFCNT_inc(cv);
-    data->arg  = arg ? SvREFCNT_inc(arg) : Nullsv;
+    data->arg  = arg ? SvREFCNT_inc(arg) : (SV *)NULL;
     data->p    = p;
 #ifdef USE_ITHREADS
     data->perl = aTHX;

Modified: perl/modperl/branches/httpd24/xs/Apache2/SubProcess/Apache2__SubProcess.h
URL: http://svn.apache.org/viewvc/perl/modperl/branches/httpd24/xs/Apache2/SubProcess/Apache2__SubProcess.h?rev=1448022&r1=1448021&r2=1448022&view=diff
==============================================================================
--- perl/modperl/branches/httpd24/xs/Apache2/SubProcess/Apache2__SubProcess.h (original)
+++ perl/modperl/branches/httpd24/xs/Apache2/SubProcess/Apache2__SubProcess.h Wed Feb 20 07:54:50 2013
@@ -135,7 +135,7 @@ MP_STATIC XS(MPXS_modperl_spawn_proc_pro
     const char *usage = "Usage: spawn_proc_prog($r, $command, [\\@argv])";
 
     if (items < 2) {
-        Perl_croak(aTHX_ usage);
+        Perl_croak(aTHX_ "%s", usage);
     }
 
     SP -= items;
@@ -144,7 +144,7 @@ MP_STATIC XS(MPXS_modperl_spawn_proc_pro
         apr_status_t rc;
         const char **argv;
         int i=0;
-        AV *av_argv = Nullav;
+        AV *av_argv = (AV *)NULL;
         I32 len=-1, av_items=0;
         request_rec *r = modperl_xs_sv2request_rec(aTHX_ ST(0), NULL, cv);
         const char *command = (const char *)SvPV_nolen(ST(1));
@@ -156,7 +156,7 @@ MP_STATIC XS(MPXS_modperl_spawn_proc_pro
                 av_items = len+1;
             }
             else {
-                Perl_croak(aTHX_ usage);
+                Perl_croak(aTHX_ "%s", usage);
             }
         }
 

Modified: perl/modperl/branches/httpd24/xs/maps/apr_functions.map
URL: http://svn.apache.org/viewvc/perl/modperl/branches/httpd24/xs/maps/apr_functions.map?rev=1448022&r1=1448021&r2=1448022&view=diff
==============================================================================
--- perl/modperl/branches/httpd24/xs/maps/apr_functions.map (original)
+++ perl/modperl/branches/httpd24/xs/maps/apr_functions.map Wed Feb 20 07:54:50 2013
@@ -50,7 +50,7 @@ MODULE=APR::Socket
 ~apr_socket_recv
  mpxs_APR__Socket_recv
  apr_socket_recvfrom
- apr_socket_send | mpxs_ | sock, SV *:buf, SV *:len=Nullsv
+ apr_socket_send | mpxs_ | sock, SV *:buf, SV *:len=(SV *)NULL
  apr_socket_sendto
 !apr_socket_shutdown
 -apr_socket_inherit_set
@@ -187,7 +187,7 @@ mpxs_APR__Pool_clear
 !apr_pool_cleanup_kill
 !apr_pool_cleanup_run
 -apr_pool_cleanup_null
- apr_pool_cleanup_register | mpxs_ | p, SV *:cv, SV *:arg=Nullsv
+ apr_pool_cleanup_register | mpxs_ | p, SV *:cv, SV *:arg=(SV *)NULL
 !apr_pool_note_subprocess
 -apr_palloc
 >apr_palloc_debug
@@ -271,7 +271,7 @@ MODULE=APR::Table
  void:DEFINE_STORE | | apr_table_t *:t, const char *:key, const char *:value
  void:DEFINE_DELETE | | apr_table_t *:t, const char *:key
  void:DEFINE_CLEAR | | apr_table_t *:t
- const char *:DEFINE_FIRSTKEY | mpxs_APR__Table_NEXTKEY | SV *:tsv, SV *:key=Nullsv
+ const char *:DEFINE_FIRSTKEY | mpxs_APR__Table_NEXTKEY | SV *:tsv, SV *:key=(SV *)NULL
  mpxs_APR__Table_NEXTKEY | | SV *:tsv, SV *:key=&PL_sv_undef
  mpxs_APR__Table_FETCH
  mpxs_APR__Table_EXISTS
@@ -593,7 +593,7 @@ MODULE=APR::URI
  apr_uri_unparse | mpxs_ | \
                   uptr, flags=APR_URI_UNP_OMITPASSWORD | unparse
  #special case to set both uri->port and uri->port_str
- mpxs_APR__URI_port | | uri, portsv=Nullsv
+ mpxs_APR__URI_port | | uri, portsv=(SV *)NULL
  mpxs_APR__URI_rpath
  apr_uri_port_of_scheme
 

Modified: perl/modperl/branches/httpd24/xs/maps/modperl_functions.map
URL: http://svn.apache.org/viewvc/perl/modperl/branches/httpd24/xs/maps/modperl_functions.map?rev=1448022&r1=1448021&r2=1448022&view=diff
==============================================================================
--- perl/modperl/branches/httpd24/xs/maps/modperl_functions.map (original)
+++ perl/modperl/branches/httpd24/xs/maps/modperl_functions.map Wed Feb 20 07:54:50 2013
@@ -15,12 +15,12 @@ MODULE=ModPerl::Global
  mpxs_ModPerl__Global_special_list_register
 
 MODULE=Apache2::RequestRec   PACKAGE=Apache2::RequestRec
- mpxs_Apache2__RequestRec_content_type   | | r, type=Nullsv
- mpxs_Apache2__RequestRec_proxyreq       | | r, val=Nullsv
- mpxs_Apache2__RequestRec_subprocess_env | | r, key=NULL, val=Nullsv
+ mpxs_Apache2__RequestRec_content_type   | | r, type=(SV *)NULL
+ mpxs_Apache2__RequestRec_proxyreq       | | r, val=(SV *)NULL
+ mpxs_Apache2__RequestRec_subprocess_env | | r, key=NULL, val=(SV *)NULL
  mpxs_Apache2__RequestRec_finfo | | r, finfo=NULL
  mpxs_Apache2__RequestRec_handler | | ...
- mpxs_Apache2__RequestRec_content_languages | | r, languages=Nullsv
+ mpxs_Apache2__RequestRec_content_languages | | r, languages=(SV *)NULL
 
 MODULE=Apache2::RequestUtil   PACKAGE=guess
  mpxs_Apache2__RequestRec_push_handlers
@@ -29,26 +29,26 @@ MODULE=Apache2::RequestUtil   PACKAGE=gu
  mpxs_Apache2__RequestRec_is_perl_option_enabled
  mpxs_Apache2__RequestRec_location
  mpxs_Apache2__RequestRec_as_string
- mpxs_Apache2__RequestRec_pnotes | | r, key=Nullsv, val=Nullsv
+ mpxs_Apache2__RequestRec_pnotes | | r, key=(SV *)NULL, val=(SV *)NULL
  mpxs_Apache2__RequestRec_add_config | | r, lines, override=MP_HTTPD_OVERRIDE_HTACCESS, path=NULL, override_options=MP_HTTPD_OVERRIDE_OPTS_UNSET
- mpxs_Apache2__RequestRec_document_root | | r, new_root=Nullsv
+ mpxs_Apache2__RequestRec_document_root | | r, new_root=(SV *)NULL
  mpxs_Apache2__RequestRec_child_terminate
 
  #protocol module helpers
  mpxs_Apache2__RequestRec_location_merge
  mpxs_Apache2__RequestRec_set_basic_credentials
- mpxs_Apache2__RequestRec_no_cache | | r, flag=Nullsv
+ mpxs_Apache2__RequestRec_no_cache | | r, flag=(SV *)NULL
 
 PACKAGE=Apache2::RequestRec
- mpxs_Apache2__RequestRec_new | | classname, c, base_pool_sv=Nullsv
- SV *:DEFINE_dir_config | | request_rec *:r, char *:key=NULL, SV *:sv_val=Nullsv
+ mpxs_Apache2__RequestRec_new | | classname, c, base_pool_sv=(SV *)NULL
+ SV *:DEFINE_dir_config | | request_rec *:r, char *:key=NULL, SV *:sv_val=(SV *)NULL
  SV *:DEFINE_slurp_filename | | request_rec *:r, int:tainted=1
 
 MODULE=Apache2::RequestUtil   PACKAGE=Apache2::RequestUtil
- mpxs_Apache2__RequestUtil_request | | classname, svr=Nullsv
+ mpxs_Apache2__RequestUtil_request | | classname, svr=(SV *)NULL
 
 MODULE=Apache2::RequestIO   PACKAGE=Apache2::RequestRec
- SV *:DEFINE_TIEHANDLE    | | SV *:stashsv, SV *:sv=Nullsv
+ SV *:DEFINE_TIEHANDLE    | | SV *:stashsv, SV *:sv=(SV *)NULL
  SV *:DEFINE_PRINT  | | ...
  apr_size_t:DEFINE_PRINTF | | ...
  SV *:DEFINE_BINMODE  | | request_rec *:r
@@ -63,7 +63,7 @@ MODULE=Apache2::RequestIO   PACKAGE=Apac
              request_rec *:r, SV *:buffer, apr_size_t:len=-1, apr_off_t:offset=0
  mpxs_Apache2__RequestRec_rflush | | ...
  mpxs_Apache2__RequestRec_GETC
- mpxs_Apache2__RequestRec_OPEN | | SV *:self, SV *:arg1, SV *:arg2=Nullsv
+ mpxs_Apache2__RequestRec_OPEN | | SV *:self, SV *:arg1, SV *:arg2=(SV *)NULL
  mpxs_Apache2__RequestRec_FILENO
 
 MODULE=Apache2::Response   PACKAGE=Apache2::RequestRec
@@ -79,22 +79,22 @@ MODULE=Apache2::ServerUtil   PACKAGE=gue
  mpxs_Apache2__ServerRec_add_config
 
 MODULE=Apache2::ServerUtil  PACKAGE=Apache2::ServerRec
- SV *:DEFINE_dir_config | | server_rec *:s, char *:key=NULL, SV *:sv_val=Nullsv
+ SV *:DEFINE_dir_config | | server_rec *:s, char *:key=NULL, SV *:sv_val=(SV *)NULL
 
 MODULE=Apache2::ServerUtil PACKAGE=Apache2::ServerUtil
- mpxs_Apache2__ServerUtil_server_shutdown_cleanup_register | | cv, arg=Nullsv
+ mpxs_Apache2__ServerUtil_server_shutdown_cleanup_register | | cv, arg=(SV *)NULL
  int:DEFINE_restart_count
 
 MODULE=Apache2::ServerUtil   PACKAGE=Apache2::ServerUtil
- server_rec *:DEFINE_server | | SV *:classname=Nullsv
- uid_t:DEFINE_user_id       | | SV *:classname=Nullsv
- gid_t:DEFINE_group_id      | | SV *:classname=Nullsv
+ server_rec *:DEFINE_server | | SV *:classname=(SV *)NULL
+ uid_t:DEFINE_user_id       | | SV *:classname=(SV *)NULL
+ gid_t:DEFINE_group_id      | | SV *:classname=(SV *)NULL
 
 MODULE=Apache2::Connection
  mpxs_Apache2__Connection_client_socket | | c, s=NULL
 
 MODULE=Apache2::ConnectionUtil   PACKAGE=guess
- mpxs_Apache2__Connection_pnotes | | c, key=Nullsv, val=Nullsv
+ mpxs_Apache2__Connection_pnotes | | c, key=(SV *)NULL, val=(SV *)NULL
 
 MODULE=Apache2::Filter
  modperl_filter_attributes | MPXS_ | ... | MODIFY_CODE_ATTRIBUTES
@@ -102,10 +102,10 @@ MODULE=Apache2::Filter
  mpxs_Apache2__Filter_print    | | ...
  mpxs_Apache2__Filter_read     | | ...
  mpxs_Apache2__Filter_seen_eos | | ...
- mpxs_Apache2__Filter_ctx      | | filter, data=Nullsv
+ mpxs_Apache2__Filter_ctx      | | filter, data=(SV *)NULL
  mpxs_Apache2__Filter_remove   | | ...
 
- SV *:DEFINE_TIEHANDLE | | SV *:stashsv, SV *:sv=Nullsv
+ SV *:DEFINE_TIEHANDLE | | SV *:stashsv, SV *:sv=(SV *)NULL
  apr_size_t:DEFINE_PRINT      | | ...
 
 MODULE=Apache2::Filter PACKAGE=Apache2::RequestRec

Modified: perl/modperl/branches/httpd24/xs/modperl_xs_util.h
URL: http://svn.apache.org/viewvc/perl/modperl/branches/httpd24/xs/modperl_xs_util.h?rev=1448022&r1=1448021&r2=1448022&view=diff
==============================================================================
--- perl/modperl/branches/httpd24/xs/modperl_xs_util.h (original)
+++ perl/modperl/branches/httpd24/xs/modperl_xs_util.h Wed Feb 20 07:54:50 2013
@@ -121,17 +121,17 @@
       * the object is generated by modperl_hash_tie, so under 5.8+
       * need to use sv_magicext, since sv_magicext does only one magic
       * of the same type at 5.8+ */
-#define mpxs_add_pool_magic_doit(obj, pool_obj)                         \
-    sv_magicext(SvRV(obj), pool_obj, PERL_MAGIC_ext, NULL, Nullch, -1)
+#define mpxs_add_pool_magic_doit(obj, pool_obj)                               \
+    sv_magicext(SvRV(obj), pool_obj, PERL_MAGIC_ext, NULL, (char *)NULL, -1)
 #else
-#define mpxs_add_pool_magic_doit(obj, pool_obj)                         \
-    sv_magic(SvRV(obj), pool_obj, PERL_MAGIC_ext, Nullch, -1)
+#define mpxs_add_pool_magic_doit(obj, pool_obj)                               \
+    sv_magic(SvRV(obj), pool_obj, PERL_MAGIC_ext, (char *)NULL, -1)
 #endif
 
 /* add dependency magic only for custom pools.  there are all kind of
  * complications when more than one magic of the same type(in this
  * case PERL_MAGIC_ext is added), luckily most of the PERL_MAGIC_ext
- * magic used by modperl-core, uses Nullsv as mg->mg_obj, therefore
+ * magic used by modperl-core, uses (SV *)NULL as mg->mg_obj, therefore
  * the following code tries to workaround the multiple magic issue, by
  * simply hanging the pool object into the unused slot, incrementing
  * its refcnt just like sv_magic does internally. In case we ever hit
@@ -142,7 +142,7 @@
     if (mpxs_pool_is_custom(SvRV(pool_obj))) {                     \
         MAGIC *mg = mg_find(SvRV(obj), PERL_MAGIC_ext);            \
         if (mg) {                                                  \
-            if (mg->mg_obj == Nullsv) {                            \
+            if (mg->mg_obj == (SV *)NULL) {                        \
                 mg->mg_obj = SvREFCNT_inc(SvRV(pool_obj));         \
                 mg->mg_flags |= MGf_REFCOUNTED;                    \
             }                                                      \