You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@subversion.apache.org by rh...@apache.org on 2014/03/21 15:04:49 UTC

svn commit: r1579943 [3/3] - in /subversion/branches/1.8.x-r1536854: ./ build/ build/generator/ subversion/bindings/swig/ subversion/bindings/swig/perl/native/ subversion/include/ subversion/include/private/ subversion/libsvn_client/ subversion/libsvn_...

Modified: subversion/branches/1.8.x-r1536854/subversion/tests/cmdline/diff_tests.py
URL: http://svn.apache.org/viewvc/subversion/branches/1.8.x-r1536854/subversion/tests/cmdline/diff_tests.py?rev=1579943&r1=1579942&r2=1579943&view=diff
==============================================================================
--- subversion/branches/1.8.x-r1536854/subversion/tests/cmdline/diff_tests.py (original)
+++ subversion/branches/1.8.x-r1536854/subversion/tests/cmdline/diff_tests.py Fri Mar 21 14:04:47 2014
@@ -4648,6 +4648,26 @@ def diff_local_missing_obstruction(sbox)
                                      'diff', wc_dir)
 
 
+@Issue(4444)
+def diff_move_inside_copy(sbox):
+  "diff copied-along child that contains a moved file"
+  sbox.build(read_only=True)
+  wc_dir = sbox.wc_dir
+
+  d_path = 'A/D'
+  d_copy = 'A/D-copy'
+  h_path = 'A/D-copy/H'
+  chi_path = '%s/chi' % h_path
+  chi_moved = '%s/chi-moved' % h_path
+
+  sbox.simple_copy(d_path, d_copy)
+  sbox.simple_move(chi_path, chi_moved)
+  sbox.simple_append(chi_moved, 'a new line')
+
+  # Bug: Diffing the copied-along parent directory asserts
+  svntest.actions.run_and_verify_svn(None, svntest.verify.AnyOutput, [],
+                                     'diff', sbox.ospath(h_path))
+
 ########################################################################
 #Run the tests
 
@@ -4729,6 +4749,7 @@ test_list = [ None,
               diff_repos_empty_file_addition,
               diff_missing_tree_conflict_victim,
               diff_local_missing_obstruction,
+              diff_move_inside_copy,
               ]
 
 if __name__ == '__main__':

Modified: subversion/branches/1.8.x-r1536854/subversion/tests/cmdline/move_tests.py
URL: http://svn.apache.org/viewvc/subversion/branches/1.8.x-r1536854/subversion/tests/cmdline/move_tests.py?rev=1579943&r1=1579942&r2=1579943&view=diff
==============================================================================
--- subversion/branches/1.8.x-r1536854/subversion/tests/cmdline/move_tests.py (original)
+++ subversion/branches/1.8.x-r1536854/subversion/tests/cmdline/move_tests.py Fri Mar 21 14:04:47 2014
@@ -1397,6 +1397,29 @@ def move_many_update_add(sbox):
                                         wc_dir, '--accept', 'mine-conflict')
 
 
+def move_to_from_external(sbox):
+  "move to and from an external"
+
+  sbox.build()
+  sbox.simple_propset('svn:externals', '^/A/D/G GG', '')
+  sbox.simple_update()
+
+  svntest.actions.run_and_verify_svn(None, None, [],
+                                     'move',
+                                     sbox.ospath('GG/tau'),
+                                     sbox.ospath('tau'))
+
+  svntest.actions.run_and_verify_svn(None, None, [],
+                                     'move',
+                                     sbox.ospath('iota'),
+                                     sbox.ospath('GG/tau'))
+                                     
+  svntest.actions.run_and_verify_svn(None, None, [],
+                                     'ci', '-m', 'Commit both',
+                                     sbox.ospath(''),
+                                     sbox.ospath('GG'))
+  
+
 #######################################################################
 # Run the tests
 
@@ -1410,6 +1433,7 @@ test_list = [ None,
               move_missing,
               move_many_update_delete,
               move_many_update_add,
+              move_to_from_external,
             ]
 
 if __name__ == '__main__':

Modified: subversion/branches/1.8.x-r1536854/subversion/tests/cmdline/prop_tests.py
URL: http://svn.apache.org/viewvc/subversion/branches/1.8.x-r1536854/subversion/tests/cmdline/prop_tests.py?rev=1579943&r1=1579942&r2=1579943&view=diff
==============================================================================
--- subversion/branches/1.8.x-r1536854/subversion/tests/cmdline/prop_tests.py (original)
+++ subversion/branches/1.8.x-r1536854/subversion/tests/cmdline/prop_tests.py Fri Mar 21 14:04:47 2014
@@ -2612,6 +2612,48 @@ def peg_rev_base_working(sbox):
                                      'propget', '--strict', 'ordinal',
                                      sbox.ospath('iota') + '@BASE')
 
+def iprops_list_abspath(sbox):
+  "test listing iprops via abspath"
+
+  sbox.build()
+
+  sbox.simple_propset('im', 'root', '')
+  sbox.simple_commit()
+
+  svntest.actions.run_and_verify_svn(None, None, [],
+                                     'switch', '^/A/D', sbox.ospath(''),
+                                     '--ignore-ancestry')
+
+  sbox.simple_propset('im', 'GammA', 'gamma')
+
+  expected_output = [
+    'Inherited properties on \'%s\',\n' % sbox.ospath('')[:-1],
+    'from \'%s\':\n' % sbox.repo_url,
+    '  im\n',
+    '    root\n',
+    'Properties on \'%s\':\n' % sbox.ospath('gamma'),
+    '  im\n',
+    '    GammA\n'
+  ]
+  svntest.actions.run_and_verify_svn(None, expected_output, [],
+                                     'pl', '-R',
+                                     '--show-inherited-props', '-v',
+                                     sbox.ospath(''))
+
+  expected_output = [
+    'Inherited properties on \'%s\',\n' % os.path.abspath(sbox.ospath('')),
+    'from \'%s\':\n' % sbox.repo_url,
+    '  im\n',
+    '    root\n',
+    'Properties on \'%s\':\n' % os.path.abspath(sbox.ospath('gamma')),
+    '  im\n',
+    '    GammA\n'
+  ]
+  svntest.actions.run_and_verify_svn(None, expected_output, [],
+                                     'pl', '-R',
+                                     '--show-inherited-props', '-v',
+                                     os.path.abspath(sbox.ospath('')))
+
 ########################################################################
 # Run the tests
 
