You are viewing a plain text version of this content. The canonical link for it is here.
Posted to notifications@ant.apache.org by hi...@apache.org on 2010/12/14 17:28:36 UTC

svn commit: r1049146 [11/19] - in /ant/ivy/core/trunk: ./ src/etc/checkstyle/ src/etc/license/ src/example/build-a-ivy-repository/ src/example/build-a-ivy-repository/settings/ src/example/chained-resolvers/ src/example/chained-resolvers/chainedresolver...

Propchange: ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/conflict/ivysettings-strict-test.xml
------------------------------------------------------------------------------
    svn:keywords = Date Revision Author HeadURL Id

Propchange: ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/conflict/ivysettings-strict-test.xml
------------------------------------------------------------------------------
    svn:mime-type = text/xml

Propchange: ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/latest/LatestRevisionStrategyTest.java
------------------------------------------------------------------------------
    svn:keywords = Date Revision Author HeadURL Id

Propchange: ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/latest/LatestRevisionStrategyTest.java
------------------------------------------------------------------------------
    svn:mime-type = text/plain

Modified: ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/lock/ArtifactLockStrategyTest.java
URL: http://svn.apache.org/viewvc/ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/lock/ArtifactLockStrategyTest.java?rev=1049146&r1=1049145&r2=1049146&view=diff
==============================================================================
--- ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/lock/ArtifactLockStrategyTest.java (original)
+++ ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/lock/ArtifactLockStrategyTest.java Tue Dec 14 16:28:01 2010
@@ -1,193 +1,193 @@
-/*
- *  Licensed to the Apache Software Foundation (ASF) under one or more
- *  contributor license agreements.  See the NOTICE file distributed with
- *  this work for additional information regarding copyright ownership.
- *  The ASF licenses this file to You under the Apache License, Version 2.0
- *  (the "License"); you may not use this file except in compliance with
- *  the License.  You may obtain a copy of the License at
- *
- *      http://www.apache.org/licenses/LICENSE-2.0
- *
- *  Unless required by applicable law or agreed to in writing, software
- *  distributed under the License is distributed on an "AS IS" BASIS,
- *  WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- *  See the License for the specific language governing permissions and
- *  limitations under the License.
- *
- */
-package org.apache.ivy.plugins.lock;
-
-import java.io.File;
-import java.text.ParseException;
-
-import junit.framework.TestCase;
-
-import org.apache.ivy.core.cache.DefaultRepositoryCacheManager;
-import org.apache.ivy.core.cache.RepositoryCacheManager;
-import org.apache.ivy.core.event.EventManager;
-import org.apache.ivy.core.module.descriptor.DefaultDependencyDescriptor;
-import org.apache.ivy.core.module.id.ModuleRevisionId;
-import org.apache.ivy.core.resolve.ResolveData;
-import org.apache.ivy.core.resolve.ResolveEngine;
-import org.apache.ivy.core.resolve.ResolveOptions;
-import org.apache.ivy.core.resolve.ResolvedModuleRevision;
-import org.apache.ivy.core.settings.IvySettings;
-import org.apache.ivy.core.sort.SortEngine;
-import org.apache.ivy.plugins.repository.RepositoryCopyProgressListener;
-import org.apache.ivy.plugins.repository.file.FileRepository;
-import org.apache.ivy.plugins.resolver.FileSystemResolver;
-import org.apache.ivy.util.CopyProgressEvent;
-import org.apache.ivy.util.FileUtil;
-import org.apache.ivy.util.Message;
-
-public class ArtifactLockStrategyTest extends TestCase {
-    protected void setUp() throws Exception {
-        FileUtil.forceDelete(new File("build/test/cache"));
-    }
-    protected void tearDown() throws Exception {
-        FileUtil.forceDelete(new File("build/test/cache"));
-    }
-
-    public void testConcurrentResolve() throws Exception {
-        // we use different settings because Ivy do not support multi thread resolve with the same
-        // settings yet and this is not what this test is about: the focus of this test is running
-        // concurrent resolves in separate vms but using the same cache. We don't span the test on
-        // multiple vms, but using separate settings we should only run into shared cache related
-        // issues, and not multi thread related issues.
-        IvySettings settings1 = new IvySettings();
-        IvySettings settings2 = new IvySettings();
-        IvySettings settings3 = new IvySettings();
-
-        // run 3 concurrent resolves, one taking 100ms to download files, one 20ms and one 5ms
-        // the first one do 10 resolves, the second one 20 and the third 50
-        // note that the download time is useful only at the very beginning, then the cached file is used
-        ResolveThread t1 = asyncResolve(
-            settings1, createSlowResolver(settings1, 100), "org6#mod6.4;3", 10);
-        ResolveThread t2 = asyncResolve(
-            settings2, createSlowResolver(settings2, 20), "org6#mod6.4;3", 20);
-        ResolveThread t3 = asyncResolve(
-            settings3, createSlowResolver(settings3, 5), "org6#mod6.4;3", 50);
-        t1.join(100000);
-        t2.join(20000);
-        t3.join(20000);
-        assertEquals(10, t1.getCount());
-        assertFound("org6#mod6.4;3", t1.getFinalResult());
-        assertEquals(20, t2.getCount());
-        assertFound("org6#mod6.4;3", t2.getFinalResult());
-        assertEquals(50, t3.getCount());
-        assertFound("org6#mod6.4;3", t3.getFinalResult());
-    }    
-
-    
-    private RepositoryCacheManager newCacheManager(IvySettings settings) {
-        DefaultRepositoryCacheManager cacheManager 
-            = new DefaultRepositoryCacheManager("cache", settings, new File("build/test/cache"));
-        cacheManager.setLockStrategy(new ArtifactLockStrategy());
-        return cacheManager;
-    }
-    
-    
-    private FileSystemResolver createSlowResolver(IvySettings settings, final int sleep) {
-        FileSystemResolver resolver = new FileSystemResolver();
-        resolver.setRepositoryCacheManager(newCacheManager(settings));
-        resolver.setRepository(new FileRepository() {
-            private RepositoryCopyProgressListener progress = new RepositoryCopyProgressListener(this) {
-                public void progress(CopyProgressEvent evt) {
-                    super.progress(evt);
-                    sleepSilently(sleep); // makes the file copy longer to test concurrency issues
-                }
-            };
-            protected RepositoryCopyProgressListener getProgressListener() {
-                return progress ;
-            }
-        });
-        resolver.setName("test");
-        resolver.setSettings(settings);
-        resolver.addIvyPattern(
-            settings.getBaseDir() + "/test/repositories/1/[organisation]/[module]/[type]s/[artifact]-[revision].[ext]");
-        resolver.addArtifactPattern(
-            settings.getBaseDir() + "/test/repositories/1/[organisation]/[module]/[type]s/[artifact]-[revision].[ext]");
-        return resolver;
-    }
-
-    
-    private ResolveThread asyncResolve(
-            IvySettings settings, FileSystemResolver resolver, String module, int loop) {
-        ResolveThread thread = new ResolveThread(settings, resolver, module, loop);
-        thread.start();
-        return thread;
-    }
-    
-    
-    private void assertFound(String module, ResolvedModuleRevision rmr) {
-        assertNotNull(rmr);
-        assertEquals(module, rmr.getId().toString());
-    }
-    private ResolvedModuleRevision resolveModule(
-            IvySettings settings, FileSystemResolver resolver, String module)
-            throws ParseException {
-        return resolver.getDependency(
-            new DefaultDependencyDescriptor(ModuleRevisionId.parse(module), false), 
-            new ResolveData(
-                new ResolveEngine(settings, new EventManager(), new SortEngine(settings)), 
-                new ResolveOptions()));
-    }
-    private void sleepSilently(int timeout) {
-        try {
-            Thread.sleep(timeout);
-        } catch (InterruptedException e) {
-        }
-    }
-    private class ResolveThread extends Thread {
-        private IvySettings settings;
-        private FileSystemResolver resolver;
-        private String module;
-        private final int loop;
-
-        private ResolvedModuleRevision finalResult;
-        private int count;
-        
-        public ResolveThread(IvySettings settings, FileSystemResolver resolver, String module, int loop) {
-            this.settings = settings;
-            this.resolver = resolver;
-            this.module = module;
-            this.loop = loop;
-        }
-        
-        public synchronized ResolvedModuleRevision getFinalResult() {
-            return finalResult;
-        }
-        public synchronized int getCount() {
-            return count;
-        }
-        public void run() {
-            ResolvedModuleRevision rmr = null;
-            for (int i =0; i<loop; i++) {
-                try {
-                    rmr = resolveModule(settings, resolver, module);
-                    if (rmr == null) {
-                        throw new RuntimeException("module not found: " + module);
-                    }
-                    synchronized (this) {
-                        //Message.info(this.toString() + " count = " + count);
-                        count++;
-                    }
-                } catch (ParseException e) {
-                    Message.info("parse exception "+e);
-                } catch (RuntimeException e) {
-                    Message.info("exception "+e);
-                    e.printStackTrace();
-                    throw e;
-                } catch (Error e) {
-                    Message.info("exception "+e);
-                    e.printStackTrace();
-                    throw e;
-                }
-            }
-            synchronized (this) {
-                finalResult = rmr;
-            }
-        }
-    }
-
-}
+/*
+ *  Licensed to the Apache Software Foundation (ASF) under one or more
+ *  contributor license agreements.  See the NOTICE file distributed with
+ *  this work for additional information regarding copyright ownership.
+ *  The ASF licenses this file to You under the Apache License, Version 2.0
+ *  (the "License"); you may not use this file except in compliance with
+ *  the License.  You may obtain a copy of the License at
+ *
+ *      http://www.apache.org/licenses/LICENSE-2.0
+ *
+ *  Unless required by applicable law or agreed to in writing, software
+ *  distributed under the License is distributed on an "AS IS" BASIS,
+ *  WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ *  See the License for the specific language governing permissions and
+ *  limitations under the License.
+ *
+ */
+package org.apache.ivy.plugins.lock;
+
+import java.io.File;
+import java.text.ParseException;
+
+import junit.framework.TestCase;
+
+import org.apache.ivy.core.cache.DefaultRepositoryCacheManager;
+import org.apache.ivy.core.cache.RepositoryCacheManager;
+import org.apache.ivy.core.event.EventManager;
+import org.apache.ivy.core.module.descriptor.DefaultDependencyDescriptor;
+import org.apache.ivy.core.module.id.ModuleRevisionId;
+import org.apache.ivy.core.resolve.ResolveData;
+import org.apache.ivy.core.resolve.ResolveEngine;
+import org.apache.ivy.core.resolve.ResolveOptions;
+import org.apache.ivy.core.resolve.ResolvedModuleRevision;
+import org.apache.ivy.core.settings.IvySettings;
+import org.apache.ivy.core.sort.SortEngine;
+import org.apache.ivy.plugins.repository.RepositoryCopyProgressListener;
+import org.apache.ivy.plugins.repository.file.FileRepository;
+import org.apache.ivy.plugins.resolver.FileSystemResolver;
+import org.apache.ivy.util.CopyProgressEvent;
+import org.apache.ivy.util.FileUtil;
+import org.apache.ivy.util.Message;
+
+public class ArtifactLockStrategyTest extends TestCase {
+    protected void setUp() throws Exception {
+        FileUtil.forceDelete(new File("build/test/cache"));
+    }
+    protected void tearDown() throws Exception {
+        FileUtil.forceDelete(new File("build/test/cache"));
+    }
+
+    public void testConcurrentResolve() throws Exception {
+        // we use different settings because Ivy do not support multi thread resolve with the same
+        // settings yet and this is not what this test is about: the focus of this test is running
+        // concurrent resolves in separate vms but using the same cache. We don't span the test on
+        // multiple vms, but using separate settings we should only run into shared cache related
+        // issues, and not multi thread related issues.
+        IvySettings settings1 = new IvySettings();
+        IvySettings settings2 = new IvySettings();
+        IvySettings settings3 = new IvySettings();
+
+        // run 3 concurrent resolves, one taking 100ms to download files, one 20ms and one 5ms
+        // the first one do 10 resolves, the second one 20 and the third 50
+        // note that the download time is useful only at the very beginning, then the cached file is used
+        ResolveThread t1 = asyncResolve(
+            settings1, createSlowResolver(settings1, 100), "org6#mod6.4;3", 10);
+        ResolveThread t2 = asyncResolve(
+            settings2, createSlowResolver(settings2, 20), "org6#mod6.4;3", 20);
+        ResolveThread t3 = asyncResolve(
+            settings3, createSlowResolver(settings3, 5), "org6#mod6.4;3", 50);
+        t1.join(100000);
+        t2.join(20000);
+        t3.join(20000);
+        assertEquals(10, t1.getCount());
+        assertFound("org6#mod6.4;3", t1.getFinalResult());
+        assertEquals(20, t2.getCount());
+        assertFound("org6#mod6.4;3", t2.getFinalResult());
+        assertEquals(50, t3.getCount());
+        assertFound("org6#mod6.4;3", t3.getFinalResult());
+    }    
+
+    
+    private RepositoryCacheManager newCacheManager(IvySettings settings) {
+        DefaultRepositoryCacheManager cacheManager 
+            = new DefaultRepositoryCacheManager("cache", settings, new File("build/test/cache"));
+        cacheManager.setLockStrategy(new ArtifactLockStrategy());
+        return cacheManager;
+    }
+    
+    
+    private FileSystemResolver createSlowResolver(IvySettings settings, final int sleep) {
+        FileSystemResolver resolver = new FileSystemResolver();
+        resolver.setRepositoryCacheManager(newCacheManager(settings));
+        resolver.setRepository(new FileRepository() {
+            private RepositoryCopyProgressListener progress = new RepositoryCopyProgressListener(this) {
+                public void progress(CopyProgressEvent evt) {
+                    super.progress(evt);
+                    sleepSilently(sleep); // makes the file copy longer to test concurrency issues
+                }
+            };
+            protected RepositoryCopyProgressListener getProgressListener() {
+                return progress ;
+            }
+        });
+        resolver.setName("test");
+        resolver.setSettings(settings);
+        resolver.addIvyPattern(
+            settings.getBaseDir() + "/test/repositories/1/[organisation]/[module]/[type]s/[artifact]-[revision].[ext]");
+        resolver.addArtifactPattern(
+            settings.getBaseDir() + "/test/repositories/1/[organisation]/[module]/[type]s/[artifact]-[revision].[ext]");
+        return resolver;
+    }
+
+    
+    private ResolveThread asyncResolve(
+            IvySettings settings, FileSystemResolver resolver, String module, int loop) {
+        ResolveThread thread = new ResolveThread(settings, resolver, module, loop);
+        thread.start();
+        return thread;
+    }
+    
+    
+    private void assertFound(String module, ResolvedModuleRevision rmr) {
+        assertNotNull(rmr);
+        assertEquals(module, rmr.getId().toString());
+    }
+    private ResolvedModuleRevision resolveModule(
+            IvySettings settings, FileSystemResolver resolver, String module)
+            throws ParseException {
+        return resolver.getDependency(
+            new DefaultDependencyDescriptor(ModuleRevisionId.parse(module), false), 
+            new ResolveData(
+                new ResolveEngine(settings, new EventManager(), new SortEngine(settings)), 
+                new ResolveOptions()));
+    }
+    private void sleepSilently(int timeout) {
+        try {
+            Thread.sleep(timeout);
+        } catch (InterruptedException e) {
+        }
+    }
+    private class ResolveThread extends Thread {
+        private IvySettings settings;
+        private FileSystemResolver resolver;
+        private String module;
+        private final int loop;
+
+        private ResolvedModuleRevision finalResult;
+        private int count;
+        
+        public ResolveThread(IvySettings settings, FileSystemResolver resolver, String module, int loop) {
+            this.settings = settings;
+            this.resolver = resolver;
+            this.module = module;
+            this.loop = loop;
+        }
+        
+        public synchronized ResolvedModuleRevision getFinalResult() {
+            return finalResult;
+        }
+        public synchronized int getCount() {
+            return count;
+        }
+        public void run() {
+            ResolvedModuleRevision rmr = null;
+            for (int i =0; i<loop; i++) {
+                try {
+                    rmr = resolveModule(settings, resolver, module);
+                    if (rmr == null) {
+                        throw new RuntimeException("module not found: " + module);
+                    }
+                    synchronized (this) {
+                        //Message.info(this.toString() + " count = " + count);
+                        count++;
+                    }
+                } catch (ParseException e) {
+                    Message.info("parse exception "+e);
+                } catch (RuntimeException e) {
+                    Message.info("exception "+e);
+                    e.printStackTrace();
+                    throw e;
+                } catch (Error e) {
+                    Message.info("exception "+e);
+                    e.printStackTrace();
+                    throw e;
+                }
+            }
+            synchronized (this) {
+                finalResult = rmr;
+            }
+        }
+    }
+
+}

