You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@subversion.apache.org by bl...@apache.org on 2012/11/04 12:36:06 UTC

svn commit: r1405529 - in /subversion/trunk/subversion/bindings/javahl/native: JNICriticalSection.cpp JNIMutex.cpp JNIThreadData.cpp JNIUtil.cpp Revision.cpp SVNRepos.cpp Targets.cpp

Author: blair
Date: Sun Nov  4 11:36:06 2012
New Revision: 1405529

URL: http://svn.apache.org/viewvc?rev=1405529&view=rev
Log:
Remove space before function call open parenthesis.

* subversion/bindings/javahl/native/JNICriticalSection.cpp,
* subversion/bindings/javahl/native/JNIMutex.cpp,
* subversion/bindings/javahl/native/JNIThreadData.cpp,
* subversion/bindings/javahl/native/JNIUtil.cpp,
* subversion/bindings/javahl/native/Revision.cpp,
* subversion/bindings/javahl/native/SVNRepos.cpp,
* subversion/bindings/javahl/native/Targets.cpp:
  Remove space before function call open parenthesis.

Modified:
    subversion/trunk/subversion/bindings/javahl/native/JNICriticalSection.cpp
    subversion/trunk/subversion/bindings/javahl/native/JNIMutex.cpp
    subversion/trunk/subversion/bindings/javahl/native/JNIThreadData.cpp
    subversion/trunk/subversion/bindings/javahl/native/JNIUtil.cpp
    subversion/trunk/subversion/bindings/javahl/native/Revision.cpp
    subversion/trunk/subversion/bindings/javahl/native/SVNRepos.cpp
    subversion/trunk/subversion/bindings/javahl/native/Targets.cpp

Modified: subversion/trunk/subversion/bindings/javahl/native/JNICriticalSection.cpp
URL: http://svn.apache.org/viewvc/subversion/trunk/subversion/bindings/javahl/native/JNICriticalSection.cpp?rev=1405529&r1=1405528&r2=1405529&view=diff
==============================================================================
--- subversion/trunk/subversion/bindings/javahl/native/JNICriticalSection.cpp (original)
+++ subversion/trunk/subversion/bindings/javahl/native/JNICriticalSection.cpp Sun Nov  4 11:36:06 2012
@@ -39,7 +39,7 @@
 JNICriticalSection::JNICriticalSection(JNIMutex &mutex)
 {
   m_mutex = &mutex;
-  apr_status_t apr_err = apr_thread_mutex_lock (mutex.m_mutex);
+  apr_status_t apr_err = apr_thread_mutex_lock(mutex.m_mutex);
   if (apr_err)
     {
       JNIUtil::handleAPRError(apr_err, "apr_thread_mutex_lock");
@@ -53,7 +53,7 @@ JNICriticalSection::JNICriticalSection(J
  */
 JNICriticalSection::~JNICriticalSection()
 {
-  apr_status_t apr_err = apr_thread_mutex_unlock (m_mutex->m_mutex);
+  apr_status_t apr_err = apr_thread_mutex_unlock(m_mutex->m_mutex);
   if (apr_err)
     {
       JNIUtil::handleAPRError(apr_err, "apr_thread_mutex_unlock");

Modified: subversion/trunk/subversion/bindings/javahl/native/JNIMutex.cpp
URL: http://svn.apache.org/viewvc/subversion/trunk/subversion/bindings/javahl/native/JNIMutex.cpp?rev=1405529&r1=1405528&r2=1405529&view=diff
==============================================================================
--- subversion/trunk/subversion/bindings/javahl/native/JNIMutex.cpp (original)
+++ subversion/trunk/subversion/bindings/javahl/native/JNIMutex.cpp Sun Nov  4 11:36:06 2012
@@ -38,7 +38,7 @@
 JNIMutex::JNIMutex(apr_pool_t *pool)
 {
   apr_status_t apr_err =
-    apr_thread_mutex_create (&m_mutex, APR_THREAD_MUTEX_NESTED, pool);
+    apr_thread_mutex_create(&m_mutex, APR_THREAD_MUTEX_NESTED, pool);
   if (apr_err)
     JNIUtil::handleAPRError(apr_err, "apr_thread_mutex_create");
 }
@@ -48,7 +48,7 @@ JNIMutex::JNIMutex(apr_pool_t *pool)
  */
 JNIMutex::~JNIMutex()
 {
-  apr_status_t apr_err = apr_thread_mutex_destroy (m_mutex);
+  apr_status_t apr_err = apr_thread_mutex_destroy(m_mutex);
   if (apr_err)
     JNIUtil::handleAPRError(apr_err, "apr_thread_mutex_destroy");
 }

Modified: subversion/trunk/subversion/bindings/javahl/native/JNIThreadData.cpp
URL: http://svn.apache.org/viewvc/subversion/trunk/subversion/bindings/javahl/native/JNIThreadData.cpp?rev=1405529&r1=1405528&r2=1405529&view=diff
==============================================================================
--- subversion/trunk/subversion/bindings/javahl/native/JNIThreadData.cpp (original)
+++ subversion/trunk/subversion/bindings/javahl/native/JNIThreadData.cpp Sun Nov  4 11:36:06 2012
@@ -124,7 +124,7 @@ void JNIThreadData::pushNewThreadData()
     }
   JNIThreadData *newData = new JNIThreadData();
   newData->m_previous =data;
-  apr_err = apr_threadkey_private_set (newData, g_key);
+  apr_err = apr_threadkey_private_set(newData, g_key);
   if (apr_err)
     {
       JNIUtil::handleAPRError(apr_err, "apr_threadkey_private_set");
@@ -151,7 +151,7 @@ void JNIThreadData::popThreadData()
 
   JNIThreadData *oldData = data->m_previous;
   delete data;
-  apr_err = apr_threadkey_private_set (oldData, g_key);
+  apr_err = apr_threadkey_private_set(oldData, g_key);
   if (apr_err)
     {
       JNIUtil::handleAPRError(apr_err, "apr_threadkey_private_set");

Modified: subversion/trunk/subversion/bindings/javahl/native/JNIUtil.cpp
URL: http://svn.apache.org/viewvc/subversion/trunk/subversion/bindings/javahl/native/JNIUtil.cpp?rev=1405529&r1=1405528&r2=1405529&view=diff
==============================================================================
--- subversion/trunk/subversion/bindings/javahl/native/JNIUtil.cpp (original)
+++ subversion/trunk/subversion/bindings/javahl/native/JNIUtil.cpp Sun Nov  4 11:36:06 2012
@@ -240,7 +240,7 @@ bool JNIUtil::JNIGlobalInit(JNIEnv *env)
   /* See http://svn.apache.org/repos/asf/subversion/trunk/notes/asp-dot-net-hack.txt */
   /* ### This code really only needs to be invoked by consumers of
      ### the libsvn_wc library, which basically means SVNClient. */
-  if (getenv ("SVN_ASP_DOT_NET_HACK"))
+  if (getenv("SVN_ASP_DOT_NET_HACK"))
     {
       err = svn_wc_set_adm_dir("_svn", g_pool);
       if (err)

Modified: subversion/trunk/subversion/bindings/javahl/native/Revision.cpp
URL: http://svn.apache.org/viewvc/subversion/trunk/subversion/bindings/javahl/native/Revision.cpp?rev=1405529&r1=1405528&r2=1405529&view=diff
==============================================================================
--- subversion/trunk/subversion/bindings/javahl/native/Revision.cpp (original)
+++ subversion/trunk/subversion/bindings/javahl/native/Revision.cpp Sun Nov  4 11:36:06 2012
@@ -31,7 +31,7 @@
 const svn_opt_revision_kind Revision::START = svn_opt_revision_unspecified;
 const svn_opt_revision_kind Revision::HEAD = svn_opt_revision_head;
 
-Revision::Revision (const svn_opt_revision_kind kind)
+Revision::Revision(const svn_opt_revision_kind kind)
 {
   m_revision.kind = kind;
   m_revision.value.number = 0;
@@ -149,7 +149,7 @@ Revision::~Revision()
 {
 }
 
-const svn_opt_revision_t *Revision::revision () const
+const svn_opt_revision_t *Revision::revision() const
 {
   return &m_revision;
 }

Modified: subversion/trunk/subversion/bindings/javahl/native/SVNRepos.cpp
URL: http://svn.apache.org/viewvc/subversion/trunk/subversion/bindings/javahl/native/SVNRepos.cpp?rev=1405529&r1=1405528&r2=1405529&view=diff
==============================================================================
--- subversion/trunk/subversion/bindings/javahl/native/SVNRepos.cpp (original)
+++ subversion/trunk/subversion/bindings/javahl/native/SVNRepos.cpp Sun Nov  4 11:36:06 2012
@@ -169,7 +169,7 @@ void SVNRepos::deltify(File &path, Revis
   for (revision = start; revision <= end; ++revision)
     {
       revisionPool.clear();
-      SVN_JNI_ERR(svn_fs_deltify_revision (fs, revision, revisionPool.getPool()),
+      SVN_JNI_ERR(svn_fs_deltify_revision(fs, revision, revisionPool.getPool()),
                   );
     }
 
@@ -273,7 +273,7 @@ void SVNRepos::hotcopy(File &path, File 
 }
 
 static void
-list_dblogs (File &path, MessageReceiver &receiver, bool only_unused)
+list_dblogs(File &path, MessageReceiver &receiver, bool only_unused)
 {
   SVN::Pool requestPool;
   apr_array_header_t *logfiles;
@@ -297,7 +297,7 @@ list_dblogs (File &path, MessageReceiver
       log_utf8 = svn_dirent_join(path.getInternalStyle(requestPool),
                                  APR_ARRAY_IDX(logfiles, i, const char *),
                                  requestPool.getPool());
-      log_utf8 = svn_dirent_local_style (log_utf8, requestPool.getPool());
+      log_utf8 = svn_dirent_local_style(log_utf8, requestPool.getPool());
       receiver.receiveMessage(log_utf8);
     }
 }
@@ -365,13 +365,13 @@ void SVNRepos::lstxns(File &path, Messag
 
   SVN_JNI_ERR(svn_repos_open2(&repos, path.getInternalStyle(requestPool),
                               NULL, requestPool.getPool()), );
-  fs = svn_repos_fs (repos);
+  fs = svn_repos_fs(repos);
   SVN_JNI_ERR(svn_fs_list_transactions(&txns, fs, requestPool.getPool()), );
 
   /* Loop, printing revisions. */
   for (int i = 0; i < txns->nelts; ++i)
     {
-      messageReceiver.receiveMessage(APR_ARRAY_IDX (txns, i, const char *));
+      messageReceiver.receiveMessage(APR_ARRAY_IDX(txns, i, const char *));
     }
 
 
@@ -402,7 +402,7 @@ jlong SVNRepos::recover(File &path, Repo
    * recovery actually worked. */
   SVN_JNI_ERR(svn_repos_open2(&repos, path.getInternalStyle(requestPool),
                               NULL, requestPool.getPool()), -1);
-  SVN_JNI_ERR(svn_fs_youngest_rev(&youngest_rev, svn_repos_fs (repos),
+  SVN_JNI_ERR(svn_fs_youngest_rev(&youngest_rev, svn_repos_fs(repos),
                                   requestPool.getPool()),
               -1);
   return youngest_rev;
@@ -426,13 +426,13 @@ void SVNRepos::rmtxns(File &path, String
 
   SVN_JNI_ERR(svn_repos_open2(&repos, path.getInternalStyle(requestPool),
                               NULL, requestPool.getPool()), );
-  fs = svn_repos_fs (repos);
+  fs = svn_repos_fs(repos);
 
   args = transactions.array(requestPool);
   /* All the rest of the arguments are transaction names. */
   for (i = 0; i < args->nelts; ++i)
     {
-      const char *txn_name = APR_ARRAY_IDX (args, i, const char *);
+      const char *txn_name = APR_ARRAY_IDX(args, i, const char *);
       svn_error_t *err;
 
       /* Try to open the txn.  If that succeeds, try to abort it. */
@@ -446,7 +446,7 @@ void SVNRepos::rmtxns(File &path, String
        * all.  */
       if (err && (err->apr_err == SVN_ERR_FS_TRANSACTION_DEAD))
         {
-          svn_error_clear (err);
+          svn_error_clear(err);
           err = svn_fs_purge_txn(fs, txn_name, transactionPool.getPool());
         }
 
@@ -500,7 +500,7 @@ void SVNRepos::setRevProp(File &path, Re
     }
   else
     {
-      svn_fs_t *fs = svn_repos_fs (repos);
+      svn_fs_t *fs = svn_repos_fs(repos);
       err = svn_fs_change_rev_prop2(fs, revision.revision()->value.number,
                                     propName, NULL, propValStr,
                                     requestPool.getPool());
@@ -557,7 +557,7 @@ SVNRepos::verify(File &path, Revision &r
    * with no interest in the output. */
   SVN_JNI_ERR(svn_repos_open2(&repos, path.getInternalStyle(requestPool),
                               NULL, requestPool.getPool()), );
-  SVN_JNI_ERR(svn_fs_youngest_rev(&youngest, svn_repos_fs (repos),
+  SVN_JNI_ERR(svn_fs_youngest_rev(&youngest, svn_repos_fs(repos),
                                   requestPool.getPool()), );
 
   /* Find the revision numbers at which to start and end. */
@@ -661,12 +661,12 @@ jobject SVNRepos::lslocks(File &path, sv
 
   std::vector<jobject> jlocks;
 
-  for (hi = apr_hash_first (requestPool.getPool(), locks);
+  for (hi = apr_hash_first(requestPool.getPool(), locks);
        hi;
-       hi = apr_hash_next (hi))
+       hi = apr_hash_next(hi))
     {
       void *val;
-      apr_hash_this (hi, NULL, NULL, &val);
+      apr_hash_this(hi, NULL, NULL, &val);
       svn_lock_t *lock = (svn_lock_t *)val;
       jobject jLock = CreateJ::Lock(lock);
 
@@ -693,7 +693,7 @@ void SVNRepos::rmlocks(File &path, Strin
 
   SVN_JNI_ERR(svn_repos_open2(&repos, path.getInternalStyle(requestPool),
                               NULL, requestPool.getPool()), );
-  fs = svn_repos_fs (repos);
+  fs = svn_repos_fs(repos);
   const char *username;
 
   /* svn_fs_unlock() demands that some username be associated with the
@@ -702,12 +702,12 @@ void SVNRepos::rmlocks(File &path, Strin
     apr_uid_t uid;
     apr_gid_t gid;
     char *un;
-    if (apr_uid_current (&uid, &gid, requestPool.getPool()) == APR_SUCCESS &&
-        apr_uid_name_get (&un, uid, requestPool.getPool()) == APR_SUCCESS)
+    if (apr_uid_current(&uid, &gid, requestPool.getPool()) == APR_SUCCESS &&
+        apr_uid_name_get(&un, uid, requestPool.getPool()) == APR_SUCCESS)
       {
         svn_error_t *err = svn_utf_cstring_to_utf8(&username, un,
                                                    requestPool.getPool());
-        svn_error_clear (err);
+        svn_error_clear(err);
         if (err)
           username = "administrator";
       }
@@ -723,7 +723,7 @@ void SVNRepos::rmlocks(File &path, Strin
   const apr_array_header_t *args = locks.array(requestPool);
   for (int i = 0; i < args->nelts; ++i)
     {
-      const char *lock_path = APR_ARRAY_IDX (args, i, const char *);
+      const char *lock_path = APR_ARRAY_IDX(args, i, const char *);
       svn_lock_t *lock;
 
       /* Fetch the path's svn_lock_t. */
@@ -734,13 +734,13 @@ void SVNRepos::rmlocks(File &path, Strin
         continue;
 
       /* Now forcibly destroy the lock. */
-      err = svn_fs_unlock (fs, lock_path,
-                           lock->token, 1 /* force */, subpool.getPool());
+      err = svn_fs_unlock(fs, lock_path,
+                          lock->token, 1 /* force */, subpool.getPool());
       if (err)
         goto move_on;
 
     move_on:
-      svn_error_clear (err);
+      svn_error_clear(err);
       subpool.clear();
     }
 

Modified: subversion/trunk/subversion/bindings/javahl/native/Targets.cpp
URL: http://svn.apache.org/viewvc/subversion/trunk/subversion/bindings/javahl/native/Targets.cpp?rev=1405529&r1=1405528&r2=1405529&view=diff
==============================================================================
--- subversion/trunk/subversion/bindings/javahl/native/Targets.cpp (original)
+++ subversion/trunk/subversion/bindings/javahl/native/Targets.cpp Sun Nov  4 11:36:06 2012
@@ -40,13 +40,13 @@ Targets::Targets(const char *path, SVN::
     : m_subpool(in_pool)
 {
   m_strArray = NULL;
-  m_targets.push_back (apr_pstrdup(m_subpool.getPool(), path));
+  m_targets.push_back(apr_pstrdup(m_subpool.getPool(), path));
   m_error_occured = NULL;
 }
 
 void Targets::add(const char *path)
 {
-  m_targets.push_back (path);
+  m_targets.push_back(path);
 }
 
 const apr_array_header_t *Targets::array(const SVN::Pool &pool)
@@ -72,9 +72,9 @@ const apr_array_header_t *Targets::array
   std::vector<const char*>::const_iterator it;
 
   apr_pool_t *apr_pool = pool.getPool();
-  apr_array_header_t *apr_targets = apr_array_make (apr_pool,
-                                                    (int)m_targets.size(),
-                                                    sizeof(const char *));
+  apr_array_header_t *apr_targets = apr_array_make(apr_pool,
+                                                   (int)m_targets.size(),
+                                                   sizeof(const char *));
 
   for (it = m_targets.begin(); it != m_targets.end(); ++it)
     {