@@ -2657,6 +2699,7 @@ test_list = [ None,
               inheritable_ignores,
               almost_known_prop_names,
               peg_rev_base_working,
+              iprops_list_abspath,
              ]
 
 if __name__ == '__main__':

Modified: subversion/branches/1.8.x-r1536854/subversion/tests/cmdline/redirect_tests.py
URL: http://svn.apache.org/viewvc/subversion/branches/1.8.x-r1536854/subversion/tests/cmdline/redirect_tests.py?rev=1579943&r1=1579942&r2=1579943&view=diff
==============================================================================
--- subversion/branches/1.8.x-r1536854/subversion/tests/cmdline/redirect_tests.py (original)
+++ subversion/branches/1.8.x-r1536854/subversion/tests/cmdline/redirect_tests.py Fri Mar 21 14:04:47 2014
@@ -140,6 +140,44 @@ def redirected_update(sbox):
   verify_url(wc_dir, sbox.repo_url)
 
 #----------------------------------------------------------------------
+@SkipUnless(svntest.main.is_ra_type_dav)
+def redirected_nonroot_update(sbox):
+  "redirected update of non-repos-root wc"
+
+  sbox.build(create_wc=False)
+  wc_dir = sbox.wc_dir
+  checkout_url = sbox.repo_url + '/A'
+  relocate_url = sbox.redirected_root_url() + '/A'
+
+  # Checkout a subdir of the repository root.
+  exit_code, out, err = svntest.main.run_svn(None, 'co',
+                                             checkout_url, wc_dir)
+  if err:
+    raise svntest.Failure
+  
+  # Relocate (by cheating) the working copy to the redirect URL.  When
+  # we then update, we'll expect to find ourselves automagically back
+  # to the original URL.  (This is because we can't easily introduce a
+  # redirect to the Apache configuration from the test suite here.)
+  svntest.actions.no_relocate_validation()
+  exit_code, out, err = svntest.main.run_svn(None, 'sw', '--relocate',
+                                             checkout_url, relocate_url,
+                                             wc_dir)
+  svntest.actions.do_relocate_validation()
+
+  # Now update the working copy.
+  exit_code, out, err = svntest.main.run_svn(None, 'up', wc_dir)
+  if err:
+    raise svntest.Failure
+  if not re.match("^Updating '.*':", out[0]):
+    raise svntest.Failure
+  if not redirect_regex.match(out[1]):
+    raise svntest.Failure
+
+  # Verify that we have the expected URL.
+  verify_url(wc_dir, checkout_url)
+
+#----------------------------------------------------------------------
 
 ########################################################################
 # Run the tests
@@ -149,6 +187,7 @@ test_list = [ None,
               temporary_redirect,
               redirected_checkout,
               redirected_update,
+              redirected_nonroot_update,
              ]
 
 if __name__ == '__main__':

Modified: subversion/branches/1.8.x-r1536854/subversion/tests/cmdline/upgrade_tests.py
URL: http://svn.apache.org/viewvc/subversion/branches/1.8.x-r1536854/subversion/tests/cmdline/upgrade_tests.py?rev=1579943&r1=1579942&r2=1579943&view=diff
==============================================================================
--- subversion/branches/1.8.x-r1536854/subversion/tests/cmdline/upgrade_tests.py (original)
+++ subversion/branches/1.8.x-r1536854/subversion/tests/cmdline/upgrade_tests.py Fri Mar 21 14:04:47 2014
@@ -1428,6 +1428,17 @@ def changelist_upgrade_1_6(sbox):
   if paths != expected_paths:
     raise svntest.Failure("changelist not matched")
 
+
+def upgrade_1_7_dir_external(sbox):
+  "upgrade from 1.7 with dir external"
+
+  sbox.build(create_wc = False)
+  replace_sbox_with_tarfile(sbox, 'upgrade_1_7_dir_external.tar.bz2')
+
+  # This fails for 'make check EXCLUSIVE_WC_LOCKS=1' giving an error:
+  # svn: warning: W200033: sqlite[S5]: database is locked
+  svntest.actions.run_and_verify_svn(None, None, [], 'upgrade', sbox.wc_dir)
+
 ########################################################################
 # Run the tests
 
@@ -1483,6 +1494,7 @@ test_list = [ None,
               iprops_upgrade,
               iprops_upgrade1_6,
               changelist_upgrade_1_6,
+              upgrade_1_7_dir_external,
              ]
 
 

Modified: subversion/branches/1.8.x-r1536854/subversion/tests/libsvn_subr/checksum-test.c
URL: http://svn.apache.org/viewvc/subversion/branches/1.8.x-r1536854/subversion/tests/libsvn_subr/checksum-test.c?rev=1579943&r1=1579942&r2=1579943&view=diff
==============================================================================
--- subversion/branches/1.8.x-r1536854/subversion/tests/libsvn_subr/checksum-test.c (original)
+++ subversion/branches/1.8.x-r1536854/subversion/tests/libsvn_subr/checksum-test.c Fri Mar 21 14:04:47 2014
@@ -23,7 +23,10 @@
 
 #include <apr_pools.h>
 
+#include <zlib.h>
+
 #include "svn_error.h"
+#include "svn_io.h"
 #include "private/svn_pseudo_md5.h"
 
 #include "../svn_test.h"
@@ -155,6 +158,87 @@ zero_match(apr_pool_t *pool)
   return SVN_NO_ERROR;
 }
 