Propchange: ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/lock/ArtifactLockStrategyTest.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/lock/ArtifactLockStrategyTest.java
------------------------------------------------------------------------------
    svn:keywords = Date Revision Author HeadURL Id

Propchange: ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/matcher/AbstractPatternMatcherTest.java
------------------------------------------------------------------------------
    svn:keywords = Date Revision Author HeadURL Id

Propchange: ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/matcher/AbstractPatternMatcherTest.java
------------------------------------------------------------------------------
    svn:mime-type = text/plain

Propchange: ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/matcher/ExactOrRegexpPatternMatcherTest.java
------------------------------------------------------------------------------
    svn:keywords = Date Revision Author HeadURL Id

Propchange: ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/matcher/ExactOrRegexpPatternMatcherTest.java
------------------------------------------------------------------------------
    svn:mime-type = text/plain

Propchange: ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/matcher/ExactPatternMatcherTest.java
------------------------------------------------------------------------------
    svn:keywords = Date Revision Author HeadURL Id

Propchange: ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/matcher/ExactPatternMatcherTest.java
------------------------------------------------------------------------------
    svn:mime-type = text/plain

Propchange: ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/matcher/GlobPatternMatcherTest.java
------------------------------------------------------------------------------
    svn:keywords = Date Revision Author HeadURL Id

