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 [6/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/chainedresolvers...

Modified: ant/ivy/core/trunk/src/java/org/apache/ivy/plugins/lock/FileBasedLockStrategy.java
URL: http://svn.apache.org/viewvc/ant/ivy/core/trunk/src/java/org/apache/ivy/plugins/lock/FileBasedLockStrategy.java?rev=1049146&r1=1049145&r2=1049146&view=diff
==============================================================================
--- ant/ivy/core/trunk/src/java/org/apache/ivy/plugins/lock/FileBasedLockStrategy.java (original)
+++ ant/ivy/core/trunk/src/java/org/apache/ivy/plugins/lock/FileBasedLockStrategy.java Tue Dec 14 16:28:01 2010
@@ -1,230 +1,230 @@
-/*
- *  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.io.IOException;
-import java.io.RandomAccessFile;
-import java.nio.channels.FileChannel;
-import java.nio.channels.FileLock;
-import java.util.HashMap;
-import java.util.Map;
-
-import org.apache.ivy.util.Message;
-
-public abstract class FileBasedLockStrategy extends AbstractLockStrategy {
-    private static final int SLEEP_TIME = 100;
-
-    private static final long DEFAULT_TIMEOUT = 2 * 60 * 1000;
-
-    /**
-     * The locker to use to make file lock attempts.
-     * <p>
-     * Two implementations of FileLocker are provided below, according to our tests the
-     * CreateFileLocker is both performing better and much more reliable than NIOFileLocker.
-     * </p>
-     */
-    private FileLocker locker;
-    
-    private long timeout = DEFAULT_TIMEOUT;
-    
-    private Map/*<File, Integer>*/ currentLockCounters = new HashMap();
-    
-    protected FileBasedLockStrategy() {
-        this(new CreateFileLocker(false), false);
-    }
-
-    protected FileBasedLockStrategy(boolean debugLocking) {
-        this(new CreateFileLocker(debugLocking), debugLocking);
-    }
-
-    protected FileBasedLockStrategy(FileLocker locker, boolean debugLocking) {
-        super(debugLocking);
-        this.locker = locker;
-    }
-
-        
-    protected boolean acquireLock(File file) throws InterruptedException {
-        if (isDebugLocking()) {
-            debugLocking("acquiring lock on " + file);
-        }
-        long start = System.currentTimeMillis();
-        do {
-            synchronized (this) {
-                if (hasLock(file)) {
-                    int holdLocks = incrementLock(file);
-                    if (isDebugLocking()) {
-                        debugLocking("reentrant lock acquired on " + file 
-                            + " in " + (System.currentTimeMillis() - start) + "ms"
-                            + " - hold locks = " + holdLocks);
-                    }
-                    return true;
-                }
-                if (locker.tryLock(file)) {
-                    if (isDebugLocking()) {
-                        debugLocking("lock acquired on " + file 
-                            + " in " + (System.currentTimeMillis() - start) + "ms");
-                    }
-                    incrementLock(file);
-                    return true;
-                }
-            }
-            Thread.sleep(SLEEP_TIME);
-        } while (System.currentTimeMillis() - start < timeout);
-        return false;
-    }
-
-    protected void releaseLock(File file) {
-        synchronized (this) {
-            int holdLocks = decrementLock(file);
-            if (holdLocks == 0) {
-                locker.unlock(file);
-                if (isDebugLocking()) {
-                    debugLocking("lock released on " + file);
-                }
-            } else {
-                if (isDebugLocking()) {
-                    debugLocking("reentrant lock released on " + file 
-                        + " - hold locks = " + holdLocks);
-                }                
-            }
-        }
-    }
-
-    
-    private static void debugLocking(String msg) {
-        Message.info(Thread.currentThread() + " " + System.currentTimeMillis() + " " + msg);
-    }
-
-    private boolean hasLock(File file) {
-        Integer c = (Integer) currentLockCounters.get(file);
-        return c != null && c.intValue() > 0;
-    }
-    
-    private int incrementLock(File file) {
-        Integer c = (Integer) currentLockCounters.get(file);
-        int holdLocks = c == null ? 1 : c.intValue() + 1;
-        currentLockCounters.put(file, new Integer(holdLocks));
-        return holdLocks;
-    }
-
-    private int decrementLock(File file) {
-        Integer c = (Integer) currentLockCounters.get(file);
-        int dc = c == null ? 0 : c.intValue() - 1;
-        currentLockCounters.put(file, new Integer(dc));
-        return dc;
-    }
-
-    public static interface FileLocker {
-        boolean tryLock(File f);
-        void unlock(File f);
-    }
-    
-    /**
-     * "locks" a file by creating it if it doesn't exist, relying on the
-     * {@link File#createNewFile()} atomicity.
-     */
-    public static class CreateFileLocker implements FileLocker {
-        private boolean debugLocking;
-
-        public CreateFileLocker(boolean debugLocking) {
-            this.debugLocking = debugLocking;
-        }
-
-        public boolean tryLock(File file) {
-            try {
-                if (file.getParentFile().exists() || file.getParentFile().mkdirs()) {
-                    if (file.createNewFile()) {
-                        return true;
-                    } else {
-                        if (debugLocking) {
-                            debugLocking("file creation failed " + file);
-                        }
-                    }
-                }
-            } catch (IOException e) {
-                // ignored
-                Message.verbose("file creation failed due to an exception: " 
-                    + e.getMessage() + " (" + file + ")");
-            }
-            return false;
-        }
-
-        public void unlock(File file) {
-            file.delete();
-        }
-    }
-    /**
-     * Locks a file using the {@link FileLock} mechanism. 
-     */
-    public static class NIOFileLocker implements FileLocker {
-        
-        private Map locks = new HashMap();
-        private boolean debugLocking;
-        
-        public NIOFileLocker(boolean debugLocking) {
-            this.debugLocking = debugLocking;
-        }
-
-        public boolean tryLock(File file) {
-            try {
-                if (file.getParentFile().exists() || file.getParentFile().mkdirs()) {
-                    RandomAccessFile raf =
-                        new RandomAccessFile(file, "rw");            
-                    FileChannel channel = raf.getChannel();
-                    try {
-                        FileLock l = channel.tryLock();
-                        if (l != null) {
-                            synchronized (this) {
-                                locks.put(file, l);
-                            }
-                            return true;
-                        } else {
-                            if (debugLocking) {
-                                debugLocking("failed to acquire lock on " + file);
-                            }
-                        }
-                    } finally {
-                        raf.close();
-                    }
-                }
-            } catch (IOException e) {
-                // ignored
-                Message.verbose("file lock failed due to an exception: " 
-                    + e.getMessage() + " (" + file + ")");
-            }
-            return false;
-        }
-
-        public void unlock(File file) {
-            synchronized (this) {
-                FileLock l = (FileLock) locks.get(file);
-                if (l == null) {
-                    throw new IllegalArgumentException("file not previously locked: " + file);
-                }
-                try {
-                    l.release();
-                } catch (IOException e) {
-                    Message.error(
-                        "problem while releasing lock on " + file + ": " + e.getMessage());
-                }
-            }
-        }
-        
-    }
-}
+/*
+ *  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.io.IOException;
+import java.io.RandomAccessFile;
+import java.nio.channels.FileChannel;
+import java.nio.channels.FileLock;
+import java.util.HashMap;
+import java.util.Map;
+
+import org.apache.ivy.util.Message;
+
+public abstract class FileBasedLockStrategy extends AbstractLockStrategy {
+    private static final int SLEEP_TIME = 100;
+
+    private static final long DEFAULT_TIMEOUT = 2 * 60 * 1000;
+
+    /**
+     * The locker to use to make file lock attempts.
+     * <p>
+     * Two implementations of FileLocker are provided below, according to our tests the
+     * CreateFileLocker is both performing better and much more reliable than NIOFileLocker.
+     * </p>
+     */
+    private FileLocker locker;
+    
+    private long timeout = DEFAULT_TIMEOUT;
+    
+    private Map/*<File, Integer>*/ currentLockCounters = new HashMap();
+    
+    protected FileBasedLockStrategy() {
+        this(new CreateFileLocker(false), false);
+    }
+
+    protected FileBasedLockStrategy(boolean debugLocking) {
+        this(new CreateFileLocker(debugLocking), debugLocking);
+    }
+
+    protected FileBasedLockStrategy(FileLocker locker, boolean debugLocking) {
+        super(debugLocking);
+        this.locker = locker;
+    }
+
+        
+    protected boolean acquireLock(File file) throws InterruptedException {
+        if (isDebugLocking()) {
+            debugLocking("acquiring lock on " + file);
+        }
+        long start = System.currentTimeMillis();
+        do {
+            synchronized (this) {
+                if (hasLock(file)) {
+                    int holdLocks = incrementLock(file);
+                    if (isDebugLocking()) {
+                        debugLocking("reentrant lock acquired on " + file 
+                            + " in " + (System.currentTimeMillis() - start) + "ms"
+                            + " - hold locks = " + holdLocks);
+                    }
+                    return true;
+                }
+                if (locker.tryLock(file)) {
+                    if (isDebugLocking()) {
+                        debugLocking("lock acquired on " + file 
+                            + " in " + (System.currentTimeMillis() - start) + "ms");
+                    }
+                    incrementLock(file);
+                    return true;
+                }
+            }
+            Thread.sleep(SLEEP_TIME);
+        } while (System.currentTimeMillis() - start < timeout);
+        return false;
+    }
+
+    protected void releaseLock(File file) {
+        synchronized (this) {
+            int holdLocks = decrementLock(file);
+            if (holdLocks == 0) {
+                locker.unlock(file);
+                if (isDebugLocking()) {
+                    debugLocking("lock released on " + file);
+                }
+            } else {
+                if (isDebugLocking()) {
+                    debugLocking("reentrant lock released on " + file 
+                        + " - hold locks = " + holdLocks);
+                }                
+            }
+        }
+    }
+
+    
+    private static void debugLocking(String msg) {
+        Message.info(Thread.currentThread() + " " + System.currentTimeMillis() + " " + msg);
+    }
+
+    private boolean hasLock(File file) {
+        Integer c = (Integer) currentLockCounters.get(file);
+        return c != null && c.intValue() > 0;
+    }
+    
+    private int incrementLock(File file) {
+        Integer c = (Integer) currentLockCounters.get(file);
+        int holdLocks = c == null ? 1 : c.intValue() + 1;
+        currentLockCounters.put(file, new Integer(holdLocks));
+        return holdLocks;
+    }
+
+    private int decrementLock(File file) {
+        Integer c = (Integer) currentLockCounters.get(file);
+        int dc = c == null ? 0 : c.intValue() - 1;
+        currentLockCounters.put(file, new Integer(dc));
+        return dc;
+    }
+
+    public static interface FileLocker {
+        boolean tryLock(File f);
+        void unlock(File f);
+    }
+    
+    /**
+     * "locks" a file by creating it if it doesn't exist, relying on the
+     * {@link File#createNewFile()} atomicity.
+     */
+    public static class CreateFileLocker implements FileLocker {
+        private boolean debugLocking;
+
+        public CreateFileLocker(boolean debugLocking) {
+            this.debugLocking = debugLocking;
+        }
+
+        public boolean tryLock(File file) {
+            try {
+                if (file.getParentFile().exists() || file.getParentFile().mkdirs()) {
+                    if (file.createNewFile()) {
+                        return true;
+                    } else {
+                        if (debugLocking) {
+                            debugLocking("file creation failed " + file);
+                        }
+                    }
+                }
+            } catch (IOException e) {
+                // ignored
+                Message.verbose("file creation failed due to an exception: " 
+                    + e.getMessage() + " (" + file + ")");
+            }
+            return false;
+        }
+
+        public void unlock(File file) {
+            file.delete();
+        }
+    }
+    /**
+     * Locks a file using the {@link FileLock} mechanism. 
+     */
+    public static class NIOFileLocker implements FileLocker {
+        
+        private Map locks = new HashMap();
+        private boolean debugLocking;
+        
+        public NIOFileLocker(boolean debugLocking) {
+            this.debugLocking = debugLocking;
+        }
+
+        public boolean tryLock(File file) {
+            try {
+                if (file.getParentFile().exists() || file.getParentFile().mkdirs()) {
+                    RandomAccessFile raf =
+                        new RandomAccessFile(file, "rw");            
+                    FileChannel channel = raf.getChannel();
+                    try {
+                        FileLock l = channel.tryLock();
+                        if (l != null) {
+                            synchronized (this) {
+                                locks.put(file, l);
+                            }
+                            return true;
+                        } else {
+                            if (debugLocking) {
+                                debugLocking("failed to acquire lock on " + file);
+                            }
+                        }
+                    } finally {
+                        raf.close();
+                    }
+                }
+            } catch (IOException e) {
+                // ignored
+                Message.verbose("file lock failed due to an exception: " 
+                    + e.getMessage() + " (" + file + ")");
+            }
+            return false;
+        }
+
+        public void unlock(File file) {
+            synchronized (this) {
+                FileLock l = (FileLock) locks.get(file);
+                if (l == null) {
+                    throw new IllegalArgumentException("file not previously locked: " + file);
+                }
+                try {
+                    l.release();
+                } catch (IOException e) {
+                    Message.error(
+                        "problem while releasing lock on " + file + ": " + e.getMessage());
+                }
+            }
+        }
+        
+    }
+}

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

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

Modified: ant/ivy/core/trunk/src/java/org/apache/ivy/plugins/lock/LockStrategy.java
URL: http://svn.apache.org/viewvc/ant/ivy/core/trunk/src/java/org/apache/ivy/plugins/lock/LockStrategy.java?rev=1049146&r1=1049145&r2=1049146&view=diff
==============================================================================
--- ant/ivy/core/trunk/src/java/org/apache/ivy/plugins/lock/LockStrategy.java (original)
+++ ant/ivy/core/trunk/src/java/org/apache/ivy/plugins/lock/LockStrategy.java Tue Dec 14 16:28:01 2010
@@ -1,73 +1,73 @@
-/*
- *  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 org.apache.ivy.core.module.descriptor.Artifact;
-
-/**
- * A lock strategy determines when and how lock should be performed when downloading data to a
- * cache.
- * <p>
- * Note that some implementations may actually choose to NOT perform locking, when no lock is
- * necessary (cache not shared). Some other implementations may choose to lock the cache for the
- * download of a whole module (not possible yet), or at the artifact level.
- * <p>
- * </p>
- * The lock methods should return true when the lock is either actually acquired or not performed by
- * the strategy.
- * </p>
- * <p>
- * Locking used in the locking strategy must support reentrant lock. Reentrant locking should be
- * performed for the whole strategy.
- * </p>
- */
-public interface LockStrategy {
-
-    /**
-     * Returns the name of the strategy
-     * @return the name of the strategy
-     */
-    String getName();
-
-    /**
-     * Performs a lock before downloading the given {@link Artifact} to the given file.
-     * 
-     * @param artifact
-     *            the artifact about to be downloaded
-     * @param artifactFileToDownload
-     *            the file where the artifact will be downloaded
-     * @return true if the artifact is locked, false otherwise
-     * @throws InterruptedException
-     *             if the thread is interrupted while waiting to acquire the lock
-     */
-    boolean lockArtifact(Artifact artifact, File artifactFileToDownload) 
-        throws InterruptedException;
-
-    /**
-     * Release the lock acquired for an artifact download.
-     * 
-     * @param artifact
-     *            the artifact for which the lock was acquired
-     * @param artifactFileToDownload
-     *            the file where the artifact is supposed to have been downloaded
-     */
-    void unlockArtifact(Artifact artifact, File artifactFileToDownload);
-
-}
+/*
+ *  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 org.apache.ivy.core.module.descriptor.Artifact;
+
+/**
+ * A lock strategy determines when and how lock should be performed when downloading data to a
+ * cache.
+ * <p>
+ * Note that some implementations may actually choose to NOT perform locking, when no lock is
+ * necessary (cache not shared). Some other implementations may choose to lock the cache for the
+ * download of a whole module (not possible yet), or at the artifact level.
+ * <p>
+ * </p>
+ * The lock methods should return true when the lock is either actually acquired or not performed by
+ * the strategy.
+ * </p>
+ * <p>
+ * Locking used in the locking strategy must support reentrant lock. Reentrant locking should be
+ * performed for the whole strategy.
+ * </p>
+ */
+public interface LockStrategy {
+
+    /**
+     * Returns the name of the strategy
+     * @return the name of the strategy
+     */
+    String getName();
+
+    /**
+     * Performs a lock before downloading the given {@link Artifact} to the given file.
+     * 
+     * @param artifact
+     *            the artifact about to be downloaded
+     * @param artifactFileToDownload
+     *            the file where the artifact will be downloaded
+     * @return true if the artifact is locked, false otherwise
+     * @throws InterruptedException
+     *             if the thread is interrupted while waiting to acquire the lock
+     */
+    boolean lockArtifact(Artifact artifact, File artifactFileToDownload) 
+        throws InterruptedException;
+
+    /**
+     * Release the lock acquired for an artifact download.
+     * 
+     * @param artifact
+     *            the artifact for which the lock was acquired
+     * @param artifactFileToDownload
+     *            the file where the artifact is supposed to have been downloaded
+     */
+    void unlockArtifact(Artifact artifact, File artifactFileToDownload);
+
+}

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

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

Modified: ant/ivy/core/trunk/src/java/org/apache/ivy/plugins/lock/NoLockStrategy.java
URL: http://svn.apache.org/viewvc/ant/ivy/core/trunk/src/java/org/apache/ivy/plugins/lock/NoLockStrategy.java?rev=1049146&r1=1049145&r2=1049146&view=diff
==============================================================================
--- ant/ivy/core/trunk/src/java/org/apache/ivy/plugins/lock/NoLockStrategy.java (original)
+++ ant/ivy/core/trunk/src/java/org/apache/ivy/plugins/lock/NoLockStrategy.java Tue Dec 14 16:28:01 2010
@@ -1,35 +1,35 @@
-/*
- *  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 org.apache.ivy.core.module.descriptor.Artifact;
-
-public class NoLockStrategy extends AbstractLockStrategy {
-    public NoLockStrategy() {
-        setName("no-lock");
-    }
-
-    public final boolean lockArtifact(Artifact artifact, File artifactFileToDownload) {
-        return true;
-    }
-
-    public final void unlockArtifact(Artifact artifact, File artifactFileToDownload) {
-    }
-}
+/*
+ *  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 org.apache.ivy.core.module.descriptor.Artifact;
+
+public class NoLockStrategy extends AbstractLockStrategy {
+    public NoLockStrategy() {
+        setName("no-lock");
+    }
+
+    public final boolean lockArtifact(Artifact artifact, File artifactFileToDownload) {
+        return true;
+    }
+
+    public final void unlockArtifact(Artifact artifact, File artifactFileToDownload) {
+    }
+}

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

Modified: ant/ivy/core/trunk/src/java/org/apache/ivy/plugins/parser/m2/PomWriterOptions.java
URL: http://svn.apache.org/viewvc/ant/ivy/core/trunk/src/java/org/apache/ivy/plugins/parser/m2/PomWriterOptions.java?rev=1049146&r1=1049145&r2=1049146&view=diff
==============================================================================
--- ant/ivy/core/trunk/src/java/org/apache/ivy/plugins/parser/m2/PomWriterOptions.java (original)
+++ ant/ivy/core/trunk/src/java/org/apache/ivy/plugins/parser/m2/PomWriterOptions.java Tue Dec 14 16:28:01 2010
@@ -1,191 +1,191 @@
-/*
- *  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.parser.m2;
-
-import java.io.File;
-import java.util.ArrayList;
-import java.util.HashMap;
-import java.util.List;
-import java.util.Map;
-
-public class PomWriterOptions {
-
-    private String[] confs;
-    
-    private String licenseHeader;
-    
-    private ConfigurationScopeMapping mapping;
-    
-    private boolean printIvyInfo = true;
-    
-    private String artifactName;
-    
-    private String artifactPackaging;
-    
-    private List/*<ExtraDependency>*/ extraDependencies = new ArrayList();
-
-    private String description;
-    
-    private File template;
-    
-    public File getTemplate() {
-        return template;
-    }
-    
-    public PomWriterOptions setTemplate(File template) {
-        this.template = template;
-        return this;
-    }
-
-    public String[] getConfs() {
-        return confs;
-    }
-
-    public PomWriterOptions setConfs(String[] confs) {
-        this.confs = confs;
-        return this;
-    }
-
-    public String getLicenseHeader() {
-        return licenseHeader;
-    }
-
-    public PomWriterOptions setLicenseHeader(String licenseHeader) {
-        this.licenseHeader = licenseHeader;
-        if (this.licenseHeader != null) {
-            this.licenseHeader = this.licenseHeader.trim();
-        }
-        return this;
-    }
-
-    public ConfigurationScopeMapping getMapping() {
-        return mapping;
-    }
-
-    public PomWriterOptions setMapping(ConfigurationScopeMapping mapping) {
-        this.mapping = mapping;
-        return this;
-    }
-
-    public boolean isPrintIvyInfo() {
-        return printIvyInfo;
-    }
-
-    public PomWriterOptions setPrintIvyInfo(boolean printIvyInfo) {
-        this.printIvyInfo = printIvyInfo;
-        return this;
-    }
-    
-    public List/*<ExtraDependency>*/ getExtraDependencies() {
-        return extraDependencies;
-    }
-
-    public PomWriterOptions setExtraDependencies(List/*<ExtraDependency>*/ extraDependencies) {
-        this.extraDependencies = extraDependencies;
-        return this;
-    }
-    
-    public String getArtifactName() {
-        return artifactName;
-    }
-
-    public PomWriterOptions setArtifactName(String artifactName) {
-        this.artifactName = artifactName;
-        return this;
-    }
-
-    public String getArtifactPackaging() {
-        return artifactPackaging;
-    }
-
-    public PomWriterOptions setArtifactPackaging(String artifactPackaging) {
-        this.artifactPackaging = artifactPackaging;
-        return this;
-    }
-
-    public String getDescription() {
-        return description;
-    }
-
-    public PomWriterOptions setDescription(String description) {
-        this.description = description;
-        return this;
-    }
-
-    public static class ConfigurationScopeMapping {
-        private Map/*<String,String>*/ scopes;
-        
-        public ConfigurationScopeMapping(Map/*<String,String>*/ scopesMapping) {
-            this.scopes = new HashMap(scopesMapping);
-        }
-
-        /**
-         * Returns the scope mapped to the given configuration array.
-         * 
-         * @param confs the configurations for which the scope should be returned
-         * @return the scope to which the conf is mapped
-         */
-        public String getScope(String[] confs) {
-            for (int i = 0; i < confs.length; i++) {
-                if (scopes.containsKey(confs[i])) {
-                    return (String) scopes.get(confs[i]);
-                }
-            }
-
-            return null;
-        }
-        
-        public boolean isOptional(String[] confs) {
-            return getScope(confs) == null;
-        }
-    }
-
-    public static class ExtraDependency {
-            private String group;
-            private String artifact;
-            private String version;
-            private String scope;
-            private boolean optional;
-            
-            public ExtraDependency(String group, String artifact, String version, String scope, boolean optional) {
-                this.group = group;
-                this.artifact = artifact;
-                this.version = version;
-                this.scope = scope;
-                this.optional = optional;
-            }
-            
-            public String getGroup() {
-                return group;
-            }
-            public String getArtifact() {
-                return artifact;
-            }
-            public String getVersion() {
-                return version;
-            }
-            public String getScope() {
-                return scope;
-            }
-            public boolean isOptional() {
-                return optional;
-            }
-        }
-
-    
-}
+/*
+ *  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.parser.m2;
+
+import java.io.File;
+import java.util.ArrayList;
+import java.util.HashMap;
+import java.util.List;
+import java.util.Map;
+
+public class PomWriterOptions {
+
+    private String[] confs;
+    
+    private String licenseHeader;
+    
+    private ConfigurationScopeMapping mapping;
+    
+    private boolean printIvyInfo = true;
+    
+    private String artifactName;
+    
+    private String artifactPackaging;
+    
+    private List/*<ExtraDependency>*/ extraDependencies = new ArrayList();
+
+    private String description;
+    
+    private File template;
+    
+    public File getTemplate() {
+        return template;
+    }
+    
+    public PomWriterOptions setTemplate(File template) {
+        this.template = template;
+        return this;
+    }
+
+    public String[] getConfs() {
+        return confs;
+    }
+
+    public PomWriterOptions setConfs(String[] confs) {
+        this.confs = confs;
+        return this;
+    }
+
+    public String getLicenseHeader() {
+        return licenseHeader;
+    }
+
+    public PomWriterOptions setLicenseHeader(String licenseHeader) {
+        this.licenseHeader = licenseHeader;
+        if (this.licenseHeader != null) {
+            this.licenseHeader = this.licenseHeader.trim();
+        }
+        return this;
+    }
+
+    public ConfigurationScopeMapping getMapping() {
+        return mapping;
+    }
+
+    public PomWriterOptions setMapping(ConfigurationScopeMapping mapping) {
+        this.mapping = mapping;
+        return this;
+    }
+
+    public boolean isPrintIvyInfo() {
+        return printIvyInfo;
+    }
+
+    public PomWriterOptions setPrintIvyInfo(boolean printIvyInfo) {
+        this.printIvyInfo = printIvyInfo;
+        return this;
+    }
+    
+    public List/*<ExtraDependency>*/ getExtraDependencies() {
+        return extraDependencies;
+    }
+
+    public PomWriterOptions setExtraDependencies(List/*<ExtraDependency>*/ extraDependencies) {
+        this.extraDependencies = extraDependencies;
+        return this;
+    }
+    
+    public String getArtifactName() {
+        return artifactName;
+    }
+
+    public PomWriterOptions setArtifactName(String artifactName) {
+        this.artifactName = artifactName;
+        return this;
+    }
+
+    public String getArtifactPackaging() {
+        return artifactPackaging;
+    }
+
+    public PomWriterOptions setArtifactPackaging(String artifactPackaging) {
+        this.artifactPackaging = artifactPackaging;
+        return this;
+    }
+
+    public String getDescription() {
+        return description;
+    }
+
+    public PomWriterOptions setDescription(String description) {
+        this.description = description;
+        return this;
+    }
+
+    public static class ConfigurationScopeMapping {
+        private Map/*<String,String>*/ scopes;
+        
+        public ConfigurationScopeMapping(Map/*<String,String>*/ scopesMapping) {
+            this.scopes = new HashMap(scopesMapping);
+        }
+
+        /**
+         * Returns the scope mapped to the given configuration array.
+         * 
+         * @param confs the configurations for which the scope should be returned
+         * @return the scope to which the conf is mapped
+         */
+        public String getScope(String[] confs) {
+            for (int i = 0; i < confs.length; i++) {
+                if (scopes.containsKey(confs[i])) {
+                    return (String) scopes.get(confs[i]);
+                }
+            }
+
+            return null;
+        }
+        
+        public boolean isOptional(String[] confs) {
+            return getScope(confs) == null;
+        }
+    }
+
+    public static class ExtraDependency {
+            private String group;
+            private String artifact;
+            private String version;
+            private String scope;
+            private boolean optional;
+            
+            public ExtraDependency(String group, String artifact, String version, String scope, boolean optional) {
+                this.group = group;
+                this.artifact = artifact;
+                this.version = version;
+                this.scope = scope;
+                this.optional = optional;
+            }
+            
+            public String getGroup() {
+                return group;
+            }
+            public String getArtifact() {
+                return artifact;
+            }
+            public String getVersion() {
+                return version;
+            }
+            public String getScope() {
+                return scope;
+            }
+            public boolean isOptional() {
+                return optional;
+            }
+        }
+
+    
+}

Propchange: ant/ivy/core/trunk/src/java/org/apache/ivy/plugins/parser/m2/PomWriterOptions.java
------------------------------------------------------------------------------
    svn:eol-style = native

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

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

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

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

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

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

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

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

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

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

Propchange: ant/ivy/core/trunk/src/java/org/apache/ivy/plugins/report/LogReportOutputter.java
------------------------------------------------------------------------------
    svn:keywords = Date Revision Author HeadURL Id

Propchange: ant/ivy/core/trunk/src/java/org/apache/ivy/plugins/report/LogReportOutputter.java
------------------------------------------------------------------------------
    svn:mime-type = text/plain

Propchange: ant/ivy/core/trunk/src/java/org/apache/ivy/plugins/report/ReportOutputter.java
------------------------------------------------------------------------------
    svn:keywords = Date Revision Author HeadURL Id

Propchange: ant/ivy/core/trunk/src/java/org/apache/ivy/plugins/report/ReportOutputter.java
------------------------------------------------------------------------------
    svn:mime-type = text/plain

Propchange: ant/ivy/core/trunk/src/java/org/apache/ivy/plugins/report/XmlReportOutputter.java
------------------------------------------------------------------------------
    svn:keywords = Date Revision Author HeadURL Id

Propchange: ant/ivy/core/trunk/src/java/org/apache/ivy/plugins/report/XmlReportOutputter.java
------------------------------------------------------------------------------
    svn:mime-type = text/plain

Propchange: ant/ivy/core/trunk/src/java/org/apache/ivy/plugins/report/XmlReportParser.java
------------------------------------------------------------------------------
    svn:keywords = Date Revision Author HeadURL Id

Propchange: ant/ivy/core/trunk/src/java/org/apache/ivy/plugins/report/XmlReportParser.java
------------------------------------------------------------------------------
    svn:mime-type = text/plain

Propchange: ant/ivy/core/trunk/src/java/org/apache/ivy/plugins/report/XmlReportWriter.java
------------------------------------------------------------------------------
    svn:keywords = Date Revision Author HeadURL Id

Propchange: ant/ivy/core/trunk/src/java/org/apache/ivy/plugins/report/XmlReportWriter.java
------------------------------------------------------------------------------
    svn:mime-type = text/plain

Propchange: ant/ivy/core/trunk/src/java/org/apache/ivy/plugins/report/ivy-report-dot-all.xsl
------------------------------------------------------------------------------
    svn:keywords = Date Revision Author HeadURL Id

Propchange: ant/ivy/core/trunk/src/java/org/apache/ivy/plugins/report/ivy-report-dot-all.xsl
------------------------------------------------------------------------------
    svn:mime-type = text/xml

Propchange: ant/ivy/core/trunk/src/java/org/apache/ivy/plugins/report/ivy-report-dot.xsl
------------------------------------------------------------------------------
    svn:keywords = Date Revision Author HeadURL Id

Propchange: ant/ivy/core/trunk/src/java/org/apache/ivy/plugins/report/ivy-report-dot.xsl
------------------------------------------------------------------------------
    svn:mime-type = text/xml

Propchange: ant/ivy/core/trunk/src/java/org/apache/ivy/plugins/report/ivy-report-graph-all.xsl
------------------------------------------------------------------------------
    svn:keywords = Date Revision Author HeadURL Id

Propchange: ant/ivy/core/trunk/src/java/org/apache/ivy/plugins/report/ivy-report-graph-all.xsl
------------------------------------------------------------------------------
    svn:mime-type = text/xml

Propchange: ant/ivy/core/trunk/src/java/org/apache/ivy/plugins/report/ivy-report-graph.xsl
------------------------------------------------------------------------------
    svn:keywords = Date Revision Author HeadURL Id

Propchange: ant/ivy/core/trunk/src/java/org/apache/ivy/plugins/report/ivy-report-graph.xsl
------------------------------------------------------------------------------
    svn:mime-type = text/xml

Propchange: ant/ivy/core/trunk/src/java/org/apache/ivy/plugins/report/ivy-report.css
------------------------------------------------------------------------------
    svn:keywords = Date Revision Author HeadURL Id

Propchange: ant/ivy/core/trunk/src/java/org/apache/ivy/plugins/report/ivy-report.css
------------------------------------------------------------------------------
    svn:mime-type = text/css

Propchange: ant/ivy/core/trunk/src/java/org/apache/ivy/plugins/report/ivy-report.xsl
------------------------------------------------------------------------------
    svn:keywords = Date Revision Author HeadURL Id

Propchange: ant/ivy/core/trunk/src/java/org/apache/ivy/plugins/report/ivy-report.xsl
------------------------------------------------------------------------------
    svn:mime-type = text/xml

Propchange: ant/ivy/core/trunk/src/java/org/apache/ivy/plugins/repository/AbstractRepository.java
------------------------------------------------------------------------------
    svn:keywords = Date Revision Author HeadURL Id

Propchange: ant/ivy/core/trunk/src/java/org/apache/ivy/plugins/repository/AbstractRepository.java
------------------------------------------------------------------------------
    svn:mime-type = text/plain

Modified: ant/ivy/core/trunk/src/java/org/apache/ivy/plugins/repository/ArtifactResourceResolver.java
URL: http://svn.apache.org/viewvc/ant/ivy/core/trunk/src/java/org/apache/ivy/plugins/repository/ArtifactResourceResolver.java?rev=1049146&r1=1049145&r2=1049146&view=diff
==============================================================================
--- ant/ivy/core/trunk/src/java/org/apache/ivy/plugins/repository/ArtifactResourceResolver.java (original)
+++ ant/ivy/core/trunk/src/java/org/apache/ivy/plugins/repository/ArtifactResourceResolver.java Tue Dec 14 16:28:01 2010
@@ -1,29 +1,29 @@
-/*
- *  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.repository;
-
-import org.apache.ivy.core.module.descriptor.Artifact;
-import org.apache.ivy.plugins.resolver.util.ResolvedResource;
-
-/**
- * An {@link ArtifactResourceResolver} is responsible for the resolution of an artifact into a
- * {@link ResolvedResource}.
- */
-public interface ArtifactResourceResolver {
-    public ResolvedResource resolve(Artifact artifact);
-}
+/*
+ *  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.repository;
+
+import org.apache.ivy.core.module.descriptor.Artifact;
+import org.apache.ivy.plugins.resolver.util.ResolvedResource;
+
+/**
+ * An {@link ArtifactResourceResolver} is responsible for the resolution of an artifact into a
+ * {@link ResolvedResource}.
+ */
+public interface ArtifactResourceResolver {
+    public ResolvedResource resolve(Artifact artifact);
+}

Propchange: ant/ivy/core/trunk/src/java/org/apache/ivy/plugins/repository/ArtifactResourceResolver.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: ant/ivy/core/trunk/src/java/org/apache/ivy/plugins/repository/ArtifactResourceResolver.java
------------------------------------------------------------------------------
    svn:keywords = Date Revision Author HeadURL Id

Propchange: ant/ivy/core/trunk/src/java/org/apache/ivy/plugins/repository/BasicResource.java
------------------------------------------------------------------------------
    svn:keywords = Date Revision Author HeadURL Id

Propchange: ant/ivy/core/trunk/src/java/org/apache/ivy/plugins/repository/BasicResource.java
------------------------------------------------------------------------------
    svn:mime-type = text/plain

Propchange: ant/ivy/core/trunk/src/java/org/apache/ivy/plugins/repository/LazyResource.java
------------------------------------------------------------------------------
    svn:keywords = Date Revision Author HeadURL Id

Propchange: ant/ivy/core/trunk/src/java/org/apache/ivy/plugins/repository/LazyResource.java
------------------------------------------------------------------------------
    svn:mime-type = text/plain

Propchange: ant/ivy/core/trunk/src/java/org/apache/ivy/plugins/repository/Repository.java
------------------------------------------------------------------------------
    svn:keywords = Date Revision Author HeadURL Id

Propchange: ant/ivy/core/trunk/src/java/org/apache/ivy/plugins/repository/Repository.java
------------------------------------------------------------------------------
    svn:mime-type = text/plain

Propchange: ant/ivy/core/trunk/src/java/org/apache/ivy/plugins/repository/RepositoryCopyProgressListener.java
------------------------------------------------------------------------------
    svn:keywords = Date Revision Author HeadURL Id

Propchange: ant/ivy/core/trunk/src/java/org/apache/ivy/plugins/repository/RepositoryCopyProgressListener.java
------------------------------------------------------------------------------
    svn:mime-type = text/plain

Propchange: ant/ivy/core/trunk/src/java/org/apache/ivy/plugins/repository/Resource.java
------------------------------------------------------------------------------
    svn:keywords = Date Revision Author HeadURL Id

Propchange: ant/ivy/core/trunk/src/java/org/apache/ivy/plugins/repository/Resource.java
------------------------------------------------------------------------------
    svn:mime-type = text/plain

Modified: ant/ivy/core/trunk/src/java/org/apache/ivy/plugins/repository/ResourceDownloader.java
URL: http://svn.apache.org/viewvc/ant/ivy/core/trunk/src/java/org/apache/ivy/plugins/repository/ResourceDownloader.java?rev=1049146&r1=1049145&r2=1049146&view=diff
==============================================================================
--- ant/ivy/core/trunk/src/java/org/apache/ivy/plugins/repository/ResourceDownloader.java (original)
+++ ant/ivy/core/trunk/src/java/org/apache/ivy/plugins/repository/ResourceDownloader.java Tue Dec 14 16:28:01 2010
@@ -1,38 +1,38 @@
-/*
- *  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.repository;
-
-import java.io.File;
-import java.io.IOException;
-
-import org.apache.ivy.core.module.descriptor.Artifact;
-
-/**
- * A {@link ResourceDownloader} is able to download a Resource to a File.
- * <p>
- * Depending on the implementation, the downloader may also choose to download checksums
- * automatically and check the consistency of the downloaded resource.
- * </p>
- * <p>
- * The implementation is also responsible for using a .part file during download, to ensure the
- * destination file will exist only if the download is completed successfully.
- * </p>
- */
-public interface ResourceDownloader {
-    public void download(Artifact artifact, Resource resource, File dest) throws IOException;
-}
+/*
+ *  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.repository;
+
+import java.io.File;
+import java.io.IOException;
+
+import org.apache.ivy.core.module.descriptor.Artifact;
+
+/**
+ * A {@link ResourceDownloader} is able to download a Resource to a File.
+ * <p>
+ * Depending on the implementation, the downloader may also choose to download checksums
+ * automatically and check the consistency of the downloaded resource.
+ * </p>
+ * <p>
+ * The implementation is also responsible for using a .part file during download, to ensure the
+ * destination file will exist only if the download is completed successfully.
+ * </p>
+ */
+public interface ResourceDownloader {
+    public void download(Artifact artifact, Resource resource, File dest) throws IOException;
+}

Propchange: ant/ivy/core/trunk/src/java/org/apache/ivy/plugins/repository/ResourceDownloader.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: ant/ivy/core/trunk/src/java/org/apache/ivy/plugins/repository/ResourceDownloader.java
------------------------------------------------------------------------------
    svn:keywords = Date Revision Author HeadURL Id

Propchange: ant/ivy/core/trunk/src/java/org/apache/ivy/plugins/repository/ResourceHelper.java
------------------------------------------------------------------------------
    svn:keywords = Date Revision Author HeadURL Id

Propchange: ant/ivy/core/trunk/src/java/org/apache/ivy/plugins/repository/ResourceHelper.java
------------------------------------------------------------------------------
    svn:mime-type = text/plain

Propchange: ant/ivy/core/trunk/src/java/org/apache/ivy/plugins/repository/TransferEvent.java
------------------------------------------------------------------------------
    svn:keywords = Date Revision Author HeadURL Id

Propchange: ant/ivy/core/trunk/src/java/org/apache/ivy/plugins/repository/TransferEvent.java
------------------------------------------------------------------------------
    svn:mime-type = text/plain

Propchange: ant/ivy/core/trunk/src/java/org/apache/ivy/plugins/repository/TransferListener.java
------------------------------------------------------------------------------
    svn:keywords = Date Revision Author HeadURL Id

Propchange: ant/ivy/core/trunk/src/java/org/apache/ivy/plugins/repository/TransferListener.java
------------------------------------------------------------------------------
    svn:mime-type = text/plain

Propchange: ant/ivy/core/trunk/src/java/org/apache/ivy/plugins/repository/file/FileRepository.java
------------------------------------------------------------------------------
    svn:keywords = Date Revision Author HeadURL Id

Propchange: ant/ivy/core/trunk/src/java/org/apache/ivy/plugins/repository/file/FileRepository.java
------------------------------------------------------------------------------
    svn:mime-type = text/plain

Propchange: ant/ivy/core/trunk/src/java/org/apache/ivy/plugins/repository/file/FileResource.java
------------------------------------------------------------------------------
    svn:keywords = Date Revision Author HeadURL Id

Propchange: ant/ivy/core/trunk/src/java/org/apache/ivy/plugins/repository/file/FileResource.java
------------------------------------------------------------------------------
    svn:mime-type = text/plain

Propchange: ant/ivy/core/trunk/src/java/org/apache/ivy/plugins/repository/sftp/SFTPRepository.java
------------------------------------------------------------------------------
    svn:keywords = Date Revision Author HeadURL Id

Propchange: ant/ivy/core/trunk/src/java/org/apache/ivy/plugins/repository/sftp/SFTPRepository.java
------------------------------------------------------------------------------
    svn:mime-type = text/plain

Propchange: ant/ivy/core/trunk/src/java/org/apache/ivy/plugins/repository/sftp/SFTPResource.java
------------------------------------------------------------------------------
    svn:keywords = Date Revision Author HeadURL Id

Propchange: ant/ivy/core/trunk/src/java/org/apache/ivy/plugins/repository/sftp/SFTPResource.java
------------------------------------------------------------------------------
    svn:mime-type = text/plain

Propchange: ant/ivy/core/trunk/src/java/org/apache/ivy/plugins/repository/ssh/AbstractSshBasedRepository.java
------------------------------------------------------------------------------
    svn:keywords = Date Revision Author HeadURL Id

Propchange: ant/ivy/core/trunk/src/java/org/apache/ivy/plugins/repository/ssh/AbstractSshBasedRepository.java
------------------------------------------------------------------------------
    svn:mime-type = text/plain

Propchange: ant/ivy/core/trunk/src/java/org/apache/ivy/plugins/repository/ssh/RemoteScpException.java
------------------------------------------------------------------------------
    svn:keywords = Date Revision Author HeadURL Id

Propchange: ant/ivy/core/trunk/src/java/org/apache/ivy/plugins/repository/ssh/RemoteScpException.java
------------------------------------------------------------------------------
    svn:mime-type = text/plain

Propchange: ant/ivy/core/trunk/src/java/org/apache/ivy/plugins/repository/ssh/Scp.java
------------------------------------------------------------------------------
    svn:keywords = Date Revision Author HeadURL Id

Propchange: ant/ivy/core/trunk/src/java/org/apache/ivy/plugins/repository/ssh/Scp.java
------------------------------------------------------------------------------
    svn:mime-type = text/plain

Propchange: ant/ivy/core/trunk/src/java/org/apache/ivy/plugins/repository/ssh/SshCache.java
------------------------------------------------------------------------------
    svn:keywords = Date Revision Author HeadURL Id

Propchange: ant/ivy/core/trunk/src/java/org/apache/ivy/plugins/repository/ssh/SshCache.java
------------------------------------------------------------------------------
    svn:mime-type = text/plain

Propchange: ant/ivy/core/trunk/src/java/org/apache/ivy/plugins/repository/ssh/SshRepository.java
------------------------------------------------------------------------------
    svn:keywords = Date Revision Author HeadURL Id

Propchange: ant/ivy/core/trunk/src/java/org/apache/ivy/plugins/repository/ssh/SshRepository.java
------------------------------------------------------------------------------
    svn:mime-type = text/plain

Propchange: ant/ivy/core/trunk/src/java/org/apache/ivy/plugins/repository/ssh/SshResource.java
------------------------------------------------------------------------------
    svn:keywords = Date Revision Author HeadURL Id

Propchange: ant/ivy/core/trunk/src/java/org/apache/ivy/plugins/repository/ssh/SshResource.java
------------------------------------------------------------------------------
    svn:mime-type = text/plain

Propchange: ant/ivy/core/trunk/src/java/org/apache/ivy/plugins/repository/url/URLRepository.java
------------------------------------------------------------------------------
    svn:keywords = Date Revision Author HeadURL Id

Propchange: ant/ivy/core/trunk/src/java/org/apache/ivy/plugins/repository/url/URLRepository.java
------------------------------------------------------------------------------
    svn:mime-type = text/plain

Propchange: ant/ivy/core/trunk/src/java/org/apache/ivy/plugins/repository/url/URLResource.java
------------------------------------------------------------------------------
    svn:keywords = Date Revision Author HeadURL Id

Propchange: ant/ivy/core/trunk/src/java/org/apache/ivy/plugins/repository/url/URLResource.java
------------------------------------------------------------------------------
    svn:mime-type = text/plain

Propchange: ant/ivy/core/trunk/src/java/org/apache/ivy/plugins/repository/vfs/VfsRepository.java
------------------------------------------------------------------------------
    svn:keywords = Date Revision Author HeadURL Id

Propchange: ant/ivy/core/trunk/src/java/org/apache/ivy/plugins/repository/vfs/VfsRepository.java
------------------------------------------------------------------------------
    svn:mime-type = text/plain

Propchange: ant/ivy/core/trunk/src/java/org/apache/ivy/plugins/repository/vfs/VfsResource.java
------------------------------------------------------------------------------
    svn:keywords = Date Revision Author HeadURL Id

Propchange: ant/ivy/core/trunk/src/java/org/apache/ivy/plugins/repository/vfs/VfsResource.java
------------------------------------------------------------------------------
    svn:mime-type = text/plain

Propchange: ant/ivy/core/trunk/src/java/org/apache/ivy/plugins/repository/vfs/ivy_vfs.xml
------------------------------------------------------------------------------
    svn:keywords = Date Revision Author HeadURL Id

Propchange: ant/ivy/core/trunk/src/java/org/apache/ivy/plugins/repository/vfs/ivy_vfs.xml
------------------------------------------------------------------------------
    svn:mime-type = text/xml

Propchange: ant/ivy/core/trunk/src/java/org/apache/ivy/plugins/repository/vsftp/VsftpRepository.java
------------------------------------------------------------------------------
    svn:keywords = Date Revision Author HeadURL Id

Propchange: ant/ivy/core/trunk/src/java/org/apache/ivy/plugins/repository/vsftp/VsftpRepository.java
------------------------------------------------------------------------------
    svn:mime-type = text/plain

Propchange: ant/ivy/core/trunk/src/java/org/apache/ivy/plugins/repository/vsftp/VsftpResource.java
------------------------------------------------------------------------------
    svn:keywords = Date Revision Author HeadURL Id

Propchange: ant/ivy/core/trunk/src/java/org/apache/ivy/plugins/repository/vsftp/VsftpResource.java
------------------------------------------------------------------------------
    svn:mime-type = text/plain

Propchange: ant/ivy/core/trunk/src/java/org/apache/ivy/plugins/resolver/AbstractPatternsBasedResolver.java
------------------------------------------------------------------------------
    svn:keywords = Date Revision Author HeadURL Id

Propchange: ant/ivy/core/trunk/src/java/org/apache/ivy/plugins/resolver/AbstractPatternsBasedResolver.java
------------------------------------------------------------------------------
    svn:mime-type = text/plain

Propchange: ant/ivy/core/trunk/src/java/org/apache/ivy/plugins/resolver/AbstractResolver.java
------------------------------------------------------------------------------
    svn:keywords = Date Revision Author HeadURL Id

Propchange: ant/ivy/core/trunk/src/java/org/apache/ivy/plugins/resolver/AbstractResolver.java
------------------------------------------------------------------------------
    svn:mime-type = text/plain

Propchange: ant/ivy/core/trunk/src/java/org/apache/ivy/plugins/resolver/AbstractSshBasedResolver.java
------------------------------------------------------------------------------
    svn:keywords = Date Revision Author HeadURL Id

Propchange: ant/ivy/core/trunk/src/java/org/apache/ivy/plugins/resolver/AbstractSshBasedResolver.java
------------------------------------------------------------------------------
    svn:mime-type = text/plain

Propchange: ant/ivy/core/trunk/src/java/org/apache/ivy/plugins/resolver/BasicResolver.java
------------------------------------------------------------------------------
    svn:keywords = Date Revision Author HeadURL Id

Propchange: ant/ivy/core/trunk/src/java/org/apache/ivy/plugins/resolver/BasicResolver.java
------------------------------------------------------------------------------
    svn:mime-type = text/plain

Propchange: ant/ivy/core/trunk/src/java/org/apache/ivy/plugins/resolver/CacheResolver.java
------------------------------------------------------------------------------
    svn:keywords = Date Revision Author HeadURL Id

Propchange: ant/ivy/core/trunk/src/java/org/apache/ivy/plugins/resolver/CacheResolver.java
------------------------------------------------------------------------------
    svn:mime-type = text/plain

Propchange: ant/ivy/core/trunk/src/java/org/apache/ivy/plugins/resolver/ChainResolver.java
------------------------------------------------------------------------------
    svn:keywords = Date Revision Author HeadURL Id

Propchange: ant/ivy/core/trunk/src/java/org/apache/ivy/plugins/resolver/ChainResolver.java
------------------------------------------------------------------------------
    svn:mime-type = text/plain

Propchange: ant/ivy/core/trunk/src/java/org/apache/ivy/plugins/resolver/DependencyResolver.java
------------------------------------------------------------------------------
    svn:keywords = Date Revision Author HeadURL Id

Propchange: ant/ivy/core/trunk/src/java/org/apache/ivy/plugins/resolver/DependencyResolver.java
------------------------------------------------------------------------------
    svn:mime-type = text/plain

Propchange: ant/ivy/core/trunk/src/java/org/apache/ivy/plugins/resolver/DualResolver.java
------------------------------------------------------------------------------
    svn:keywords = Date Revision Author HeadURL Id

Propchange: ant/ivy/core/trunk/src/java/org/apache/ivy/plugins/resolver/DualResolver.java
------------------------------------------------------------------------------
    svn:mime-type = text/plain

Propchange: ant/ivy/core/trunk/src/java/org/apache/ivy/plugins/resolver/FileSystemResolver.java
------------------------------------------------------------------------------
    svn:keywords = Date Revision Author HeadURL Id

Propchange: ant/ivy/core/trunk/src/java/org/apache/ivy/plugins/resolver/FileSystemResolver.java
------------------------------------------------------------------------------
    svn:mime-type = text/plain

Propchange: ant/ivy/core/trunk/src/java/org/apache/ivy/plugins/resolver/IBiblioResolver.java
------------------------------------------------------------------------------
    svn:keywords = Date Revision Author HeadURL Id

Propchange: ant/ivy/core/trunk/src/java/org/apache/ivy/plugins/resolver/IBiblioResolver.java
------------------------------------------------------------------------------
    svn:mime-type = text/plain

Propchange: ant/ivy/core/trunk/src/java/org/apache/ivy/plugins/resolver/IvyRepResolver.java
------------------------------------------------------------------------------
    svn:keywords = Date Revision Author HeadURL Id

Propchange: ant/ivy/core/trunk/src/java/org/apache/ivy/plugins/resolver/IvyRepResolver.java
------------------------------------------------------------------------------
    svn:mime-type = text/plain

Propchange: ant/ivy/core/trunk/src/java/org/apache/ivy/plugins/resolver/RepositoryResolver.java
------------------------------------------------------------------------------
    svn:keywords = Date Revision Author HeadURL Id

Propchange: ant/ivy/core/trunk/src/java/org/apache/ivy/plugins/resolver/RepositoryResolver.java
------------------------------------------------------------------------------
    svn:mime-type = text/plain

Propchange: ant/ivy/core/trunk/src/java/org/apache/ivy/plugins/resolver/ResolverSettings.java
------------------------------------------------------------------------------
    svn:keywords = Date Revision Author HeadURL Id

Propchange: ant/ivy/core/trunk/src/java/org/apache/ivy/plugins/resolver/ResolverSettings.java
------------------------------------------------------------------------------
    svn:mime-type = text/plain

Propchange: ant/ivy/core/trunk/src/java/org/apache/ivy/plugins/resolver/SFTPResolver.java
------------------------------------------------------------------------------
    svn:keywords = Date Revision Author HeadURL Id

Propchange: ant/ivy/core/trunk/src/java/org/apache/ivy/plugins/resolver/SFTPResolver.java
------------------------------------------------------------------------------
    svn:mime-type = text/plain

Propchange: ant/ivy/core/trunk/src/java/org/apache/ivy/plugins/resolver/SshResolver.java
------------------------------------------------------------------------------
    svn:keywords = Date Revision Author HeadURL Id

Propchange: ant/ivy/core/trunk/src/java/org/apache/ivy/plugins/resolver/SshResolver.java
------------------------------------------------------------------------------
    svn:mime-type = text/plain

Propchange: ant/ivy/core/trunk/src/java/org/apache/ivy/plugins/resolver/URLResolver.java
------------------------------------------------------------------------------
    svn:keywords = Date Revision Author HeadURL Id

Propchange: ant/ivy/core/trunk/src/java/org/apache/ivy/plugins/resolver/URLResolver.java
------------------------------------------------------------------------------
    svn:mime-type = text/plain

Propchange: ant/ivy/core/trunk/src/java/org/apache/ivy/plugins/resolver/VfsResolver.java
------------------------------------------------------------------------------
    svn:keywords = Date Revision Author HeadURL Id

Propchange: ant/ivy/core/trunk/src/java/org/apache/ivy/plugins/resolver/VfsResolver.java
------------------------------------------------------------------------------
    svn:mime-type = text/plain

Propchange: ant/ivy/core/trunk/src/java/org/apache/ivy/plugins/resolver/VsftpResolver.java
------------------------------------------------------------------------------
    svn:keywords = Date Revision Author HeadURL Id

Propchange: ant/ivy/core/trunk/src/java/org/apache/ivy/plugins/resolver/VsftpResolver.java
------------------------------------------------------------------------------
    svn:mime-type = text/plain

Propchange: ant/ivy/core/trunk/src/java/org/apache/ivy/plugins/resolver/packager/BuiltFileResource.java
------------------------------------------------------------------------------
    svn:keywords = Date Revision Author HeadURL Id

Propchange: ant/ivy/core/trunk/src/java/org/apache/ivy/plugins/resolver/packager/PackagerCacheEntry.java
------------------------------------------------------------------------------
    svn:keywords = Date Revision Author HeadURL Id

Propchange: ant/ivy/core/trunk/src/java/org/apache/ivy/plugins/resolver/packager/PackagerResolver.java
------------------------------------------------------------------------------
    svn:keywords = Date Revision Author HeadURL Id

Propchange: ant/ivy/core/trunk/src/java/org/apache/ivy/plugins/resolver/packager/build.xml
------------------------------------------------------------------------------
    svn:keywords = Date Revision Author HeadURL Id

Propchange: ant/ivy/core/trunk/src/java/org/apache/ivy/plugins/resolver/packager/build.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/src/java/org/apache/ivy/plugins/resolver/packager/packager-1.0.xsd
------------------------------------------------------------------------------
    svn:keywords = Date Revision Author HeadURL Id

Propchange: ant/ivy/core/trunk/src/java/org/apache/ivy/plugins/resolver/packager/packager-1.0.xsd
------------------------------------------------------------------------------
--- 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/src/java/org/apache/ivy/plugins/resolver/packager/packager.xsl
------------------------------------------------------------------------------
    svn:keywords = Date Revision Author HeadURL Id

Propchange: ant/ivy/core/trunk/src/java/org/apache/ivy/plugins/resolver/packager/packager.xsl
------------------------------------------------------------------------------
--- 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/src/java/org/apache/ivy/plugins/resolver/util/ApacheHttpURLLister.java
------------------------------------------------------------------------------
    svn:keywords = Date Revision Author HeadURL Id

Propchange: ant/ivy/core/trunk/src/java/org/apache/ivy/plugins/resolver/util/ApacheHttpURLLister.java
------------------------------------------------------------------------------
    svn:mime-type = text/plain

Propchange: ant/ivy/core/trunk/src/java/org/apache/ivy/plugins/resolver/util/FileURLLister.java
------------------------------------------------------------------------------
    svn:keywords = Date Revision Author HeadURL Id

Propchange: ant/ivy/core/trunk/src/java/org/apache/ivy/plugins/resolver/util/FileURLLister.java
------------------------------------------------------------------------------
    svn:mime-type = text/plain

Propchange: ant/ivy/core/trunk/src/java/org/apache/ivy/plugins/resolver/util/HasLatestStrategy.java
------------------------------------------------------------------------------
    svn:keywords = Date Revision Author HeadURL Id

Propchange: ant/ivy/core/trunk/src/java/org/apache/ivy/plugins/resolver/util/HasLatestStrategy.java
------------------------------------------------------------------------------
    svn:mime-type = text/plain

Propchange: ant/ivy/core/trunk/src/java/org/apache/ivy/plugins/resolver/util/MDResolvedResource.java
------------------------------------------------------------------------------
    svn:keywords = Date Revision Author HeadURL Id

Propchange: ant/ivy/core/trunk/src/java/org/apache/ivy/plugins/resolver/util/MDResolvedResource.java
------------------------------------------------------------------------------
    svn:mime-type = text/plain

Propchange: ant/ivy/core/trunk/src/java/org/apache/ivy/plugins/resolver/util/ResolvedResource.java
------------------------------------------------------------------------------
    svn:keywords = Date Revision Author HeadURL Id

Propchange: ant/ivy/core/trunk/src/java/org/apache/ivy/plugins/resolver/util/ResolvedResource.java
------------------------------------------------------------------------------
    svn:mime-type = text/plain

Propchange: ant/ivy/core/trunk/src/java/org/apache/ivy/plugins/resolver/util/ResolverHelper.java
------------------------------------------------------------------------------
    svn:keywords = Date Revision Author HeadURL Id

Propchange: ant/ivy/core/trunk/src/java/org/apache/ivy/plugins/resolver/util/ResolverHelper.java
------------------------------------------------------------------------------
    svn:mime-type = text/plain