+static svn_error_t *
+zlib_expansion_test(const svn_test_opts_t *opts,
+                    apr_pool_t *pool)
+{
+  const char *data_path;
+  svn_stringbuf_t *deflated;
+  Byte dst_buffer[256 * 1024];
+  Byte *src_buffer;
+  apr_size_t sz;
+
+  data_path = svn_dirent_join(opts->srcdir, "zlib.deflated", pool);
+
+  SVN_ERR(svn_stringbuf_from_file2(&deflated, data_path, pool));
+  src_buffer = (Byte*)deflated->data;
+
+  /* Try to decompress the same data with different blocksizes */
+  for (sz = 1; sz < 256; sz++)
+    {
+      z_stream stream;
+      memset(&stream, 0, sizeof(stream));
+      inflateInit2(&stream, -15 /* DEFLATE_WINDOW_SIZE */);
+
+      stream.avail_in = sz;
+      stream.next_in = src_buffer;
+      stream.avail_out = sizeof(dst_buffer);
+      stream.next_out = dst_buffer;
+
+      do
+        {
+          int zr = inflate(&stream, Z_NO_FLUSH);
+
+          if (zr != Z_OK && zr != Z_STREAM_END)
+          {
+              return svn_error_createf(
+                          SVN_ERR_TEST_FAILED, NULL,
+                          "Failure decompressing with blocksize %d", (int)sz);
+          }
+          stream.avail_in += sz;
+      } while (stream.next_in + stream.avail_in  < src_buffer + deflated->len);
+
+      stream.avail_in = (src_buffer + deflated->len) - stream.next_in;
+
+      {
+          int zr = inflate(&stream, Z_NO_FLUSH);
+
+          if (zr != Z_STREAM_END)
+            {
+              return svn_error_createf(
+                        SVN_ERR_TEST_FAILED, NULL,
+                        "Final flush failed with blocksize %d", (int)sz);
+            }
+
+          zr = inflateEnd(&stream);
+
+          if (zr != Z_OK)
+            {
+              return svn_error_createf(
+                        SVN_ERR_TEST_FAILED, NULL,
+                        "End of stream handling failed with blocksize %d",
+                        (int)sz);
+            }
+      }
+
+      {
+          apr_uint32_t crc = crc32(0, dst_buffer, stream.total_out);
+
+          if (stream.total_out != 242014 || crc != 0x8f03d934)
+            {
+              return svn_error_createf(
+                  SVN_ERR_TEST_FAILED, NULL,
+                  "Decompressed data doesn't match expected size or crc with "
+                  "blocksize %d: Found crc32=0x%08x, size=%d.\n"
+                  "Verify your ZLib installation, as this should never happen",
+                  (int)sz, (unsigned)crc, (int)stream.total_out);
+            }
+      }
+  }
+
+  return SVN_NO_ERROR;
+}
+
 /* An array of all test functions */
 struct svn_test_descriptor_t test_funcs[] =
   {
@@ -167,5 +251,7 @@ struct svn_test_descriptor_t test_funcs[
                    "pseudo-md5 compatibility"),
     SVN_TEST_PASS2(zero_match,
                    "zero checksum matching"),
+    SVN_TEST_OPTS_PASS(zlib_expansion_test,
+                       "zlib expansion test (zlib regression)"),
     SVN_TEST_NULL
   };

Modified: subversion/branches/1.8.x-r1536854/subversion/tests/libsvn_wc/wc-queries-test.c
URL: http://svn.apache.org/viewvc/subversion/branches/1.8.x-r1536854/subversion/tests/libsvn_wc/wc-queries-test.c?rev=1579943&r1=1579942&r2=1579943&view=diff
==============================================================================
--- subversion/branches/1.8.x-r1536854/subversion/tests/libsvn_wc/wc-queries-test.c (original)
+++ subversion/branches/1.8.x-r1536854/subversion/tests/libsvn_wc/wc-queries-test.c Fri Mar 21 14:04:47 2014
@@ -77,6 +77,7 @@ static const int schema_statements[] =
   STMT_CREATE_NODES,
   STMT_CREATE_NODES_TRIGGERS,
   STMT_CREATE_EXTERNALS,
+  STMT_INSTALL_SCHEMA_STATISTICS,
   /* Memory tables */
   STMT_CREATE_TARGETS_LIST,
   STMT_CREATE_CHANGELIST_LIST,
@@ -95,8 +96,8 @@ static const int slow_statements[] =
   /* Operate on the entire WC */
   STMT_SELECT_ALL_NODES,                /* schema validation code */
 
-  /* Is there a record? ### Can we somehow check for LIMIT 1? */
-  STMT_LOOK_FOR_WORK,
+  /* Updates all records for a repository (designed slow) */
+  STMT_UPDATE_LOCK_REPOS_ID,
 
   /* Full temporary table read */
   STMT_INSERT_ACTUAL_EMPTIES,
@@ -114,6 +115,19 @@ static const int slow_statements[] =
   -1 /* final marker */
 };
 
+/* Statements that just read the first record from a table,
+   using the primary key. Specialized as different sqlite
+   versions produce different results */
+static const int primary_key_statements[] =
+{
+  /* Is there a record? ### Can we somehow check for LIMIT 1,
+     and primary key instead of adding a list? */
+  STMT_LOOK_FOR_WORK,
+  STMT_SELECT_WORK_ITEM,
+
+  -1 /* final marker */
+};
+
 /* Helper function to determine if a statement is in a list */
 static svn_boolean_t
 in_list(const int list[], int stmt_idx)
@@ -529,6 +543,7 @@ is_node_table(const char *table_name)
   return (apr_strnatcasecmp(table_name, "nodes") == 0
           || apr_strnatcasecmp(table_name, "actual_node") == 0
           || apr_strnatcasecmp(table_name, "externals") == 0
+          || apr_strnatcasecmp(table_name, "lock") == 0
           || apr_strnatcasecmp(table_name, "wc_lock") == 0
           || FALSE);
 }