Propchange: ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/matcher/GlobPatternMatcherTest.java
------------------------------------------------------------------------------
    svn:mime-type = text/plain

Propchange: ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/matcher/RegexpPatternMatcherTest.java
------------------------------------------------------------------------------
    svn:keywords = Date Revision Author HeadURL Id

Propchange: ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/matcher/RegexpPatternMatcherTest.java
------------------------------------------------------------------------------
    svn:mime-type = text/plain

Propchange: ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/namespace/MRIDTransformationRuleTest.java
------------------------------------------------------------------------------
    svn:keywords = Date Revision Author HeadURL Id

Propchange: ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/namespace/MRIDTransformationRuleTest.java
------------------------------------------------------------------------------
    svn:mime-type = text/plain

Propchange: ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/namespace/NameSpaceHelperTest.java
------------------------------------------------------------------------------
    svn:keywords = Date Revision Author HeadURL Id

Propchange: ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/parser/AbstractModuleDescriptorParserTester.java
------------------------------------------------------------------------------
    svn:keywords = Date Revision Author HeadURL Id

Propchange: ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/parser/AbstractModuleDescriptorParserTester.java
------------------------------------------------------------------------------
    svn:mime-type = text/plain

Propchange: ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/parser/ModuleDescriptorParserRegistryTest.java
------------------------------------------------------------------------------
    svn:keywords = Date Revision Author HeadURL Id

Propchange: ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/parser/ModuleDescriptorParserRegistryTest.java
------------------------------------------------------------------------------
    svn:mime-type = text/plain

Propchange: ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/parser/m2/PomModuleDescriptorParserTest.java
------------------------------------------------------------------------------
    svn:keywords = Date Revision Author HeadURL Id

Propchange: ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/parser/m2/PomModuleDescriptorParserTest.java
------------------------------------------------------------------------------
    svn:mime-type = text/plain

Propchange: ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/parser/m2/PomModuleDescriptorWriterTest.java
------------------------------------------------------------------------------
    svn:keywords = Date Revision Author HeadURL Id

Propchange: ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/parser/m2/PomModuleDescriptorWriterTest.java
------------------------------------------------------------------------------
    svn:mime-type = text/plain

Propchange: ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/parser/m2/license.xml
------------------------------------------------------------------------------
    svn:keywords = Date Revision Author HeadURL Id

Propchange: ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/parser/m2/license.xml
------------------------------------------------------------------------------
    svn:mime-type = text/xml

Modified: ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/parser/m2/test-write-compile-dependencies.xml
URL: http://svn.apache.org/viewvc/ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/parser/m2/test-write-compile-dependencies.xml?rev=1049146&r1=1049145&r2=1049146&view=diff
==============================================================================
--- ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/parser/m2/test-write-compile-dependencies.xml (original)
+++ ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/parser/m2/test-write-compile-dependencies.xml Tue Dec 14 16:28:01 2010
@@ -1,43 +1,43 @@
-<?xml version="1.0" encoding="UTF-8"?>
-<!--
-   Licensed to the Apache Software Foundation (ASF) under one
-   or more contributor license agreements.  See the NOTICE file
-   distributed with this work for additional information
-   regarding copyright ownership.  The ASF licenses this file
-   to you under the Apache License, Version 2.0 (the
-   "License"); you may not use this file except in compliance
-   with the License.  You may obtain a copy of the License at
-
-     http://www.apache.org/licenses/LICENSE-2.0
-
-   Unless required by applicable law or agreed to in writing,
-   software distributed under the License is distributed on an
-   "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
-   KIND, either express or implied.  See the License for the
-   specific language governing permissions and limitations
-   under the License.    
--->
-<project xmlns="http://maven.apache.org/POM/4.0.0" xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
-    xsi:schemaLocation="http://maven.apache.org/POM/4.0.0 http://maven.apache.org/maven-v4_0_0.xsd">
-
-  <modelVersion>4.0.0</modelVersion>
-  <groupId>org.apache</groupId>
-  <artifactId>test</artifactId>
-  <packaging>jar</packaging>
-  <version>1.0</version>
-  <url>http://ant.apache.org/ivy</url>
-  <dependencies>
-    <dependency>
-      <groupId>commons-logging</groupId>
-      <artifactId>commons-logging</artifactId>
-      <version>1.0.4</version>
-      <scope>compile</scope>
-    </dependency>
-    <dependency>
-      <groupId>cglib</groupId>
-      <artifactId>cglib</artifactId>
-      <version>2.0.2</version>
-      <scope>compile</scope>
-    </dependency>
-  </dependencies>
-</project>
+<?xml version="1.0" encoding="UTF-8"?>
+<!--
+   Licensed to the Apache Software Foundation (ASF) under one
+   or more contributor license agreements.  See the NOTICE file
+   distributed with this work for additional information
+   regarding copyright ownership.  The ASF licenses this file
+   to you under the Apache License, Version 2.0 (the
+   "License"); you may not use this file except in compliance
+   with the License.  You may obtain a copy of the License at
+
+     http://www.apache.org/licenses/LICENSE-2.0
+
+   Unless required by applicable law or agreed to in writing,
+   software distributed under the License is distributed on an
+   "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+   KIND, either express or implied.  See the License for the
+   specific language governing permissions and limitations
+   under the License.    
+-->
+<project xmlns="http://maven.apache.org/POM/4.0.0" xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
+    xsi:schemaLocation="http://maven.apache.org/POM/4.0.0 http://maven.apache.org/maven-v4_0_0.xsd">
+
+  <modelVersion>4.0.0</modelVersion>
+  <groupId>org.apache</groupId>
+  <artifactId>test</artifactId>
+  <packaging>jar</packaging>
+  <version>1.0</version>
+  <url>http://ant.apache.org/ivy</url>
+  <dependencies>
+    <dependency>
+      <groupId>commons-logging</groupId>
+      <artifactId>commons-logging</artifactId>
+      <version>1.0.4</version>
+      <scope>compile</scope>
+    </dependency>
+    <dependency>
+      <groupId>cglib</groupId>
+      <artifactId>cglib</artifactId>
+      <version>2.0.2</version>
+      <scope>compile</scope>
+    </dependency>
+  </dependencies>
+</project>

Propchange: ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/parser/m2/test-write-compile-dependencies.xml
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/parser/m2/test-write-compile-dependencies.xml
------------------------------------------------------------------------------
    svn:keywords = Date Revision Author HeadURL Id

Propchange: ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/parser/m2/test-write-compile-dependencies.xml
------------------------------------------------------------------------------
--- svn:mime-type (original)
+++ svn:mime-type Tue Dec 14 16:28:01 2010
@@ -1 +1 @@
-text/plain
+text/xml

Propchange: ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/parser/m2/test-write-dependencies-optional.xml
------------------------------------------------------------------------------
    svn:keywords = Date Revision Author HeadURL Id

Propchange: ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/parser/m2/test-write-dependencies-optional.xml
------------------------------------------------------------------------------
    svn:mime-type = text/xml

Propchange: ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/parser/m2/test-write-dependencies-with-scope.xml
------------------------------------------------------------------------------
    svn:keywords = Date Revision Author HeadURL Id

Propchange: ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/parser/m2/test-write-dependencies-with-scope.xml
------------------------------------------------------------------------------
    svn:mime-type = text/xml

Modified: ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/parser/m2/test-write-packaging.xml
URL: http://svn.apache.org/viewvc/ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/parser/m2/test-write-packaging.xml?rev=1049146&r1=1049145&r2=1049146&view=diff
==============================================================================
--- ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/parser/m2/test-write-packaging.xml (original)
+++ ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/parser/m2/test-write-packaging.xml Tue Dec 14 16:28:01 2010
@@ -1,29 +1,29 @@
-<?xml version="1.0" encoding="UTF-8"?>
-<!--
-   Licensed to the Apache Software Foundation (ASF) under one
-   or more contributor license agreements.  See the NOTICE file
-   distributed with this work for additional information
-   regarding copyright ownership.  The ASF licenses this file
-   to you under the Apache License, Version 2.0 (the
-   "License"); you may not use this file except in compliance
-   with the License.  You may obtain a copy of the License at
-
-     http://www.apache.org/licenses/LICENSE-2.0
-
-   Unless required by applicable law or agreed to in writing,
-   software distributed under the License is distributed on an
-   "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
-   KIND, either express or implied.  See the License for the
-   specific language governing permissions and limitations
-   under the License.    
--->
-<project xmlns="http://maven.apache.org/POM/4.0.0" xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
-    xsi:schemaLocation="http://maven.apache.org/POM/4.0.0 http://maven.apache.org/maven-v4_0_0.xsd">
-
-  <modelVersion>4.0.0</modelVersion>
-  <groupId>org.apache</groupId>
-  <artifactId>test</artifactId>
-  <packaging>war</packaging>
-  <version>1.0</version>
-  <url>http://ivy.jayasoft.org/</url>
-</project>
+<?xml version="1.0" encoding="UTF-8"?>
+<!--
+   Licensed to the Apache Software Foundation (ASF) under one
+   or more contributor license agreements.  See the NOTICE file
+   distributed with this work for additional information
+   regarding copyright ownership.  The ASF licenses this file
+   to you under the Apache License, Version 2.0 (the
+   "License"); you may not use this file except in compliance
+   with the License.  You may obtain a copy of the License at
+
+     http://www.apache.org/licenses/LICENSE-2.0
+
+   Unless required by applicable law or agreed to in writing,
+   software distributed under the License is distributed on an
+   "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+   KIND, either express or implied.  See the License for the
+   specific language governing permissions and limitations
+   under the License.    
+-->
+<project xmlns="http://maven.apache.org/POM/4.0.0" xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
+    xsi:schemaLocation="http://maven.apache.org/POM/4.0.0 http://maven.apache.org/maven-v4_0_0.xsd">
+
+  <modelVersion>4.0.0</modelVersion>
+  <groupId>org.apache</groupId>
+  <artifactId>test</artifactId>
+  <packaging>war</packaging>
+  <version>1.0</version>
+  <url>http://ivy.jayasoft.org/</url>
+</project>

