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 [2/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/bindings/swig/perl/libsvn_swig_perl/swigutil_pl.c
URL: http://svn.apache.org/viewvc/subversion/branches/diff-optimizations-bytes/subversion/bindings/swig/perl/libsvn_swig_perl/swigutil_pl.c?rev=1054012&r1=1054011&r2=1054012&view=diff
==============================================================================
--- subversion/branches/diff-optimizations-bytes/subversion/bindings/swig/perl/libsvn_swig_perl/swigutil_pl.c (original)
+++ subversion/branches/diff-optimizations-bytes/subversion/bindings/swig/perl/libsvn_swig_perl/swigutil_pl.c Thu Dec 30 22:20:48 2010
@@ -457,7 +457,7 @@ svn_error_t *svn_swig_pl_callback_thunk(
 /*** Editor Wrapping ***/
 
 /* this could be more perlish */
-typedef struct {
+typedef struct item_baton {
     SV *editor;     /* the editor handling the callbacks */
     SV *baton;      /* the dir/file baton (or NULL for edit baton) */
 } item_baton;
@@ -1343,7 +1343,7 @@ apr_pool_t *svn_swig_pl_make_pool(SV *ob
 
 /* stream interpolability with io::handle */
 
-typedef struct  {
+typedef struct io_baton_t {
     SV *obj;
     IO *io;
 } io_baton_t;

Modified: subversion/branches/diff-optimizations-bytes/subversion/bindings/swig/python/libsvn_swig_py/swigutil_py.c
URL: http://svn.apache.org/viewvc/subversion/branches/diff-optimizations-bytes/subversion/bindings/swig/python/libsvn_swig_py/swigutil_py.c?rev=1054012&r1=1054011&r2=1054012&view=diff
==============================================================================
--- subversion/branches/diff-optimizations-bytes/subversion/bindings/swig/python/libsvn_swig_py/swigutil_py.c (original)
+++ subversion/branches/diff-optimizations-bytes/subversion/bindings/swig/python/libsvn_swig_py/swigutil_py.c Thu Dec 30 22:20:48 2010
@@ -1474,7 +1474,7 @@ static svn_error_t *type_conversion_erro
 /*** Editor Wrapping ***/
 
 /* this baton is used for the editor, directory, and file batons. */
-typedef struct {
+typedef struct item_baton {
   PyObject *editor;     /* the editor handling the callbacks */
   PyObject *baton;      /* the dir/file baton (or NULL for edit baton) */
 } item_baton;
@@ -4115,7 +4115,7 @@ svn_swig_py_txdelta_window_t_ops_get(svn
 {
   PyObject *result = PyList_New(window->num_ops);
   int i;
-  
+
   for (i = 0; i < window->num_ops; ++i)
       PyList_SET_ITEM(result, i,
                       svn_swig_NewPointerObj(window->ops + i, op_type_info,

Modified: subversion/branches/diff-optimizations-bytes/subversion/bindings/swig/python/svn/core.py
URL: http://svn.apache.org/viewvc/subversion/branches/diff-optimizations-bytes/subversion/bindings/swig/python/svn/core.py?rev=1054012&r1=1054011&r2=1054012&view=diff
==============================================================================
--- subversion/branches/diff-optimizations-bytes/subversion/bindings/swig/python/svn/core.py (original)
+++ subversion/branches/diff-optimizations-bytes/subversion/bindings/swig/python/svn/core.py Thu Dec 30 22:20:48 2010
@@ -68,7 +68,7 @@ class SubversionException(Exception):
 
   def __str__(self):
     dump = '%d - %s' % (self.apr_err, self.message)
-    if self.file != None:    
+    if self.file != None:
       dump = dump + '\n at %s:%d' % (self.file, self.line)
     if self.child != None:
       dump = dump + '\n' + self.child.__str__()

Modified: subversion/branches/diff-optimizations-bytes/subversion/bindings/swig/python/tests/core.py
URL: http://svn.apache.org/viewvc/subversion/branches/diff-optimizations-bytes/subversion/bindings/swig/python/tests/core.py?rev=1054012&r1=1054011&r2=1054012&view=diff
==============================================================================
--- subversion/branches/diff-optimizations-bytes/subversion/bindings/swig/python/tests/core.py (original)
+++ subversion/branches/diff-optimizations-bytes/subversion/bindings/swig/python/tests/core.py Thu Dec 30 22:20:48 2010
@@ -55,11 +55,11 @@ class SubversionCoreTestCase(unittest.Te
     rev = svn.core.svn_opt_revision_t()
     rev.kind = svn.core.svn_opt_revision_head
     ctx = svn.client.create_context()
-    
+
     class Receiver:
       def __call__(self, path, info, pool):
         raise self.e
-    
+
     rec = Receiver()
     args = (repos_uri, rev, rev, rec, svn.core.svn_depth_empty, None, ctx)
 
@@ -67,7 +67,7 @@ class SubversionCoreTestCase(unittest.Te
       # ordinary Python exceptions must be passed through
       rec.e = TypeError()
       self.assertRaises(TypeError, svn.client.info2, *args)
-      
+
       # SubversionException will be translated into an svn_error_t, propagated
       # through the call chain and translated back to SubversionException.
       rec.e = svn.core.SubversionException("Bla bla bla.",
@@ -76,14 +76,14 @@ class SubversionCoreTestCase(unittest.Te
       rec.e.child = svn.core.SubversionException("Yada yada.",
                                              svn.core.SVN_ERR_INCOMPLETE_DATA)
       self.assertRaises(svn.core.SubversionException, svn.client.info2, *args)
-      
+
       # It must remain unchanged through the process.
       try:
         svn.client.info2(*args)
       except svn.core.SubversionException, exc:
         # find the original exception
         while exc.file != rec.e.file: exc = exc.child
-        
+
         self.assertEqual(exc.message, rec.e.message)
         self.assertEqual(exc.apr_err, rec.e.apr_err)
         self.assertEqual(exc.line, rec.e.line)
@@ -92,7 +92,7 @@ class SubversionCoreTestCase(unittest.Te
         self.assertEqual(exc.child.child, None)
         self.assertEqual(exc.child.file, None)
         self.assertEqual(exc.child.line, 0)
-        
+
       # Incomplete SubversionExceptions must trigger Python exceptions, which
       # will be passed through.
       rec.e = svn.core.SubversionException("No fields except message.")

Modified: subversion/branches/diff-optimizations-bytes/subversion/bindings/swig/python/tests/delta.py
URL: http://svn.apache.org/viewvc/subversion/branches/diff-optimizations-bytes/subversion/bindings/swig/python/tests/delta.py?rev=1054012&r1=1054011&r2=1054012&view=diff
==============================================================================
--- subversion/branches/diff-optimizations-bytes/subversion/bindings/swig/python/tests/delta.py (original)
+++ subversion/branches/diff-optimizations-bytes/subversion/bindings/swig/python/tests/delta.py Thu Dec 30 22:20:48 2010
@@ -46,15 +46,15 @@ class DeltaTestCase(unittest.TestCase):
     window_handler, baton = \
        svn.delta.tx_apply(src_stream, target_stream, None)
     window_handler(None, baton)
-    
+
   def testTxdeltaWindowT(self):
     """Test the svn_txdelta_window_t wrapper."""
     a = StringIO("abc\ndef\n")
     b = StringIO("def\nghi\n")
-    
+
     delta_stream = svn.delta.svn_txdelta(a, b)
     window = svn.delta.svn_txdelta_next_window(delta_stream)
-    
+
     self.assert_(window.sview_offset + window.sview_len <= len(a.getvalue()))
     self.assert_(window.tview_len <= len(b.getvalue()))
     self.assert_(len(window.new_data) > 0)

Modified: subversion/branches/diff-optimizations-bytes/subversion/bindings/swig/python/tests/ra.py
URL: http://svn.apache.org/viewvc/subversion/branches/diff-optimizations-bytes/subversion/bindings/swig/python/tests/ra.py?rev=1054012&r1=1054011&r2=1054012&view=diff
==============================================================================
--- subversion/branches/diff-optimizations-bytes/subversion/bindings/swig/python/tests/ra.py (original)
+++ subversion/branches/diff-optimizations-bytes/subversion/bindings/swig/python/tests/ra.py Thu Dec 30 22:20:48 2010
@@ -28,7 +28,7 @@ if version_info[0] >= 3:
 else:
   # Python <3.0
   from StringIO import StringIO
-  
+
 import utils
 
 class SubversionRepositoryAccessTestCase(unittest.TestCase):
@@ -40,7 +40,7 @@ class SubversionRepositoryAccessTestCase
     ra.initialize()
     self.temper = utils.Temper()
     # Isolate each test from the others with a fresh repository.
-    
+
     # Open repository directly for cross-checking
     (self.repos, _, self.repos_uri) = self.temper.alloc_known_repo(
       'trac/versioncontrol/tests/svnrepos.dump', suffix='-ra')

Modified: subversion/branches/diff-optimizations-bytes/subversion/bindings/swig/python/tests/repository.py
URL: http://svn.apache.org/viewvc/subversion/branches/diff-optimizations-bytes/subversion/bindings/swig/python/tests/repository.py?rev=1054012&r1=1054011&r2=1054012&view=diff
==============================================================================
--- subversion/branches/diff-optimizations-bytes/subversion/bindings/swig/python/tests/repository.py (original)
+++ subversion/branches/diff-optimizations-bytes/subversion/bindings/swig/python/tests/repository.py Thu Dec 30 22:20:48 2010
@@ -72,7 +72,7 @@ class SubversionRepositoryTestCase(unitt
       revs.append(rev)
       raise core.SubversionException(apr_err=core.SVN_ERR_CEASE_INVOCATION,
                                      message="Hi from history_lookup")
-    
+
     repos.history2(self.fs, '/trunk/README2.txt', history_lookup, None, 0,
                    self.rev, True)
     self.assertEqual(len(revs), 1)

Modified: subversion/branches/diff-optimizations-bytes/subversion/bindings/swig/python/tests/utils.py
URL: http://svn.apache.org/viewvc/subversion/branches/diff-optimizations-bytes/subversion/bindings/swig/python/tests/utils.py?rev=1054012&r1=1054011&r2=1054012&view=diff
==============================================================================
--- subversion/branches/diff-optimizations-bytes/subversion/bindings/swig/python/tests/utils.py (original)
+++ subversion/branches/diff-optimizations-bytes/subversion/bindings/swig/python/tests/utils.py Thu Dec 30 22:20:48 2010
@@ -64,7 +64,7 @@ class Temper(object):
     repos.svn_repos_load_fs2(handle, open(dump_path, 'rb'), StringIO(),
                              repos.load_uuid_default, None, False, False, None)
     return (handle, repo_path, repo_uri)
-    
+
 def file_uri_for_path(path):
   """Return the file: URI corresponding to the given path."""
   uri_path = urllib.pathname2url(path)

Modified: subversion/branches/diff-optimizations-bytes/subversion/bindings/swig/ruby/libsvn_swig_ruby/swigutil_rb.c
URL: http://svn.apache.org/viewvc/subversion/branches/diff-optimizations-bytes/subversion/bindings/swig/ruby/libsvn_swig_ruby/swigutil_rb.c?rev=1054012&r1=1054011&r2=1054012&view=diff
==============================================================================
--- subversion/branches/diff-optimizations-bytes/subversion/bindings/swig/ruby/libsvn_swig_ruby/swigutil_rb.c (original)
+++ subversion/branches/diff-optimizations-bytes/subversion/bindings/swig/ruby/libsvn_swig_ruby/swigutil_rb.c Thu Dec 30 22:20:48 2010
@@ -1012,7 +1012,7 @@ c2r_svn_string(void *value, void *ctx)
   return c2r_string2(s->data);
 }
 
-typedef struct {
+typedef struct prop_hash_each_arg_t {
   apr_array_header_t *array;
   apr_pool_t *pool;
 } prop_hash_each_arg_t;
@@ -1576,19 +1576,19 @@ svn_swig_rb_hash_to_apr_hash_merge_range
 
 
 /* callback */
-typedef struct {
+typedef struct callback_baton_t {
   VALUE pool;
   VALUE receiver;
   ID message;
   VALUE args;
 } callback_baton_t;
 
-typedef struct {
+typedef struct callback_rescue_baton_t {
   svn_error_t **err;
   VALUE pool;
 } callback_rescue_baton_t;
 
-typedef struct {
+typedef struct callback_handle_error_baton_t {
   callback_baton_t *callback_baton;
   callback_rescue_baton_t *rescue_baton;
 } callback_handle_error_baton_t;
@@ -1675,7 +1675,7 @@ invoke_callback_handle_error(VALUE baton
 
 
 /* svn_delta_editor_t */
-typedef struct {
+typedef struct item_baton {
   VALUE editor;
   VALUE baton;
 } item_baton;

Modified: subversion/branches/diff-optimizations-bytes/subversion/include/private/svn_mergeinfo_private.h
URL: http://svn.apache.org/viewvc/subversion/branches/diff-optimizations-bytes/subversion/include/private/svn_mergeinfo_private.h?rev=1054012&r1=1054011&r2=1054012&view=diff
==============================================================================
--- subversion/branches/diff-optimizations-bytes/subversion/include/private/svn_mergeinfo_private.h (original)
+++ subversion/branches/diff-optimizations-bytes/subversion/include/private/svn_mergeinfo_private.h Thu Dec 30 22:20:48 2010
@@ -226,7 +226,7 @@ svn_rangelist__initialize(svn_revnum_t s
                           svn_boolean_t inheritable,
                           apr_pool_t *result_pool);
 
-/* Adjust in-place MERGEINFO's rangelists by OFFSET.  If OFFSET is negative 
+/* Adjust in-place MERGEINFO's rangelists by OFFSET.  If OFFSET is negative
    and would adjust any part of MERGEINFO's source revisions to 0 or less,
    then those revisions are dropped.  If all the source revisions for a merge
    source path are dropped, then the path itself is dropped.  If all merge

Modified: subversion/branches/diff-optimizations-bytes/subversion/include/private/svn_repos_private.h
URL: http://svn.apache.org/viewvc/subversion/branches/diff-optimizations-bytes/subversion/include/private/svn_repos_private.h?rev=1054012&r1=1054011&r2=1054012&view=diff
==============================================================================
--- subversion/branches/diff-optimizations-bytes/subversion/include/private/svn_repos_private.h (original)
+++ subversion/branches/diff-optimizations-bytes/subversion/include/private/svn_repos_private.h Thu Dec 30 22:20:48 2010
@@ -74,7 +74,7 @@ svn_repos__obliterate_path_rev(svn_repos
  * repository; return @c SVN_ERR_REPOS_BAD_ARGS if it isn't.  For some
  * "svn:" properties, also validate the @a value, and return
  * @c SVN_ERR_BAD_PROPERTY_VALUE if it is not valid.
- * 
+ *
  * Use @a pool for temporary allocations.
  *
  * @since New in 1.7.

Modified: subversion/branches/diff-optimizations-bytes/subversion/include/private/svn_token.h
URL: http://svn.apache.org/viewvc/subversion/branches/diff-optimizations-bytes/subversion/include/private/svn_token.h?rev=1054012&r1=1054011&r2=1054012&view=diff
==============================================================================
--- subversion/branches/diff-optimizations-bytes/subversion/include/private/svn_token.h (original)
+++ subversion/branches/diff-optimizations-bytes/subversion/include/private/svn_token.h Thu Dec 30 22:20:48 2010
@@ -36,7 +36,7 @@ extern "C" {
  *
  * Maps are an array of these, terminated with a struct where STR == NULL.
  */
-typedef struct
+typedef struct svn_token_map_t
 {
   const char *str;
   int val;

Modified: subversion/branches/diff-optimizations-bytes/subversion/include/private/svn_wc_private.h
URL: http://svn.apache.org/viewvc/subversion/branches/diff-optimizations-bytes/subversion/include/private/svn_wc_private.h?rev=1054012&r1=1054011&r2=1054012&view=diff
==============================================================================
--- subversion/branches/diff-optimizations-bytes/subversion/include/private/svn_wc_private.h (original)
+++ subversion/branches/diff-optimizations-bytes/subversion/include/private/svn_wc_private.h Thu Dec 30 22:20:48 2010
@@ -187,7 +187,7 @@ svn_wc__cd_to_cd2(const svn_wc_conflict_
  */
 svn_error_t *
 svn_wc__status2_from_3(svn_wc_status2_t **status,
-                       const svn_wc_status3_t *old_status, 
+                       const svn_wc_status3_t *old_status,
                        svn_wc_context_t *wc_ctx,
                        const char *local_abspath,
                        apr_pool_t *result_pool,
@@ -324,7 +324,7 @@ svn_wc__node_get_url(const char **url,
  * repos_relpath it will have in the repository.
  *
  * If @a local_abspath is not in the working copy, return @c
- * SVN_ERR_WC_PATH_NOT_FOUND. 
+ * SVN_ERR_WC_PATH_NOT_FOUND.
  * */
 svn_error_t *
 svn_wc__node_get_repos_relpath(const char **repos_relpath,
@@ -344,7 +344,7 @@ svn_wc__node_get_repos_relpath(const cha
  * @a copyfrom_root_url and @a copyfrom_repos_relpath return the exact same
  * information as @a copyfrom_url, just still separated as root and relpath.
  *
- * If @a local_abspath is not copied, set @a *copyfrom_root_url, 
+ * If @a local_abspath is not copied, set @a *copyfrom_root_url,
  * @a *copyfrom_repos_relpath and @a copyfrom_url to NULL and
  * @a *copyfrom_rev to @c SVN_INVALID_REVNUM.
  *
@@ -467,7 +467,7 @@ svn_wc__node_get_base_rev(svn_revnum_t *
 
 /* Get the working revision of @a local_abspath using @a wc_ctx. If @a
  * local_abspath is not in the working copy, return @c
- * SVN_ERR_WC_PATH_NOT_FOUND.  
+ * SVN_ERR_WC_PATH_NOT_FOUND.
  *
  * This function is meant as a temporary solution for using the old-style
  * semantics of entries. It will handle any uncommitted changes (delete,
@@ -477,24 +477,24 @@ svn_wc__node_get_base_rev(svn_revnum_t *
  * the path that was deleted. But if the delete is  below an add, the
  * revision is set to SVN_INVALID_REVNUM. For an add, copy or move we return
  * SVN_INVALID_REVNUM. In case of a replacement, we return the BASE
- * revision. 
+ * revision.
  *
  * The @a changed_rev is set to the latest committed change to @a
  * local_abspath before or equal to @a revision, unless the node is
  * copied-here or moved-here. Then it is the revision of the latest committed
  * change before or equal to the copyfrom_rev.  NOTE, that we use
- * SVN_INVALID_REVNUM for a scheduled copy or move. 
+ * SVN_INVALID_REVNUM for a scheduled copy or move.
  *
  * The @a changed_date and @a changed_author are the ones associated with @a
- * changed_rev.  
+ * changed_rev.
  */
 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);
 

Modified: subversion/branches/diff-optimizations-bytes/subversion/include/svn_checksum.h
URL: http://svn.apache.org/viewvc/subversion/branches/diff-optimizations-bytes/subversion/include/svn_checksum.h?rev=1054012&r1=1054011&r2=1054012&view=diff
==============================================================================
--- subversion/branches/diff-optimizations-bytes/subversion/include/svn_checksum.h (original)
+++ subversion/branches/diff-optimizations-bytes/subversion/include/svn_checksum.h Thu Dec 30 22:20:48 2010
@@ -42,7 +42,7 @@ extern "C" {
  *
  * @since New in 1.6.
  */
-typedef enum
+typedef enum svn_checksum_kind_t
 {
   /** The checksum is (or should be set to) an MD5 checksum. */
   svn_checksum_md5,

Modified: subversion/branches/diff-optimizations-bytes/subversion/include/svn_client.h
URL: http://svn.apache.org/viewvc/subversion/branches/diff-optimizations-bytes/subversion/include/svn_client.h?rev=1054012&r1=1054011&r2=1054012&view=diff
==============================================================================
--- subversion/branches/diff-optimizations-bytes/subversion/include/svn_client.h (original)
+++ subversion/branches/diff-optimizations-bytes/subversion/include/svn_client.h Thu Dec 30 22:20:48 2010
@@ -679,9 +679,9 @@ typedef svn_error_t *(*svn_client_get_co
  * which has the revision properties @a rev_props, and that the contents were
  * @a line.
  *
- * @a start_revnum and @a end_revnum contain the start and end revision 
+ * @a start_revnum and @a end_revnum contain the start and end revision
  * number of the entire blame operation, as determined from the repository
- * inside svn_client_blame5(). This can be useful for the blame receiver 
+ * inside svn_client_blame5(). This can be useful for the blame receiver
  * to format the blame output.
  *
  * If svn_client_blame5() was called with @a include_merged_revisions set to
@@ -1050,7 +1050,7 @@ svn_client_args_to_target_array(apr_arra
  * Checkout a working copy from a repository.
  *
  * @param[out] result_rev   If non-NULL, the value of the revision checked
- *              out form the repository.
+ *              out from the repository.
  * @param[in] URL       The repository URL of the checkout source.
  * @param[in] path      The root of the new working copy.
  * @param[in] peg_revision  The peg revision.
@@ -2030,7 +2030,7 @@ typedef struct svn_client_status_t
   /** The URL of the repository */
   const char *repos_root_url;
 
-  /** The in-repository path relative to the repository root. 
+  /** The in-repository path relative to the repository root.
    * Use svn_path_url_component2() to join this value to the
    * repos_root_url to get the full URL.
    */
@@ -4129,7 +4129,7 @@ svn_client_propset4(const char *propname
                     const apr_array_header_t *changelists,
                     const apr_hash_t *revprop_table,
                     svn_commit_callback2_t commit_callback,
-                    void *commit_baton, 
+                    void *commit_baton,
                     svn_client_ctx_t *ctx,
                     apr_pool_t *pool);
 

Modified: subversion/branches/diff-optimizations-bytes/subversion/include/svn_diff.h
URL: http://svn.apache.org/viewvc/subversion/branches/diff-optimizations-bytes/subversion/include/svn_diff.h?rev=1054012&r1=1054011&r2=1054012&view=diff
==============================================================================
--- subversion/branches/diff-optimizations-bytes/subversion/include/svn_diff.h (original)
+++ subversion/branches/diff-optimizations-bytes/subversion/include/svn_diff.h Thu Dec 30 22:20:48 2010
@@ -946,7 +946,7 @@ svn_diff_hunk_get_trailing_context(const
 
 /**
  * Data type to manage parsing of properties in patches.
- * 
+ *
  * @since New in 1.7. */
 typedef struct svn_prop_patch_t {
   const char *name;
@@ -1005,7 +1005,7 @@ typedef struct svn_patch_t {
  * whitespace to be parsed.
  * Allocate results in @a result_pool.
  * Use @a scratch_pool for all other allocations.
- * 
+ *
  * @since New in 1.7. */
 svn_error_t *
 svn_diff_parse_next_patch(svn_patch_t **patch,

Modified: subversion/branches/diff-optimizations-bytes/subversion/include/svn_editor.h
URL: http://svn.apache.org/viewvc/subversion/branches/diff-optimizations-bytes/subversion/include/svn_editor.h?rev=1054012&r1=1054011&r2=1054012&view=diff
==============================================================================
--- subversion/branches/diff-optimizations-bytes/subversion/include/svn_editor.h (original)
+++ subversion/branches/diff-optimizations-bytes/subversion/include/svn_editor.h Thu Dec 30 22:20:48 2010
@@ -640,7 +640,7 @@ svn_editor_setcb_abort(svn_editor_t *edi
  * @see svn_editor_setcb_many(), svn_editor_create(), svn_editor_t.
  * @since New in 1.7.
  */
-typedef struct
+typedef struct svn_editor_cb_many_t
 {
   svn_editor_cb_add_directory_t cb_add_directory;
   svn_editor_cb_add_file_t cb_add_file;

Modified: subversion/branches/diff-optimizations-bytes/subversion/include/svn_fs.h
URL: http://svn.apache.org/viewvc/subversion/branches/diff-optimizations-bytes/subversion/include/svn_fs.h?rev=1054012&r1=1054011&r2=1054012&view=diff
==============================================================================
--- subversion/branches/diff-optimizations-bytes/subversion/include/svn_fs.h (original)
+++ subversion/branches/diff-optimizations-bytes/subversion/include/svn_fs.h Thu Dec 30 22:20:48 2010
@@ -1061,7 +1061,7 @@ svn_fs_revision_root_revision(svn_fs_roo
 
 
 /** The kind of change that occurred on the path. */
-typedef enum
+typedef enum svn_fs_path_change_kind_t
 {
   /** path modified in txn */
   svn_fs_path_change_modify = 0,
@@ -1959,7 +1959,7 @@ svn_fs_change_rev_prop2(svn_fs_t *fs,
                         apr_pool_t *pool);
 
 
-/** 
+/**
  * Similar to svn_fs_change_rev_prop2(), but with @a old_value_p passed as
  * @c NULL.
  *
@@ -2194,7 +2194,7 @@ svn_fs_get_locks2(svn_fs_t *fs,
                   void *get_locks_baton,
                   apr_pool_t *pool);
 
-/** 
+/**
  * Similar to svn_fs_get_locks2(), but with @a depth always passed as
  * svn_depth_infinity.
  *
@@ -2222,7 +2222,7 @@ svn_fs_print_modules(svn_stringbuf_t *ou
 
 
 /** The kind of action being taken by 'pack'. */
-typedef enum
+typedef enum svn_fs_pack_notify_action_t
 {
   /** packing of the shard has commenced */
   svn_fs_pack_notify_start = 0,

Modified: subversion/branches/diff-optimizations-bytes/subversion/include/svn_mergeinfo.h
URL: http://svn.apache.org/viewvc/subversion/branches/diff-optimizations-bytes/subversion/include/svn_mergeinfo.h?rev=1054012&r1=1054011&r2=1054012&view=diff
==============================================================================
--- subversion/branches/diff-optimizations-bytes/subversion/include/svn_mergeinfo.h (original)
+++ subversion/branches/diff-optimizations-bytes/subversion/include/svn_mergeinfo.h Thu Dec 30 22:20:48 2010
@@ -507,7 +507,7 @@ svn_rangelist_dup(const apr_array_header
  *
  * @since New in 1.5.
  */
-typedef enum
+typedef enum svn_mergeinfo_inheritance_t
 {
   /** Explicit mergeinfo only. */
   svn_mergeinfo_explicit,

Modified: subversion/branches/diff-optimizations-bytes/subversion/include/svn_repos.h
URL: http://svn.apache.org/viewvc/subversion/branches/diff-optimizations-bytes/subversion/include/svn_repos.h?rev=1054012&r1=1054011&r2=1054012&view=diff
==============================================================================
--- subversion/branches/diff-optimizations-bytes/subversion/include/svn_repos.h (original)
+++ subversion/branches/diff-optimizations-bytes/subversion/include/svn_repos.h Thu Dec 30 22:20:48 2010
@@ -107,7 +107,7 @@ typedef svn_error_t *(*svn_repos_authz_f
  *
  * @since New in 1.3.
  */
-typedef enum
+typedef enum svn_repos_authz_access_t
 {
   /** No access. */
   svn_authz_none = 0,
@@ -2010,7 +2010,7 @@ svn_repos_fs_get_locks2(apr_hash_t **loc
                         void *authz_read_baton,
                         apr_pool_t *pool);
 
-/** 
+/**
  * Similar to svn_repos_fs_get_locks2(), but with @a depth always
  * passed as svn_depth_infinity.
  *
@@ -2972,7 +2972,7 @@ svn_repos_authz_check_access(svn_authz_t
  *
  * @since New in 1.5.
  */
-typedef enum
+typedef enum svn_repos_revision_access_level_t
 {
   svn_repos_revision_access_none,
   svn_repos_revision_access_partial,

Modified: subversion/branches/diff-optimizations-bytes/subversion/include/svn_string.h
URL: http://svn.apache.org/viewvc/subversion/branches/diff-optimizations-bytes/subversion/include/svn_string.h?rev=1054012&r1=1054011&r2=1054012&view=diff
==============================================================================
--- subversion/branches/diff-optimizations-bytes/subversion/include/svn_string.h (original)
+++ subversion/branches/diff-optimizations-bytes/subversion/include/svn_string.h Thu Dec 30 22:20:48 2010
@@ -405,7 +405,7 @@ svn_cstring_casecmp(const char *str1, co
  * Parse the C string @a str into a 64 bit number, and return it in @a *n.
  * Assume that the number is represented in base @a base.
  * Raise an error if conversion fails (e.g. due to overflow), or if the
- * converted number is smaller than @a minval or larger than @a maxval. 
+ * converted number is smaller than @a minval or larger than @a maxval.
  *
  * @since New in 1.7.
  */
@@ -438,7 +438,7 @@ svn_cstring_atoi(int *n, const char *str
  * Parse the C string @a str into an unsigned 64 bit number, and return
  * it in @a *n. Assume that the number is represented in base @a base.
  * Raise an error if conversion fails (e.g. due to overflow), or if the
- * converted number is smaller than @a minval or larger than @a maxval. 
+ * converted number is smaller than @a minval or larger than @a maxval.
  *
  * @since New in 1.7.
  */

Modified: subversion/branches/diff-optimizations-bytes/subversion/include/svn_types.h
URL: http://svn.apache.org/viewvc/subversion/branches/diff-optimizations-bytes/subversion/include/svn_types.h?rev=1054012&r1=1054011&r2=1054012&view=diff
==============================================================================
--- subversion/branches/diff-optimizations-bytes/subversion/include/svn_types.h (original)
+++ subversion/branches/diff-optimizations-bytes/subversion/include/svn_types.h Thu Dec 30 22:20:48 2010
@@ -169,7 +169,7 @@ svn__apr_hash_index_val(const apr_hash_i
 /** @} */
 
 /** The various types of nodes in the Subversion filesystem. */
-typedef enum
+typedef enum svn_node_kind_t
 {
   /** absent */
   svn_node_none,
@@ -211,7 +211,7 @@ svn_node_kind_from_word(const char *word
  * not a valid value.
  *
  * @since New in 1.7. */
-typedef enum
+typedef enum svn_tristate_t
 {
   svn_tristate_false = 2,
   svn_tristate_true,
@@ -364,7 +364,7 @@ enum svn_recurse_kind
  *
  * @since New in 1.5.
  */
-typedef enum
+typedef enum svn_depth_t
 {
   /* The order of these depths is important: the higher the number,
      the deeper it descends.  This allows us to compare two depths

Modified: subversion/branches/diff-optimizations-bytes/subversion/include/svn_wc.h
URL: http://svn.apache.org/viewvc/subversion/branches/diff-optimizations-bytes/subversion/include/svn_wc.h?rev=1054012&r1=1054011&r2=1054012&view=diff
==============================================================================
--- subversion/branches/diff-optimizations-bytes/subversion/include/svn_wc.h (original)
+++ subversion/branches/diff-optimizations-bytes/subversion/include/svn_wc.h Thu Dec 30 22:20:48 2010
@@ -3400,7 +3400,7 @@ typedef struct svn_wc_status3_t
   /** The URL of the repository */
   const char *repos_root_url;
 
-  /** The in-repository path relative to the repository root. 
+  /** The in-repository path relative to the repository root.
    * Use svn_path_url_component2() to join this value to the
    * repos_root_url to get the full URL.
    */
@@ -5277,7 +5277,7 @@ svn_wc_get_update_editor4(const svn_delt
 
 /** Similar to svn_wc_get_update_editor4, but uses access batons and relative
  * path instead of a working copy context-abspath pair and
- * svn_wc_traversal_info_t instead of an externals callback.  Also, 
+ * svn_wc_traversal_info_t instead of an externals callback.  Also,
  * @a fetch_func and @a fetch_baton are ignored.
  *
  * If @a ti is non-NULL, record traversal info in @a ti, for use by
@@ -5580,7 +5580,7 @@ svn_wc_get_pristine_props(apr_hash_t **p
                           const char *local_abspath,
                           apr_pool_t *result_pool,
                           apr_pool_t *scratch_pool);
-                          
+
 
 /** Set @a *value to the value of property @a name for @a local_abspath,
  * allocating @a *value in @a result_pool.  If no such prop, set @a *value

Modified: subversion/branches/diff-optimizations-bytes/subversion/libsvn_auth_kwallet/kwallet.cpp
URL: http://svn.apache.org/viewvc/subversion/branches/diff-optimizations-bytes/subversion/libsvn_auth_kwallet/kwallet.cpp?rev=1054012&r1=1054011&r2=1054012&view=diff
==============================================================================
--- subversion/branches/diff-optimizations-bytes/subversion/libsvn_auth_kwallet/kwallet.cpp (original)
+++ subversion/branches/diff-optimizations-bytes/subversion/libsvn_auth_kwallet/kwallet.cpp Thu Dec 30 22:20:48 2010
@@ -120,7 +120,7 @@ get_wid(void)
     {
       apr_int64_t wid_env;
       svn_error_t *err;
-      
+
       err = svn_cstring_atoi64(&wid_env, wid_env_string);
       if (err)
         svn_error_clear(err);

Modified: subversion/branches/diff-optimizations-bytes/subversion/libsvn_client/add.c
URL: http://svn.apache.org/viewvc/subversion/branches/diff-optimizations-bytes/subversion/libsvn_client/add.c?rev=1054012&r1=1054011&r2=1054012&view=diff
==============================================================================
--- subversion/branches/diff-optimizations-bytes/subversion/libsvn_client/add.c (original)
+++ subversion/branches/diff-optimizations-bytes/subversion/libsvn_client/add.c Thu Dec 30 22:20:48 2010
@@ -57,7 +57,7 @@
 /* This structure is used as baton for enumerating the config entries
    in the auto-props section.
 */
-typedef struct
+typedef struct auto_props_baton_t
 {
   /* the file name for which properties are searched */
   const char *filename;

Modified: subversion/branches/diff-optimizations-bytes/subversion/libsvn_client/cleanup.c
URL: http://svn.apache.org/viewvc/subversion/branches/diff-optimizations-bytes/subversion/libsvn_client/cleanup.c?rev=1054012&r1=1054011&r2=1054012&view=diff
==============================================================================
--- subversion/branches/diff-optimizations-bytes/subversion/libsvn_client/cleanup.c (original)
+++ subversion/branches/diff-optimizations-bytes/subversion/libsvn_client/cleanup.c Thu Dec 30 22:20:48 2010
@@ -174,7 +174,7 @@ svn_client_upgrade(const char *path,
 
           item = APR_ARRAY_IDX(externals_p, i, svn_wc_external_item2_t*);
 
-          external_path = svn_dirent_join(externals_parent, item->target_dir, 
+          external_path = svn_dirent_join(externals_parent, item->target_dir,
                                           iterpool);
 
           SVN_ERR(svn_dirent_get_absolute(&external_abspath, external_path,

Modified: subversion/branches/diff-optimizations-bytes/subversion/libsvn_client/client.h
URL: http://svn.apache.org/viewvc/subversion/branches/diff-optimizations-bytes/subversion/libsvn_client/client.h?rev=1054012&r1=1054011&r2=1054012&view=diff
==============================================================================
--- subversion/branches/diff-optimizations-bytes/subversion/libsvn_client/client.h (original)
+++ subversion/branches/diff-optimizations-bytes/subversion/libsvn_client/client.h Thu Dec 30 22:20:48 2010
@@ -502,7 +502,7 @@ svn_client__update_internal(svn_revnum_t
    This structure is used by svn_client__checkout_internal() to save
    one or more round-trips if the client already gathered some of this
    information.  Not all the fields need to be filled in.  */
-typedef struct
+typedef struct svn_client__ra_session_from_path_results
 {
   /* The repository root URL.  A NULL value means the root URL is
      unknown.*/
@@ -688,7 +688,7 @@ svn_client__get_diff_summarize_editor(co
    various helper functions may need.  Not every copy function uses every
    field.
 */
-typedef struct
+typedef struct svn_client__copy_pair_t
 {
     /* The absolute source path or url. */
     const char *src_abspath_or_url;

Modified: subversion/branches/diff-optimizations-bytes/subversion/libsvn_client/commit_util.c
URL: http://svn.apache.org/viewvc/subversion/branches/diff-optimizations-bytes/subversion/libsvn_client/commit_util.c?rev=1054012&r1=1054011&r2=1054012&view=diff
==============================================================================
--- subversion/branches/diff-optimizations-bytes/subversion/libsvn_client/commit_util.c (original)
+++ subversion/branches/diff-optimizations-bytes/subversion/libsvn_client/commit_util.c Thu Dec 30 22:20:48 2010
@@ -394,6 +394,7 @@ harvest_committables(apr_hash_t *committ
   const char *cf_relpath = NULL;
   svn_revnum_t entry_rev, cf_rev = SVN_INVALID_REVNUM;
   const svn_string_t *propval;
+  svn_boolean_t matches_changelists;
   svn_boolean_t is_special;
   svn_boolean_t is_file_external;
   svn_boolean_t is_added;
@@ -442,6 +443,17 @@ harvest_committables(apr_hash_t *committ
          svn_dirent_local_style(local_abspath, scratch_pool));
     }
 
+  /* Save the result for reuse. */
+  matches_changelists = svn_wc__changelist_match(ctx->wc_ctx, local_abspath,
+                                                 changelists, scratch_pool);
+
+  /* Early exit. */
+  if (working_kind != svn_node_dir && working_kind != svn_node_none
+      && ! matches_changelists)
+    {
+      return SVN_NO_ERROR;
+    }
+
   /* Verify that the node's type has not changed before attempting to
      commit. */
   SVN_ERR(svn_wc_prop_get2(&propval, ctx->wc_ctx, local_abspath,
@@ -466,8 +478,7 @@ harvest_committables(apr_hash_t *committ
 
   /* If ENTRY is in our changelist, then examine it for conflicts. We
      need to bail out if any conflicts exist.  */
-  if (svn_wc__changelist_match(ctx->wc_ctx, local_abspath, changelists,
-                               scratch_pool))
+  if (matches_changelists)
     {
       svn_boolean_t tc, pc, treec;
 

Modified: subversion/branches/diff-optimizations-bytes/subversion/libsvn_client/copy.c
URL: http://svn.apache.org/viewvc/subversion/branches/diff-optimizations-bytes/subversion/libsvn_client/copy.c?rev=1054012&r1=1054011&r2=1054012&view=diff
==============================================================================
--- subversion/branches/diff-optimizations-bytes/subversion/libsvn_client/copy.c (original)
+++ subversion/branches/diff-optimizations-bytes/subversion/libsvn_client/copy.c Thu Dec 30 22:20:48 2010
@@ -513,7 +513,7 @@ verify_wc_srcs_and_dsts(const apr_array_
 
 
 /* Path-specific state used as part of path_driver_cb_baton. */
-typedef struct
+typedef struct path_driver_info_t
 {
   const char *src_url;
   const char *src_path;
@@ -824,7 +824,7 @@ repos_to_repos_copy(const apr_array_head
      *and* destinations might be an optimization when the user is
      authorized to access all that stuff, but could cause the
      operation to fail altogether otherwise.  See issue #3242.  */
-  SVN_ERR(get_copy_pair_ancestors(copy_pairs, NULL, &top_url_dst, &top_url_all, 
+  SVN_ERR(get_copy_pair_ancestors(copy_pairs, NULL, &top_url_dst, &top_url_all,
                                   pool));
   top_url = is_move ? top_url_all : top_url_dst;
 
@@ -1629,7 +1629,7 @@ repos_to_wc_copy_locked(const apr_array_
          ### simplify the conditions? */
 
       /* Hidden by client exclusion */
-      SVN_ERR(svn_wc__node_get_depth(&node_depth, ctx->wc_ctx, 
+      SVN_ERR(svn_wc__node_get_depth(&node_depth, ctx->wc_ctx,
                                      pair->dst_abspath_or_url, iterpool));
       if (node_depth == svn_depth_exclude)
         {
@@ -1661,7 +1661,7 @@ repos_to_wc_copy_locked(const apr_array_
           SVN_ERR(svn_wc__node_is_status_deleted(&is_deleted, ctx->wc_ctx,
                                                  pair->dst_abspath_or_url,
                                                  iterpool));
-          SVN_ERR(svn_wc__node_is_status_present(&is_present, 
+          SVN_ERR(svn_wc__node_is_status_present(&is_present,
                                                  ctx->wc_ctx,
                                                  pair->dst_abspath_or_url,
                                                  iterpool));
@@ -1953,7 +1953,7 @@ try_copy(const apr_array_header_t *sourc
               src_basename = svn_dirent_basename(pair->src_abspath_or_url,
                                                  iterpool);
             }
-            
+
           pair->src_op_revision = *source->revision;
           pair->src_peg_revision = *source->peg_revision;
 

Modified: subversion/branches/diff-optimizations-bytes/subversion/libsvn_client/deprecated.c
URL: http://svn.apache.org/viewvc/subversion/branches/diff-optimizations-bytes/subversion/libsvn_client/deprecated.c?rev=1054012&r1=1054011&r2=1054012&view=diff
==============================================================================
--- subversion/branches/diff-optimizations-bytes/subversion/libsvn_client/deprecated.c (original)
+++ subversion/branches/diff-optimizations-bytes/subversion/libsvn_client/deprecated.c Thu Dec 30 22:20:48 2010
@@ -1835,7 +1835,7 @@ svn_client_update(svn_revnum_t *result_r
 {
   apr_array_header_t *paths = apr_array_make(pool, 1, sizeof(const char *));
   apr_array_header_t *result_revs;
-  
+
   APR_ARRAY_PUSH(paths, const char *) = path;
 
   SVN_ERR(svn_client_update2(&result_revs, paths, revision, recurse, FALSE,
@@ -1890,7 +1890,7 @@ svn_client_checkout2(svn_revnum_t *resul
                      apr_pool_t *pool)
 {
   return svn_error_return(svn_client_checkout3(result_rev, URL, path,
-                                        peg_revision, revision, 
+                                        peg_revision, revision,
                                         SVN_DEPTH_INFINITY_OR_FILES(recurse),
                                         ignore_externals, FALSE, ctx, pool));
 }

Modified: subversion/branches/diff-optimizations-bytes/subversion/libsvn_client/diff.c
URL: http://svn.apache.org/viewvc/subversion/branches/diff-optimizations-bytes/subversion/libsvn_client/diff.c?rev=1054012&r1=1054011&r2=1054012&view=diff
==============================================================================
--- subversion/branches/diff-optimizations-bytes/subversion/libsvn_client/diff.c (original)
+++ subversion/branches/diff-optimizations-bytes/subversion/libsvn_client/diff.c Thu Dec 30 22:20:48 2010
@@ -367,7 +367,7 @@ diff_label(const char *path,
  * PATH2 to the stream OS using HEADER_ENCODING.
  * All allocations are done in RESULT_POOL. */
 static svn_error_t *
-print_git_diff_header_added(svn_stream_t *os, const char *header_encoding, 
+print_git_diff_header_added(svn_stream_t *os, const char *header_encoding,
                             const char *path1, const char *path2,
                             apr_pool_t *result_pool)
 {
@@ -383,7 +383,7 @@ print_git_diff_header_added(svn_stream_t
  * PATH2 to the stream OS using HEADER_ENCODING.
  * All allocations are done in RESULT_POOL. */
 static svn_error_t *
-print_git_diff_header_deleted(svn_stream_t *os, const char *header_encoding, 
+print_git_diff_header_deleted(svn_stream_t *os, const char *header_encoding,
                               const char *path1, const char *path2,
                               apr_pool_t *result_pool)
 {
@@ -399,7 +399,7 @@ print_git_diff_header_deleted(svn_stream
 /* Print a git diff header for a copy from COPYFROM_PATH to PATH to the stream
  * OS using HEADER_ENCODING. All allocations are done in RESULT_POOL. */
 static svn_error_t *
-print_git_diff_header_copied(svn_stream_t *os, const char *header_encoding, 
+print_git_diff_header_copied(svn_stream_t *os, const char *header_encoding,
                              const char *copyfrom_path, const char *path,
                              apr_pool_t *result_pool)
 {
@@ -425,7 +425,7 @@ print_git_diff_header_renamed(svn_stream
                                       "diff --git a/%s b/%s%s",
                                       copyfrom_path, path, APR_EOL_STR));
   SVN_ERR(svn_stream_printf_from_utf8(os, header_encoding, result_pool,
-                                      "rename from %s%s", copyfrom_path, 
+                                      "rename from %s%s", copyfrom_path,
                                       APR_EOL_STR));
   SVN_ERR(svn_stream_printf_from_utf8(os, header_encoding, result_pool,
                                       "rename to %s%s", path, APR_EOL_STR));
@@ -436,7 +436,7 @@ print_git_diff_header_renamed(svn_stream
  * PATH2 to the stream OS using HEADER_ENCODING.
  * All allocations are done in RESULT_POOL. */
 static svn_error_t *
-print_git_diff_header_modified(svn_stream_t *os, const char *header_encoding, 
+print_git_diff_header_modified(svn_stream_t *os, const char *header_encoding,
                                const char *path1, const char *path2,
                                apr_pool_t *result_pool)
 {
@@ -531,12 +531,12 @@ print_git_diff_header(svn_stream_t *os,
    passed to svn_client_diff5, which is probably stdout.
 
    ### FIXME needs proper docstring
-   
+
    If USE_GIT_DIFF_FORMAT is TRUE, pring git diff headers, which always
    show paths relative to the repository root. RA_SESSION and WC_CTX are
    needed to normalize paths relative the repository root, and are ignored
    if USE_GIT_DIFF_FORMAT is FALSE.
-   
+
    WC_ROOT_ABSPATH is the absolute path to the root directory of a working
    copy involved in a repos-wc diff, and may be NULL. */
 static svn_error_t *
@@ -595,8 +595,8 @@ display_prop_diffs(const apr_array_heade
        * ### diff_content_changed() does not! */
 
       SVN_ERR(file_printf_from_utf8(file, encoding,
-                                    "Index: %s" APR_EOL_STR 
-                                    "%s" APR_EOL_STR, 
+                                    "Index: %s" APR_EOL_STR
+                                    "%s" APR_EOL_STR,
                                     path, equal_string));
 
       if (use_git_diff_format)
@@ -778,7 +778,7 @@ struct diff_cmd_baton {
    * directory of the working copy involved in the diff. */
   const char *wc_root_abspath;
 
-  /* A hashtable using the visited paths as keys. 
+  /* A hashtable using the visited paths as keys.
    * ### This is needed for us to know if we need to print a diff header for
    * ### a path that has property changes. */
   apr_hash_t *visited_paths;
@@ -1137,7 +1137,7 @@ diff_file_deleted_with_diff(const char *
 
   if (tmpfile1)
     SVN_ERR(diff_content_changed(path,
-                                 tmpfile1, tmpfile2, diff_cmd_baton->revnum1, 
+                                 tmpfile1, tmpfile2, diff_cmd_baton->revnum1,
                                  diff_cmd_baton->revnum2,
                                  mimetype1, mimetype2,
                                  svn_diff_op_deleted, NULL, diff_baton));
@@ -1371,7 +1371,7 @@ find_wc_root(const char *local_abspath, 
  *  and REVISION2 are local. If PEG_REVISION is not unspecified, ensure that
  *  at least one of the two revisions is non-local.
  *  If PATH1 can only be found in the repository, set *IS_REPOS1 to TRUE.
- *  If PATH2 can only be found in the repository, set *IS_REPOS2 to TRUE. */ 
+ *  If PATH2 can only be found in the repository, set *IS_REPOS2 to TRUE. */
 static svn_error_t *
 check_paths(svn_boolean_t *is_repos1,
             svn_boolean_t *is_repos2,
@@ -2072,7 +2072,7 @@ set_up_diff_cmd_and_options(struct diff_
                             apr_hash_t *config, apr_pool_t *pool)
 {
   const char *diff_cmd = NULL;
- 
+
   /* See if there is a diff command and/or diff arguments. */
   if (config)
     {
@@ -2092,7 +2092,7 @@ set_up_diff_cmd_and_options(struct diff_
 
   if (options == NULL)
     options = apr_array_make(pool, 0, sizeof(const char *));
- 
+
   if (diff_cmd)
     SVN_ERR(svn_path_cstring_to_utf8(&diff_cmd_baton->diff_cmd, diff_cmd,
                                      pool));
@@ -2264,7 +2264,7 @@ svn_client_diff_peg5(const apr_array_hea
   diff_cmd_baton.orig_path_1 = path;
   diff_cmd_baton.orig_path_2 = path;
 
-  SVN_ERR(set_up_diff_cmd_and_options(&diff_cmd_baton, options, 
+  SVN_ERR(set_up_diff_cmd_and_options(&diff_cmd_baton, options,
                                       ctx->config, pool));
   diff_cmd_baton.pool = pool;
   diff_cmd_baton.outfile = outfile;

Modified: subversion/branches/diff-optimizations-bytes/subversion/libsvn_client/export.c
URL: http://svn.apache.org/viewvc/subversion/branches/diff-optimizations-bytes/subversion/libsvn_client/export.c?rev=1054012&r1=1054011&r2=1054012&view=diff
==============================================================================
--- subversion/branches/diff-optimizations-bytes/subversion/libsvn_client/export.c (original)
+++ subversion/branches/diff-optimizations-bytes/subversion/libsvn_client/export.c Thu Dec 30 22:20:48 2010
@@ -111,7 +111,7 @@ append_basename_if_dir(const char **appe
   if (local_kind == svn_node_dir)
     {
       const char *basename2; /* _2 because it shadows basename() */
-      
+
       if (is_uri)
         basename2 = svn_path_uri_decode(svn_uri_basename(basename_of, NULL), pool);
       else
@@ -161,10 +161,10 @@ copy_one_versioned_file(const char *from
       /* Only export 'added' files when the revision is WORKING. This is not
          WORKING, so skip the 'added' files, since they didn't exist
          in the BASE revision and don't have an associated text-base.
-         
+
          'replaced' files are technically the same as 'added' files.
          ### TODO: Handle replaced nodes properly.
-         ###       svn_opt_revision_base refers to the "new" 
+         ###       svn_opt_revision_base refers to the "new"
          ###       base of the node. That means, if a node is locally
          ###       replaced, export skips this node, as if it was locally
          ###       added, because svn_opt_revision_base refers to the base
@@ -268,7 +268,7 @@ copy_one_versioned_file(const char *from
           suffix = "";
         }
 
-      SVN_ERR(svn_wc__node_get_url(&url, wc_ctx, from_abspath, 
+      SVN_ERR(svn_wc__node_get_url(&url, wc_ctx, from_abspath,
                                    scratch_pool, scratch_pool));
 
       SVN_ERR(svn_subst_build_keywords2
@@ -330,7 +330,7 @@ copy_versioned_files(const char *from,
   const char *to_abspath;
   svn_node_kind_t from_kind;
   svn_depth_t node_depth;
-  
+
   SVN_ERR(svn_dirent_get_absolute(&from_abspath, from, pool));
   SVN_ERR(svn_dirent_get_absolute(&to_abspath, to, pool));
 
@@ -1042,12 +1042,12 @@ svn_client_export5(svn_revnum_t *result_
             }
           else
             {
-              SVN_ERR(append_basename_if_dir(&to_path, from_path_or_url, 
+              SVN_ERR(append_basename_if_dir(&to_path, from_path_or_url,
                                              TRUE, pool));
               eb->root_path = to_path;
             }
 
-          
+
           /* Since you cannot actually root an editor at a file, we
            * manually drive a few functions of our editor. */
 

Modified: subversion/branches/diff-optimizations-bytes/subversion/libsvn_client/externals.c
URL: http://svn.apache.org/viewvc/subversion/branches/diff-optimizations-bytes/subversion/libsvn_client/externals.c?rev=1054012&r1=1054011&r2=1054012&view=diff
==============================================================================
--- subversion/branches/diff-optimizations-bytes/subversion/libsvn_client/externals.c (original)
+++ subversion/branches/diff-optimizations-bytes/subversion/libsvn_client/externals.c Thu Dec 30 22:20:48 2010
@@ -279,7 +279,7 @@ switch_dir_external(const char *path,
       /* Buh-bye, old and busted ... */
       SVN_ERR(svn_wc__acquire_write_lock(NULL, ctx->wc_ctx, local_abspath,
                                          FALSE, pool, pool));
-      
+
       SVN_ERR(relegate_dir_external(&baton, pool, pool));
     }
   else
@@ -858,7 +858,7 @@ handle_external_item_change(const void *
             SVN_ERR(svn_client_export4(NULL, new_item->url, local_abspath,
                                        &(new_item->peg_revision),
                                        &(new_item->revision),
-                                       TRUE, FALSE, svn_depth_infinity, 
+                                       TRUE, FALSE, svn_depth_infinity,
                                        ib->native_eol,
                                        ib->ctx, ib->iter_pool));
           else

Modified: subversion/branches/diff-optimizations-bytes/subversion/libsvn_client/log.c
URL: http://svn.apache.org/viewvc/subversion/branches/diff-optimizations-bytes/subversion/libsvn_client/log.c?rev=1054012&r1=1054011&r2=1054012&view=diff
==============================================================================
--- subversion/branches/diff-optimizations-bytes/subversion/libsvn_client/log.c (original)
+++ subversion/branches/diff-optimizations-bytes/subversion/libsvn_client/log.c Thu Dec 30 22:20:48 2010
@@ -45,7 +45,7 @@
 /*** Getting misc. information ***/
 
 /* The baton for use with copyfrom_info_receiver(). */
-typedef struct
+typedef struct copyfrom_info_t
 {
   svn_boolean_t is_first;
   const char *path;
@@ -148,7 +148,7 @@ svn_client__get_copy_source(const char *
 
 /* compatibility with pre-1.5 servers, which send only author/date/log
  *revprops in log entries */
-typedef struct
+typedef struct pre_15_receiver_baton_t
 {
   svn_client_ctx_t *ctx;
   /* ra session for retrieving revprops from old servers */
@@ -244,7 +244,7 @@ pre_15_receiver(void *baton, svn_log_ent
 }
 
 /* limit receiver */
-typedef struct
+typedef struct limit_receiver_baton_t
 {
   int limit;
   svn_log_entry_receiver_t receiver;

Modified: subversion/branches/diff-optimizations-bytes/subversion/libsvn_client/merge.c
URL: http://svn.apache.org/viewvc/subversion/branches/diff-optimizations-bytes/subversion/libsvn_client/merge.c?rev=1054012&r1=1054011&r2=1054012&view=diff
==============================================================================
--- subversion/branches/diff-optimizations-bytes/subversion/libsvn_client/merge.c (original)
+++ subversion/branches/diff-optimizations-bytes/subversion/libsvn_client/merge.c Thu Dec 30 22:20:48 2010
@@ -1213,7 +1213,7 @@ merge_props_changed(const char *local_di
 }
 
 /* Contains any state collected while resolving conflicts. */
-typedef struct
+typedef struct conflict_resolver_baton_t
 {
   /* The wrapped callback and baton. */
   svn_wc_conflict_resolver_func_t wrapped_func;
@@ -1759,7 +1759,7 @@ merge_file_added(const char *local_dir_a
           SVN_ERR(svn_wc_read_kind(&wc_kind, merge_b->ctx->wc_ctx,
                                    mine_abspath, FALSE, subpool));
 
-          if ((wc_kind != svn_node_none) 
+          if ((wc_kind != svn_node_none)
               && dry_run_deleted_p(merge_b, mine_abspath))
             *content_state = svn_wc_notify_state_changed;
           else
@@ -2492,7 +2492,7 @@ merge_dir_opened(const char *local_dir_a
       svn_pool_destroy(subpool);
       return SVN_NO_ERROR;
     }
-   
+
   /* Find out if this path is deleted. */
   err = svn_wc__node_is_status_deleted(&is_deleted, merge_b->ctx->wc_ctx,
                                        local_abspath, subpool);
@@ -2591,7 +2591,7 @@ merge_callbacks =
 
 
 /* Contains any state collected while receiving path notifications. */
-typedef struct
+typedef struct notification_receiver_baton_t
 {
   /* The wrapped callback and baton. */
   svn_wc_notify_func2_t wrapped_func;
@@ -3335,7 +3335,7 @@ get_invalid_inherited_mergeinfo(svn_merg
   svn_revnum_t base_revision;
   svn_boolean_t validate_inherited_mergeinfo;
 
-  /* Our starting assumptions. */ 
+  /* Our starting assumptions. */
   *invalid_inherited_mergeinfo = NULL;
   *validated = TRUE;
 
@@ -3546,7 +3546,7 @@ get_full_mergeinfo(svn_mergeinfo_t *reco
           /* Return RA_SESSION back to where it was when we were called. */
          SVN_ERR(svn_client__ensure_ra_session_url(&session_url,
                                                    ra_session, session_url,
-                                                   scratch_pool)); 
+                                                   scratch_pool));
         }
     } /*if (implicit_mergeinfo) */
 
@@ -4321,7 +4321,7 @@ populate_remaining_ranges(apr_array_head
                  CHILDREN_WITH_MERGEINFO, see the global comment
                  'THE CHILDREN_WITH_MERGEINFO ARRAY'. */
               SVN_ERR_ASSERT(parent);
- 
+
               child_inherits_implicit = (parent && !child->switched);
               SVN_ERR(ensure_implicit_mergeinfo(parent, child,
                                                 child_inherits_implicit,
@@ -5495,7 +5495,7 @@ record_missing_subtree_roots(const char 
   if (kind == svn_node_dir)
     {
       /* If SUBTREE_DIRENTS is empty LOCAL_ABSPATH is merge target. */
-      if (apr_hash_count(subtree_dirents) == 0 
+      if (apr_hash_count(subtree_dirents) == 0
           || apr_hash_get(subtree_dirents,
                           svn_dirent_dirname(local_abspath,
                                              scratch_pool),
@@ -5525,7 +5525,7 @@ record_missing_subtree_roots(const char 
               apr_hash_set(subtree_dirents,
                            apr_pstrdup(result_pool, local_abspath),
                            APR_HASH_KEY_STRING, dirents);
-            }      
+            }
         }
     }
   else /* kind != svn_node_dir */
@@ -8256,9 +8256,9 @@ do_directory_merge(svn_mergeinfo_catalog
          NOTIFY_B->CHILDREN_WITH_MERGEINFO to find the oldest starting
          revision that actually needs to be merged (for reverse merges this is
          the youngest starting revision).
-         
+
          We'll do this twice, right now for the start of the mergeinfo we will
-         ultimately record to describe this merge and then later for the 
+         ultimately record to describe this merge and then later for the
          start of the actual editor drive. */
       new_range_start = get_most_inclusive_start_rev(
         notify_b->children_with_mergeinfo, is_rollback);
@@ -8934,7 +8934,7 @@ merge_cousins_and_supplement_mergeinfo(c
      calculated.  (We know that each tong in our fork of our merge
      source history tree has an ancestral relationship with the common
      ancestral, so we force ancestral=TRUE here.)
-     
+
      Issue #3648: We don't actually perform these two record-only merges
      on the WC at first, but rather see what each would do and store that
      in two mergeinfo catalogs.  We then merge the catalogs together and
@@ -10256,7 +10256,7 @@ calculate_left_hand_side(const char **ur
 
       youngest_rev.kind = svn_opt_revision_number;
       youngest_rev.value.number = youngest_merged_rev;
-      
+
       unspecified_rev.kind = svn_opt_revision_unspecified;
 
       *rev_left = youngest_rev.value.number;
@@ -10634,7 +10634,7 @@ merge_peg_locked(const char *source,
   svn_node_kind_t target_kind;
 
   SVN_ERR_ASSERT(svn_dirent_is_absolute(target_abspath));
-  
+
   /* Make sure the target is really there. */
   SVN_ERR(svn_io_check_path(target_abspath, &target_kind, scratch_pool));
   if (target_kind == svn_node_none)

Modified: subversion/branches/diff-optimizations-bytes/subversion/libsvn_client/patch.c
URL: http://svn.apache.org/viewvc/subversion/branches/diff-optimizations-bytes/subversion/libsvn_client/patch.c?rev=1054012&r1=1054011&r2=1054012&view=diff
==============================================================================
--- subversion/branches/diff-optimizations-bytes/subversion/libsvn_client/patch.c (original)
+++ subversion/branches/diff-optimizations-bytes/subversion/libsvn_client/patch.c Thu Dec 30 22:20:48 2010
@@ -124,7 +124,7 @@ typedef struct prop_patch_target_t {
   const char *patched_path;
 
   /* Represents the operation performed on the property. It can be added,
-   * deleted or modified. 
+   * deleted or modified.
    * ### Should we use flags instead since we're not using all enum values? */
   svn_diff_operation_kind_t operation;
 
@@ -476,7 +476,7 @@ init_prop_target(prop_patch_target_t **p
                  apr_pool_t *result_pool, apr_pool_t *scratch_pool)
 {
   prop_patch_target_t *new_prop_target;
-  target_content_info_t *content_info; 
+  target_content_info_t *content_info;
   const svn_string_t *value;
   const char *patched_path;
   svn_error_t *err;
@@ -498,7 +498,7 @@ init_prop_target(prop_patch_target_t **p
   new_prop_target->operation = operation;
   new_prop_target->content_info = content_info;
 
-  err = svn_wc_prop_get2(&value, wc_ctx, local_abspath, prop_name, 
+  err = svn_wc_prop_get2(&value, wc_ctx, local_abspath, prop_name,
                          result_pool, scratch_pool);
   if (err)
     {
@@ -579,7 +579,7 @@ init_patch_target(patch_target_t **patch
                   apr_pool_t *result_pool, apr_pool_t *scratch_pool)
 {
   patch_target_t *target;
-  target_content_info_t *content_info; 
+  target_content_info_t *content_info;
   svn_boolean_t has_prop_changes = FALSE;
   svn_boolean_t prop_changes_only = FALSE;
 
@@ -590,7 +590,7 @@ init_patch_target(patch_target_t **patch
          hi;
          hi = apr_hash_next(hi))
       {
-        svn_prop_patch_t *prop_patch = svn__apr_hash_index_val(hi); 
+        svn_prop_patch_t *prop_patch = svn__apr_hash_index_val(hi);
         if (! has_prop_changes)
           has_prop_changes = prop_patch->hunks->nelts > 0;
         else
@@ -661,7 +661,7 @@ init_patch_target(patch_target_t **patch
        * ### the target supposed to be marked with an operation after we have
        * ### determined that the changes will apply cleanly to the WC? Maybe
        * ### we should have kept the patch field in patch_target_t to be
-       * ### able to distinguish between 'what the patch says we should do' 
+       * ### able to distinguish between 'what the patch says we should do'
        * ### and 'what we can do with the given state of our WC'. */
       if (patch->operation == svn_diff_op_added)
         target->added = TRUE;
@@ -677,7 +677,7 @@ init_patch_target(patch_target_t **patch
 
       /* We always expand keywords in the patched file, but repair newlines
        * only if svn:eol-style dictates a particular style. */
-      repair_eol = (content_info->eol_style == svn_subst_eol_style_fixed 
+      repair_eol = (content_info->eol_style == svn_subst_eol_style_fixed
                     || content_info->eol_style == svn_subst_eol_style_native);
       content_info->patched = svn_subst_stream_translated(
                               patched_raw, content_info->eol_str, repair_eol,
@@ -828,7 +828,7 @@ seek_to_line(target_content_info_t *cont
  * CONTENT_INFO at its current line. Lines within FUZZ lines of the start or
  * end of HUNK will always match. If IGNORE_WHITESPACE is set, we ignore
  * whitespace when doing the matching. When this function returns, neither
- * CONTENT_INFO->CURRENT_LINE nor the file offset in the target file will 
+ * CONTENT_INFO->CURRENT_LINE nor the file offset in the target file will
  * have changed. If MATCH_MODIFIED is TRUE, match the modified hunk text,
  * rather than the original hunk text.
  * Do temporary allocations in POOL. */
@@ -948,10 +948,10 @@ match_hunk(svn_boolean_t *matched, targe
  * Call cancel CANCEL_FUNC with baton CANCEL_BATON to trigger cancellation.
  * Do all allocations in POOL. */
 static svn_error_t *
-scan_for_match(svn_linenum_t *matched_line, 
+scan_for_match(svn_linenum_t *matched_line,
                target_content_info_t *content_info,
                const svn_diff_hunk_t *hunk, svn_boolean_t match_first,
-               svn_linenum_t upper_line, int fuzz, 
+               svn_linenum_t upper_line, int fuzz,
                svn_boolean_t ignore_whitespace,
                svn_boolean_t match_modified,
                svn_cancel_func_t cancel_func, void *cancel_baton,
@@ -1050,7 +1050,7 @@ match_existing_target(svn_boolean_t *mat
                                                    iterpool, iterpool));
       /* Contract keywords. */
       SVN_ERR(svn_subst_translate_cstring2(line->data, &line_translated,
-                                           NULL, FALSE, 
+                                           NULL, FALSE,
                                            content_info->keywords,
                                            FALSE, iterpool));
       SVN_ERR(svn_subst_translate_cstring2(hunk_line->data,
@@ -1139,7 +1139,7 @@ get_hunk_info(hunk_info_t **hi, patch_ta
       else
         matched_line = 1;
     }
-  /* Same conditions apply as for the file case above. 
+  /* Same conditions apply as for the file case above.
    *
    * ### Since the hunk says the prop should be added we just assume so for
    * ### now and don't bother with storing the previous lines and such. When
@@ -1276,7 +1276,7 @@ copy_lines_to_target(target_content_info
   apr_pool_t *iterpool;
 
   iterpool = svn_pool_create(pool);
-  while ((content_info->current_line < line || line == 0) 
+  while ((content_info->current_line < line || line == 0)
          && ! content_info->eof)
     {
       const char *target_line;
@@ -1300,7 +1300,7 @@ copy_lines_to_target(target_content_info
  * and mark TARGET as having had rejects.
  * Do temporary allocations in POOL. */
 static svn_error_t *
-reject_hunk(patch_target_t *target, target_content_info_t *content_info, 
+reject_hunk(patch_target_t *target, target_content_info_t *content_info,
             const svn_diff_hunk_t *hunk, const char *prop_name,
             apr_pool_t *pool)
 {
@@ -1312,7 +1312,7 @@ reject_hunk(patch_target_t *target, targ
   if (prop_name)
     {
       const char *prop_header;
-        
+
       /* ### Print 'Added', 'Deleted' or 'Modified' instead of 'Property'.
        */
       prop_header = apr_psprintf(pool, "Property: %s\n", prop_name);
@@ -1382,7 +1382,7 @@ reject_hunk(patch_target_t *target, targ
  * a property with the given name.
  * Do temporary allocations in POOL. */
 static svn_error_t *
-apply_hunk(patch_target_t *target, target_content_info_t *content_info,  
+apply_hunk(patch_target_t *target, target_content_info_t *content_info,
            hunk_info_t *hi, const char *prop_name, apr_pool_t *pool)
 {
   svn_linenum_t lines_read;
@@ -1472,9 +1472,9 @@ apply_hunk(patch_target_t *target, targe
  * PROP_NAME must be the name of the property, else NULL.
  * Use POOL for temporary allocations. */
 static svn_error_t *
-send_hunk_notification(const hunk_info_t *hi, 
-                       const patch_target_t *target, 
-                       const char *prop_name, 
+send_hunk_notification(const hunk_info_t *hi,
+                       const patch_target_t *target,
+                       const char *prop_name,
                        const svn_client_ctx_t *ctx,
                        apr_pool_t *pool)
 {
@@ -1578,7 +1578,7 @@ send_patch_notification(const patch_targ
 
           hi = APR_ARRAY_IDX(target->content_info->hunks, i, hunk_info_t *);
 
-          SVN_ERR(send_hunk_notification(hi, target, NULL /* prop_name */, 
+          SVN_ERR(send_hunk_notification(hi, target, NULL /* prop_name */,
                                          ctx, iterpool));
         }
 
@@ -1586,8 +1586,8 @@ send_patch_notification(const patch_targ
            hash_index;
            hash_index = apr_hash_next(hash_index))
         {
-          prop_patch_target_t *prop_target; 
-          
+          prop_patch_target_t *prop_target;
+
           prop_target = svn__apr_hash_index_val(hash_index);
 
           for (i = 0; i < prop_target->content_info->hunks->nelts; i++)
@@ -1602,7 +1602,7 @@ send_patch_notification(const patch_targ
               /* Don't notify on the hunk level for added or deleted props. */
               if (prop_target->operation != svn_diff_op_added &&
                   prop_target->operation != svn_diff_op_deleted)
-                SVN_ERR(send_hunk_notification(hi, target, prop_target->name, 
+                SVN_ERR(send_hunk_notification(hi, target, prop_target->name,
                                                ctx, iterpool));
             }
         }
@@ -1706,7 +1706,7 @@ apply_one_patch(patch_target_t **patch_t
         continue;
       else if (hi->rejected)
         SVN_ERR(reject_hunk(target, target->content_info, hi->hunk,
-                            NULL /* prop_name */, 
+                            NULL /* prop_name */,
                             iterpool));
       else
         SVN_ERR(apply_hunk(target, target->content_info, hi,
@@ -1735,7 +1735,7 @@ apply_one_patch(patch_target_t **patch_t
       svn_prop_patch_t *prop_patch;
       const char *prop_name;
       prop_patch_target_t *prop_target;
-        
+
       prop_name = svn__apr_hash_index_key(hash_index);
       prop_patch = svn__apr_hash_index_val(hash_index);
 
@@ -1743,7 +1743,7 @@ apply_one_patch(patch_target_t **patch_t
         target->is_special = TRUE;
 
       /* We'll store matched hunks in prop_content_info. */
-      prop_target = apr_hash_get(target->prop_targets, prop_name, 
+      prop_target = apr_hash_get(target->prop_targets, prop_name,
                                  APR_HASH_KEY_STRING);
 
       for (i = 0; i < prop_patch->hunks->nelts; i++)
@@ -1763,7 +1763,7 @@ apply_one_patch(patch_target_t **patch_t
            * If no match is found initially, try with fuzz. */
           do
             {
-              SVN_ERR(get_hunk_info(&hi, target, prop_target->content_info, 
+              SVN_ERR(get_hunk_info(&hi, target, prop_target->content_info,
                                     hunk, fuzz,
                                     ignore_whitespace,
                                     TRUE /* is_prop_hunk */,
@@ -1792,7 +1792,7 @@ apply_one_patch(patch_target_t **patch_t
 
           svn_pool_clear(iterpool);
 
-          hi = APR_ARRAY_IDX(prop_target->content_info->hunks, i, 
+          hi = APR_ARRAY_IDX(prop_target->content_info->hunks, i,
                              hunk_info_t *);
           if (hi->already_applied)
             continue;
@@ -1801,7 +1801,7 @@ apply_one_patch(patch_target_t **patch_t
                                 prop_target->name,
                                 iterpool));
           else
-            SVN_ERR(apply_hunk(target, prop_target->content_info, hi, 
+            SVN_ERR(apply_hunk(target, prop_target->content_info, hi,
                                prop_target->name,
                                iterpool));
         }
@@ -1810,7 +1810,7 @@ apply_one_patch(patch_target_t **patch_t
           {
             /* Copy any remaining lines to target. */
             SVN_ERR(copy_lines_to_target(prop_target->content_info, 0,
-                                         prop_target->patched_path, 
+                                         prop_target->patched_path,
                                          scratch_pool));
             if (! prop_target->content_info->eof)
               {
@@ -1883,7 +1883,7 @@ apply_one_patch(patch_target_t **patch_t
            * Report this as skipped if it didn't exist, unless in the special
            * case of adding an empty file which has properties set on it or
            * adding an empty file with a 'git diff' */
-          if (target->kind_on_disk == svn_node_none 
+          if (target->kind_on_disk == svn_node_none
               && ! target->has_prop_changes
               && ! target->added)
             target->skipped = TRUE;
@@ -2093,7 +2093,7 @@ install_patched_target(patch_target_t *t
             {
               const char *parent_abspath;
               svn_boolean_t is_deleted;
-              
+
               parent_abspath = svn_dirent_dirname(target->local_abspath,
                                                   pool);
               SVN_ERR(svn_wc__node_is_status_deleted(&is_deleted, ctx->wc_ctx,
@@ -2123,11 +2123,11 @@ install_patched_target(patch_target_t *t
 
               patched_stream = svn_stream_from_aprfile2(file, FALSE /* disown */,
                                                 pool);
-              SVN_ERR(svn_subst_create_specialfile(&stream, 
+              SVN_ERR(svn_subst_create_specialfile(&stream,
                                                    target->local_abspath,
                                                    pool, pool));
-              SVN_ERR(svn_stream_copy3(patched_stream, stream, 
-                                       NULL, /* cancel_func */ 
+              SVN_ERR(svn_stream_copy3(patched_stream, stream,
+                                       NULL, /* cancel_func */
                                        NULL, /* cancel_baton */
                                        pool));
             }
@@ -2160,7 +2160,7 @@ install_patched_target(patch_target_t *t
 }
 
 /* Write out rejected hunks, if any, to TARGET->REJECT_PATH. If DRY_RUN is
- * TRUE, don't modify the working copy.  
+ * TRUE, don't modify the working copy.
  * Do temporary allocations in POOL.
  */
 static svn_error_t *
@@ -2199,7 +2199,7 @@ install_patched_prop_targets(patch_targe
        hi;
        hi = apr_hash_next(hi))
     {
-      prop_patch_target_t *prop_target = svn__apr_hash_index_val(hi); 
+      prop_patch_target_t *prop_target = svn__apr_hash_index_val(hi);
       apr_file_t *file;
       svn_stream_t *patched_stream;
       svn_stringbuf_t *line;
@@ -2216,7 +2216,7 @@ install_patched_prop_targets(patch_targe
         {
           if (! dry_run)
             SVN_ERR(svn_wc_prop_set4(ctx->wc_ctx, target->local_abspath,
-                                     prop_target->name, NULL, 
+                                     prop_target->name, NULL,
                                      TRUE /* skip_checks */,
                                      NULL, NULL, /* suppress notification */
                                      iterpool));
@@ -2259,7 +2259,7 @@ install_patched_prop_targets(patch_targe
        *
        * ### How can we tell whether the patch really wanted to create
        * ### an empty directory? */
-      if (! target->has_text_changes 
+      if (! target->has_text_changes
           && target->kind_on_disk == svn_node_none
           && ! target->added)
         {
@@ -2358,7 +2358,7 @@ find_existing_children(void *baton,
       && status->node_status != svn_wc_status_deleted
       && strcmp(abspath, btn->parent_path))
     {
-      APR_ARRAY_PUSH(btn->existing_targets, 
+      APR_ARRAY_PUSH(btn->existing_targets,
                      const char *) = apr_pstrdup(btn->result_pool,
                                                  abspath);
     }
@@ -2373,7 +2373,7 @@ find_existing_children(void *baton,
  * Do temporary allocations in SCRATCH_POOL. */
 static svn_error_t *
 check_dir_empty(svn_boolean_t *empty, const char *local_abspath,
-                svn_wc_context_t *wc_ctx, 
+                svn_wc_context_t *wc_ctx,
                 apr_array_header_t *deleted_targets,
                 apr_array_header_t *deleted_abspath_list,
                 apr_pool_t *scratch_pool)
@@ -2392,7 +2392,7 @@ check_dir_empty(svn_boolean_t *empty, co
     }
 
   /* Find existing children of the directory. */
-  btn.existing_targets = apr_array_make(scratch_pool, 0, 
+  btn.existing_targets = apr_array_make(scratch_pool, 0,
                                         sizeof(patch_target_t *));
   btn.parent_path = local_abspath;
   btn.result_pool = scratch_pool;
@@ -2603,7 +2603,7 @@ delete_empty_dirs(apr_array_header_t *ta
 }
 
 /* Baton for apply_patches(). */
-typedef struct {
+typedef struct apply_patches_baton_t {
   /* The path to the patch file. */
   const char *patch_abspath;
 
@@ -2690,15 +2690,15 @@ apply_patches(void *baton,
 
               if (! target->skipped)
                 {
-                  if (target->has_text_changes 
-                      || target->added 
+                  if (target->has_text_changes
+                      || target->added
                       || target->deleted)
                     SVN_ERR(install_patched_target(target, btn->abs_wc_path,
                                                    btn->ctx, btn->dry_run,
                                                    iterpool));
 
                   if (target->has_prop_changes)
-                    SVN_ERR(install_patched_prop_targets(target, btn->ctx, 
+                    SVN_ERR(install_patched_prop_targets(target, btn->ctx,
                                                          btn->dry_run,
                                                          iterpool));
 

Modified: subversion/branches/diff-optimizations-bytes/subversion/libsvn_client/prop_commands.c
URL: http://svn.apache.org/viewvc/subversion/branches/diff-optimizations-bytes/subversion/libsvn_client/prop_commands.c?rev=1054012&r1=1054011&r2=1054012&view=diff
==============================================================================
--- subversion/branches/diff-optimizations-bytes/subversion/libsvn_client/prop_commands.c (original)
+++ subversion/branches/diff-optimizations-bytes/subversion/libsvn_client/prop_commands.c Thu Dec 30 22:20:48 2010
@@ -492,7 +492,7 @@ check_and_set_revprop(svn_revnum_t *set_
         }
     }
 
-  SVN_ERR(svn_ra_change_rev_prop2(ra_session, *set_rev, propname, 
+  SVN_ERR(svn_ra_change_rev_prop2(ra_session, *set_rev, propname,
                                   NULL, propval, pool));
 
   return SVN_NO_ERROR;
@@ -550,7 +550,7 @@ svn_client_revprop_set2(const char *prop
       	old_value_p = &original_propval;
 
       /* The actual RA call. */
-      SVN_ERR(svn_ra_change_rev_prop2(ra_session, *set_rev, propname, 
+      SVN_ERR(svn_ra_change_rev_prop2(ra_session, *set_rev, propname,
                                       old_value_p, propval, pool));
     }
   else

Modified: subversion/branches/diff-optimizations-bytes/subversion/libsvn_client/ra.c
URL: http://svn.apache.org/viewvc/subversion/branches/diff-optimizations-bytes/subversion/libsvn_client/ra.c?rev=1054012&r1=1054011&r2=1054012&view=diff
==============================================================================
--- subversion/branches/diff-optimizations-bytes/subversion/libsvn_client/ra.c (original)
+++ subversion/branches/diff-optimizations-bytes/subversion/libsvn_client/ra.c Thu Dec 30 22:20:48 2010
@@ -44,7 +44,7 @@
 
 /* This is the baton that we pass svn_ra_open3(), and is associated with
    the callback table we provide to RA. */
-typedef struct
+typedef struct callback_baton_t
 {
   /* Holds the directory that corresponds to the REPOS_URL at svn_ra_open3()
      time. When callbacks specify a relative path, they are joined with
@@ -364,8 +364,8 @@ svn_client__open_ra_session_internal(svn
           /* Notify the user that a redirect is being followed. */
           if (ctx->notify_func2 != NULL)
             {
-              svn_wc_notify_t *notify = 
-                svn_wc_create_notify_url(corrected, 
+              svn_wc_notify_t *notify =
+                svn_wc_create_notify_url(corrected,
                                          svn_wc_notify_url_redirect, pool);
               (*ctx->notify_func2)(ctx->notify_baton2, notify, pool);
             }

Modified: subversion/branches/diff-optimizations-bytes/subversion/libsvn_client/relocate.c
URL: http://svn.apache.org/viewvc/subversion/branches/diff-optimizations-bytes/subversion/libsvn_client/relocate.c?rev=1054012&r1=1054011&r2=1054012&view=diff
==============================================================================
--- subversion/branches/diff-optimizations-bytes/subversion/libsvn_client/relocate.c (original)
+++ subversion/branches/diff-optimizations-bytes/subversion/libsvn_client/relocate.c Thu Dec 30 22:20:48 2010
@@ -157,7 +157,7 @@ relocate_externals(const char *local_abs
         APR_ARRAY_IDX(ext_desc, i, svn_wc_external_item2_t *);
       const char *target_repos_root_url;
       const char *target_abspath;
-      
+
       svn_pool_clear(iterpool);
 
       /* If this external isn't pulled in via a relative URL, ignore
@@ -270,7 +270,7 @@ svn_client_relocate2(const char *wcroot_
         SVN_ERR(relocate_externals(this_abspath, ext_desc, old_repos_root_url,
                                    new_repos_root_url, ctx, iterpool));
     }
-    
+
   svn_pool_destroy(iterpool);
 
   return SVN_NO_ERROR;

Modified: subversion/branches/diff-optimizations-bytes/subversion/libsvn_client/repos_diff.c
URL: http://svn.apache.org/viewvc/subversion/branches/diff-optimizations-bytes/subversion/libsvn_client/repos_diff.c?rev=1054012&r1=1054011&r2=1054012&view=diff
==============================================================================
--- subversion/branches/diff-optimizations-bytes/subversion/libsvn_client/repos_diff.c (original)
+++ subversion/branches/diff-optimizations-bytes/subversion/libsvn_client/repos_diff.c Thu Dec 30 22:20:48 2010
@@ -489,7 +489,7 @@ diff_deleted_dir(const char *dir,
                           revision,
                           SVN_DIRENT_KIND,
                           pool));
-  
+
   for (hi = apr_hash_first(pool, dirents); hi;
        hi = apr_hash_next(hi))
     {
@@ -511,7 +511,7 @@ diff_deleted_dir(const char *dir,
           SVN_ERR(get_file_from_ra(b, revision));
 
           SVN_ERR(get_empty_file(b->edit_baton, &(b->path_end_revision)));
-      
+
           get_file_mime_types(&mimetype1, &mimetype2, b);
 
           SVN_ERR(eb->diff_callbacks->file_deleted(
@@ -523,7 +523,7 @@ diff_deleted_dir(const char *dir,
                                 b->edit_baton->diff_cmd_baton,
                                 iterpool));
         }
- 
+
       if (dirent->kind == svn_node_dir)
         SVN_ERR(diff_deleted_dir(path,
                                  revision,
@@ -595,7 +595,7 @@ delete_entry(const char *path,
                     (local_dir_abspath, &state, &tree_conflicted,
                      svn_dirent_join(eb->target, path, pool),
                      eb->diff_cmd_baton, pool));
- 
+
             if (eb->walk_deleted_repos_dirs)
               {
                 /* A workaround for issue 2333.  The "old" dir will be

Modified: subversion/branches/diff-optimizations-bytes/subversion/libsvn_client/repos_diff_summarize.c
URL: http://svn.apache.org/viewvc/subversion/branches/diff-optimizations-bytes/subversion/libsvn_client/repos_diff_summarize.c?rev=1054012&r1=1054011&r2=1054012&view=diff
==============================================================================
--- subversion/branches/diff-optimizations-bytes/subversion/libsvn_client/repos_diff_summarize.c (original)
+++ subversion/branches/diff-optimizations-bytes/subversion/libsvn_client/repos_diff_summarize.c Thu Dec 30 22:20:48 2010
@@ -176,7 +176,7 @@ diff_deleted_dir(const char *dir,
                           revision,
                           SVN_DIRENT_KIND,
                           pool));
-  
+
   for (hi = apr_hash_first(pool, dirents); hi;
        hi = apr_hash_next(hi))
     {

Modified: subversion/branches/diff-optimizations-bytes/subversion/libsvn_client/revert.c
URL: http://svn.apache.org/viewvc/subversion/branches/diff-optimizations-bytes/subversion/libsvn_client/revert.c?rev=1054012&r1=1054011&r2=1054012&view=diff
==============================================================================
--- subversion/branches/diff-optimizations-bytes/subversion/libsvn_client/revert.c (original)
+++ subversion/branches/diff-optimizations-bytes/subversion/libsvn_client/revert.c Thu Dec 30 22:20:48 2010
@@ -133,7 +133,7 @@ svn_client_revert2(const apr_array_heade
         return svn_error_createf(SVN_ERR_ILLEGAL_TARGET, NULL,
                                  _("'%s' is not a local path"), path);
     }
-  
+
   cfg = ctx->config ? apr_hash_get(ctx->config, SVN_CONFIG_CATEGORY_CONFIG,
                                    APR_HASH_KEY_STRING) : NULL;
 

Modified: subversion/branches/diff-optimizations-bytes/subversion/libsvn_client/update.c
URL: http://svn.apache.org/viewvc/subversion/branches/diff-optimizations-bytes/subversion/libsvn_client/update.c?rev=1054012&r1=1054011&r2=1054012&view=diff
==============================================================================
--- subversion/branches/diff-optimizations-bytes/subversion/libsvn_client/update.c (original)
+++ subversion/branches/diff-optimizations-bytes/subversion/libsvn_client/update.c Thu Dec 30 22:20:48 2010
@@ -307,7 +307,7 @@ svn_client__update_internal(svn_revnum_t
     {
       int i;
       const char *parent_abspath = local_abspath;
-      apr_array_header_t *missing_parents = 
+      apr_array_header_t *missing_parents =
         apr_array_make(pool, 4, sizeof(const char *));
 
       while (1)

Modified: subversion/branches/diff-optimizations-bytes/subversion/libsvn_delta/compose_delta.c
URL: http://svn.apache.org/viewvc/subversion/branches/diff-optimizations-bytes/subversion/libsvn_delta/compose_delta.c?rev=1054012&r1=1054011&r2=1054012&view=diff
==============================================================================
--- subversion/branches/diff-optimizations-bytes/subversion/libsvn_delta/compose_delta.c (original)
+++ subversion/branches/diff-optimizations-bytes/subversion/libsvn_delta/compose_delta.c Thu Dec 30 22:20:48 2010
@@ -160,7 +160,7 @@ create_offset_index(const svn_txdelta_wi
 }
 
 /* Find the index of the delta op thet defines that data at OFFSET in
-   NDX. HINT is an arbitrary positin within NDX and doesn't even need 
+   NDX. HINT is an arbitrary positin within NDX and doesn't even need
    to be valid. To effectively speed up the search, use the last result
    as hint because most lookups come as a sequence of decreasing values
    for OFFSET and they concentrate on the lower end of the array. */
@@ -198,7 +198,7 @@ search_offset_index(const offset_index_t
     {
       if (offset < ndx->offs[op])
         hi = op;
-      else 
+      else
         lo = ++op;
     }
 
@@ -630,12 +630,12 @@ build_range_list(apr_size_t offset, apr_
 /* Copy the instructions from WINDOW that define the range [OFFSET,
    LIMIT) in WINDOW's target stream to TARGET_OFFSET in the window
    represented by BUILD_BATON. HINT is a position in the instructions
-   array that helps finding the position for OFFSET. A safe default 
-   is 0. Use NDX to find the instructions in WINDOW. Allocate space 
+   array that helps finding the position for OFFSET. A safe default
+   is 0. Use NDX to find the instructions in WINDOW. Allocate space
    in BUILD_BATON from POOL. */
 
 static void
-copy_source_ops(apr_size_t offset, apr_size_t limit,  
+copy_source_ops(apr_size_t offset, apr_size_t limit,
                 apr_size_t target_offset,
                 apr_size_t hint,
                 svn_txdelta__ops_baton_t *build_baton,

Modified: subversion/branches/diff-optimizations-bytes/subversion/libsvn_diff/diff_file.c
URL: http://svn.apache.org/viewvc/subversion/branches/diff-optimizations-bytes/subversion/libsvn_diff/diff_file.c?rev=1054012&r1=1054011&r2=1054012&view=diff
==============================================================================
--- subversion/branches/diff-optimizations-bytes/subversion/libsvn_diff/diff_file.c (original)
+++ subversion/branches/diff-optimizations-bytes/subversion/libsvn_diff/diff_file.c Thu Dec 30 22:20:48 2010
@@ -1707,7 +1707,7 @@ svn_diff_file_output_unified3(svn_stream
 /* A stream to remember *leading* context.  Note that this stream does
    *not* copy the data that it is remembering; it just saves
    *pointers! */
-typedef struct {
+typedef struct context_saver_t {
   svn_stream_t *stream;
   const char *data[SVN_DIFF__UNIFIED_CONTEXT_SIZE];
   apr_size_t len[SVN_DIFF__UNIFIED_CONTEXT_SIZE];

Modified: subversion/branches/diff-optimizations-bytes/subversion/libsvn_diff/diff_memory.c
URL: http://svn.apache.org/viewvc/subversion/branches/diff-optimizations-bytes/subversion/libsvn_diff/diff_memory.c?rev=1054012&r1=1054011&r2=1054012&view=diff
==============================================================================
--- subversion/branches/diff-optimizations-bytes/subversion/libsvn_diff/diff_memory.c (original)
+++ subversion/branches/diff-optimizations-bytes/subversion/libsvn_diff/diff_memory.c Thu Dec 30 22:20:48 2010
@@ -656,7 +656,7 @@ svn_diff_mem_string_output_unified(svn_s
 /* A stream to remember *leading* context.  Note that this stream does
    *not* copy the data that it is remembering; it just saves
    *pointers! */
-typedef struct {
+typedef struct context_saver_t {
   svn_stream_t *stream;
   const char *data[SVN_DIFF__UNIFIED_CONTEXT_SIZE];
   apr_size_t len[SVN_DIFF__UNIFIED_CONTEXT_SIZE];