@@ -651,14 +666,24 @@ test_query_expectations(apr_pool_t *scra
                        || (item->expression_vars < 1))
                    && !is_result_table(item->table))
             {
-              warned = TRUE;
-              if (!is_slow_statement(i))
-                warnings = svn_error_createf(SVN_ERR_TEST_FAILED, warnings,
+              if (in_list(primary_key_statements, i))
+                {
+                  /* Reported as primary key index usage in Sqlite 3.7,
+                     as table scan in 3.8+, while the execution plan is
+                     identical: read first record from table */
+                }
+              else if (!is_slow_statement(i))
+                {
+                  warned = TRUE;
+                  warnings = svn_error_createf(SVN_ERR_TEST_FAILED, warnings,
                                 "%s: "
                                 "Uses %s with only %d index component: (%s)\n%s",
                                 wc_query_info[i][0], item->table,
                                 item->expression_vars, item->expressions,
                                 wc_queries[i]);
+                }
+              else
+                warned = TRUE;
             }
           else if (item->search && !item->index)
             {
@@ -718,6 +743,144 @@ test_query_expectations(apr_pool_t *scra
   return warnings;
 }
 
+/* Helper to verify a bit of data in the sqlite3 statistics */
+static int
+parse_stat_data(const char *stat)
+{
+  int n = 0;
+  apr_int64_t last = APR_INT64_MAX;
+  while (*stat)
+    {
+      apr_int64_t v;
+      char *next;
+
+      if (*stat < '0' || *stat > '9')
+        return -2;
+
+      errno = 0;
+      v = apr_strtoi64(stat, &next, 10);
+
+      /* All numbers specify the average number of rows
+         with the same values in all columns left of it,
+         so the value must be >= 1 and lower than or equal
+         to all previous seen numbers */
+      if (v <= 0 || (v > last) || (errno != 0))
+        return -1;
+
+      last = v;
+
+      n++;
+      stat = next;
+
+      if (*stat == ' ')
+        stat++;
+    }
+
+  return n;
+}
+
+static svn_error_t *
+test_schema_statistics(apr_pool_t *scratch_pool)
+{
+  sqlite3 *sdb;
+  sqlite3_stmt *stmt;
+
+  SVN_ERR(create_memory_db(&sdb, scratch_pool));
+
+  SQLITE_ERR(
+      sqlite3_exec(sdb,
+                   "CREATE TABLE shadow_stat1(tbl TEXT, idx TEXT, stat TEXT)",
+                   NULL, NULL, NULL));
+
+  SQLITE_ERR(
+      sqlite3_exec(sdb,
+                   "INSERT INTO shadow_stat1 (tbl, idx, stat) "
+                   "SELECT tbl, idx, stat FROM sqlite_stat1",
+                   NULL, NULL, NULL));
+
+  SQLITE_ERR(
+      sqlite3_exec(sdb,
+                   "DROP TABLE sqlite_stat1",
+                   NULL, NULL, NULL));
+
+  /* Insert statement to give index at least 1 record */
+  SQLITE_ERR(
+      sqlite3_exec(sdb,
+                   "INSERT INTO nodes (wc_id, local_relpath, op_depth,"
+                   "                   presence, kind) "
+                   "VALUES (1, '', 0, 'normal', 'dir')",
+                   NULL, NULL, NULL));
+
+  SQLITE_ERR(
+      sqlite3_exec(sdb,
+                   "INSERT INTO actual_node (wc_id, local_relpath) "
+                   "VALUES (1, '')",
+                   NULL, NULL, NULL));
+
+  SQLITE_ERR(
+      sqlite3_exec(sdb,
+                   "INSERT INTO lock (repos_id, repos_relpath, lock_token) "
+                   "VALUES (1, '', '')",
+                   NULL, NULL, NULL));
+
+  /* These are currently not necessary for query optimization, but it's better
+     to tell Sqlite how we intend to use this table anyway */
+  SQLITE_ERR(
+      sqlite3_exec(sdb,
+                   "INSERT INTO wc_lock (wc_id, local_dir_relpath) "
+                   "VALUES (1, '')",
+                   NULL, NULL, NULL));
+
+  SQLITE_ERR(
+      sqlite3_exec(sdb,
+                   "INSERT INTO WORK_QUEUE (work) "
+                   "VALUES ('')",
+                   NULL, NULL, NULL));
+
+  SQLITE_ERR(
+      sqlite3_exec(sdb,
+                   "ANALYZE",
+                   NULL, NULL, NULL));
+
+  SQLITE_ERR(
+      sqlite3_prepare(sdb, "SELECT s.tbl, s.idx, s.stat, r.stat "
+                           "FROM shadow_stat1 s "
+                           "LEFT JOIN sqlite_stat1 r ON "
+                                "s.tbl=r.tbl and s.idx=r.idx",
+                      -1, &stmt, NULL));
+
+  while (sqlite3_step(stmt) == SQLITE_ROW)
+    {
+      const char *wc_stat       = (const char*)sqlite3_column_text(stmt, 2);
+      const char *sqlite_stat   = (const char*)sqlite3_column_text(stmt, 3);
+
+      if (! sqlite_stat)
+        {
+          return svn_error_createf(SVN_ERR_TEST_FAILED, NULL,
+                                   "Schema statistic failure:"
+                                   " Refering to unknown index '%s' on '%s'",
+                                   sqlite3_column_text(stmt, 1),
+                                   sqlite3_column_text(stmt, 0));
+        }
+
+      if (parse_stat_data(wc_stat) != parse_stat_data(sqlite_stat))
+        {
+          return svn_error_createf(SVN_ERR_TEST_FAILED, NULL,
+                                   "Schema statistic failure:"
+                                   " Column mismatch for '%s' on '%s'",
+                                   sqlite3_column_text(stmt, 1),
+                                   sqlite3_column_text(stmt, 0));
+        }
+    }
+
+  SQLITE_ERR(sqlite3_reset(stmt));
+  SQLITE_ERR(sqlite3_finalize(stmt));
+
+  SQLITE_ERR(sqlite3_close(sdb)); /* Close the DB if ok; otherwise leaked */
+
+  return SVN_NO_ERROR;
+}
+
 struct svn_test_descriptor_t test_funcs[] =
   {
     SVN_TEST_NULL,
@@ -727,5 +890,7 @@ struct svn_test_descriptor_t test_funcs[
                    "queries are parsable"),
     SVN_TEST_PASS2(test_query_expectations,
                    "test query expectations"),
+    SVN_TEST_PASS2(test_schema_statistics,
+                   "test schema statistics"),
     SVN_TEST_NULL
   };

Modified: subversion/branches/1.8.x-r1536854/subversion/tests/svn_test.h
URL: http://svn.apache.org/viewvc/subversion/branches/1.8.x-r1536854/subversion/tests/svn_test.h?rev=1579943&r1=1579942&r2=1579943&view=diff
==============================================================================
--- subversion/branches/1.8.x-r1536854/subversion/tests/svn_test.h (original)
+++ subversion/branches/1.8.x-r1536854/subversion/tests/svn_test.h Fri Mar 21 14:04:47 2014
@@ -103,6 +103,8 @@ typedef struct svn_test_opts_t
   const char *fs_type;
   /* Config file. */
   const char *config_file;
+  /* Source dir. */
+  const char *srcdir;
   /* Minor version to use for servers and FS backends, or zero to use
      the current latest version. */
   int server_minor_version;

Modified: subversion/branches/1.8.x-r1536854/subversion/tests/svn_test_main.c
URL: http://svn.apache.org/viewvc/subversion/branches/1.8.x-r1536854/subversion/tests/svn_test_main.c?rev=1579943&r1=1579942&r2=1579943&view=diff
==============================================================================
--- subversion/branches/1.8.x-r1536854/subversion/tests/svn_test_main.c (original)
+++ subversion/branches/1.8.x-r1536854/subversion/tests/svn_test_main.c Fri Mar 21 14:04:47 2014
@@ -44,6 +44,7 @@
 #include "svn_io.h"
 #include "svn_path.h"
 #include "svn_ctype.h"
+#include "svn_utf.h"
 
 #include "private/svn_cmdline_private.h"
 
@@ -475,6 +476,10 @@ main(int argc, const char *argv[])
         case fstype_opt:
           opts.fs_type = apr_pstrdup(pool, opt_arg);
           break;
+        case srcdir_opt:
+          SVN_INT_ERR(svn_utf_cstring_to_utf8(&opts.srcdir, opt_arg, pool));
+          opts.srcdir = svn_dirent_internal_style(opts.srcdir, pool);
+          break;
         case list_opt:
           list_mode = TRUE;
           break;

Modified: subversion/branches/1.8.x-r1536854/tools/server-side/mod_dontdothat/mod_dontdothat.c
URL: http://svn.apache.org/viewvc/subversion/branches/1.8.x-r1536854/tools/server-side/mod_dontdothat/mod_dontdothat.c?rev=1579943&r1=1579942&r2=1579943&view=diff
==============================================================================
--- subversion/branches/1.8.x-r1536854/tools/server-side/mod_dontdothat/mod_dontdothat.c (original)
+++ subversion/branches/1.8.x-r1536854/tools/server-side/mod_dontdothat/mod_dontdothat.c Fri Mar 21 14:04:47 2014
@@ -30,12 +30,15 @@
 #include <util_filter.h>
 #include <ap_config.h>
 #include <apr_strings.h>
+#include <apr_uri.h>
 
 #include <expat.h>
 
 #include "mod_dav_svn.h"
 #include "svn_string.h"
 #include "svn_config.h"
+#include "svn_path.h"
+#include "private/svn_fspath.h"
 
 module AP_MODULE_DECLARE_DATA dontdothat_module;
 
@@ -161,26 +164,71 @@ matches(const char *wc, const char *p)
     }
 }
 