Propchange: ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/parser/m2/test-write-packaging.xml
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/parser/m2/test-write-packaging.xml
------------------------------------------------------------------------------
    svn:keywords = Date Revision Author HeadURL Id

Propchange: ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/parser/m2/test-write-packaging.xml
------------------------------------------------------------------------------
--- svn:mime-type (original)
+++ svn:mime-type Tue Dec 14 16:28:01 2010
@@ -1 +1 @@
-text/plain
+text/xml

Propchange: ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/parser/m2/test-write-simple-dependencies.xml
------------------------------------------------------------------------------
    svn:keywords = Date Revision Author HeadURL Id

Propchange: ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/parser/m2/test-write-simple-dependencies.xml
------------------------------------------------------------------------------
    svn:mime-type = text/xml

Propchange: ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/parser/m2/test-write-simple.xml
------------------------------------------------------------------------------
    svn:keywords = Date Revision Author HeadURL Id

Propchange: ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/parser/m2/test-write-simple.xml
------------------------------------------------------------------------------
    svn:mime-type = text/xml

Propchange: ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/parser/xml/XmlModuleDescriptorParserTest.java
------------------------------------------------------------------------------
    svn:keywords = Date Revision Author HeadURL Id

Propchange: ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/parser/xml/XmlModuleDescriptorParserTest.java
------------------------------------------------------------------------------
    svn:mime-type = text/plain

Propchange: ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/parser/xml/XmlModuleDescriptorWriterTest.java
------------------------------------------------------------------------------
    svn:keywords = Date Revision Author HeadURL Id

Propchange: ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/parser/xml/XmlModuleDescriptorWriterTest.java
------------------------------------------------------------------------------
    svn:mime-type = text/plain

Propchange: ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/parser/xml/XmlModuleUpdaterTest.java
------------------------------------------------------------------------------
    svn:keywords = Date Revision Author HeadURL Id

Propchange: ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/parser/xml/XmlModuleUpdaterTest.java
------------------------------------------------------------------------------
    svn:mime-type = text/plain

Propchange: ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/parser/xml/imported-configurations-with-mapping.xml
------------------------------------------------------------------------------
    svn:keywords = Date Revision Author HeadURL Id

Propchange: ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/parser/xml/imported-configurations-with-mapping.xml
------------------------------------------------------------------------------
    svn:mime-type = text/xml

Propchange: ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/parser/xml/imported-configurations-with-mappingoverride.xml
------------------------------------------------------------------------------
    svn:keywords = Date Revision Author HeadURL Id

Propchange: ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/parser/xml/imported-configurations-with-mappingoverride.xml
------------------------------------------------------------------------------
    svn:mime-type = text/xml

Propchange: ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/parser/xml/imported-configurations-with-wildcard.xml
------------------------------------------------------------------------------
    svn:keywords = Date Revision Author HeadURL Id

Propchange: ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/parser/xml/imported-configurations-with-wildcard.xml
------------------------------------------------------------------------------
    svn:mime-type = text/xml

Propchange: ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/parser/xml/imported-configurations.xml
------------------------------------------------------------------------------
    svn:keywords = Date Revision Author HeadURL Id

Propchange: ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/parser/xml/imported-configurations.xml
------------------------------------------------------------------------------
    svn:mime-type = text/xml

Propchange: ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/parser/xml/license.xml
------------------------------------------------------------------------------
    svn:keywords = Date Revision Author HeadURL Id

Propchange: ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/parser/xml/license.xml
------------------------------------------------------------------------------
    svn:mime-type = text/xml

Propchange: ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/parser/xml/test-artifacts-defaults.xml
------------------------------------------------------------------------------
    svn:keywords = Date Revision Author HeadURL Id

Propchange: ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/parser/xml/test-artifacts-defaults.xml
------------------------------------------------------------------------------
    svn:mime-type = text/xml

Propchange: ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/parser/xml/test-bad-confs.xml
------------------------------------------------------------------------------
    svn:keywords = Date Revision Author HeadURL Id

Propchange: ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/parser/xml/test-bad-confs.xml
------------------------------------------------------------------------------
    svn:mime-type = text/xml

Propchange: ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/parser/xml/test-bad-org.xml
------------------------------------------------------------------------------
    svn:keywords = Date Revision Author HeadURL Id

Propchange: ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/parser/xml/test-bad-org.xml
------------------------------------------------------------------------------
    svn:mime-type = text/xml

Propchange: ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/parser/xml/test-bad-version.xml
------------------------------------------------------------------------------
    svn:keywords = Date Revision Author HeadURL Id

Propchange: ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/parser/xml/test-bad-version.xml
------------------------------------------------------------------------------
    svn:mime-type = text/xml

Propchange: ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/parser/xml/test-bad.xml
------------------------------------------------------------------------------
    svn:keywords = Date Revision Author HeadURL Id

Propchange: ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/parser/xml/test-bad.xml
------------------------------------------------------------------------------
    svn:mime-type = text/xml

Propchange: ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/parser/xml/test-bug60.xml
------------------------------------------------------------------------------
    svn:keywords = Date Revision Author HeadURL Id

Propchange: ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/parser/xml/test-bug60.xml
------------------------------------------------------------------------------
    svn:mime-type = text/xml

Propchange: ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/parser/xml/test-configextendsothers1.xml
------------------------------------------------------------------------------
    svn:keywords = Date Revision Author HeadURL Id

Propchange: ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/parser/xml/test-configextendsothers1.xml
------------------------------------------------------------------------------
    svn:mime-type = text/xml

Propchange: ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/parser/xml/test-configextendsothers2.xml
------------------------------------------------------------------------------
    svn:keywords = Date Revision Author HeadURL Id

Propchange: ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/parser/xml/test-configextendsothers2.xml
------------------------------------------------------------------------------
    svn:mime-type = text/xml

Propchange: ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/parser/xml/test-configextendsothers3.xml
------------------------------------------------------------------------------
    svn:keywords = Date Revision Author HeadURL Id

Propchange: ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/parser/xml/test-configextendsothers3.xml
------------------------------------------------------------------------------
    svn:mime-type = text/xml

Propchange: ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/parser/xml/test-configurations-import1.xml
------------------------------------------------------------------------------
    svn:keywords = Date Revision Author HeadURL Id

Propchange: ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/parser/xml/test-configurations-import1.xml
------------------------------------------------------------------------------
    svn:mime-type = text/xml

Propchange: ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/parser/xml/test-configurations-import2.xml
------------------------------------------------------------------------------
    svn:keywords = Date Revision Author HeadURL Id

Propchange: ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/parser/xml/test-configurations-import2.xml
------------------------------------------------------------------------------
    svn:mime-type = text/xml

Propchange: ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/parser/xml/test-configurations-import3.xml
------------------------------------------------------------------------------
    svn:keywords = Date Revision Author HeadURL Id

Propchange: ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/parser/xml/test-configurations-import3.xml
------------------------------------------------------------------------------
    svn:mime-type = text/xml

Propchange: ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/parser/xml/test-configurations-import4.xml
------------------------------------------------------------------------------
    svn:keywords = Date Revision Author HeadURL Id

Propchange: ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/parser/xml/test-configurations-import4.xml
------------------------------------------------------------------------------
    svn:mime-type = text/xml

Propchange: ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/parser/xml/test-configurations-import5.xml
------------------------------------------------------------------------------
    svn:keywords = Date Revision Author HeadURL Id

Propchange: ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/parser/xml/test-configurations-import5.xml
------------------------------------------------------------------------------
    svn:mime-type = text/xml

Propchange: ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/parser/xml/test-cyclic-confs1.xml
------------------------------------------------------------------------------
    svn:keywords = Date Revision Author HeadURL Id

