You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@subversion.apache.org by jc...@apache.org on 2010/12/30 23:20:55 UTC

svn commit: r1054012 [4/6] - in /subversion/branches/diff-optimizations-bytes: ./ build/generator/ contrib/server-side/ contrib/server-side/mod_dontdothat/ contrib/server-side/svnstsw/src/ subversion/bindings/javahl/native/ subversion/bindings/javahl/s...

Modified: subversion/branches/diff-optimizations-bytes/subversion/libsvn_subr/stream.c
URL: http://svn.apache.org/viewvc/subversion/branches/diff-optimizations-bytes/subversion/libsvn_subr/stream.c?rev=1054012&r1=1054011&r2=1054012&view=diff
==============================================================================
--- subversion/branches/diff-optimizations-bytes/subversion/libsvn_subr/stream.c (original)
+++ subversion/branches/diff-optimizations-bytes/subversion/libsvn_subr/stream.c Thu Dec 30 22:20:48 2010
@@ -1292,7 +1292,7 @@ struct stringbuf_stream_baton
 
 /* svn_stream_mark_t for streams backed by stringbufs. */
 struct stringbuf_stream_mark {
-    apr_size_t pos; 
+    apr_size_t pos;
 };
 
 static svn_error_t *
@@ -1377,7 +1377,7 @@ struct string_stream_baton
 
 /* svn_stream_mark_t for streams backed by stringbufs. */
 struct string_stream_mark {
-    apr_size_t pos; 
+    apr_size_t pos;
 };
 
 static svn_error_t *