+/* duplicate of dav_svn__log_err() from mod_dav_svn/util.c */
+static void
+log_dav_err(request_rec *r,
+            dav_error *err,
+            int level)
+{
+    dav_error *errscan;
+
+    /* Log the errors */
+    /* ### should have a directive to log the first or all */
+    for (errscan = err; errscan != NULL; errscan = errscan->prev) {
+        apr_status_t status;
+
+        if (errscan->desc == NULL)
+            continue;
+
+#if AP_MODULE_MAGIC_AT_LEAST(20091119,0)
+        status = errscan->aprerr;
+#else
+        status = errscan->save_errno;
+#endif
+
+        ap_log_rerror(APLOG_MARK, level, status, r,
+                      "%s  [%d, #%d]",
+                      errscan->desc, errscan->status, errscan->error_id);
+    }
+}
+
 static svn_boolean_t
 is_this_legal(dontdothat_filter_ctx *ctx, const char *uri)
 {
   const char *relative_path;
   const char *cleaned_uri;
   const char *repos_name;
+  const char *uri_path;
   int trailing_slash;
   dav_error *derr;
 
-  /* Ok, so we need to skip past the scheme, host, etc. */
-  uri = ap_strstr_c(uri, "://");
-  if (uri)
-    uri = ap_strchr_c(uri + 3, '/');
+  /* uri can be an absolute uri or just a path, we only want the path to match
+   * against */
+  if (uri && svn_path_is_url(uri))
+    {
+      apr_uri_t parsed_uri;
+      apr_status_t rv = apr_uri_parse(ctx->r->pool, uri, &parsed_uri);
+      if (APR_SUCCESS != rv)
+        {
+          /* Error parsing the URI, log and reject request. */
+          ap_log_rerror(APLOG_MARK, APLOG_ERR, rv, ctx->r,
+                        "mod_dontdothat: blocked request after failing "
+                        "to parse uri: '%s'", uri);
+          return FALSE;
+        }
+      uri_path = parsed_uri.path;
+    }
+  else
+    {
+      uri_path = uri;
+    }
 
-  if (uri)
+  if (uri_path)
     {
       const char *repos_path;
 
       derr = dav_svn_split_uri(ctx->r,
-                               uri,
+                               uri_path,
                                ctx->cfg->base_path,
                                &cleaned_uri,
                                &trailing_slash,
@@ -194,7 +242,7 @@ is_this_legal(dontdothat_filter_ctx *ctx
           if (! repos_path)
             repos_path = "";
 
-          repos_path = apr_psprintf(ctx->r->pool, "/%s", repos_path);
+          repos_path = svn_fspath__canonicalize(repos_path, ctx->r->pool);
 
           /* First check the special cases that are always legal... */
           for (idx = 0; idx < ctx->allow_recursive_ops->nelts; ++idx)
@@ -228,6 +276,19 @@ is_this_legal(dontdothat_filter_ctx *ctx
                 }
             }
         }
+      else
+        {
+          log_dav_err(ctx->r, derr, APLOG_ERR);
+          return FALSE;
+        }
+
+    }
+  else
+    {
+      ap_log_rerror(APLOG_MARK, APLOG_ERR, 0, ctx->r,
+                    "mod_dontdothat: empty uri passed to is_this_legal(), "
+                    "module bug?");
+      return FALSE;
     }
 
   return TRUE;

Propchange: subversion/branches/1.8.x-r1536854/tools/server-side/mod_dontdothat/mod_dontdothat.c
------------------------------------------------------------------------------
--- svn:mergeinfo (added)
+++ svn:mergeinfo Fri Mar 21 14:04:47 2014
@@ -0,0 +1,101 @@
+/subversion/branches/1.5.x-r30215/tools/server-side/mod_dontdothat/mod_dontdothat.c:870312
+/subversion/branches/1.7.x-fs-verify/tools/server-side/mod_dontdothat/mod_dontdothat.c:1146708,1161180
+/subversion/branches/1.8.x/tools/server-side/mod_dontdothat/mod_dontdothat.c:1536952-1579873
+/subversion/branches/1.8.x-busted-proxy/tools/server-side/mod_dontdothat/mod_dontdothat.c:1499222-1502434
+/subversion/branches/1.8.x-issue4400/tools/server-side/mod_dontdothat/mod_dontdothat.c:1507591-1512557
+/subversion/branches/1.8.x-issue4448/tools/server-side/mod_dontdothat/mod_dontdothat.c:1540420-1541802
+/subversion/branches/1.8.x-libsvnjavahl-version/tools/server-side/mod_dontdothat/mod_dontdothat.c:1483910-1485054
+/subversion/branches/1.8.x-openssl-dirs/tools/server-side/mod_dontdothat/mod_dontdothat.c:1535137-1540436
+/subversion/branches/1.8.x-r1477876/tools/server-side/mod_dontdothat/mod_dontdothat.c:1477981-1487716
+/subversion/branches/1.8.x-r1481625/tools/server-side/mod_dontdothat/mod_dontdothat.c:1481637-1482135
+/subversion/branches/1.8.x-r1495063/tools/server-side/mod_dontdothat/mod_dontdothat.c:1495804-1501074
+/subversion/branches/1.8.x-r1497310-partial/tools/server-side/mod_dontdothat/mod_dontdothat.c:1497500-1501063
+/subversion/branches/1.8.x-r1502267/tools/server-side/mod_dontdothat/mod_dontdothat.c:1502268-1515998
+/subversion/branches/1.8.x-r1507044/tools/server-side/mod_dontdothat/mod_dontdothat.c:1507282-1511571
+/subversion/branches/1.8.x-r1513879/tools/server-side/mod_dontdothat/mod_dontdothat.c:1514699-1516021
+/subversion/branches/1.8.x-r1537147/tools/server-side/mod_dontdothat/mod_dontdothat.c:1537201-1537216
+/subversion/branches/1.8.x-r1537193/tools/server-side/mod_dontdothat/mod_dontdothat.c:1537217-1541815
+/subversion/branches/1.8.x-r1541790/tools/server-side/mod_dontdothat/mod_dontdothat.c:1541791-1542075
+/subversion/branches/1.8.x-r1554978/tools/server-side/mod_dontdothat/mod_dontdothat.c:1555500-1565076
+/subversion/branches/1.8.x-r1564215/tools/server-side/mod_dontdothat/mod_dontdothat.c:1564281-1564620
+/subversion/branches/1.8.x-r1567286/tools/server-side/mod_dontdothat/mod_dontdothat.c:1567364-1567731
+/subversion/branches/1.8.x-r1567985/tools/server-side/mod_dontdothat/mod_dontdothat.c:1568016-1568055
+/subversion/branches/1.8.x-r175-daemonize/tools/server-side/mod_dontdothat/mod_dontdothat.c:1515866-1516020
+/subversion/branches/1.8.x-serf-1.3+-windows/tools/server-side/mod_dontdothat/mod_dontdothat.c:1517122-1533873
+/subversion/branches/1.8.x-svn_fs_info-removal/tools/server-side/mod_dontdothat/mod_dontdothat.c:1467420-1468159
+/subversion/branches/1.8.x-svnsync-serf-memory/tools/server-side/mod_dontdothat/mod_dontdothat.c:1515248-1515701
+/subversion/branches/1.8.x-synvsync-serf-memory/tools/server-side/mod_dontdothat/mod_dontdothat.c:1515247
+/subversion/branches/1.8.x-tristate-chunked-request/tools/server-side/mod_dontdothat/mod_dontdothat.c:1502435-1503894
+/subversion/branches/10Gb/tools/server-side/mod_dontdothat/mod_dontdothat.c:1388102,1388163-1388190,1388195,1388202,1388205,1388211,1388276,1388362,1388375,1388394,1388636,1388639-1388640,1388643-1388644,1388654,1388720,1388789,1388795,1388801,1388805,1388807,1388810,1388816,1389044,1389276,1389289,1389662,1389867,1390017,1390209,1390216,1390407,1390409,1390414,1390419,1390955
+/subversion/branches/atomic-revprop/tools/server-side/mod_dontdothat/mod_dontdothat.c:965046-1000689
+/subversion/branches/auto-props-sdc/tools/server-side/mod_dontdothat/mod_dontdothat.c:1384106-1401643
+/subversion/branches/bdb-reverse-deltas/tools/server-side/mod_dontdothat/mod_dontdothat.c:872050-872529
+/subversion/branches/diff-callbacks3/tools/server-side/mod_dontdothat/mod_dontdothat.c:870059-870761
+/subversion/branches/diff-optimizations/tools/server-side/mod_dontdothat/mod_dontdothat.c:1031270-1037352
+/subversion/branches/diff-optimizations-bytes/tools/server-side/mod_dontdothat/mod_dontdothat.c:1037353-1067789
+/subversion/branches/dont-save-plaintext-passwords-by-default/tools/server-side/mod_dontdothat/mod_dontdothat.c:870728-871118
+/subversion/branches/double-delete/tools/server-side/mod_dontdothat/mod_dontdothat.c:870511-872970
+/subversion/branches/ev2-export/tools/server-side/mod_dontdothat/mod_dontdothat.c:1325914,1332738,1413107
+/subversion/branches/explore-wc/tools/server-side/mod_dontdothat/mod_dontdothat.c:875486,875493,875497,875507,875511,875514,875559,875580-875581,875584,875587,875611,875627,875647,875667-875668,875711-875712,875733-875734,875736,875744-875748,875751,875758,875782,875795-875796,875830,875836,875838,875842,875852,875855,875864,875870,875873,875880,875885-875888,875890,875897-875898,875905,875907-875909,875935,875943-875944,875946,875979,875982-875983,875985-875986,875990,875997
+/subversion/branches/file-externals/tools/server-side/mod_dontdothat/mod_dontdothat.c:871779-873302
+/subversion/branches/fs-rep-sharing/tools/server-side/mod_dontdothat/mod_dontdothat.c:869036-873803
+/subversion/branches/fsfs-pack/tools/server-side/mod_dontdothat/mod_dontdothat.c:873717-874575
+/subversion/branches/gnome-keyring/tools/server-side/mod_dontdothat/mod_dontdothat.c:870558-871410
+/subversion/branches/gpg-agent-password-store/tools/server-side/mod_dontdothat/mod_dontdothat.c:1005036-1150766
+/subversion/branches/http-protocol-v2/tools/server-side/mod_dontdothat/mod_dontdothat.c:874395-876041
+/subversion/branches/in-memory-cache/tools/server-side/mod_dontdothat/mod_dontdothat.c:869829-871452
+/subversion/branches/in-repo-authz/tools/server-side/mod_dontdothat/mod_dontdothat.c:1414342-1424779
+/subversion/branches/inheritable-props/tools/server-side/mod_dontdothat/mod_dontdothat.c:1297080-1395089
+/subversion/branches/integrate-cache-item-serialization/tools/server-side/mod_dontdothat/mod_dontdothat.c:1068724-1068739
+/subversion/branches/integrate-cache-membuffer/tools/server-side/mod_dontdothat/mod_dontdothat.c:998649-998852
+/subversion/branches/integrate-compression-level/tools/server-side/mod_dontdothat/mod_dontdothat.c:1068651-1072287
+/subversion/branches/integrate-io-improvements/tools/server-side/mod_dontdothat/mod_dontdothat.c:1068684-1072297
+/subversion/branches/integrate-is-cachable/tools/server-side/mod_dontdothat/mod_dontdothat.c:1072568-1074082
+/subversion/branches/integrate-partial-getter/tools/server-side/mod_dontdothat/mod_dontdothat.c:1072558-1076552
+/subversion/branches/integrate-readline-speedup/tools/server-side/mod_dontdothat/mod_dontdothat.c:1072553-1072555
+/subversion/branches/integrate-stream-api-extensions/tools/server-side/mod_dontdothat/mod_dontdothat.c:1068695-1072516
+/subversion/branches/integrate-string-improvements/tools/server-side/mod_dontdothat/mod_dontdothat.c:1068251-1190617
+/subversion/branches/integrate-txdelta-caching/tools/server-side/mod_dontdothat/mod_dontdothat.c:1072541-1078213
+/subversion/branches/issue-2779-dev/tools/server-side/mod_dontdothat/mod_dontdothat.c:965496-984198
+/subversion/branches/issue-2843-dev/tools/server-side/mod_dontdothat/mod_dontdothat.c:871432-874179
+/subversion/branches/issue-3000/tools/server-side/mod_dontdothat/mod_dontdothat.c:871713,871716-871719,871721-871726,871728,871734
+/subversion/branches/issue-3067-deleted-subtrees/tools/server-side/mod_dontdothat/mod_dontdothat.c:873375-874084
+/subversion/branches/issue-3148-dev/tools/server-side/mod_dontdothat/mod_dontdothat.c:875193-875204
+/subversion/branches/issue-3220-dev/tools/server-side/mod_dontdothat/mod_dontdothat.c:872210-872226
+/subversion/branches/issue-3242-dev/tools/server-side/mod_dontdothat/mod_dontdothat.c:879653-896436
+/subversion/branches/issue-3334-dirs/tools/server-side/mod_dontdothat/mod_dontdothat.c:875156-875867
+/subversion/branches/issue-3975/tools/server-side/mod_dontdothat/mod_dontdothat.c:1152931-1160746
+/subversion/branches/issue-4116-dev/tools/server-side/mod_dontdothat/mod_dontdothat.c:1424719-1425040
+/subversion/branches/issue-4194-dev/tools/server-side/mod_dontdothat/mod_dontdothat.c:1410507-1414880
+/subversion/branches/javahl-ra/tools/server-side/mod_dontdothat/mod_dontdothat.c:1342682,1344977
+/subversion/branches/kwallet/tools/server-side/mod_dontdothat/mod_dontdothat.c:870785-871314
+/subversion/branches/log-g-performance/tools/server-side/mod_dontdothat/mod_dontdothat.c:870941-871032
+/subversion/branches/merge-skips-obstructions/tools/server-side/mod_dontdothat/mod_dontdothat.c:874525-874615
+/subversion/branches/multi-layer-moves/tools/server-side/mod_dontdothat/mod_dontdothat.c:1239019-1300930
+/subversion/branches/nfc-nfd-aware-client/tools/server-side/mod_dontdothat/mod_dontdothat.c:870276,870376
+/subversion/branches/node_pool/tools/server-side/mod_dontdothat/mod_dontdothat.c:1304828-1305388
+/subversion/branches/performance/tools/server-side/mod_dontdothat/mod_dontdothat.c:979193,980118,981087,981090,981189,981194,981287,981684,981827,982043,982355,983398,983406,983430,983474,983488,983490,983760,983764,983766,983770,984927,984973,984984,985014,985037,985046,985472,985477,985482,985487-985488,985493,985497,985500,985514,985601,985603,985606,985669,985673,985695,985697,986453,986465,986485,986491-986492,986517,986521,986605,986608,986817,986832,987865,987868-987869,987872,987886-987888,987893,988319,988898,990330,990533,990535-990537,990541,990568,990572,990574-990575,990600,990759,992899,992904,992911,993127,993141,994956,995478,995507,995603,998012,998858,999098,1001413,1001417,1004291,1022668,1022670,1022676,1022715,1022719,1025660,1025672,1027193,1027203,1027206,1027214,1027227,1028077,1028092,1028094,1028104,1028107,1028111,1028354,1029038,1029042-1029043,1029054-1029055,1029062-1029063,1029078,1029080,1029090,1029092-1029093,1029111,1029151,1029158,1029229-1029230,
 1029232,1029335-1029336,1029339-1029340,1029342,1029344,1030763,1030827,1031203,1031235,1032285,1032333,1033040,1033057,1033294,1035869,1035882,1039511,1043705,1053735,1056015,1066452,1067683,1067697-1078365
+/subversion/branches/py-tests-as-modules/tools/server-side/mod_dontdothat/mod_dontdothat.c:956579-1033052
+/subversion/branches/ra_serf-digest-authn/tools/server-side/mod_dontdothat/mod_dontdothat.c:875693-876404
+/subversion/branches/reintegrate-improvements/tools/server-side/mod_dontdothat/mod_dontdothat.c:873853-874164
+/subversion/branches/revprop-cache/tools/server-side/mod_dontdothat/mod_dontdothat.c:1298521-1326293
+/subversion/branches/revprop-packing/tools/server-side/mod_dontdothat/mod_dontdothat.c:1143907,1143971,1143997,1144017,1144499,1144568,1146145
+/subversion/branches/subtree-mergeinfo/tools/server-side/mod_dontdothat/mod_dontdothat.c:876734-878766
+/subversion/branches/svn-mergeinfo-enhancements/tools/server-side/mod_dontdothat/mod_dontdothat.c:870119-870195,870197-870288
+/subversion/branches/svn-patch-improvements/tools/server-side/mod_dontdothat/mod_dontdothat.c:918519-934609
+/subversion/branches/svn_mutex/tools/server-side/mod_dontdothat/mod_dontdothat.c:1141683-1182099
+/subversion/branches/svnpatch-diff/tools/server-side/mod_dontdothat/mod_dontdothat.c:865738-876477
+/subversion/branches/svnraisetc/tools/server-side/mod_dontdothat/mod_dontdothat.c:874709-875149
+/subversion/branches/svnserve-logging/tools/server-side/mod_dontdothat/mod_dontdothat.c:869828-870893
+/subversion/branches/tc-issue-3334/tools/server-side/mod_dontdothat/mod_dontdothat.c:874697-874773
+/subversion/branches/tc-merge-notify/tools/server-side/mod_dontdothat/mod_dontdothat.c:874017-874062
+/subversion/branches/tc-resolve/tools/server-side/mod_dontdothat/mod_dontdothat.c:874191-874239
+/subversion/branches/tc_url_rev/tools/server-side/mod_dontdothat/mod_dontdothat.c:874351-874483
+/subversion/branches/tree-conflicts/tools/server-side/mod_dontdothat/mod_dontdothat.c:868291-873154
+/subversion/branches/tree-conflicts-notify/tools/server-side/mod_dontdothat/mod_dontdothat.c:873926-874008
+/subversion/branches/tristate-chunked-request/tools/server-side/mod_dontdothat/mod_dontdothat.c:1502401,1502673
+/subversion/branches/tweak-build-take-two/tools/server-side/mod_dontdothat/mod_dontdothat.c:1424288-1425049,1425051-1425613
+/subversion/branches/uris-as-urls/tools/server-side/mod_dontdothat/mod_dontdothat.c:1060426-1064427
+/subversion/branches/verify-at-commit/tools/server-side/mod_dontdothat/mod_dontdothat.c:1462039-1462408
+/subversion/branches/wc-collate-path/tools/server-side/mod_dontdothat/mod_dontdothat.c:1407642
+/subversion/trunk/tools/server-side/mod_dontdothat/mod_dontdothat.c:1467440,1467450,1467481,1467587,1467597,1467668,1467675,1467803,1467807,1467951,1468109,1468116,1468151,1468347,1468395,1468439,1468487,1468565-1468566,1468980,1469248,1469363,1469478,1469489,1469512-1469513,1469550,1469556,1469645,1469674,1469833,1469862,1469866,1469871,1469994,1470031,1470037,1470221,1470238,1470246,1470248,1470537,1470650,1470738,1470781,1470898,1470904,1470908,1470913,1470936,1470993-1470994,1471028-1471029,1471107,1471153,1471302,1471443,1471490,1471744,1475704,1475724,1475772,1475963,1476092,1476155,1476181,1476193,1476254,1476359,1476366,1476607,1477294,1477359,1477729-1477730,1477876,1477891,1478001,1478220-1478221,1478465,1478617,1478897,1478951,1478987,1478998,1479320-1479321,1479323,1479326,1479329,1479540,1479563,1479605,1479896,1480054,1480077,1480080,1480082,1480119,1480149,1480344,1480412,1480426,1480442,1480616,1480641-1480642,1480664,1480669,1480681,1480723,1480738,1480765,1481010,1
 481418,1481594,1481596,1481625,1481627-1481628,1481631-1481632,1481772,1481800,1481813,1481847,1481944,1481981,1482282,1482327,1482338,1482350,1482354,1482436,1482479,1482524,1482528,1482536,1482554,1482558,1482592,1482724,1482759,1482779,1482829,1482969-1482970,1482973,1483015,1483077,1483101,1483116,1483125,1483391,1483397,1483555,1483557,1483575,1483580,1483781,1483927,1483939,1483947,1483964-1483965,1483968,1483972,1483975,1483977,1483984,1484006,1484016-1484017,1484023,1484755,1485018,1485127,1485350,1485413,1485427,1485447,1485449,1485497,1485501,1485650,1486072,1486457,1486572,1486809,1486915,1486931,1487083,1487094,1488183,1488267,1488294,1488425,1488639,1488693,1488878,1489114,1489116-1489117,1489203,1489339,1489935,1490045,1490326,1490679,1490684,1490721,1491432,1491499,1491707,1491739,1491755-1491756,1491762,1491770,1491816,1491868,1492005,1492020,1492145,1492148,1492152,1492164,1492264,1492295,1493102,1493424,1493475,1493703,1493720,1493951,1494089,1494171,1494223,149428
 7,1494298,1494318,1494342,1494657,1494913,1494967,1495063,1495104,1495204,1495209,1495214,1495256,1495329,1495428,1495432,1495446,1495597,1495805,1495850,1495978,1496007,1496110-1496111,1496127,1496132,1496151,1496470,1496938,1496957,1497002,1497318-1497319,1497551,1497614,1497804,1497975,1497980,1498000,1498012,1498136,1498449,1498455-1498456,1498483-1498484,1498486,1498550,1498564,1498851,1498885,1498997,1499034,1499044,1499064,1499095-1499096,1499100,1499403,1499423,1499438,1499447,1499460,1499470,1499483,1499492,1499496,1499498,1499595,1499727,1500074,1500175,1500226,1500680,1500695,1500762,1500799,1500801-1500802,1500904,1500928,1501199,1501207,1501656,1501702,1502097,1502267,1502577,1502777,1502811,1502901,1502909,1502952,1503009-1503010,1503058,1503061,1503211,1503318,1503528,1503884,1504192,1504505,1506040-1506041,1506047,1506058,1506966,1507044,1507382,1507567,1507589,1507889,1507891,1508438,1509186,1509196,1511057,1511272,1511353,1511603,1512067,1512119,1512195,1512300-151
 2301,1512432,1512471-1512472,1513119,1513122,1513156,1513463,1513472,1513874,1513879-1513880,1513943,1514295,1514315,1514318,1514356,1514628,1514763,1514785,1514804,1515119,1515141,1515201,1515225,1515237,1515343,1515366,1515516,1515534,1515721,1515992,1515997,1516023-1516024,1516049,1516051-1516053,1516071,1516271,1516429,1516556,1516565,1516567,1516806,1518184,1519615,1519617,1519733,1519816,1519823,1519955,1520065,1520529,1520532,1520539,1520745,1522892,1523666,1524869,1525902,1526439,1526655,1527103,1527105,1530763,1530768,1530872,1530922,1530967,1531002,1531004,1531938,1532023,1532098,1534102,1534149,1534158,1534713,1534737,1534860,1535115,1535161,1535532,1535610,1535676,1536537,1536854,1537018,1537147,1537190,1537193,1537221,1537263,1537360,1537415,1537555,1537700,1537812,1538516-1538517,1538519,1538574,1538581,1540044,1540417,1540752,1541432,1541635,1541638,1541705,1541790,1542042,1542069,1542071,1542119,1542129,1542138,1542146,1542151,1542765,1542767,1542774,1543145,1543187,
 1543413,1543961,1544295,1544316,1544878,1544895,1545302,1547252,1547774,1547866,1547873,1548097,1548105,1548170,1548486,1548673,1549858,1549874,1550803,1551524,1551579,1553101,1553105,1553113,1553376-1553377,1554978,1555499,1557320,1557522,1559009,1560690,1560701,1563110,1564292,1564966,1564969,1565085,1567064,1567109,1567134,1567286,1567392,1567492,1567494,1567740,1567752,1567985,1568070,1568872,1568953,1568955,1571214,1572102,1572200,1573088,1575270,1575284