Propchange: ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/parser/xml/test-cyclic-confs1.xml
------------------------------------------------------------------------------
--- svn:mime-type (original)
+++ svn:mime-type Tue Dec 14 16:28:01 2010
@@ -1 +1 @@
-text/plain
+text/xml

Propchange: ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/parser/xml/test-cyclic-confs2.xml
------------------------------------------------------------------------------
    svn:keywords = Date Revision Author HeadURL Id

Propchange: ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/parser/xml/test-cyclic-confs2.xml
------------------------------------------------------------------------------
--- svn:mime-type (original)
+++ svn:mime-type Tue Dec 14 16:28:01 2010
@@ -1 +1 @@
-text/plain
+text/xml

Modified: ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/parser/xml/test-defaultconf-withdefaultconfmapping.xml
URL: http://svn.apache.org/viewvc/ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/parser/xml/test-defaultconf-withdefaultconfmapping.xml?rev=1049146&r1=1049145&r2=1049146&view=diff
==============================================================================
--- ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/parser/xml/test-defaultconf-withdefaultconfmapping.xml (original)
+++ ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/parser/xml/test-defaultconf-withdefaultconfmapping.xml Tue Dec 14 16:28:01 2010
@@ -1,35 +1,35 @@
-<?xml version="1.0" encoding="ISO-8859-1"?>
-<?xml-stylesheet type="text/xsl" href="http://www.jayasoft.fr/org/ivyrep/ivy-doc.xsl"?>
-<!--
-   Licensed to the Apache Software Foundation (ASF) under one
-   or more contributor license agreements.  See the NOTICE file
-   distributed with this work for additional information
-   regarding copyright ownership.  The ASF licenses this file
-   to you under the Apache License, Version 2.0 (the
-   "License"); you may not use this file except in compliance
-   with the License.  You may obtain a copy of the License at
-
-     http://www.apache.org/licenses/LICENSE-2.0
-
-   Unless required by applicable law or agreed to in writing,
-   software distributed under the License is distributed on an
-   "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
-   KIND, either express or implied.  See the License for the
-   specific language governing permissions and limitations
-   under the License.    
--->
-<ivy-module version="1.0">
-	<info organisation="myorg"
-	       module="mymodule"
-	       revision="myrev"
-	       status="integration"
-	       publication="20041101110000"/>
-	<configurations defaultconfmapping="test->default" defaultconf="default">
-		<conf name="default"/>
-		<conf name="test"/>
-	</configurations>
-	<dependencies>
-		<dependency name="mymodule1" rev="1.0"/>
-		<dependency name="mymodule2" rev="2.0" conf="test"/>
-	</dependencies>
-</ivy-module>
+<?xml version="1.0" encoding="ISO-8859-1"?>
+<?xml-stylesheet type="text/xsl" href="http://www.jayasoft.fr/org/ivyrep/ivy-doc.xsl"?>
+<!--
+   Licensed to the Apache Software Foundation (ASF) under one
+   or more contributor license agreements.  See the NOTICE file
+   distributed with this work for additional information
+   regarding copyright ownership.  The ASF licenses this file
+   to you under the Apache License, Version 2.0 (the
+   "License"); you may not use this file except in compliance
+   with the License.  You may obtain a copy of the License at
+
+     http://www.apache.org/licenses/LICENSE-2.0
+
+   Unless required by applicable law or agreed to in writing,
+   software distributed under the License is distributed on an
+   "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+   KIND, either express or implied.  See the License for the
+   specific language governing permissions and limitations
+   under the License.    
+-->
+<ivy-module version="1.0">
+	<info organisation="myorg"
+	       module="mymodule"
+	       revision="myrev"
+	       status="integration"
+	       publication="20041101110000"/>
+	<configurations defaultconfmapping="test->default" defaultconf="default">
+		<conf name="default"/>
+		<conf name="test"/>
+	</configurations>
+	<dependencies>
+		<dependency name="mymodule1" rev="1.0"/>
+		<dependency name="mymodule2" rev="2.0" conf="test"/>
+	</dependencies>
+</ivy-module>

Propchange: ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/parser/xml/test-defaultconf-withdefaultconfmapping.xml
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/parser/xml/test-defaultconf-withdefaultconfmapping.xml
------------------------------------------------------------------------------
    svn:keywords = Date Revision Author HeadURL Id

Propchange: ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/parser/xml/test-defaultconf-withdefaultconfmapping.xml
------------------------------------------------------------------------------
--- svn:mime-type (original)
+++ svn:mime-type Tue Dec 14 16:28:01 2010
@@ -1 +1 @@
-text/plain
+text/xml

Propchange: ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/parser/xml/test-defaultconf.xml
------------------------------------------------------------------------------
    svn:keywords = Date Revision Author HeadURL Id

Propchange: ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/parser/xml/test-defaultconf.xml
------------------------------------------------------------------------------
    svn:mime-type = text/xml

Propchange: ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/parser/xml/test-defaultconf2.xml
------------------------------------------------------------------------------
    svn:keywords = Date Revision Author HeadURL Id

Propchange: ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/parser/xml/test-defaultconf2.xml
------------------------------------------------------------------------------
    svn:mime-type = text/xml

Propchange: ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/parser/xml/test-defaultconfmapping-withselectors.xml
------------------------------------------------------------------------------
    svn:keywords = Date Revision Author HeadURL Id

Propchange: ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/parser/xml/test-defaultconfmapping-withselectors.xml
------------------------------------------------------------------------------
    svn:mime-type = text/xml

Propchange: ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/parser/xml/test-defaultconfmapping.xml
------------------------------------------------------------------------------
    svn:keywords = Date Revision Author HeadURL Id

Propchange: ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/parser/xml/test-defaultconfmapping.xml
------------------------------------------------------------------------------
    svn:mime-type = text/xml

Propchange: ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/parser/xml/test-dependencies.xml
------------------------------------------------------------------------------
    svn:keywords = Date Revision Author HeadURL Id

Propchange: ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/parser/xml/test-dependencies.xml
------------------------------------------------------------------------------
    svn:mime-type = text/xml

Propchange: ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/parser/xml/test-empty-dependencies.xml
------------------------------------------------------------------------------
    svn:keywords = Date Revision Author HeadURL Id

Propchange: ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/parser/xml/test-empty-dependencies.xml
------------------------------------------------------------------------------
    svn:mime-type = text/xml

Modified: ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/parser/xml/test-extends-all.xml
URL: http://svn.apache.org/viewvc/ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/parser/xml/test-extends-all.xml?rev=1049146&r1=1049145&r2=1049146&view=diff
==============================================================================
--- ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/parser/xml/test-extends-all.xml (original)
+++ ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/parser/xml/test-extends-all.xml Tue Dec 14 16:28:01 2010
@@ -1,32 +1,32 @@
-<!--
-   Licensed to the Apache Software Foundation (ASF) under one
-   or more contributor license agreements.  See the NOTICE file
-   distributed with this work for additional information
-   regarding copyright ownership.  The ASF licenses this file
-   to you under the Apache License, Version 2.0 (the
-   "License"); you may not use this file except in compliance
-   with the License.  You may obtain a copy of the License at
-
-     http://www.apache.org/licenses/LICENSE-2.0
-
-   Unless required by applicable law or agreed to in writing,
-   software distributed under the License is distributed on an
-   "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
-   KIND, either express or implied.  See the License for the
-   specific language governing permissions and limitations
-   under the License.    
--->
-<ivy-module version="1.0">
-	<info organisation="myorg"
-	       module="mymodule"
-	       status="integration"
-	       publication="20091206000000">
-	       <extends organisation="myorg" module="myparent" revision="latest.revision" location="test-extends-parent.xml"/>
-	</info>
-	<configurations>
-		<conf name="conf2" visibility="private"/>
-	</configurations>
-	<dependencies>
-		<dependency name="mymodule2" rev="2.0" conf="conf1,conf2"/>
-	</dependencies>
-</ivy-module>
+<!--
+   Licensed to the Apache Software Foundation (ASF) under one
+   or more contributor license agreements.  See the NOTICE file
+   distributed with this work for additional information
+   regarding copyright ownership.  The ASF licenses this file
+   to you under the Apache License, Version 2.0 (the
+   "License"); you may not use this file except in compliance
+   with the License.  You may obtain a copy of the License at
+
+     http://www.apache.org/licenses/LICENSE-2.0
+
+   Unless required by applicable law or agreed to in writing,
+   software distributed under the License is distributed on an
+   "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+   KIND, either express or implied.  See the License for the
+   specific language governing permissions and limitations
+   under the License.    
+-->
+<ivy-module version="1.0">
+	<info organisation="myorg"
+	       module="mymodule"
+	       status="integration"
+	       publication="20091206000000">
+	       <extends organisation="myorg" module="myparent" revision="latest.revision" location="test-extends-parent.xml"/>
+	</info>
+	<configurations>
+		<conf name="conf2" visibility="private"/>
+	</configurations>
+	<dependencies>
+		<dependency name="mymodule2" rev="2.0" conf="conf1,conf2"/>
+	</dependencies>
+</ivy-module>

Propchange: ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/parser/xml/test-extends-all.xml
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/parser/xml/test-extends-all.xml
------------------------------------------------------------------------------
    svn:keywords = Date Revision Author HeadURL Id

Propchange: ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/parser/xml/test-extends-all.xml
------------------------------------------------------------------------------
--- svn:mime-type (original)
+++ svn:mime-type Tue Dec 14 16:28:01 2010
@@ -1 +1 @@
-text/plain
+text/xml

Modified: ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/parser/xml/test-extends-cached.xml
URL: http://svn.apache.org/viewvc/ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/parser/xml/test-extends-cached.xml?rev=1049146&r1=1049145&r2=1049146&view=diff
==============================================================================
--- ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/parser/xml/test-extends-cached.xml (original)
+++ ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/parser/xml/test-extends-cached.xml Tue Dec 14 16:28:01 2010
@@ -1,32 +1,32 @@
-<!--
-   Licensed to the Apache Software Foundation (ASF) under one
-   or more contributor license agreements.  See the NOTICE file
-   distributed with this work for additional information
-   regarding copyright ownership.  The ASF licenses this file
-   to you under the Apache License, Version 2.0 (the
-   "License"); you may not use this file except in compliance
-   with the License.  You may obtain a copy of the License at
-
-     http://www.apache.org/licenses/LICENSE-2.0
-
-   Unless required by applicable law or agreed to in writing,
-   software distributed under the License is distributed on an
-   "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
-   KIND, either express or implied.  See the License for the
-   specific language governing permissions and limitations
-   under the License.    
--->
-<ivy-module version="1.0">
-	<info organisation="myorg"
-	       module="mymodule"
-	       status="integration"
-	       publication="20091206000000">
-	       <extends organisation="myorg" module="myparent" revision="latest.revision"/>
-	</info>
-	<configurations>
-		<conf name="conf2" visibility="private"/>
-	</configurations>
-	<dependencies>
-		<dependency name="mymodule2" rev="2.0" conf="conf1,conf2"/>
-	</dependencies>
-</ivy-module>
+<!--
+   Licensed to the Apache Software Foundation (ASF) under one
+   or more contributor license agreements.  See the NOTICE file
+   distributed with this work for additional information
+   regarding copyright ownership.  The ASF licenses this file
+   to you under the Apache License, Version 2.0 (the
+   "License"); you may not use this file except in compliance
+   with the License.  You may obtain a copy of the License at
+
+     http://www.apache.org/licenses/LICENSE-2.0
+
+   Unless required by applicable law or agreed to in writing,
+   software distributed under the License is distributed on an
+   "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+   KIND, either express or implied.  See the License for the
+   specific language governing permissions and limitations
+   under the License.    
+-->
+<ivy-module version="1.0">
+	<info organisation="myorg"
+	       module="mymodule"
+	       status="integration"
+	       publication="20091206000000">
+	       <extends organisation="myorg" module="myparent" revision="latest.revision"/>
+	</info>
+	<configurations>
+		<conf name="conf2" visibility="private"/>
+	</configurations>
+	<dependencies>
+		<dependency name="mymodule2" rev="2.0" conf="conf1,conf2"/>
+	</dependencies>
+</ivy-module>

Propchange: ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/parser/xml/test-extends-cached.xml
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/parser/xml/test-extends-cached.xml
------------------------------------------------------------------------------
    svn:keywords = Date Revision Author HeadURL Id

Propchange: ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/parser/xml/test-extends-cached.xml
------------------------------------------------------------------------------
--- svn:mime-type (original)
+++ svn:mime-type Tue Dec 14 16:28:01 2010
@@ -1 +1 @@
-text/plain
+text/xml

Modified: ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/parser/xml/test-extends-configurations.xml
URL: http://svn.apache.org/viewvc/ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/parser/xml/test-extends-configurations.xml?rev=1049146&r1=1049145&r2=1049146&view=diff
==============================================================================
--- ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/parser/xml/test-extends-configurations.xml (original)
+++ ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/parser/xml/test-extends-configurations.xml Tue Dec 14 16:28:01 2010
@@ -1,33 +1,33 @@
-<!--
-   Licensed to the Apache Software Foundation (ASF) under one
-   or more contributor license agreements.  See the NOTICE file
-   distributed with this work for additional information
-   regarding copyright ownership.  The ASF licenses this file
-   to you under the Apache License, Version 2.0 (the
-   "License"); you may not use this file except in compliance
-   with the License.  You may obtain a copy of the License at
-
-     http://www.apache.org/licenses/LICENSE-2.0
-
-   Unless required by applicable law or agreed to in writing,
-   software distributed under the License is distributed on an
-   "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
-   KIND, either express or implied.  See the License for the
-   specific language governing permissions and limitations
-   under the License.    
--->
-<ivy-module version="1.0">
-	<info organisation="myorg"
-	       module="mymodule"
-	       status="integration"
-	       publication="20091206000000">
-	       <extends organisation="myorg" module="myparent" revision="latest.revision" 
-	       			location="test-extends-parent.xml" extendType="configurations"/>
-	</info>
-	<configurations>
-		<conf name="conf2" visibility="private"/>
-	</configurations>
-	<dependencies>
-		<dependency name="mymodule2" rev="2.0" conf="conf1,conf2"/>
-	</dependencies>
-</ivy-module>
+<!--
+   Licensed to the Apache Software Foundation (ASF) under one
+   or more contributor license agreements.  See the NOTICE file
+   distributed with this work for additional information
+   regarding copyright ownership.  The ASF licenses this file
+   to you under the Apache License, Version 2.0 (the
+   "License"); you may not use this file except in compliance
+   with the License.  You may obtain a copy of the License at
+
+     http://www.apache.org/licenses/LICENSE-2.0
+
+   Unless required by applicable law or agreed to in writing,
+   software distributed under the License is distributed on an
+   "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+   KIND, either express or implied.  See the License for the
+   specific language governing permissions and limitations
+   under the License.    
+-->
+<ivy-module version="1.0">
+	<info organisation="myorg"
+	       module="mymodule"
+	       status="integration"
+	       publication="20091206000000">
+	       <extends organisation="myorg" module="myparent" revision="latest.revision" 
+	       			location="test-extends-parent.xml" extendType="configurations"/>
+	</info>
+	<configurations>
+		<conf name="conf2" visibility="private"/>
+	</configurations>
+	<dependencies>
+		<dependency name="mymodule2" rev="2.0" conf="conf1,conf2"/>
+	</dependencies>
+</ivy-module>

Propchange: ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/parser/xml/test-extends-configurations.xml
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/parser/xml/test-extends-configurations.xml
------------------------------------------------------------------------------
    svn:keywords = Date Revision Author HeadURL Id

Propchange: ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/parser/xml/test-extends-configurations.xml
------------------------------------------------------------------------------
--- svn:mime-type (original)
+++ svn:mime-type Tue Dec 14 16:28:01 2010
@@ -1 +1 @@
-text/plain
+text/xml

Modified: ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/parser/xml/test-extends-dependencies.xml
URL: http://svn.apache.org/viewvc/ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/parser/xml/test-extends-dependencies.xml?rev=1049146&r1=1049145&r2=1049146&view=diff
==============================================================================
--- ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/parser/xml/test-extends-dependencies.xml (original)
+++ ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/parser/xml/test-extends-dependencies.xml Tue Dec 14 16:28:01 2010
@@ -1,30 +1,30 @@
-<!--
-   Licensed to the Apache Software Foundation (ASF) under one
-   or more contributor license agreements.  See the NOTICE file
-   distributed with this work for additional information
-   regarding copyright ownership.  The ASF licenses this file
-   to you under the Apache License, Version 2.0 (the
-   "License"); you may not use this file except in compliance
-   with the License.  You may obtain a copy of the License at
-
-     http://www.apache.org/licenses/LICENSE-2.0
-
-   Unless required by applicable law or agreed to in writing,
-   software distributed under the License is distributed on an
-   "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
-   KIND, either express or implied.  See the License for the
-   specific language governing permissions and limitations
-   under the License.    
--->
-<ivy-module version="1.0">
-	<info organisation="myorg"
-	       module="mymodule"
-	       status="integration"
-	       publication="20091206000000">
-	       <extends organisation="myorg" module="myparent" revision="latest.revision" 
-	       			location="test-extends-parent.xml" extendType="dependencies"/>
-	</info>
-	<dependencies>
-		<dependency name="mymodule2" rev="2.0" conf="default"/>
-	</dependencies>
-</ivy-module>
+<!--
+   Licensed to the Apache Software Foundation (ASF) under one
+   or more contributor license agreements.  See the NOTICE file
+   distributed with this work for additional information
+   regarding copyright ownership.  The ASF licenses this file
+   to you under the Apache License, Version 2.0 (the
+   "License"); you may not use this file except in compliance
+   with the License.  You may obtain a copy of the License at
+
+     http://www.apache.org/licenses/LICENSE-2.0
+
+   Unless required by applicable law or agreed to in writing,
+   software distributed under the License is distributed on an
+   "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+   KIND, either express or implied.  See the License for the
+   specific language governing permissions and limitations
+   under the License.    
+-->
+<ivy-module version="1.0">
+	<info organisation="myorg"
+	       module="mymodule"
+	       status="integration"
+	       publication="20091206000000">
+	       <extends organisation="myorg" module="myparent" revision="latest.revision" 
+	       			location="test-extends-parent.xml" extendType="dependencies"/>
+	</info>
+	<dependencies>
+		<dependency name="mymodule2" rev="2.0" conf="default"/>
+	</dependencies>
+</ivy-module>

Propchange: ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/parser/xml/test-extends-dependencies.xml
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/parser/xml/test-extends-dependencies.xml
------------------------------------------------------------------------------
    svn:keywords = Date Revision Author HeadURL Id

Propchange: ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/parser/xml/test-extends-dependencies.xml
------------------------------------------------------------------------------
--- svn:mime-type (original)
+++ svn:mime-type Tue Dec 14 16:28:01 2010
@@ -1 +1 @@
-text/plain
+text/xml

Modified: ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/parser/xml/test-extends-description-override.xml
URL: http://svn.apache.org/viewvc/ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/parser/xml/test-extends-description-override.xml?rev=1049146&r1=1049145&r2=1049146&view=diff
==============================================================================
--- ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/parser/xml/test-extends-description-override.xml (original)
+++ ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/parser/xml/test-extends-description-override.xml Tue Dec 14 16:28:01 2010
@@ -1,31 +1,31 @@
-<!--
-   Licensed to the Apache Software Foundation (ASF) under one
-   or more contributor license agreements.  See the NOTICE file
-   distributed with this work for additional information
-   regarding copyright ownership.  The ASF licenses this file
-   to you under the Apache License, Version 2.0 (the
-   "License"); you may not use this file except in compliance
-   with the License.  You may obtain a copy of the License at
-
-     http://www.apache.org/licenses/LICENSE-2.0
-
-   Unless required by applicable law or agreed to in writing,
-   software distributed under the License is distributed on an
-   "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
-   KIND, either express or implied.  See the License for the
-   specific language governing permissions and limitations
-   under the License.    
--->
-<ivy-module version="1.0">
-	<info organisation="myorg"
-	       module="mymodule"
-	       status="integration"
-	       publication="20091206000000">
-	       <extends organisation="myorg" module="myparent" revision="latest.revision" 
-	       			location="test-extends-parent.xml" extendType="description"/>
-	       <description>Child description overrides parent.</description>
-	</info>
-	<dependencies>
-		<dependency name="mymodule2" rev="2.0" conf="default"/>
-	</dependencies>
-</ivy-module>
+<!--
+   Licensed to the Apache Software Foundation (ASF) under one
+   or more contributor license agreements.  See the NOTICE file
+   distributed with this work for additional information
+   regarding copyright ownership.  The ASF licenses this file
+   to you under the Apache License, Version 2.0 (the
+   "License"); you may not use this file except in compliance
+   with the License.  You may obtain a copy of the License at
+
+     http://www.apache.org/licenses/LICENSE-2.0
+
+   Unless required by applicable law or agreed to in writing,
+   software distributed under the License is distributed on an
+   "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+   KIND, either express or implied.  See the License for the
+   specific language governing permissions and limitations
+   under the License.    
+-->
+<ivy-module version="1.0">
+	<info organisation="myorg"
+	       module="mymodule"
+	       status="integration"
+	       publication="20091206000000">
+	       <extends organisation="myorg" module="myparent" revision="latest.revision" 
+	       			location="test-extends-parent.xml" extendType="description"/>
+	       <description>Child description overrides parent.</description>
+	</info>
+	<dependencies>
+		<dependency name="mymodule2" rev="2.0" conf="default"/>
+	</dependencies>
+</ivy-module>

Propchange: ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/parser/xml/test-extends-description-override.xml
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/parser/xml/test-extends-description-override.xml
------------------------------------------------------------------------------
    svn:keywords = Date Revision Author HeadURL Id

Propchange: ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/parser/xml/test-extends-description-override.xml
------------------------------------------------------------------------------
--- svn:mime-type (original)
+++ svn:mime-type Tue Dec 14 16:28:01 2010
@@ -1 +1 @@
-text/plain
+text/xml

Modified: ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/parser/xml/test-extends-description.xml
URL: http://svn.apache.org/viewvc/ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/parser/xml/test-extends-description.xml?rev=1049146&r1=1049145&r2=1049146&view=diff
==============================================================================
--- ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/parser/xml/test-extends-description.xml (original)
+++ ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/parser/xml/test-extends-description.xml Tue Dec 14 16:28:01 2010
@@ -1,30 +1,30 @@
-<!--
-   Licensed to the Apache Software Foundation (ASF) under one
-   or more contributor license agreements.  See the NOTICE file
-   distributed with this work for additional information
-   regarding copyright ownership.  The ASF licenses this file
-   to you under the Apache License, Version 2.0 (the
-   "License"); you may not use this file except in compliance
-   with the License.  You may obtain a copy of the License at
-
-     http://www.apache.org/licenses/LICENSE-2.0
-
-   Unless required by applicable law or agreed to in writing,
-   software distributed under the License is distributed on an
-   "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
-   KIND, either express or implied.  See the License for the
-   specific language governing permissions and limitations
-   under the License.    
--->
-<ivy-module version="1.0">
-	<info organisation="myorg"
-	       module="mymodule"
-	       status="integration"
-	       publication="20091206000000">
-	       <extends organisation="myorg" module="myparent" revision="latest.revision" 
-	       			location="test-extends-parent.xml" extendType="description"/>
-	</info>
-	<dependencies>
-		<dependency name="mymodule2" rev="2.0" conf="default"/>
-	</dependencies>
-</ivy-module>
+<!--
+   Licensed to the Apache Software Foundation (ASF) under one
+   or more contributor license agreements.  See the NOTICE file
+   distributed with this work for additional information
+   regarding copyright ownership.  The ASF licenses this file
+   to you under the Apache License, Version 2.0 (the
+   "License"); you may not use this file except in compliance
+   with the License.  You may obtain a copy of the License at
+
+     http://www.apache.org/licenses/LICENSE-2.0
+
+   Unless required by applicable law or agreed to in writing,
+   software distributed under the License is distributed on an
+   "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+   KIND, either express or implied.  See the License for the
+   specific language governing permissions and limitations
+   under the License.    
+-->
+<ivy-module version="1.0">
+	<info organisation="myorg"
+	       module="mymodule"
+	       status="integration"
+	       publication="20091206000000">
+	       <extends organisation="myorg" module="myparent" revision="latest.revision" 
+	       			location="test-extends-parent.xml" extendType="description"/>
+	</info>
+	<dependencies>
+		<dependency name="mymodule2" rev="2.0" conf="default"/>
+	</dependencies>
+</ivy-module>

Propchange: ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/parser/xml/test-extends-description.xml
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/parser/xml/test-extends-description.xml
------------------------------------------------------------------------------
    svn:keywords = Date Revision Author HeadURL Id

Propchange: ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/parser/xml/test-extends-description.xml
------------------------------------------------------------------------------
--- svn:mime-type (original)
+++ svn:mime-type Tue Dec 14 16:28:01 2010
@@ -1 +1 @@
-text/plain
+text/xml

Modified: ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/parser/xml/test-extends-mixed.xml
URL: http://svn.apache.org/viewvc/ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/parser/xml/test-extends-mixed.xml?rev=1049146&r1=1049145&r2=1049146&view=diff
==============================================================================
--- ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/parser/xml/test-extends-mixed.xml (original)
+++ ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/parser/xml/test-extends-mixed.xml Tue Dec 14 16:28:01 2010
@@ -1,33 +1,33 @@
-<!--
-   Licensed to the Apache Software Foundation (ASF) under one
-   or more contributor license agreements.  See the NOTICE file
-   distributed with this work for additional information
-   regarding copyright ownership.  The ASF licenses this file
-   to you under the Apache License, Version 2.0 (the
-   "License"); you may not use this file except in compliance
-   with the License.  You may obtain a copy of the License at
-
-     http://www.apache.org/licenses/LICENSE-2.0
-
-   Unless required by applicable law or agreed to in writing,
-   software distributed under the License is distributed on an
-   "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
-   KIND, either express or implied.  See the License for the
-   specific language governing permissions and limitations
-   under the License.    
--->
-<ivy-module version="1.0">
-	<info organisation="myorg"
-	       module="mymodule"
-	       status="integration"
-	       publication="20091206000000">
-	       <extends organisation="myorg" module="myparent" revision="latest.revision" 
-	       			location="test-extends-parent.xml" extendType="configurations,dependencies"/>
-	</info>
-	<configurations>
-		<conf name="conf2" visibility="private"/>
-	</configurations>
-	<dependencies>
-		<dependency name="mymodule2" rev="2.0" conf="conf1,conf2"/>
-	</dependencies>
-</ivy-module>
+<!--
+   Licensed to the Apache Software Foundation (ASF) under one
+   or more contributor license agreements.  See the NOTICE file
+   distributed with this work for additional information
+   regarding copyright ownership.  The ASF licenses this file
+   to you under the Apache License, Version 2.0 (the
+   "License"); you may not use this file except in compliance
+   with the License.  You may obtain a copy of the License at
+
+     http://www.apache.org/licenses/LICENSE-2.0
+
+   Unless required by applicable law or agreed to in writing,
+   software distributed under the License is distributed on an
+   "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+   KIND, either express or implied.  See the License for the
+   specific language governing permissions and limitations
+   under the License.    
+-->
+<ivy-module version="1.0">
+	<info organisation="myorg"
+	       module="mymodule"
+	       status="integration"
+	       publication="20091206000000">
+	       <extends organisation="myorg" module="myparent" revision="latest.revision" 
+	       			location="test-extends-parent.xml" extendType="configurations,dependencies"/>
+	</info>
+	<configurations>
+		<conf name="conf2" visibility="private"/>
+	</configurations>
+	<dependencies>
+		<dependency name="mymodule2" rev="2.0" conf="conf1,conf2"/>
+	</dependencies>
+</ivy-module>

Propchange: ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/parser/xml/test-extends-mixed.xml
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/parser/xml/test-extends-mixed.xml
------------------------------------------------------------------------------
    svn:keywords = Date Revision Author HeadURL Id

Propchange: ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/parser/xml/test-extends-mixed.xml
------------------------------------------------------------------------------
--- svn:mime-type (original)
+++ svn:mime-type Tue Dec 14 16:28:01 2010
@@ -1 +1 @@
-text/plain
+text/xml

Modified: ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/parser/xml/test-extends-parent.xml
URL: http://svn.apache.org/viewvc/ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/parser/xml/test-extends-parent.xml?rev=1049146&r1=1049145&r2=1049146&view=diff
==============================================================================
--- ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/parser/xml/test-extends-parent.xml (original)
+++ ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/parser/xml/test-extends-parent.xml Tue Dec 14 16:28:01 2010
@@ -1,34 +1,34 @@
-<!--
-   Licensed to the Apache Software Foundation (ASF) under one
-   or more contributor license agreements.  See the NOTICE file
-   distributed with this work for additional information
-   regarding copyright ownership.  The ASF licenses this file
-   to you under the Apache License, Version 2.0 (the
-   "License"); you may not use this file except in compliance
-   with the License.  You may obtain a copy of the License at
-
-     http://www.apache.org/licenses/LICENSE-2.0
-
-   Unless required by applicable law or agreed to in writing,
-   software distributed under the License is distributed on an
-   "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
-   KIND, either express or implied.  See the License for the
-   specific language governing permissions and limitations
-   under the License.    
--->
-<ivy-module version="1.0">
-	<info organisation="myorg"
-	       module="myparent"
-	       revision="myrev"
-	       status="integration"
-	       publication="20091206000000">
-	       <description>Parent module description.  </description>
-	</info>
-	<configurations>
-		<conf name="default"/>
-		<conf name="conf1" visibility="public"/>
-	</configurations>
-	<dependencies>
-		<dependency name="mymodule1" rev="1.0" conf="default"/>
-	</dependencies>
-</ivy-module>
+<!--
+   Licensed to the Apache Software Foundation (ASF) under one
+   or more contributor license agreements.  See the NOTICE file
+   distributed with this work for additional information
+   regarding copyright ownership.  The ASF licenses this file
+   to you under the Apache License, Version 2.0 (the
+   "License"); you may not use this file except in compliance
+   with the License.  You may obtain a copy of the License at
+
+     http://www.apache.org/licenses/LICENSE-2.0
+
+   Unless required by applicable law or agreed to in writing,
+   software distributed under the License is distributed on an
+   "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+   KIND, either express or implied.  See the License for the
+   specific language governing permissions and limitations
+   under the License.    
+-->
+<ivy-module version="1.0">
+	<info organisation="myorg"
+	       module="myparent"
+	       revision="myrev"
+	       status="integration"
+	       publication="20091206000000">
+	       <description>Parent module description.  </description>
+	</info>
+	<configurations>
+		<conf name="default"/>
+		<conf name="conf1" visibility="public"/>
+	</configurations>
+	<dependencies>
+		<dependency name="mymodule1" rev="1.0" conf="default"/>
+	</dependencies>
+</ivy-module>

Propchange: ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/parser/xml/test-extends-parent.xml
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/parser/xml/test-extends-parent.xml
------------------------------------------------------------------------------
    svn:keywords = Date Revision Author HeadURL Id

Propchange: ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/parser/xml/test-extends-parent.xml
------------------------------------------------------------------------------
--- svn:mime-type (original)
+++ svn:mime-type Tue Dec 14 16:28:01 2010
@@ -1 +1 @@
-text/plain
+text/xml

Propchange: ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/parser/xml/test-extra-attributes.xml
------------------------------------------------------------------------------
    svn:keywords = Date Revision Author HeadURL Id

Propchange: ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/parser/xml/test-extra-attributes.xml
------------------------------------------------------------------------------
    svn:mime-type = text/xml

Propchange: ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/parser/xml/test-incorrectconf1.xml
------------------------------------------------------------------------------
    svn:keywords = Date Revision Author HeadURL Id

Propchange: ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/parser/xml/test-incorrectconf1.xml
------------------------------------------------------------------------------
    svn:mime-type = text/xml

Propchange: ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/parser/xml/test-incorrectconf2.xml
------------------------------------------------------------------------------
    svn:keywords = Date Revision Author HeadURL Id

Propchange: ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/parser/xml/test-incorrectconf2.xml
------------------------------------------------------------------------------
    svn:mime-type = text/xml

Propchange: ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/parser/xml/test-incorrectconf3.xml
------------------------------------------------------------------------------
    svn:keywords = Date Revision Author HeadURL Id

Propchange: ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/parser/xml/test-incorrectconf3.xml
------------------------------------------------------------------------------
    svn:mime-type = text/xml

Modified: ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/parser/xml/test-info.xml
URL: http://svn.apache.org/viewvc/ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/parser/xml/test-info.xml?rev=1049146&r1=1049145&r2=1049146&view=diff
==============================================================================
--- ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/parser/xml/test-info.xml (original)
+++ ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/parser/xml/test-info.xml Tue Dec 14 16:28:01 2010
@@ -1,27 +1,27 @@
-<!--
-   Licensed to the Apache Software Foundation (ASF) under one
-   or more contributor license agreements.  See the NOTICE file
-   distributed with this work for additional information
-   regarding copyright ownership.  The ASF licenses this file
-   to you under the Apache License, Version 2.0 (the
-   "License"); you may not use this file except in compliance
-   with the License.  You may obtain a copy of the License at
-
-     http://www.apache.org/licenses/LICENSE-2.0
-
-   Unless required by applicable law or agreed to in writing,
-   software distributed under the License is distributed on an
-   "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
-   KIND, either express or implied.  See the License for the
-   specific language governing permissions and limitations
-   under the License.    
--->
-<ivy-module version="1.0">
-	<info organisation="myorg"
-	       module="mymodule">
-		<license name="Apache Sofware License" url="http://www.apache.org/licenses/LICENSE-2.0.txt" />
-		<description homepage="http://myorg.com/mymodule">
-		My module description.
-		</description>
-	</info>
-</ivy-module>
+<!--
+   Licensed to the Apache Software Foundation (ASF) under one
+   or more contributor license agreements.  See the NOTICE file
+   distributed with this work for additional information
+   regarding copyright ownership.  The ASF licenses this file
+   to you under the Apache License, Version 2.0 (the
+   "License"); you may not use this file except in compliance
+   with the License.  You may obtain a copy of the License at
+
+     http://www.apache.org/licenses/LICENSE-2.0
+
+   Unless required by applicable law or agreed to in writing,
+   software distributed under the License is distributed on an
+   "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+   KIND, either express or implied.  See the License for the
+   specific language governing permissions and limitations
+   under the License.    
+-->
+<ivy-module version="1.0">
+	<info organisation="myorg"
+	       module="mymodule">
+		<license name="Apache Sofware License" url="http://www.apache.org/licenses/LICENSE-2.0.txt" />
+		<description homepage="http://myorg.com/mymodule">
+		My module description.
+		</description>
+	</info>
+</ivy-module>

Propchange: ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/parser/xml/test-info.xml
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/parser/xml/test-info.xml
------------------------------------------------------------------------------
    svn:keywords = Date Revision Author HeadURL Id

Propchange: ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/parser/xml/test-info.xml
------------------------------------------------------------------------------
--- svn:mime-type (original)
+++ svn:mime-type Tue Dec 14 16:28:01 2010
@@ -1 +1 @@
-text/plain
+text/xml

Propchange: ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/parser/xml/test-namespaces.xml
------------------------------------------------------------------------------
    svn:keywords = Date Revision Author HeadURL Id

Propchange: ant/ivy/core/trunk/test/java/org/apache/ivy/plugins/parser/xml/test-namespaces.xml
------------------------------------------------------------------------------
    svn:mime-type = text/xml