Modified: subversion/branches/diff-optimizations-bytes/subversion/libsvn_subr/subst.c
URL: http://svn.apache.org/viewvc/subversion/branches/diff-optimizations-bytes/subversion/libsvn_subr/subst.c?rev=1054012&r1=1054011&r2=1054012&view=diff
==============================================================================
--- subversion/branches/diff-optimizations-bytes/subversion/libsvn_subr/subst.c (original)
+++ subversion/branches/diff-optimizations-bytes/subversion/libsvn_subr/subst.c Thu Dec 30 22:20:48 2010
@@ -905,7 +905,7 @@ eol_unchanged(struct translation_baton *
               const char *buf)
 {
   /* If the first byte doesn't match, the whole EOL won't.
-   * This does also handle the (certainly invalid) case that 
+   * This does also handle the (certainly invalid) case that
    * eol_str would be an empty string.
    */
   if (buf[0] != b->eol_str[0])
@@ -915,7 +915,7 @@ eol_unchanged(struct translation_baton *
   if (b->eol_str_len == 2)
     return buf[1] == b->eol_str[1];
 
-  /* The first char matches the required 1-byte EOL. 
+  /* The first char matches the required 1-byte EOL.
    * But maybe, buf[] contains a 2-byte EOL?
    * In that case, the second byte will be interesting
    * and not be another EOL of its own.
@@ -1036,9 +1036,9 @@ translate_chunk(svn_stream_t *dst,
           /* translate_newline will modify the baton for src_format_len==0
              or may return an error if b->repair is FALSE.  In all other
              cases, we can skip the newline translation as long as source
-             EOL format and actual EOL format match.  If there is a 
-             mismatch, translate_newline will be called regardless of 
-             nl_translation_skippable. 
+             EOL format and actual EOL format match.  If there is a
+             mismatch, translate_newline will be called regardless of
+             nl_translation_skippable.
            */
           if (b->nl_translation_skippable == svn_tristate_unknown &&
               b->src_format_len > 0)
@@ -1047,14 +1047,14 @@ translate_chunk(svn_stream_t *dst,
               if (b->eol_str_len == b->src_format_len &&
                   strncmp(b->eol_str, b->src_format, b->eol_str_len) == 0)
                 b->nl_translation_skippable = svn_tristate_true;
-              else if (b->repair) 
+              else if (b->repair)
                 b->nl_translation_skippable = svn_tristate_true;
               else
                 b->nl_translation_skippable = svn_tristate_false;
             }
 
           /* We're in the boring state; look for interesting characters.
-             Offset len such that it will become 0 in the first iteration. 
+             Offset len such that it will become 0 in the first iteration.
            */
           len = 0 - b->eol_str_len;
 
@@ -1081,7 +1081,7 @@ translate_chunk(svn_stream_t *dst,
                   len += 4;
                 }
 
-               /* Found an interesting char or EOF in the next 4 bytes. 
+               /* Found an interesting char or EOF in the next 4 bytes.
                   Find its exact position. */
                while ((p + len) < end && !interesting[(unsigned char)p[len]])
                  ++len;
@@ -1281,7 +1281,7 @@ translated_stream_close(void *baton)
 
 
 /* svn_stream_mark_t for translation streams. */
-typedef struct
+typedef struct mark_translated_t
 {
   /* Saved translation state. */
   struct translated_stream_baton saved_baton;
@@ -1296,7 +1296,7 @@ translated_stream_mark(void *baton, svn_
 {
   mark_translated_t *mt;
   struct translated_stream_baton *b = baton;
-  
+
   mt = apr_palloc(pool, sizeof(*mt));
   SVN_ERR(svn_stream_mark(b->stream, &mt->mark, pool));
 
@@ -1331,13 +1331,13 @@ translated_stream_seek(void *baton, svn_
                                 b->iterpool));
 
       SVN_ERR(svn_stream_seek(b->stream, mt->mark));
-    
+
       /* Restore translation state, avoiding new allocations. */
       *b->in_baton = *mt->saved_baton.in_baton;
       *b->out_baton = *mt->saved_baton.out_baton;
       b->written = mt->saved_baton.written;
       svn_stringbuf_setempty(b->readbuf);
-      svn_stringbuf_appendbytes(b->readbuf, mt->saved_baton.readbuf->data, 
+      svn_stringbuf_appendbytes(b->readbuf, mt->saved_baton.readbuf->data,
                                 mt->saved_baton.readbuf->len);
       b->readbuf_off = mt->saved_baton.readbuf_off;
       memcpy(b->buf, mt->saved_baton.buf, SVN__TRANSLATION_BUF_SIZE);

Modified: subversion/branches/diff-optimizations-bytes/subversion/libsvn_subr/svn_string.c
URL: http://svn.apache.org/viewvc/subversion/branches/diff-optimizations-bytes/subversion/libsvn_subr/svn_string.c?rev=1054012&r1=1054011&r2=1054012&view=diff
==============================================================================
--- subversion/branches/diff-optimizations-bytes/subversion/libsvn_subr/svn_string.c (original)
+++ subversion/branches/diff-optimizations-bytes/subversion/libsvn_subr/svn_string.c Thu Dec 30 22:20:48 2010
@@ -404,8 +404,8 @@ svn_stringbuf_ensure(svn_stringbuf_t *st
 }
 
 
-/* WARNING - Optimized code ahead! 
- * This function has been hand-tuned for performance. Please read 
+/* WARNING - Optimized code ahead!
+ * This function has been hand-tuned for performance. Please read
  * the comments below before modifying the code.
  */
 void
@@ -423,7 +423,7 @@ svn_stringbuf_appendbyte(svn_stringbuf_t
       /* The following read does not depend this write, so we
        * can issue the write first to minimize register pressure:
        * The value of old_len+1 is no longer needed; on most processors,
-       * dest[old_len+1] will be calculated implicitly as part of 
+       * dest[old_len+1] will be calculated implicitly as part of
        * the addressing scheme.
        */
       str->len = old_len+1;
@@ -441,7 +441,7 @@ svn_stringbuf_appendbyte(svn_stringbuf_t
        *
        * Including the "byte" fetch, all operations so far could be
        * issued at once and be scheduled at the CPU's descression.
-       * Most likely, no-one will soon depend on the data that will be 
+       * Most likely, no-one will soon depend on the data that will be
        * written in this function. So, no stalls there, either.
        */
       dest[old_len] = byte;

Modified: subversion/branches/diff-optimizations-bytes/subversion/libsvn_subr/username_providers.c
URL: http://svn.apache.org/viewvc/subversion/branches/diff-optimizations-bytes/subversion/libsvn_subr/username_providers.c?rev=1054012&r1=1054011&r2=1054012&view=diff
==============================================================================
--- subversion/branches/diff-optimizations-bytes/subversion/libsvn_subr/username_providers.c (original)
+++ subversion/branches/diff-optimizations-bytes/subversion/libsvn_subr/username_providers.c Thu Dec 30 22:20:48 2010
@@ -165,7 +165,7 @@ svn_auth_get_username_provider(svn_auth_
 /*-----------------------------------------------------------------------*/
 
 /* Baton type for username-only prompting. */
-typedef struct
+typedef struct username_prompt_provider_baton_t
 {
   svn_auth_username_prompt_func_t prompt_func;
   void *prompt_baton;
@@ -176,7 +176,7 @@ typedef struct
 
 
 /* Iteration baton type for username-only prompting. */
-typedef struct
+typedef struct username_prompt_iter_baton_t
 {
   /* how many times we've reprompted */
   int retries;

Modified: subversion/branches/diff-optimizations-bytes/subversion/libsvn_subr/win32_crashrpt.c
URL: http://svn.apache.org/viewvc/subversion/branches/diff-optimizations-bytes/subversion/libsvn_subr/win32_crashrpt.c?rev=1054012&r1=1054011&r2=1054012&view=diff
==============================================================================
--- subversion/branches/diff-optimizations-bytes/subversion/libsvn_subr/win32_crashrpt.c (original)
+++ subversion/branches/diff-optimizations-bytes/subversion/libsvn_subr/win32_crashrpt.c Thu Dec 30 22:20:48 2010
@@ -375,7 +375,7 @@ format_value(char *value_str, DWORD64 mo
 
 /* Internal structure used to pass some data to the enumerate symbols
  * callback */
-typedef struct {
+typedef struct symbols_baton_t {
   STACKFRAME64 *stack_frame;
   FILE *log_file;
   int nr_of_frame;

Modified: subversion/branches/diff-optimizations-bytes/subversion/libsvn_wc/adm_crawler.c
URL: http://svn.apache.org/viewvc/subversion/branches/diff-optimizations-bytes/subversion/libsvn_wc/adm_crawler.c?rev=1054012&r1=1054011&r2=1054012&view=diff
==============================================================================
--- subversion/branches/diff-optimizations-bytes/subversion/libsvn_wc/adm_crawler.c (original)
+++ subversion/branches/diff-optimizations-bytes/subversion/libsvn_wc/adm_crawler.c Thu Dec 30 22:20:48 2010
@@ -476,7 +476,7 @@ report_revisions_and_depths(svn_wc__db_t
               const char *file_ext_str;
 
               this_switched = TRUE;
-             
+
               /* This could be a file external!  We need to know
                  that. */
               SVN_ERR(svn_wc__db_temp_get_file_external(&file_ext_str, db,

Modified: subversion/branches/diff-optimizations-bytes/subversion/libsvn_wc/adm_ops.c
URL: http://svn.apache.org/viewvc/subversion/branches/diff-optimizations-bytes/subversion/libsvn_wc/adm_ops.c?rev=1054012&r1=1054011&r2=1054012&view=diff
==============================================================================
--- subversion/branches/diff-optimizations-bytes/subversion/libsvn_wc/adm_ops.c (original)
+++ subversion/branches/diff-optimizations-bytes/subversion/libsvn_wc/adm_ops.c Thu Dec 30 22:20:48 2010
@@ -74,7 +74,7 @@ struct svn_wc_committed_queue_t
   svn_boolean_t have_recursive;
 };
 
-typedef struct
+typedef struct committed_queue_item_t
 {
   const char *local_abspath;
   svn_boolean_t recurse;
@@ -1108,7 +1108,7 @@ svn_wc_add4(svn_wc_context_t *wc_ctx,
         {
           /* This code should never be used, as it doesn't install proper
              pristine and/or properties. But it was not an error in the old
-             version of this function. 
+             version of this function.
 
              ===> Use svn_wc_add_repos_file4() directly! */
           svn_stream_t *content = svn_stream_empty(scratch_pool);
@@ -1869,7 +1869,7 @@ svn_wc__internal_remove_from_revision_co
 
           entry_abspath = svn_dirent_join(local_abspath, entry_name, iterpool);
 
-          /* ### where did the adm_missing and depth_exclude test go?!? 
+          /* ### where did the adm_missing and depth_exclude test go?!?
 
              ### BH: depth exclude is handled by hidden and missing is ok
                      for this temp_op. */

Modified: subversion/branches/diff-optimizations-bytes/subversion/libsvn_wc/ambient_depth_filter_editor.c
URL: http://svn.apache.org/viewvc/subversion/branches/diff-optimizations-bytes/subversion/libsvn_wc/ambient_depth_filter_editor.c?rev=1054012&r1=1054011&r2=1054012&view=diff
==============================================================================
--- subversion/branches/diff-optimizations-bytes/subversion/libsvn_wc/ambient_depth_filter_editor.c (original)
+++ subversion/branches/diff-optimizations-bytes/subversion/libsvn_wc/ambient_depth_filter_editor.c Thu Dec 30 22:20:48 2010
@@ -301,7 +301,7 @@ make_file_baton(struct file_baton **f_p,
          depth==empty.  So if the parent doesn't
          already have an entry for the file, then the parent
          doesn't want to hear about the file at all. */
-      
+
       if (hidden || kind == svn_wc__db_kind_unknown)
         {
           f->ambiently_excluded = TRUE;

Modified: subversion/branches/diff-optimizations-bytes/subversion/libsvn_wc/conflicts.h
URL: http://svn.apache.org/viewvc/subversion/branches/diff-optimizations-bytes/subversion/libsvn_wc/conflicts.h?rev=1054012&r1=1054011&r2=1054012&view=diff
==============================================================================
--- subversion/branches/diff-optimizations-bytes/subversion/libsvn_wc/conflicts.h (original)
+++ subversion/branches/diff-optimizations-bytes/subversion/libsvn_wc/conflicts.h Thu Dec 30 22:20:48 2010
@@ -58,10 +58,10 @@ svn_wc__conflict_skel_new(apr_pool_t *re
 
 /* Set 'update' as the conflicting operation in CONFLICT_SKEL.
    Allocate data stored in the skel in RESULT_POOL.
- 
+
    BASE_REVISION is the revision the node was at before the update.
    TARGET_REVISION is the revision being updated to.
- 
+
    Do temporary allocations in SCRATCH_POOL. */
 svn_error_t *
 svn_wc__conflict_skel_set_op_update(svn_skel_t *conflict_skel,
@@ -92,7 +92,7 @@ svn_wc__conflict_skel_set_op_switch(svn_
    Allocate data stored in the skel in RESULT_POOL.
 
    REPOS_UUID is the UUID of the repository accessed via REPOS_ROOT_URL.
-  
+
    LEFT_REPOS_RELPATH and RIGHT_REPOS_RELPATH paths to the merge-left
    and merge-right merge sources, relative to REPOS_URL
 

Modified: subversion/branches/diff-optimizations-bytes/subversion/libsvn_wc/copy.c
URL: http://svn.apache.org/viewvc/subversion/branches/diff-optimizations-bytes/subversion/libsvn_wc/copy.c?rev=1054012&r1=1054011&r2=1054012&view=diff
==============================================================================
--- subversion/branches/diff-optimizations-bytes/subversion/libsvn_wc/copy.c (original)
+++ subversion/branches/diff-optimizations-bytes/subversion/libsvn_wc/copy.c Thu Dec 30 22:20:48 2010
@@ -114,7 +114,7 @@ copy_to_tmpdir(const char **dst_abspath,
                              scratch_pool));
   else
     SVN_ERR(svn_io_copy_link(src_abspath, *dst_abspath, scratch_pool));
-    
+
 
   return SVN_NO_ERROR;
 }
@@ -461,7 +461,7 @@ svn_wc_copy3(svn_wc_context_t *wc_ctx,
 
   SVN_ERR_ASSERT(svn_dirent_is_absolute(src_abspath));
   SVN_ERR_ASSERT(svn_dirent_is_absolute(dst_abspath));
-  
+
   dstdir_abspath = svn_dirent_dirname(dst_abspath, scratch_pool);
 
   /* Ensure DSTDIR_ABSPATH belongs to the same repository as SRC_ABSPATH;

Modified: subversion/branches/diff-optimizations-bytes/subversion/libsvn_wc/deprecated.c
URL: http://svn.apache.org/viewvc/subversion/branches/diff-optimizations-bytes/subversion/libsvn_wc/deprecated.c?rev=1054012&r1=1054011&r2=1054012&view=diff
==============================================================================
--- subversion/branches/diff-optimizations-bytes/subversion/libsvn_wc/deprecated.c (original)
+++ subversion/branches/diff-optimizations-bytes/subversion/libsvn_wc/deprecated.c Thu Dec 30 22:20:48 2010
@@ -3637,7 +3637,7 @@ svn_wc_copy2(const char *src,
   SVN_ERR(svn_wc_copy3(wc_ctx,
                        src_abspath,
                        dst_abspath,
-                       FALSE /* metadata_only */, 
+                       FALSE /* metadata_only */,
                        cancel_func, cancel_baton,
                        notify_func, notify_baton,
                        pool));

Modified: subversion/branches/diff-optimizations-bytes/subversion/libsvn_wc/entries.c
URL: http://svn.apache.org/viewvc/subversion/branches/diff-optimizations-bytes/subversion/libsvn_wc/entries.c?rev=1054012&r1=1054011&r2=1054012&view=diff
==============================================================================
--- subversion/branches/diff-optimizations-bytes/subversion/libsvn_wc/entries.c (original)
+++ subversion/branches/diff-optimizations-bytes/subversion/libsvn_wc/entries.c Thu Dec 30 22:20:48 2010
@@ -52,7 +52,7 @@
 
 /* Temporary structures which mirror the tables in wc-metadata.sql.
    For detailed descriptions of each field, see that file. */
-typedef struct {
+typedef struct db_base_node_t {
   apr_int64_t wc_id;
   const char *local_relpath;
   apr_int64_t repos_id;
@@ -71,7 +71,7 @@ typedef struct {
   apr_hash_t *properties;
 } db_base_node_t;
 
-typedef struct {
+typedef struct db_working_node_t {
   apr_int64_t wc_id;
   const char *local_relpath;
   apr_int64_t op_depth;
@@ -93,7 +93,7 @@ typedef struct {
   apr_hash_t *properties;
 } db_working_node_t;
 
-typedef struct {
+typedef struct db_actual_node_t {
   apr_int64_t wc_id;
   const char *local_relpath;
   const char *parent_relpath;
@@ -540,8 +540,8 @@ read_one_entry(const svn_wc_entry_t **ne
         entry->copied = TRUE;
 
       /* If there is still a directory on-disk we keep it, if not it is
-         already deleted. Simple, isn't it? 
-         
+         already deleted. Simple, isn't it?
+
          Before single-db we had to keep the administative area alive until
          after the commit really deletes it. Setting keep alive stopped the
          commit processing from deleting the directory. We don't delete it
@@ -625,7 +625,7 @@ read_one_entry(const svn_wc_entry_t **ne
                                            entry_abspath,
                                            result_pool, scratch_pool));
 
-          /* In wc.db we want to keep the valid revision of the not-present 
+          /* In wc.db we want to keep the valid revision of the not-present
              BASE_REV, but when we used entries we set the revision to 0
              when adding a new node over a not present base node. */
           if (work_status == svn_wc__db_status_added

Modified: subversion/branches/diff-optimizations-bytes/subversion/libsvn_wc/lock.c
URL: http://svn.apache.org/viewvc/subversion/branches/diff-optimizations-bytes/subversion/libsvn_wc/lock.c?rev=1054012&r1=1054011&r2=1054012&view=diff
==============================================================================
--- subversion/branches/diff-optimizations-bytes/subversion/libsvn_wc/lock.c (original)
+++ subversion/branches/diff-optimizations-bytes/subversion/libsvn_wc/lock.c Thu Dec 30 22:20:48 2010
@@ -162,19 +162,19 @@ svn_wc__internal_check_wc(int *wc_format
                 return SVN_NO_ERROR;
               }
           }
-      
+
         err = svn_wc__db_read_info(&db_status, &db_kind, NULL, NULL, NULL,
                                    NULL, NULL, NULL, NULL, NULL, NULL, NULL,
                                    NULL, NULL, NULL, NULL, NULL, NULL, NULL,
                                    NULL, NULL, NULL, NULL, NULL,
                                    db, local_abspath,
                                    scratch_pool, scratch_pool);
-      
+
         if (err && err->apr_err == SVN_ERR_WC_PATH_NOT_FOUND)
           {
             svn_error_clear(err);
             *wc_format = 0;
-            return SVN_NO_ERROR; 
+            return SVN_NO_ERROR;
           }
         else
           SVN_ERR(err);

Modified: subversion/branches/diff-optimizations-bytes/subversion/libsvn_wc/lock.h
URL: http://svn.apache.org/viewvc/subversion/branches/diff-optimizations-bytes/subversion/libsvn_wc/lock.h?rev=1054012&r1=1054011&r2=1054012&view=diff
==============================================================================
--- subversion/branches/diff-optimizations-bytes/subversion/libsvn_wc/lock.h (original)
+++ subversion/branches/diff-optimizations-bytes/subversion/libsvn_wc/lock.h Thu Dec 30 22:20:48 2010
@@ -59,7 +59,7 @@ svn_wc__adm_retrieve_internal2(svn_wc__d
 /* ### this is probably bunk. but I dunna want to trace backwards-compat
    ### users of svn_wc_check_wc(). probably gonna be rewritten for wc-ng
    ### in any case.
-   
+
    If CHECK_PATH is TRUE, a not-existing directory is not a working copy */
 svn_error_t *
 svn_wc__internal_check_wc(int *wc_format,

Modified: subversion/branches/diff-optimizations-bytes/subversion/libsvn_wc/node.c
URL: http://svn.apache.org/viewvc/subversion/branches/diff-optimizations-bytes/subversion/libsvn_wc/node.c?rev=1054012&r1=1054011&r2=1054012&view=diff
==============================================================================
--- subversion/branches/diff-optimizations-bytes/subversion/libsvn_wc/node.c (original)
+++ subversion/branches/diff-optimizations-bytes/subversion/libsvn_wc/node.c Thu Dec 30 22:20:48 2010
@@ -421,7 +421,7 @@ svn_wc__node_get_url(const char **url,
                             result_pool, scratch_pool));
 }
 
-/* ### This is essentially a copy-paste of svn_wc__internal_get_url(). 
+/* ### This is essentially a copy-paste of svn_wc__internal_get_url().
  * ### If we decide to keep this one, then it should be rewritten to avoid
  * ### code duplication.*/
 svn_error_t *
@@ -980,11 +980,11 @@ svn_wc__node_get_base_rev(svn_revnum_t *
 
 svn_error_t *
 svn_wc__node_get_working_rev_info(svn_revnum_t *revision,
-                                  svn_revnum_t *changed_rev, 
-                                  apr_time_t *changed_date, 
+                                  svn_revnum_t *changed_rev,
+                                  apr_time_t *changed_date,
                                   const char **changed_author,
-                                  svn_wc_context_t *wc_ctx, 
-                                  const char *local_abspath, 
+                                  svn_wc_context_t *wc_ctx,
+                                  const char *local_abspath,
                                   apr_pool_t *scratch_pool,
                                   apr_pool_t *result_pool)
 {
@@ -1016,7 +1016,7 @@ svn_wc__node_get_working_rev_info(svn_re
                                        NULL, changed_rev, changed_date,
                                        changed_author, NULL, NULL, NULL,
                                        NULL, NULL, NULL, NULL, NULL, NULL,
-                                       NULL, NULL, NULL, NULL, 
+                                       NULL, NULL, NULL, NULL,
                                        NULL, NULL, wc_ctx->db, work_del_abspath,
                                        result_pool, scratch_pool));
         }
@@ -1169,7 +1169,7 @@ svn_wc__node_get_lock_info(const char **
     *lock_comment = lock ? lock->comment : NULL;
   if (lock_date)
     *lock_date = lock ? lock->date : 0;
-      
+
   return SVN_NO_ERROR;
 }
 

Modified: subversion/branches/diff-optimizations-bytes/subversion/libsvn_wc/props.c
URL: http://svn.apache.org/viewvc/subversion/branches/diff-optimizations-bytes/subversion/libsvn_wc/props.c?rev=1054012&r1=1054011&r2=1054012&view=diff
==============================================================================
--- subversion/branches/diff-optimizations-bytes/subversion/libsvn_wc/props.c (original)
+++ subversion/branches/diff-optimizations-bytes/subversion/libsvn_wc/props.c Thu Dec 30 22:20:48 2010
@@ -480,7 +480,7 @@ generate_conflict_message(const char *pr
                                       "value '%s',\nbut property with value "
                                       "'%s' is locally deleted."),
                                     propname, incoming_base->data,
-                                    original->data);          
+                                    original->data);
         }
 
       /* We were trying to delete INCOMING_BASE but our ORIGINAL is
@@ -535,7 +535,7 @@ generate_conflict_message(const char *pr
                                 "added with value '%s'."),
                               propname, incoming_base->data, incoming->data,
                               mine->data);
-  
+
   return svn_string_createf(result_pool,
                             _("Trying to change property '%s' from '%s' to "
                               "'%s',\nbut the property does not exist."),

Modified: subversion/branches/diff-optimizations-bytes/subversion/libsvn_wc/relocate.c
URL: http://svn.apache.org/viewvc/subversion/branches/diff-optimizations-bytes/subversion/libsvn_wc/relocate.c?rev=1054012&r1=1054011&r2=1054012&view=diff
==============================================================================
--- subversion/branches/diff-optimizations-bytes/subversion/libsvn_wc/relocate.c (original)
+++ subversion/branches/diff-optimizations-bytes/subversion/libsvn_wc/relocate.c Thu Dec 30 22:20:48 2010
@@ -136,7 +136,7 @@ svn_wc_relocate4(svn_wc_context_t *wc_ct
                              _("Invalid source URL prefix: '%s' (does not "
                                "overlap target's URL '%s')"),
                              from, old_url);
-  
+
   if (old_url_len == from_len)
     new_url = to;
   else

Modified: subversion/branches/diff-optimizations-bytes/subversion/libsvn_wc/revision_status.c
URL: http://svn.apache.org/viewvc/subversion/branches/diff-optimizations-bytes/subversion/libsvn_wc/revision_status.c?rev=1054012&r1=1054011&r2=1054012&view=diff
==============================================================================
--- subversion/branches/diff-optimizations-bytes/subversion/libsvn_wc/revision_status.c (original)
+++ subversion/branches/diff-optimizations-bytes/subversion/libsvn_wc/revision_status.c Thu Dec 30 22:20:48 2010
@@ -59,12 +59,12 @@ analyze_status(const char *local_abspath
   struct walk_baton *wb = baton;
   svn_revnum_t changed_rev;
   svn_revnum_t revision;
-  svn_revnum_t item_rev; 
+  svn_revnum_t item_rev;
   svn_depth_t depth;
   svn_wc__db_status_t status;
 
-  SVN_ERR(svn_wc__db_read_info(&status, NULL, &revision, NULL, 
-                               NULL, NULL, &changed_rev, 
+  SVN_ERR(svn_wc__db_read_info(&status, NULL, &revision, NULL,
+                               NULL, NULL, &changed_rev,
                                NULL, NULL, NULL, &depth, NULL, NULL, NULL,
                                NULL, NULL, NULL, NULL, NULL, NULL,
                                NULL, NULL, NULL, NULL, wb->db,
@@ -73,7 +73,7 @@ analyze_status(const char *local_abspath
   /* We need the excluded and absent paths when checking for sparse
    * checkouts. But only for that. To collect those we're walking all the
    * hidden nodes. */
-  if (status == svn_wc__db_status_excluded 
+  if (status == svn_wc__db_status_excluded
       || status == svn_wc__db_status_absent)
     {
       wb->result->sparse_checkout = TRUE;
@@ -86,7 +86,7 @@ analyze_status(const char *local_abspath
   else if (status == svn_wc__db_status_added
            || status == svn_wc__db_status_deleted)
     {
-      wb->result->modified = TRUE; 
+      wb->result->modified = TRUE;
     }
 
   if (! wb->result->switched)
@@ -135,10 +135,10 @@ analyze_status(const char *local_abspath
                                                FALSE,
                                                TRUE,
                                                scratch_pool));
-      wb->result->modified |= text_mod; 
+      wb->result->modified |= text_mod;
     }
 
-  wb->result->sparse_checkout |= (depth != svn_depth_infinity 
+  wb->result->sparse_checkout |= (depth != svn_depth_infinity
                                   && depth != svn_depth_unknown);
   return SVN_NO_ERROR;
 }

Modified: subversion/branches/diff-optimizations-bytes/subversion/libsvn_wc/status.c
URL: http://svn.apache.org/viewvc/subversion/branches/diff-optimizations-bytes/subversion/libsvn_wc/status.c?rev=1054012&r1=1054011&r2=1054012&view=diff
==============================================================================
--- subversion/branches/diff-optimizations-bytes/subversion/libsvn_wc/status.c (original)
+++ subversion/branches/diff-optimizations-bytes/subversion/libsvn_wc/status.c Thu Dec 30 22:20:48 2010
@@ -187,7 +187,7 @@ struct dir_baton
   /* out-of-date info corresponding to ood_* fields in svn_wc_status3_t. */
   svn_node_kind_t ood_kind;
   svn_revnum_t ood_changed_rev;
-  apr_time_t ood_changed_date;  
+  apr_time_t ood_changed_date;
   const char *ood_changed_author;
 };
 
@@ -243,7 +243,7 @@ read_info(const struct svn_wc__db_info_t
           apr_pool_t *result_pool,
           apr_pool_t *scratch_pool)
 {
-  struct svn_wc__db_info_t *mutable 
+  struct svn_wc__db_info_t *mutable
     = apr_palloc(scratch_pool, sizeof(struct svn_wc__db_info_t));
 
   SVN_ERR(svn_wc__db_read_info(&mutable->status, &mutable->kind,
@@ -560,7 +560,7 @@ assemble_status(svn_wc_status3_t **statu
                                             db, local_abspath, scratch_pool));
 
       if (!text_conflicted && !prop_conflicted && !tree_conflicted)
-        conflicted = FALSE; 
+        conflicted = FALSE;
     }
 
   if (node_status == svn_wc_status_normal)
@@ -586,7 +586,7 @@ assemble_status(svn_wc_status3_t **statu
 
   if (node_status == svn_wc_status_normal)
     node_status = text_status;
-  
+
   if (node_status == svn_wc_status_normal
       && prop_status != svn_wc_status_none)
     node_status = prop_status;
@@ -599,7 +599,7 @@ assemble_status(svn_wc_status3_t **statu
          || (node_status == svn_wc_status_normal))
 
         && (! switched_p)
-        && (! info->lock) 
+        && (! info->lock)
         && (! repos_lock)
         && (! info->changelist)
         && (! conflicted))
@@ -2530,8 +2530,8 @@ internal_status(svn_wc_status3_t **statu
       else if (err)
         return svn_error_return(err);
 
-      if (!err 
-          && parent_repos_relpath == NULL 
+      if (!err
+          && parent_repos_relpath == NULL
           && parent_status != svn_wc__db_status_added
           && parent_status != svn_wc__db_status_deleted)
         SVN_ERR(svn_wc__db_scan_base_repos(&parent_repos_relpath,

Modified: subversion/branches/diff-optimizations-bytes/subversion/libsvn_wc/update_editor.c
URL: http://svn.apache.org/viewvc/subversion/branches/diff-optimizations-bytes/subversion/libsvn_wc/update_editor.c?rev=1054012&r1=1054011&r2=1054012&view=diff
==============================================================================
--- subversion/branches/diff-optimizations-bytes/subversion/libsvn_wc/update_editor.c (original)
+++ subversion/branches/diff-optimizations-bytes/subversion/libsvn_wc/update_editor.c Thu Dec 30 22:20:48 2010
@@ -935,7 +935,7 @@ struct file_baton
 
   /* The last-changed-date of the file.  This is actually a property
      that comes through as an 'entry prop', and will be used to set
-     the working file's timestamp if it's added. 
+     the working file's timestamp if it's added.
 
      Will be NULL unless eb->use_commit_times is TRUE. */
   const char *last_changed_date;
@@ -1081,8 +1081,6 @@ static svn_error_t *
 accumulate_last_change(svn_revnum_t *changed_rev,
                        apr_time_t *changed_date,
                        const char **changed_author,
-                       svn_wc__db_t *db,
-                       const char *local_abspath,
                        const apr_array_header_t *entry_props,
                        apr_pool_t *scratch_pool,
                        apr_pool_t *result_pool)
@@ -1947,7 +1945,7 @@ do_entry_deletion(struct edit_baton *eb,
     }
 
     /* Receive the remote removal of excluded/absent/not present node.
-       Do not notify. 
+       Do not notify.
 
        ### This is wrong if svn_wc__db_status_excluded refers to a
            working node replacing the base node.  */
@@ -2024,7 +2022,7 @@ do_entry_deletion(struct edit_baton *eb,
           /* The item was locally replaced with something else. We should
            * remove the BASE node below the new working node, which turns
            * the replacement in an addition. */
-           
+
            /* Fall through to the normal "delete" code path. */
         }
       else
@@ -2797,7 +2795,7 @@ close_directory(void *dir_baton,
       SVN_ERR(accumulate_last_change(&new_changed_rev,
                                      &new_changed_date,
                                      &new_changed_author,
-                                     eb->db, db->local_abspath, entry_props,
+                                     entry_props,
                                      pool, pool));
     }
 
@@ -4099,7 +4097,6 @@ close_file(void *file_baton,
   SVN_ERR(accumulate_last_change(&new_changed_rev,
                                  &new_changed_date,
                                  &new_changed_author,
-                                 eb->db, fb->local_abspath,
                                  entry_props,
                                  pool, pool));
 
@@ -5550,7 +5547,6 @@ svn_wc_add_repos_file4(svn_wc_context_t 
     SVN_ERR(accumulate_last_change(&changed_rev,
                                    &changed_date,
                                    &changed_author,
-                                   db, local_abspath,
                                    entry_props, pool, pool));
   }
 

Modified: subversion/branches/diff-optimizations-bytes/subversion/libsvn_wc/util.c
URL: http://svn.apache.org/viewvc/subversion/branches/diff-optimizations-bytes/subversion/libsvn_wc/util.c?rev=1054012&r1=1054011&r2=1054012&view=diff
==============================================================================
--- subversion/branches/diff-optimizations-bytes/subversion/libsvn_wc/util.c (original)
+++ subversion/branches/diff-optimizations-bytes/subversion/libsvn_wc/util.c Thu Dec 30 22:20:48 2010
@@ -642,7 +642,7 @@ svn_wc__status2_from_3(svn_wc_status2_t 
   if (old_status->versioned
       && old_status->conflicted
       && old_status->node_status != svn_wc_status_obstructed
-      && (old_status->kind == svn_node_file 
+      && (old_status->kind == svn_node_file
           || old_status->node_status != svn_wc_status_missing))
     {
       svn_boolean_t text_conflict_p, prop_conflict_p;

Modified: subversion/branches/diff-optimizations-bytes/subversion/libsvn_wc/wc.h
URL: http://svn.apache.org/viewvc/subversion/branches/diff-optimizations-bytes/subversion/libsvn_wc/wc.h?rev=1054012&r1=1054011&r2=1054012&view=diff
==============================================================================
--- subversion/branches/diff-optimizations-bytes/subversion/libsvn_wc/wc.h (original)
+++ subversion/branches/diff-optimizations-bytes/subversion/libsvn_wc/wc.h Thu Dec 30 22:20:48 2010
@@ -122,7 +122,7 @@ extern "C" {
  * the working copy.
  *
  * The change from 19 to 20 introduces NODES and drops BASE_NODE and
- * WORKING_NODE, op_depth is always 0 or 2. 
+ * WORKING_NODE, op_depth is always 0 or 2.
  *
  * The change from 20 to 21 moved tree conflict storage from the
  * parent to the conflicted node.

Modified: subversion/branches/diff-optimizations-bytes/subversion/libsvn_wc/wc_db.c
URL: http://svn.apache.org/viewvc/subversion/branches/diff-optimizations-bytes/subversion/libsvn_wc/wc_db.c?rev=1054012&r1=1054011&r2=1054012&view=diff
==============================================================================
--- subversion/branches/diff-optimizations-bytes/subversion/libsvn_wc/wc_db.c (original)
+++ subversion/branches/diff-optimizations-bytes/subversion/libsvn_wc/wc_db.c Thu Dec 30 22:20:48 2010
@@ -170,7 +170,7 @@ typedef struct insert_base_baton_t {
 } insert_base_baton_t;
 
 
-typedef struct {
+typedef struct insert_working_baton_t {
   /* common to all insertions into WORKING (including NODE_DATA) */
   svn_wc__db_status_t presence;
   svn_wc__db_kind_t kind;
@@ -723,7 +723,7 @@ blank_ibb(insert_base_baton_t *pibb)
 
               0         1         2         3         4
               normal
-   A          normal          
+   A          normal
    A/B        normal              normal
    A/B/C                          not-pres  normal
    A/B/C/D                                            normal
@@ -733,7 +733,7 @@ blank_ibb(insert_base_baton_t *pibb)
 
    Now an update that adds base nodes for A/B/C, A/B/C/D and A/B/C/D/E
    must extend the A/B deletion:
-   
+
               0         1         2         3         4
               normal
    A          normal
@@ -3221,7 +3221,7 @@ op_depth_for_copy(apr_int64_t *op_depth,
         }
     }
   SVN_ERR(svn_sqlite__reset(stmt));
-  
+
   return SVN_NO_ERROR;
 }
 
@@ -4109,7 +4109,7 @@ read_all_tree_conflicts(apr_hash_t **tre
       const char *conflict_data;
       const svn_skel_t *skel;
       const svn_wc_conflict_description2_t *conflict;
-      
+
       svn_pool_clear(iterpool);
 
       child_relpath = svn_sqlite__column_text(stmt, 0, NULL);
@@ -4728,7 +4728,7 @@ info_below_working(svn_boolean_t *have_b
             *have_work = TRUE;
           else
             *have_base = TRUE;
-              
+
           *status = svn_sqlite__column_token(stmt, 3, presence_map);
           if (op_depth > 0)
             SVN_ERR(convert_to_working_status(status, *status));
@@ -4855,7 +4855,7 @@ svn_wc__db_temp_op_delete(svn_wc__db_t *
   VERIFY_USABLE_PDH(b.pdh);
 
   /* These two for svn_wc__db_temp_forget_directory */
-  b.db = db; 
+  b.db = db;
   b.local_abspath = local_abspath;
 
   SVN_ERR(svn_sqlite__with_transaction(b.pdh->wcroot->sdb, temp_op_delete_txn,
@@ -6176,7 +6176,7 @@ svn_wc__db_global_commit(svn_wc__db_t *d
 
   cb.new_revision = new_revision;
 
-  cb.changed_rev = changed_revision; 
+  cb.changed_rev = changed_revision;
   cb.changed_date = changed_date;
   cb.changed_author = changed_author;
   cb.new_checksum = new_checksum;
@@ -8751,7 +8751,7 @@ svn_wc__db_temp_op_set_file_external(svn
   svn_boolean_t got_row;
 
   SVN_ERR_ASSERT(svn_dirent_is_absolute(local_abspath));
-  SVN_ERR_ASSERT(!repos_relpath 
+  SVN_ERR_ASSERT(!repos_relpath
                  || svn_relpath_is_canonical(repos_relpath, scratch_pool));
 
   SVN_ERR(svn_wc__db_pdh_parse_local_abspath(&pdh, &local_relpath, db,

Modified: subversion/branches/diff-optimizations-bytes/subversion/libsvn_wc/wc_db.h
URL: http://svn.apache.org/viewvc/subversion/branches/diff-optimizations-bytes/subversion/libsvn_wc/wc_db.h?rev=1054012&r1=1054011&r2=1054012&view=diff
==============================================================================
--- subversion/branches/diff-optimizations-bytes/subversion/libsvn_wc/wc_db.h (original)
+++ subversion/branches/diff-optimizations-bytes/subversion/libsvn_wc/wc_db.h Thu Dec 30 22:20:48 2010
@@ -2414,7 +2414,7 @@ svn_wc__db_temp_op_set_rev_and_repos_rel
    REPOS_RELPATH is not NULL, apply REPOS_RELPATH, REPOS_ROOT_URL and
    REPOS_UUID.
    Perform all temporary allocations in SCRATCH_POOL.
-   
+
    ### For 1.7 this should probably become a proper tree conflict and
    ### just handled by putting a base directory below the existing
    ### working node.

Modified: subversion/branches/diff-optimizations-bytes/subversion/libsvn_wc/workqueue.c
URL: http://svn.apache.org/viewvc/subversion/branches/diff-optimizations-bytes/subversion/libsvn_wc/workqueue.c?rev=1054012&r1=1054011&r2=1054012&view=diff
==============================================================================
--- subversion/branches/diff-optimizations-bytes/subversion/libsvn_wc/workqueue.c (original)
+++ subversion/branches/diff-optimizations-bytes/subversion/libsvn_wc/workqueue.c Thu Dec 30 22:20:48 2010
@@ -480,8 +480,8 @@ svn_wc__wq_add_revert(svn_boolean_t *wil
 
 /* Removes a BASE_NODE and all it's data, leaving any adds and copies as is.
    Do this as a depth first traversal to make sure than any parent still exists
-   on error conditions. 
-   
+   on error conditions.
+
    ### This function needs review for 4th tree behavior.*/
 static svn_error_t *
 remove_base_node(svn_wc__db_t *db,
@@ -712,7 +712,7 @@ run_deletion_postcommit(svn_wc__db_t *db
                 db, local_abspath,
                 FALSE, FALSE, cancel_func, cancel_baton, scratch_pool));
 
-      /* If the parent entry's working rev 'lags' behind new_rev... 
+      /* If the parent entry's working rev 'lags' behind new_rev...
          ### Maybe we should also add a not-present node if the
          ### deleted node was switched? */
       if (new_revision > parent_revision)

Modified: subversion/branches/diff-optimizations-bytes/subversion/mod_authz_svn/mod_authz_svn.c
URL: http://svn.apache.org/viewvc/subversion/branches/diff-optimizations-bytes/subversion/mod_authz_svn/mod_authz_svn.c?rev=1054012&r1=1054011&r2=1054012&view=diff
==============================================================================
--- subversion/branches/diff-optimizations-bytes/subversion/mod_authz_svn/mod_authz_svn.c (original)
+++ subversion/branches/diff-optimizations-bytes/subversion/mod_authz_svn/mod_authz_svn.c Thu Dec 30 22:20:48 2010
@@ -46,7 +46,7 @@
 
 extern module AP_MODULE_DECLARE_DATA authz_svn_module;
 
-typedef struct {
+typedef struct authz_svn_config_rec {
   int authoritative;
   int anonymous;
   int no_auth_when_anon_ok;
@@ -166,7 +166,7 @@ get_access_conf(request_rec *r, authz_sv
   dav_error *dav_err;
   char errbuf[256];
 
-  if (conf->repo_relative_access_file) 
+  if (conf->repo_relative_access_file)
     {
       dav_err = dav_svn_get_repos_path(r, conf->base_path, &repos_path);
       if (dav_err) {
@@ -176,12 +176,12 @@ get_access_conf(request_rec *r, authz_sv
       access_file = svn_dirent_join_many(r->pool, repos_path, "conf",
                                          conf->repo_relative_access_file,
                                          NULL);
-    } 
+    }
   else
     {
       access_file = conf->access_file;
     }
-  
+
   ap_log_rerror(APLOG_MARK, APLOG_DEBUG, 0, r,
                 "Path to authz file is %s", access_file);
 

Modified: subversion/branches/diff-optimizations-bytes/subversion/mod_dav_svn/dav_svn.h
URL: http://svn.apache.org/viewvc/subversion/branches/diff-optimizations-bytes/subversion/mod_dav_svn/dav_svn.h?rev=1054012&r1=1054011&r2=1054012&view=diff
==============================================================================
--- subversion/branches/diff-optimizations-bytes/subversion/mod_dav_svn/dav_svn.h (original)
+++ subversion/branches/diff-optimizations-bytes/subversion/mod_dav_svn/dav_svn.h Thu Dec 30 22:20:48 2010
@@ -73,7 +73,7 @@ extern "C" {
  * ### only a single FS open; otherwise, it will have to work a bit harder
  * ### to keep the things in sync.
  */
-typedef struct {
+typedef struct dav_svn_repos {
   apr_pool_t *pool;     /* request_rec -> pool */
 
   /* Remember the root URL path of this repository (just a path; no
@@ -175,7 +175,7 @@ enum dav_svn_private_restype {
 
 
 /* store info about a root in a repository */
-typedef struct {
+typedef struct dav_svn_root {
   /* If a root within the FS has been opened, the value is stored here.
      Otherwise, this field is NULL. */
   svn_fs_root_t *root;
@@ -662,7 +662,7 @@ dav_svn__post_create_txn(const dav_resou
 /*** authz.c ***/
 
 /* A baton needed by dav_svn__authz_read_func(). */
-typedef struct
+typedef struct dav_svn__authz_read_baton
 {
   /* The original request, needed to generate a subrequest. */
   request_rec *r;
@@ -809,7 +809,7 @@ dav_svn__build_uri(const dav_svn_repos *
    ### URIs which we may need to parse. it also ignores any scheme, host,
    ### and port in the URI and simply assumes it refers to the same server.
 */
-typedef struct {
+typedef struct dav_svn__uri_info {
   svn_revnum_t rev;
   const char *repos_path;
   const char *activity_id;

Modified: subversion/branches/diff-optimizations-bytes/subversion/mod_dav_svn/deadprops.c
URL: http://svn.apache.org/viewvc/subversion/branches/diff-optimizations-bytes/subversion/mod_dav_svn/deadprops.c?rev=1054012&r1=1054011&r2=1054012&view=diff
==============================================================================
--- subversion/branches/diff-optimizations-bytes/subversion/mod_dav_svn/deadprops.c (original)
+++ subversion/branches/diff-optimizations-bytes/subversion/mod_dav_svn/deadprops.c Thu Dec 30 22:20:48 2010
@@ -180,7 +180,7 @@ save_value(dav_db *db, const dav_prop_na
       else
         return dav_svn__new_error(db->p, HTTP_CONFLICT, 0,
                                   "Properties may only be defined in the "
-                                  SVN_DAV_PROP_NS_SVN " and " 
+                                  SVN_DAV_PROP_NS_SVN " and "
                                   SVN_DAV_PROP_NS_CUSTOM " namespaces.");
     }
 
@@ -503,7 +503,7 @@ db_store(dav_db *db,
   if (absent && ! elem->first_child)
     /* ### better error check */
     return dav_svn__new_error(pool, HTTP_INTERNAL_SERVER_ERROR, 0,
-                              apr_psprintf(pool, 
+                              apr_psprintf(pool,
                                            "'%s' cannot be specified on the "
                                            "value without specifying an "
                                            "expectation",
@@ -762,7 +762,7 @@ db_apply_rollback(dav_db *db, dav_deadpr
 
   if (! db->resource->info->revprop_error)
     return NULL;
-  
+
   /* Returning the original revprop change error here will cause this
      detailed error to get returned to the client in preference to the
      more generic error created by mod_dav. */

Modified: subversion/branches/diff-optimizations-bytes/subversion/mod_dav_svn/mod_dav_svn.c
URL: http://svn.apache.org/viewvc/subversion/branches/diff-optimizations-bytes/subversion/mod_dav_svn/mod_dav_svn.c?rev=1054012&r1=1054011&r2=1054012&view=diff
==============================================================================
--- subversion/branches/diff-optimizations-bytes/subversion/mod_dav_svn/mod_dav_svn.c (original)
+++ subversion/branches/diff-optimizations-bytes/subversion/mod_dav_svn/mod_dav_svn.c Thu Dec 30 22:20:48 2010
@@ -50,7 +50,7 @@
 #define PATHAUTHZ_BYPASS_ARG "short_circuit"
 
 /* per-server configuration */
-typedef struct {
+typedef struct server_conf_t {
   const char *special_uri;
 } server_conf_t;
 
@@ -73,7 +73,7 @@ enum path_authz_conf {
 };
 
 /* per-dir configuration */
-typedef struct {
+typedef struct dir_conf_t {
   const char *fs_path;               /* path to the SVN FS */
   const char *repo_name;             /* repository name */
   const char *xslt_uri;              /* XSL transform URI */
@@ -663,7 +663,7 @@ merge_xml_filter_insert(request_rec *r)
 }
 
 
-typedef struct {
+typedef struct merge_ctx_t {
   apr_bucket_brigade *bb;
   apr_xml_parser *parser;
   apr_pool_t *pool;

Modified: subversion/branches/diff-optimizations-bytes/subversion/mod_dav_svn/reports/replay.c
URL: http://svn.apache.org/viewvc/subversion/branches/diff-optimizations-bytes/subversion/mod_dav_svn/reports/replay.c?rev=1054012&r1=1054011&r2=1054012&view=diff
==============================================================================
--- subversion/branches/diff-optimizations-bytes/subversion/mod_dav_svn/reports/replay.c (original)
+++ subversion/branches/diff-optimizations-bytes/subversion/mod_dav_svn/reports/replay.c Thu Dec 30 22:20:48 2010
@@ -42,7 +42,7 @@
 #include "../dav_svn.h"
 
 
-typedef struct {
+typedef struct edit_baton_t {
   apr_bucket_brigade *bb;
   ap_filter_t *output;
   svn_boolean_t started;

Modified: subversion/branches/diff-optimizations-bytes/subversion/mod_dav_svn/reports/update.c
URL: http://svn.apache.org/viewvc/subversion/branches/diff-optimizations-bytes/subversion/mod_dav_svn/reports/update.c?rev=1054012&r1=1054011&r2=1054012&view=diff
==============================================================================
--- subversion/branches/diff-optimizations-bytes/subversion/mod_dav_svn/reports/update.c (original)
+++ subversion/branches/diff-optimizations-bytes/subversion/mod_dav_svn/reports/update.c Thu Dec 30 22:20:48 2010
@@ -43,7 +43,7 @@
 #include "../dav_svn.h"
 
 
-typedef struct {
+typedef struct update_ctx_t {
   const dav_resource *resource;
 
   /* the revision we are updating to. used to generated IDs. */

Modified: subversion/branches/diff-optimizations-bytes/subversion/mod_dav_svn/repos.c
URL: http://svn.apache.org/viewvc/subversion/branches/diff-optimizations-bytes/subversion/mod_dav_svn/repos.c?rev=1054012&r1=1054011&r2=1054012&view=diff
==============================================================================
--- subversion/branches/diff-optimizations-bytes/subversion/mod_dav_svn/repos.c (original)
+++ subversion/branches/diff-optimizations-bytes/subversion/mod_dav_svn/repos.c Thu Dec 30 22:20:48 2010
@@ -71,7 +71,7 @@ struct dav_stream {
 
 /* Convenience structure that facilitates combined memory allocation of
    a dav_resource and dav_resource_private pair. */
-typedef struct {
+typedef struct dav_resource_combined {
   dav_resource res;
   dav_resource_private priv;
 } dav_resource_combined;
@@ -3049,7 +3049,7 @@ set_headers(request_rec *r, const dav_re
 }
 
 
-typedef struct {
+typedef struct diff_ctx_t {
   ap_filter_t *output;
   apr_pool_t *pool;
 } diff_ctx_t;
@@ -3932,7 +3932,7 @@ move_resource(dav_resource *src,
 }
 
 
-typedef struct {
+typedef struct walker_ctx_t {
   /* the input walk parameters */
   const dav_walk_params *params;
 
@@ -4054,7 +4054,7 @@ do_walk(walker_ctx_t *ctx, int depth)
       if (params->walk_type & DAV_WALKTYPE_AUTH)
         {
           const char *repos_relpath =
-            apr_pstrcat(iterpool, 
+            apr_pstrcat(iterpool,
                         apr_pstrmemdup(iterpool,
                                        ctx->repos_path->data,
                                        ctx->repos_path->len),
@@ -4103,7 +4103,7 @@ do_walk(walker_ctx_t *ctx, int depth)
       ctx->uri->len = uri_len;
       ctx->repos_path->len = repos_len;
     }
-  
+
   svn_pool_destroy(iterpool);
 
   return NULL;
@@ -4379,7 +4379,7 @@ int dav_svn__method_post(request_rec *r)
      the client with (hopefully) some helpful information. */
   if (derr)
     return dav_svn__error_response_tag(r, derr);
-    
+
   return OK;
 }
 

Modified: subversion/branches/diff-optimizations-bytes/subversion/mod_dav_svn/util.c
URL: http://svn.apache.org/viewvc/subversion/branches/diff-optimizations-bytes/subversion/mod_dav_svn/util.c?rev=1054012&r1=1054011&r2=1054012&view=diff
==============================================================================
--- subversion/branches/diff-optimizations-bytes/subversion/mod_dav_svn/util.c (original)
+++ subversion/branches/diff-optimizations-bytes/subversion/mod_dav_svn/util.c Thu Dec 30 22:20:48 2010
@@ -717,20 +717,20 @@ request_body_to_string(svn_string_t **re
         {
           const char *data;
           apr_size_t len;
-          
+
           if (APR_BUCKET_IS_EOS(bucket))
             {
               seen_eos = 1;
               break;
             }
-          
+
           if (APR_BUCKET_IS_METADATA(bucket))
             continue;
-          
+
           status = apr_bucket_read(bucket, &data, &len, APR_BLOCK_READ);
           if (status != APR_SUCCESS)
             goto cleanup;
-          
+
           total_read += len;
           if (limit_req_body && total_read > limit_req_body)
             {
@@ -740,10 +740,10 @@ request_body_to_string(svn_string_t **re
               result = HTTP_REQUEST_ENTITY_TOO_LARGE;
               goto cleanup;
             }
-          
+
           svn_stringbuf_appendbytes(buf, data, len);
         }
-      
+
       apr_brigade_cleanup(brigade);
     }
   while (!seen_eos);
@@ -758,7 +758,7 @@ request_body_to_string(svn_string_t **re
 
  cleanup:
   apr_brigade_destroy(brigade);
-  
+
   /* Apache will supply a default error, plus the error log above. */
   return result;
 }

Modified: subversion/branches/diff-optimizations-bytes/subversion/svn/blame-cmd.c
URL: http://svn.apache.org/viewvc/subversion/branches/diff-optimizations-bytes/subversion/svn/blame-cmd.c?rev=1054012&r1=1054011&r2=1054012&view=diff
==============================================================================
--- subversion/branches/diff-optimizations-bytes/subversion/svn/blame-cmd.c (original)
+++ subversion/branches/diff-optimizations-bytes/subversion/svn/blame-cmd.c Thu Dec 30 22:20:48 2010
@@ -37,7 +37,7 @@
 
 #include "svn_private_config.h"
 
-typedef struct
+typedef struct blame_baton_t
 {
   svn_cl__opt_state_t *opt_state;
   svn_stream_t *out;

Modified: subversion/branches/diff-optimizations-bytes/subversion/svn/cl.h
URL: http://svn.apache.org/viewvc/subversion/branches/diff-optimizations-bytes/subversion/svn/cl.h?rev=1054012&r1=1054011&r2=1054012&view=diff
==============================================================================
--- subversion/branches/diff-optimizations-bytes/subversion/svn/cl.h (original)
+++ subversion/branches/diff-optimizations-bytes/subversion/svn/cl.h Thu Dec 30 22:20:48 2010
@@ -47,7 +47,7 @@ extern "C" {
 /*** Option processing ***/
 
 /* --accept actions */
-typedef enum
+typedef enum svn_cl__accept_t
 {
   /* invalid accept action */
   svn_cl__accept_invalid = -2,
@@ -112,7 +112,7 @@ svn_cl__accept_from_word(const char *wor
 /*** Mergeinfo flavors. ***/
 
 /* --show-revs values */
-typedef enum {
+typedef enum svn_cl__show_revs_t {
   svn_cl__show_revs_invalid = -1,
   svn_cl__show_revs_merged,
   svn_cl__show_revs_eligible
@@ -233,7 +233,7 @@ typedef struct svn_cl__opt_state_t
 } svn_cl__opt_state_t;
 
 
-typedef struct
+typedef struct svn_cl__cmd_baton_t
 {
   svn_cl__opt_state_t *opt_state;
   svn_client_ctx_t *ctx;
@@ -324,7 +324,7 @@ svn_cl__check_cancel(void *baton);
 
 /* Various conflict-resolution callbacks. */
 
-typedef struct {
+typedef struct svn_cl__conflict_baton_t {
   svn_cl__accept_t accept_which;
   apr_hash_t *config;
   const char *editor_cmd;

Modified: subversion/branches/diff-optimizations-bytes/subversion/svn/commit-cmd.c
URL: http://svn.apache.org/viewvc/subversion/branches/diff-optimizations-bytes/subversion/svn/commit-cmd.c?rev=1054012&r1=1054011&r2=1054012&view=diff
==============================================================================
--- subversion/branches/diff-optimizations-bytes/subversion/svn/commit-cmd.c (original)
+++ subversion/branches/diff-optimizations-bytes/subversion/svn/commit-cmd.c Thu Dec 30 22:20:48 2010
@@ -109,7 +109,7 @@ svn_cl__commit(apr_getopt_t *os,
                                  "directories in a separate commit.\n"),
                                svn_depth_to_word(opt_state->depth),
                                svn_depth_to_word(svn_depth_infinity)));
-    
+
   cfg = apr_hash_get(ctx->config, SVN_CONFIG_CATEGORY_CONFIG,
                      APR_HASH_KEY_STRING);
   if (cfg)

Modified: subversion/branches/diff-optimizations-bytes/subversion/svn/log-cmd.c
URL: http://svn.apache.org/viewvc/subversion/branches/diff-optimizations-bytes/subversion/svn/log-cmd.c?rev=1054012&r1=1054011&r2=1054012&view=diff
==============================================================================
--- subversion/branches/diff-optimizations-bytes/subversion/svn/log-cmd.c (original)
+++ subversion/branches/diff-optimizations-bytes/subversion/svn/log-cmd.c Thu Dec 30 22:20:48 2010
@@ -283,7 +283,7 @@ log_entry_receiver(void *baton,
 
       /* Fall back to "" to get options initialized either way. */
       if (lb->diff_extensions)
-        diff_options = svn_cstring_split(lb->diff_extensions, " \t\n\r", 
+        diff_options = svn_cstring_split(lb->diff_extensions, " \t\n\r",
                                          TRUE, pool);
       else
         diff_options = NULL;

Modified: subversion/branches/diff-optimizations-bytes/subversion/svn/main.c
URL: http://svn.apache.org/viewvc/subversion/branches/diff-optimizations-bytes/subversion/svn/main.c?rev=1054012&r1=1054011&r2=1054012&view=diff
==============================================================================
--- subversion/branches/diff-optimizations-bytes/subversion/svn/main.c (original)
+++ subversion/branches/diff-optimizations-bytes/subversion/svn/main.c Thu Dec 30 22:20:48 2010
@@ -64,7 +64,7 @@
 /* Add an identifier here for long options that don't have a short
    option. Options that have both long and short options should just
    use the short option letter as identifier.  */
-typedef enum {
+typedef enum svn_cl__longopt_t {
   opt_ancestor_path = SVN_OPT_FIRST_LONGOPT_ID,
   opt_auth_password,
   opt_auth_username,
@@ -142,11 +142,11 @@ const apr_getopt_option_t svn_cl__option
   {"quiet",         'q', 0, N_("print nothing, or only summary information")},
   {"recursive",     'R', 0, N_("descend recursively, same as --depth=infinity")},
   {"non-recursive", 'N', 0, N_("obsolete; try --depth=files or --depth=immediates")},
-  {"change",        'c', 1, 
+  {"change",        'c', 1,
                     N_("the change made by revision ARG (like -r ARG-1:ARG)\n"
                        SVN_CL__OPTION_CONTINUATION_INDENT
                        "If ARG is negative this is like -r ARG:ARG-1")},
-  {"revision",      'r', 1, 
+  {"revision",      'r', 1,
                     N_("ARG (some commands also take ARG1:ARG2 range)\n"
                        SVN_CL__OPTION_CONTINUATION_INDENT
                        "A revision argument can be one of:\n"

Modified: subversion/branches/diff-optimizations-bytes/subversion/svn/notify.c
URL: http://svn.apache.org/viewvc/subversion/branches/diff-optimizations-bytes/subversion/svn/notify.c?rev=1054012&r1=1054011&r2=1054012&view=diff
==============================================================================
--- subversion/branches/diff-optimizations-bytes/subversion/svn/notify.c (original)
+++ subversion/branches/diff-optimizations-bytes/subversion/svn/notify.c Thu Dec 30 22:20:48 2010
@@ -548,7 +548,7 @@ notify(void *baton, const svn_wc_notify_
       break;
 
     case svn_wc_notify_update_started:
-      if (! (nb->suppress_summary_lines || 
+      if (! (nb->suppress_summary_lines ||
              nb->in_external ||
              nb->is_checkout ||
              nb->is_export))

Modified: subversion/branches/diff-optimizations-bytes/subversion/svn/proplist-cmd.c
URL: http://svn.apache.org/viewvc/subversion/branches/diff-optimizations-bytes/subversion/svn/proplist-cmd.c?rev=1054012&r1=1054011&r2=1054012&view=diff
==============================================================================
--- subversion/branches/diff-optimizations-bytes/subversion/svn/proplist-cmd.c (original)
+++ subversion/branches/diff-optimizations-bytes/subversion/svn/proplist-cmd.c Thu Dec 30 22:20:48 2010
@@ -39,7 +39,7 @@
 
 #include "svn_private_config.h"
 
-typedef struct
+typedef struct proplist_baton_t
 {
   svn_cl__opt_state_t *opt_state;
   svn_boolean_t is_url;

Modified: subversion/branches/diff-optimizations-bytes/subversion/svn/props.c
URL: http://svn.apache.org/viewvc/subversion/branches/diff-optimizations-bytes/subversion/svn/props.c?rev=1054012&r1=1054011&r2=1054012&view=diff
==============================================================================
--- subversion/branches/diff-optimizations-bytes/subversion/svn/props.c (original)
+++ subversion/branches/diff-optimizations-bytes/subversion/svn/props.c Thu Dec 30 22:20:48 2010
@@ -104,7 +104,7 @@ svn_cl__print_prop_hash(svn_stream_t *ou
 
       if (out)
         {
-          pname_stdout = apr_psprintf(pool, "  %s\n", pname_stdout); 
+          pname_stdout = apr_psprintf(pool, "  %s\n", pname_stdout);
           SVN_ERR(svn_subst_translate_cstring2(pname_stdout, &pname_stdout,
                                               APR_EOL_STR,  /* 'native' eol */
                                               FALSE, /* no repair */

Modified: subversion/branches/diff-optimizations-bytes/subversion/svn/resolve-cmd.c
URL: http://svn.apache.org/viewvc/subversion/branches/diff-optimizations-bytes/subversion/svn/resolve-cmd.c?rev=1054012&r1=1054011&r2=1054012&view=diff
==============================================================================
--- subversion/branches/diff-optimizations-bytes/subversion/svn/resolve-cmd.c (original)
+++ subversion/branches/diff-optimizations-bytes/subversion/svn/resolve-cmd.c Thu Dec 30 22:20:48 2010
@@ -104,7 +104,7 @@ svn_cl__resolve(apr_getopt_t *os,
         return svn_error_createf(SVN_ERR_CL_ARG_PARSING_ERROR, NULL,
                                  _("'%s' is not a local path"), target);
     }
-  
+
   iterpool = svn_pool_create(scratch_pool);
   for (i = 0; i < targets->nelts; i++)
     {

Modified: subversion/branches/diff-optimizations-bytes/subversion/svn/resolved-cmd.c
URL: http://svn.apache.org/viewvc/subversion/branches/diff-optimizations-bytes/subversion/svn/resolved-cmd.c?rev=1054012&r1=1054011&r2=1054012&view=diff
==============================================================================
--- subversion/branches/diff-optimizations-bytes/subversion/svn/resolved-cmd.c (original)
+++ subversion/branches/diff-optimizations-bytes/subversion/svn/resolved-cmd.c Thu Dec 30 22:20:48 2010
@@ -74,7 +74,7 @@ svn_cl__resolved(apr_getopt_t *os,
         return svn_error_createf(SVN_ERR_CL_ARG_PARSING_ERROR, NULL,
                                  _("'%s' is not a local path"), target);
     }
-  
+
   iterpool = svn_pool_create(scratch_pool);
   for (i = 0; i < targets->nelts; i++)
     {

Modified: subversion/branches/diff-optimizations-bytes/subversion/svn/update-cmd.c
URL: http://svn.apache.org/viewvc/subversion/branches/diff-optimizations-bytes/subversion/svn/update-cmd.c?rev=1054012&r1=1054011&r2=1054012&view=diff
==============================================================================
--- subversion/branches/diff-optimizations-bytes/subversion/svn/update-cmd.c (original)
+++ subversion/branches/diff-optimizations-bytes/subversion/svn/update-cmd.c Thu Dec 30 22:20:48 2010
@@ -161,7 +161,7 @@ svn_cl__update(apr_getopt_t *os,
   nwb.had_externals_error = FALSE;
   ctx->notify_func2 = svn_cl__check_externals_failed_notify_wrapper;
   ctx->notify_baton2 = &nwb;
-  
+
   SVN_ERR(svn_client_update4(&result_revs, targets,
                              &(opt_state->start_revision),
                              depth, depth_is_sticky,

Modified: subversion/branches/diff-optimizations-bytes/subversion/svn/util.c
URL: http://svn.apache.org/viewvc/subversion/branches/diff-optimizations-bytes/subversion/svn/util.c?rev=1054012&r1=1054011&r2=1054012&view=diff
==============================================================================
--- subversion/branches/diff-optimizations-bytes/subversion/svn/util.c (original)
+++ subversion/branches/diff-optimizations-bytes/subversion/svn/util.c Thu Dec 30 22:20:48 2010
@@ -1340,7 +1340,7 @@ svn_cl__opt_parse_path(svn_opt_revision_
                        apr_pool_t *pool)
 {
   SVN_ERR(svn_opt_parse_path(rev, truepath, path, pool));
-  
+
   if (svn_path_is_url(*truepath))
     *truepath = svn_uri_canonicalize(*truepath, pool);
   else

Modified: subversion/branches/diff-optimizations-bytes/subversion/svnadmin/main.c
URL: http://svn.apache.org/viewvc/subversion/branches/diff-optimizations-bytes/subversion/svnadmin/main.c?rev=1054012&r1=1054011&r2=1054012&view=diff
==============================================================================
--- subversion/branches/diff-optimizations-bytes/subversion/svnadmin/main.c (original)
+++ subversion/branches/diff-optimizations-bytes/subversion/svnadmin/main.c Thu Dec 30 22:20:48 2010
@@ -741,25 +741,25 @@ repos_notify_handler(void *baton,
                                   _("     * editing path : %s ..."),
                                   notify->path));
             break;
-          
+
           case svn_node_action_delete:
             svn_error_clear(svn_stream_printf(feedback_stream, scratch_pool,
                                   _("     * deleting path : %s ..."),
                                   notify->path));
             break;
-          
+
           case svn_node_action_add:
             svn_error_clear(svn_stream_printf(feedback_stream, scratch_pool,
                                   _("     * adding path : %s ..."),
                                   notify->path));
             break;
-          
+
           case svn_node_action_replace:
             svn_error_clear(svn_stream_printf(feedback_stream, scratch_pool,
                                   _("     * replacing path : %s ..."),
                                   notify->path));
             break;
-          
+
         }
       }
       return;

Modified: subversion/branches/diff-optimizations-bytes/subversion/svnrdump/load_editor.c
URL: http://svn.apache.org/viewvc/subversion/branches/diff-optimizations-bytes/subversion/svnrdump/load_editor.c?rev=1054012&r1=1054011&r2=1054012&view=diff
==============================================================================
--- subversion/branches/diff-optimizations-bytes/subversion/svnrdump/load_editor.c (original)
+++ subversion/branches/diff-optimizations-bytes/subversion/svnrdump/load_editor.c Thu Dec 30 22:20:48 2010
@@ -83,7 +83,7 @@ get_lock(const svn_string_t **lock_strin
          apr_pool_t *pool)
 {
   svn_boolean_t be_atomic;
-  
+
   SVN_ERR(svn_ra_has_capability(session, &be_atomic,
                                 SVN_RA_CAPABILITY_ATOMIC_REVPROPS,
                                 pool));
@@ -289,7 +289,7 @@ new_node_record(void **node_baton,
           SVN_ERR(commit_editor->close_directory(rb->db->baton, rb->pool));
           rb->db = rb->db->parent;
         }
-        
+
       for (i = 0; i < residual_open_path->nelts; i ++)
         {
           relpath_compose =

Modified: subversion/branches/diff-optimizations-bytes/subversion/svnrdump/svnrdump.c
URL: http://svn.apache.org/viewvc/subversion/branches/diff-optimizations-bytes/subversion/svnrdump/svnrdump.c?rev=1054012&r1=1054011&r2=1054012&view=diff
==============================================================================
--- subversion/branches/diff-optimizations-bytes/subversion/svnrdump/svnrdump.c (original)
+++ subversion/branches/diff-optimizations-bytes/subversion/svnrdump/svnrdump.c Thu Dec 30 22:20:48 2010
@@ -111,7 +111,7 @@ static const svn_opt_subcommand_desc2_t 
 
 static const apr_getopt_option_t svnrdump__options[] =
   {
-    {"revision",     'r', 1, 
+    {"revision",     'r', 1,
                       N_("specify revision number ARG (or X:Y range)")},
     {"quiet",         'q', 0,
                       N_("no progress (only errors) to stderr")},
@@ -289,7 +289,7 @@ open_connection(svn_ra_session_t **sessi
  */
 static svn_error_t *
 dump_revision_header(svn_ra_session_t *session,
-                     svn_stream_t *stdout_stream, 
+                     svn_stream_t *stdout_stream,
                      svn_revnum_t revision,
                      apr_pool_t *pool)
 {
@@ -349,7 +349,7 @@ replay_revisions(svn_ra_session_t *sessi
 
   SVN_ERR(svn_stream_for_stdout(&stdout_stream, pool));
 
-  SVN_ERR(get_dump_editor(&dump_editor, &dump_baton, stdout_stream, 
+  SVN_ERR(get_dump_editor(&dump_editor, &dump_baton, stdout_stream,
                           check_cancel, NULL, pool));
 
   replay_baton = apr_pcalloc(pool, sizeof(*replay_baton));
@@ -410,7 +410,7 @@ replay_revisions(svn_ra_session_t *sessi
       SVN_ERR(reporter->set_path(report_baton, "", start_revision,
                                  svn_depth_infinity, TRUE, NULL, pool));
       SVN_ERR(reporter->finish_report(report_baton, pool));
-      
+
       /* All finished with START_REVISION! */
       if (! quiet)
         SVN_ERR(svn_cmdline_fprintf(stderr, pool, "* Dumped revision %lu.\n",
@@ -485,7 +485,7 @@ static svn_error_t *
 version(const char *progname,
         apr_pool_t *pool)
 {
-  svn_stringbuf_t *version_footer = 
+  svn_stringbuf_t *version_footer =
     svn_stringbuf_create(_("The following repository access (RA) modules "
                            "are available:\n\n"),
                          pool);
@@ -626,7 +626,7 @@ validate_and_resolve_revisions(opt_baton
 
   /* Finally, make sure that the end revision is younger than the
      start revision.  We don't do "backwards" 'round here.  */
-  if (opt_baton->end_revision.value.number < 
+  if (opt_baton->end_revision.value.number <
       opt_baton->start_revision.value.number)
     {
       return svn_error_create(SVN_ERR_CL_ARG_PARSING_ERROR, NULL,
@@ -884,7 +884,7 @@ main(int argc, const char **argv)
                                         &latest_revision, pool));
 
   /* Make sure any provided revisions make sense. */
-  SVNRDUMP_ERR(validate_and_resolve_revisions(opt_baton, 
+  SVNRDUMP_ERR(validate_and_resolve_revisions(opt_baton,
                                               latest_revision, pool));
 
   /* Dispatch the subcommand */

Modified: subversion/branches/diff-optimizations-bytes/subversion/svnserve/serve.c
URL: http://svn.apache.org/viewvc/subversion/branches/diff-optimizations-bytes/subversion/svnserve/serve.c?rev=1054012&r1=1054011&r2=1054012&view=diff
==============================================================================
--- subversion/branches/diff-optimizations-bytes/subversion/svnserve/serve.c (original)
+++ subversion/branches/diff-optimizations-bytes/subversion/svnserve/serve.c Thu Dec 30 22:20:48 2010
@@ -59,7 +59,7 @@
 
 #include "server.h"
 
-typedef struct {
+typedef struct commit_callback_baton_t {
   apr_pool_t *pool;
   svn_revnum_t *new_rev;
   const char **date;
@@ -67,7 +67,7 @@ typedef struct {
   const char **post_commit_err;
 } commit_callback_baton_t;
 
-typedef struct {
+typedef struct report_driver_baton_t {
   server_baton_t *sb;
   const char *repos_url;  /* Decoded repository URL. */
   void *report_baton;
@@ -79,18 +79,18 @@ typedef struct {
   svn_revnum_t *from_rev;
 } report_driver_baton_t;
 
-typedef struct {
+typedef struct log_baton_t {
   const char *fs_path;
   svn_ra_svn_conn_t *conn;
   int stack_depth;
 } log_baton_t;
 
-typedef struct {
+typedef struct file_revs_baton_t {
   svn_ra_svn_conn_t *conn;
   apr_pool_t *pool;  /* Pool provided in the handler call. */
 } file_revs_baton_t;
 
-typedef struct {
+typedef struct fs_warning_baton_t {
   server_baton_t *server;
   svn_ra_svn_conn_t *conn;
   apr_pool_t *pool;
@@ -307,7 +307,7 @@ svn_error_t *load_configs(svn_config_t *
              * will go to standard error for the admin to see. */
             return err;
         }
-      
+
       /* Are we going to be case-normalizing usernames when we consult
        * this authz file? */
       svn_config_get(*cfg, &case_force_val, SVN_CONFIG_SECTION_GENERAL,

Modified: subversion/branches/diff-optimizations-bytes/subversion/svnsync/main.c
URL: http://svn.apache.org/viewvc/subversion/branches/diff-optimizations-bytes/subversion/svnsync/main.c?rev=1054012&r1=1054011&r2=1054012&view=diff
==============================================================================
--- subversion/branches/diff-optimizations-bytes/subversion/svnsync/main.c (original)
+++ subversion/branches/diff-optimizations-bytes/subversion/svnsync/main.c Thu Dec 30 22:20:48 2010
@@ -159,7 +159,7 @@ static const apr_getopt_option_t svnsync
   {
     {"quiet",          'q', 0,
                        N_("print as little as possible") },
-    {"revision",       'r', 1, 
+    {"revision",       'r', 1,
                        N_("operate on revision ARG (or range ARG1:ARG2)\n"
                           "                             "
                           "A revision argument can be one of:\n"
@@ -226,7 +226,7 @@ static const apr_getopt_option_t svnsync
     { 0, 0, 0, 0 }
   };
 
-typedef struct {
+typedef struct opt_baton_t {
   svn_boolean_t non_interactive;
   svn_boolean_t trust_server_cert;
   svn_boolean_t no_auth_cache;
@@ -355,7 +355,7 @@ get_lock(const svn_string_t **lock_strin
 
 
 /* Baton for the various subcommands to share. */
-typedef struct {
+typedef struct subcommand_baton_t {
   /* common to all subcommands */
   apr_hash_t *config;
   svn_ra_callbacks2_t source_callbacks;
@@ -441,7 +441,7 @@ check_if_session_is_at_repos_root(svn_ra
  * revision REV of the repository associated with RA session SESSION.
  *
  * For REV zero, don't remove properties with the "svn:sync-" prefix.
- * 
+ *
  * All allocations will be done in a subpool of POOL.
  */
 static svn_error_t *
@@ -930,7 +930,7 @@ open_target_session(svn_ra_session_t **t
 }
 
 /* Replay baton, used during sychnronization. */
-typedef struct {
+typedef struct replay_baton_t {
   svn_ra_session_t *from_session;
   svn_ra_session_t *to_session;
   subcommand_baton_t *sb;
@@ -1482,7 +1482,7 @@ resolve_revnums(svn_revnum_t *start_revn
                                  _("Invalid revision number (%ld)"),
                                  end_rev);
     }
-  
+
   *start_revnum = start_rev;
   *end_revnum = end_rev;
   return SVN_NO_ERROR;
@@ -1552,7 +1552,7 @@ copy_revprops_cmd(apr_getopt_t *os, void
           from_url = NULL;
         }
     }
-  
+
   if (! to_url)
     {
       /* This is the "... TO_URL SOURCE_URL" syntax.  Revisions
@@ -1580,7 +1580,7 @@ copy_revprops_cmd(apr_getopt_t *os, void
   if (from_url && (! svn_path_is_url(from_url)))
     return svn_error_createf(SVN_ERR_CL_ARG_PARSING_ERROR, NULL,
                              _("Path '%s' is not a URL"), from_url);
-      
+
   baton = make_subcommand_baton(opt_baton, to_url, from_url,
                                 start_rev, end_rev, pool);
   SVN_ERR(open_target_session(&to_session, baton, pool));

Modified: subversion/branches/diff-optimizations-bytes/subversion/svnsync/sync.c
URL: http://svn.apache.org/viewvc/subversion/branches/diff-optimizations-bytes/subversion/svnsync/sync.c?rev=1054012&r1=1054011&r2=1054012&view=diff
==============================================================================
--- subversion/branches/diff-optimizations-bytes/subversion/svnsync/sync.c (original)
+++ subversion/branches/diff-optimizations-bytes/subversion/svnsync/sync.c Thu Dec 30 22:20:48 2010
@@ -137,7 +137,7 @@ svnsync_normalize_revprops(apr_hash_t *r
 
 
 /* Edit baton */
-typedef struct {
+typedef struct edit_baton_t {
   const svn_delta_editor_t *wrapped_editor;
   void *wrapped_edit_baton;
   const char *to_url;  /* URL we're copying into, for correct copyfrom URLs */
@@ -155,7 +155,7 @@ typedef struct {
 
 
 /* A dual-purpose baton for files and directories. */
-typedef struct {
+typedef struct node_baton_t {
   void *edit_baton;
   void *wrapped_node_baton;
 } node_baton_t;

Modified: subversion/branches/diff-optimizations-bytes/subversion/tests/cmdline/atomic-ra-revprop-change.c
URL: http://svn.apache.org/viewvc/subversion/branches/diff-optimizations-bytes/subversion/tests/cmdline/atomic-ra-revprop-change.c?rev=1054012&r1=1054011&r2=1054012&view=diff
==============================================================================
--- subversion/branches/diff-optimizations-bytes/subversion/tests/cmdline/atomic-ra-revprop-change.c (original)
+++ subversion/branches/diff-optimizations-bytes/subversion/tests/cmdline/atomic-ra-revprop-change.c Thu Dec 30 22:20:48 2010
@@ -196,7 +196,7 @@ extract_values_from_skel(svn_string_t **
 {
   apr_hash_t *proplist;
   svn_skel_t *skel;
-  
+
   skel = svn_skel__parse(skel_cstr, strlen(skel_cstr), pool);
   SVN_ERR(svn_skel__parse_proplist(&proplist, skel, pool));
   *old_propval_p = apr_hash_get(proplist, KEY_OLD_PROPVAL, APR_HASH_KEY_STRING);

Modified: subversion/branches/diff-optimizations-bytes/subversion/tests/cmdline/authz_tests.py
URL: http://svn.apache.org/viewvc/subversion/branches/diff-optimizations-bytes/subversion/tests/cmdline/authz_tests.py?rev=1054012&r1=1054011&r2=1054012&view=diff
==============================================================================
--- subversion/branches/diff-optimizations-bytes/subversion/tests/cmdline/authz_tests.py (original)
+++ subversion/branches/diff-optimizations-bytes/subversion/tests/cmdline/authz_tests.py Thu Dec 30 22:20:48 2010
@@ -920,8 +920,8 @@ def authz_access_required_at_repo_root2(
                        '-m', 'rename file in readable writable space',
                        root_url + '/A/B/E/alpha',
                        root_url + '/A/B/E/alpha-renamed')
-  
-  # Check out original greek sub tree below /A/B/E 
+
+  # Check out original greek sub tree below /A/B/E
   # and update it to the above rename.
   wc_dir = sbox.add_wc_path('ABE')
   os.mkdir(wc_dir)
@@ -933,7 +933,7 @@ def authz_access_required_at_repo_root2(
                        '-m', 'rename diretory in readable writable space',
                        root_url + '/A/D/H',
                        root_url + '/A/D/a g e')
-  
+
   # Check out original greek sub tree below /A/D
   # and update it to the above rename.
   wc_dir = sbox.add_wc_path('AD')
@@ -1022,7 +1022,7 @@ def wc_wc_copy_revert(sbox):
 
   svntest.actions.run_and_verify_svn(None, None, [],
                                      'revert', '--recursive', sbox.ospath('A2'))
-  
+
   expected_status = svntest.actions.get_virginal_state(sbox.wc_dir, 1)
   expected_status.remove('A/B/E', 'A/B/E/alpha', 'A/B/E/beta')
   svntest.actions.run_and_verify_status(sbox.wc_dir, expected_status)

Modified: subversion/branches/diff-optimizations-bytes/subversion/tests/cmdline/basic_tests.py
URL: http://svn.apache.org/viewvc/subversion/branches/diff-optimizations-bytes/subversion/tests/cmdline/basic_tests.py?rev=1054012&r1=1054011&r2=1054012&view=diff
==============================================================================
--- subversion/branches/diff-optimizations-bytes/subversion/tests/cmdline/basic_tests.py (original)
+++ subversion/branches/diff-optimizations-bytes/subversion/tests/cmdline/basic_tests.py Thu Dec 30 22:20:48 2010
@@ -2490,7 +2490,7 @@ def basic_mkdir_mix_targets(sbox):
 
 def delete_from_url_with_spaces(sbox):
   "delete a directory with ' ' using its url"
-  
+
   sbox.build()
   sbox.simple_mkdir('Dir With Spaces')
   sbox.simple_mkdir('Dir With')
@@ -2498,7 +2498,7 @@ def delete_from_url_with_spaces(sbox):
 
   svntest.actions.run_and_verify_svn(None, None, [],
                                       'ci', sbox.wc_dir, '-m', 'Added dir')
-  
+
   # This fails on 1.6.11 with an escaping error.
   svntest.actions.run_and_verify_svn(None, None, [],
                                       'rm', sbox.repo_url + '/Dir%20With%20Spaces',
@@ -2619,7 +2619,7 @@ def basic_relocate(sbox):
   svntest.actions.run_and_verify_svn(None, None, [], 'switch', '--relocate',
                                      substring, substring, wc_dir)
   _verify_url(wc_dir, repo_url)
-  
+
   # Real relocation to OTHER_REPO_URL.
   svntest.actions.run_and_verify_svn(None, None, [], 'switch', '--relocate',
                                      repo_url, other_repo_url, wc_dir)
@@ -2644,24 +2644,24 @@ def basic_relocate(sbox):
 def delete_urls_with_spaces(sbox):
   "delete multiple targets with spaces"
   sbox.build(create_wc = False)
-  
-  # Create three directories with a space in their name  
+
+  # Create three directories with a space in their name
   svntest.actions.run_and_verify_svn(None, None, [], 'mkdir',
                                      sbox.repo_url + '/A spaced',
                                      sbox.repo_url + '/B spaced',
                                      sbox.repo_url + '/C spaced',
                                      '-m', 'Created dirs')
 
-  # Try to delete the first                                     
+  # Try to delete the first
   svntest.actions.run_and_verify_svn(None, None, [], 'rm',
                                      sbox.repo_url + '/A spaced',
-                                     '-m', 'Deleted A') 
+                                     '-m', 'Deleted A')
 
   # And then two at once
   svntest.actions.run_and_verify_svn(None, None, [], 'rm',
                                      sbox.repo_url + '/B spaced',
                                      sbox.repo_url + '/C spaced',
-                                     '-m', 'Deleted B and C') 
+                                     '-m', 'Deleted B and C')
 
 def ls_url_special_characters(sbox):
   """special characters in svn ls URL"""
@@ -2673,7 +2673,7 @@ def ls_url_special_characters(sbox):
   for url in special_urls:
     svntest.actions.run_and_verify_svn('ls URL with special characters',
                                        ['B/\n', 'C/\n', 'D/\n', 'mu\n'],
-                                       [], 'ls', 
+                                       [], 'ls',
                                        url)
 
 ########################################################################

Modified: subversion/branches/diff-optimizations-bytes/subversion/tests/cmdline/commit_tests.py
URL: http://svn.apache.org/viewvc/subversion/branches/diff-optimizations-bytes/subversion/tests/cmdline/commit_tests.py?rev=1054012&r1=1054011&r2=1054012&view=diff
==============================================================================
--- subversion/branches/diff-optimizations-bytes/subversion/tests/cmdline/commit_tests.py (original)
+++ subversion/branches/diff-optimizations-bytes/subversion/tests/cmdline/commit_tests.py Thu Dec 30 22:20:48 2010
@@ -2676,7 +2676,7 @@ def commit_url(sbox):
   url = sbox.repo_url
 
   # Commit directly to a URL
-  expected_error = ("svn: '" + url + 
+  expected_error = ("svn: '" + url +
                     "' is a URL, but URLs cannot be commit targets")
   svntest.actions.run_and_verify_commit(None,
                                         None,

Modified: subversion/branches/diff-optimizations-bytes/subversion/tests/cmdline/copy_tests.py
URL: http://svn.apache.org/viewvc/subversion/branches/diff-optimizations-bytes/subversion/tests/cmdline/copy_tests.py?rev=1054012&r1=1054011&r2=1054012&view=diff
==============================================================================
--- subversion/branches/diff-optimizations-bytes/subversion/tests/cmdline/copy_tests.py (original)
+++ subversion/branches/diff-optimizations-bytes/subversion/tests/cmdline/copy_tests.py Thu Dec 30 22:20:48 2010
@@ -4330,11 +4330,11 @@ def nonrecursive_commit_of_copy(sbox):
 
 
   svntest.actions.run_and_verify_status(wc_dir, expected_status)
-  
+
   expected_output = svntest.wc.State(wc_dir, {
     'A_new': Item(verb='Adding'),
     })
-  
+
   # These nodes are added by the commit
   expected_status.tweak('A_new', 'A_new/D', 'A_new/D/G', 'A_new/D/G/pi',
                         'A_new/D/G/rho', 'A_new/D/G/tau', 'A_new/D/H',
@@ -4703,7 +4703,7 @@ def copy_over_deleted_dir(sbox):
 
 def mixed_rev_copy_del(sbox):
   """copy mixed-rev and delete children"""
-  
+
   sbox.build()
   wc_dir = sbox.wc_dir
 

Modified: subversion/branches/diff-optimizations-bytes/subversion/tests/cmdline/depth_tests.py
URL: http://svn.apache.org/viewvc/subversion/branches/diff-optimizations-bytes/subversion/tests/cmdline/depth_tests.py?rev=1054012&r1=1054011&r2=1054012&view=diff
==============================================================================
--- subversion/branches/diff-optimizations-bytes/subversion/tests/cmdline/depth_tests.py (original)
+++ subversion/branches/diff-optimizations-bytes/subversion/tests/cmdline/depth_tests.py Thu Dec 30 22:20:48 2010
@@ -2726,7 +2726,7 @@ def sparse_update_with_dash_dash_parents
   alpha_path = os.path.join(sbox.wc_dir, 'A', 'B', 'E', 'alpha')
   pi_path = os.path.join(sbox.wc_dir, 'A', 'D', 'G', 'pi')
   omega_path = os.path.join(sbox.wc_dir, 'A', 'D', 'H', 'omega')
-  
+
   # Start with a depth=empty root checkout.
   svntest.actions.run_and_verify_svn(
       "Unexpected error from co --depth=empty",
@@ -2774,14 +2774,14 @@ def sparse_update_with_dash_dash_parents
     'A/D'          : Item(status='  ', wc_rev=1),
     'A/D/G'        : Item(status='  ', wc_rev=1),
     'A/D/G/pi'     : Item(status='  ', wc_rev=1),
-    })    
+    })
   svntest.actions.run_and_verify_update(sbox.wc_dir,
                                         expected_output,
                                         expected_disk,
                                         expected_status,
                                         None, None, None, None, None, False,
                                         '--parents', pi_path)
-                    
+
   expected_output = svntest.wc.State(sbox.wc_dir, {
     'A/D/H'        : Item(status='A '),
     'A/D/H/omega'  : Item(status='A '),
@@ -2793,14 +2793,14 @@ def sparse_update_with_dash_dash_parents
   expected_status.add({
     'A/D/H'        : Item(status='  ', wc_rev=1),
     'A/D/H/omega'  : Item(status='  ', wc_rev=1),
-    })    
+    })
   svntest.actions.run_and_verify_update(sbox.wc_dir,
                                         expected_output,
                                         expected_disk,
                                         expected_status,
                                         None, None, None, None, None, False,
                                         '--parents', omega_path)
-  
+
 
 #----------------------------------------------------------------------
 # list all tests here, starting with None: