You are viewing a plain text version of this content. The canonical link for it is here.
Posted to notifications@ant.apache.org by jl...@apache.org on 2014/01/14 09:27:43 UTC

svn commit: r1557968 [9/26] - in /ant/ivy/core/trunk: src/java/org/apache/ivy/ src/java/org/apache/ivy/ant/ src/java/org/apache/ivy/core/ src/java/org/apache/ivy/core/cache/ src/java/org/apache/ivy/core/check/ src/java/org/apache/ivy/core/deliver/ src/...

Modified: ant/ivy/core/trunk/src/java/org/apache/ivy/core/settings/IvySettings.java
URL: http://svn.apache.org/viewvc/ant/ivy/core/trunk/src/java/org/apache/ivy/core/settings/IvySettings.java?rev=1557968&r1=1557967&r2=1557968&view=diff
==============================================================================
--- ant/ivy/core/trunk/src/java/org/apache/ivy/core/settings/IvySettings.java (original)
+++ ant/ivy/core/trunk/src/java/org/apache/ivy/core/settings/IvySettings.java Tue Jan 14 08:27:37 2014
@@ -111,9 +111,8 @@ import org.apache.ivy.util.filter.Filter
 import org.apache.ivy.util.url.URLHandlerRegistry;
 
 public class IvySettings implements SortEngineSettings, PublishEngineSettings, ParserSettings,
-        DeliverEngineSettings, CheckEngineSettings, InstallEngineSettings, 
-        ResolverSettings, ResolveEngineSettings, RetrieveEngineSettings, 
-        RepositoryManagementEngineSettings {
+        DeliverEngineSettings, CheckEngineSettings, InstallEngineSettings, ResolverSettings,
+        ResolveEngineSettings, RetrieveEngineSettings, RepositoryManagementEngineSettings {
     private static final long INTERUPT_TIMEOUT = 2000;
 
     private Map typeDefs = new HashMap();
@@ -132,40 +131,40 @@ public class IvySettings implements Sort
 
     private boolean checkUpToDate = true;
 
-    private ModuleRules moduleSettings = new ModuleRules(); 
+    private ModuleRules moduleSettings = new ModuleRules();
 
     // Map (String conflictManagerName -> ConflictManager)
-    private Map conflictsManager = new HashMap(); 
+    private Map conflictsManager = new HashMap();
 
     // Map (String latestStrategyName -> LatestStrategy)
-    private Map latestStrategies = new HashMap(); 
-    
+    private Map latestStrategies = new HashMap();
+
     // Map (String name -> LockStrategy)
-    private Map lockStrategies = new HashMap(); 
+    private Map lockStrategies = new HashMap();
 
     // Map (String namespaceName -> Namespace)
-    private Map namespaces = new HashMap(); 
+    private Map namespaces = new HashMap();
 
     // Map (String matcherName -> Matcher)
-    private Map matchers = new HashMap(); 
+    private Map matchers = new HashMap();
 
     // Map (String outputterName -> ReportOutputter)
-    private Map reportOutputters = new HashMap(); 
+    private Map reportOutputters = new HashMap();
 
     // Map (String matcherName -> VersionMatcher)
-    private Map versionMatchers = new HashMap(); 
+    private Map versionMatchers = new HashMap();
 
     // Map (String name -> CircularDependencyStrategy)
-    private Map circularDependencyStrategies = new HashMap(); 
+    private Map circularDependencyStrategies = new HashMap();
 
     // Map (String name -> RepositoryCacheManager)
-    private Map repositoryCacheManagers = new HashMap(); 
-    
+    private Map repositoryCacheManagers = new HashMap();
+
     // Map (String name -> SignatureGenerator)
     private Map signatureGenerators = new HashMap();
 
     // List (Trigger)
-    private List triggers = new ArrayList(); 
+    private List triggers = new ArrayList();
 
     private IvyVariableContainer variableContainer = new IvyVariableContainerImpl();
 
@@ -190,7 +189,7 @@ public class IvySettings implements Sort
     private boolean useRemoteConfig = false;
 
     private File defaultUserDir;
-    
+
     private File baseDir = new File(".").getAbsoluteFile();
 
     private List classpathURLs = new ArrayList();
@@ -234,8 +233,9 @@ public class IvySettings implements Sort
             String[] files = ivyTypeDefs.split("\\,");
             for (int i = 0; i < files.length; i++) {
                 try {
-                    typeDefs(new FileInputStream(
-                        Checks.checkAbsolute(files[i].trim(), "ivy.typedef.files")), true);
+                    typeDefs(
+                        new FileInputStream(Checks.checkAbsolute(files[i].trim(),
+                            "ivy.typedef.files")), true);
                 } catch (FileNotFoundException e) {
                     Message.warn("typedefs file not found: " + files[i].trim());
                 } catch (IOException e) {
@@ -264,9 +264,9 @@ public class IvySettings implements Sort
         addLockStrategy("artifact-lock-nio", new NIOFileLockStrategy(debugLocking()));
 
         addConflictManager("latest-revision", new LatestConflictManager("latest-revision",
-            latestRevisionStrategy));
-        addConflictManager("latest-compatible", 
-            new LatestCompatibleConflictManager("latest-compatible", latestRevisionStrategy));
+                latestRevisionStrategy));
+        addConflictManager("latest-compatible", new LatestCompatibleConflictManager(
+                "latest-compatible", latestRevisionStrategy));
         addConflictManager("latest-time", new LatestConflictManager("latest-time",
                 latestTimeStrategy));
         addConflictManager("all", new NoConflictManager());
@@ -307,9 +307,8 @@ public class IvySettings implements Sort
         try {
             addAllVariables((Map) System.getProperties().clone());
         } catch (AccessControlException ex) {
-            Message.verbose(
-                "access denied to getting all system properties: they won't be available as Ivy variables."
-                + "\nset " + ex.getPermission() + " permission if you want to access them");
+            Message.verbose("access denied to getting all system properties: they won't be available as Ivy variables."
+                    + "\nset " + ex.getPermission() + " permission if you want to access them");
         }
     }
 
@@ -343,7 +342,7 @@ public class IvySettings implements Sort
                         try {
                             repositoryPropsStream.close();
                         } catch (Exception ex) {
-                            //nothing to do
+                            // nothing to do
                         }
                     }
                 }
@@ -383,8 +382,8 @@ public class IvySettings implements Sort
         long start = System.currentTimeMillis();
         setSettingsVariables(settingsFile);
         if (getVariable("ivy.default.ivy.user.dir") != null) {
-            setDefaultIvyUserDir(Checks.checkAbsolute(
-                getVariable("ivy.default.ivy.user.dir"), "ivy.default.ivy.user.dir"));
+            setDefaultIvyUserDir(Checks.checkAbsolute(getVariable("ivy.default.ivy.user.dir"),
+                "ivy.default.ivy.user.dir"));
         } else {
             getDefaultIvyUserDir();
         }
@@ -408,8 +407,8 @@ public class IvySettings implements Sort
         long start = System.currentTimeMillis();
         setSettingsVariables(settingsURL);
         if (getVariable("ivy.default.ivy.user.dir") != null) {
-            setDefaultIvyUserDir(Checks.checkAbsolute(
-                getVariable("ivy.default.ivy.user.dir"), "ivy.default.ivy.user.dir"));
+            setDefaultIvyUserDir(Checks.checkAbsolute(getVariable("ivy.default.ivy.user.dir"),
+                "ivy.default.ivy.user.dir"));
         } else {
             getDefaultIvyUserDir();
         }
@@ -420,7 +419,7 @@ public class IvySettings implements Sort
         Message.verbose("settings loaded (" + (System.currentTimeMillis() - start) + "ms)");
         dumpSettings();
     }
-    
+
     /**
      * Default initialization of settings, useful when you don't want to load your settings from a
      * settings file or URL, but prefer to set them manually. By calling this method you will still
@@ -430,8 +429,8 @@ public class IvySettings implements Sort
      */
     public synchronized void defaultInit() throws IOException {
         if (getVariable("ivy.default.ivy.user.dir") != null) {
-            setDefaultIvyUserDir(Checks.checkAbsolute(
-                    getVariable("ivy.default.ivy.user.dir"), "ivy.default.ivy.user.dir"));
+            setDefaultIvyUserDir(Checks.checkAbsolute(getVariable("ivy.default.ivy.user.dir"),
+                "ivy.default.ivy.user.dir"));
         } else {
             getDefaultIvyUserDir();
         }
@@ -468,8 +467,8 @@ public class IvySettings implements Sort
 
     private String getDefaultSettingsDir() {
         String ivysettingsLocation = getDefaultSettingsURL().toExternalForm();
-        return ivysettingsLocation.substring(0, ivysettingsLocation.length()
-                - "ivysettings.xml".length() - 1);
+        return ivysettingsLocation.substring(0,
+            ivysettingsLocation.length() - "ivysettings.xml".length() - 1);
     }
 
     private static URL getSettingsURL(String file) {
@@ -517,8 +516,8 @@ public class IvySettings implements Sort
             setVariable("ivy.settings.dir.url", dirUrl);
             setDeprecatedVariable("ivy.conf.dir", "ivy.settings.dir");
         } else {
-            Message.warn("settings url does not contain any slash (/): " 
-                + "ivy.settings.dir variable not set");
+            Message.warn("settings url does not contain any slash (/): "
+                    + "ivy.settings.dir variable not set");
         }
     }
 
@@ -572,7 +571,7 @@ public class IvySettings implements Sort
                 try {
                     stream.close();
                 } catch (IOException e) {
-                    //nothing
+                    // nothing
                 }
             }
         }
@@ -590,7 +589,7 @@ public class IvySettings implements Sort
             String ifSetVar, String unlessSetVar) {
         if (ifSetVar != null && variableContainer.getVariable(ifSetVar) == null) {
             Message.verbose("Not setting '" + varName + "' to '" + value + "' since '" + ifSetVar
-                + "' is not set.");
+                    + "' is not set.");
             return;
         }
         if (unlessSetVar != null && variableContainer.getVariable(unlessSetVar) != null) {
@@ -618,8 +617,8 @@ public class IvySettings implements Sort
      * 
      * @param str
      *            the string in which substitution should be made
-     * @return the string where all current ivy variables have been substituted by their value
-     *         If the input str doesn't use any variable, the same object is returned
+     * @return the string where all current ivy variables have been substituted by their value If
+     *         the input str doesn't use any variable, the same object is returned
      */
     public synchronized String substitute(String str) {
         return IvyPatternHelper.substituteVariables(str, variableContainer);
@@ -634,7 +633,7 @@ public class IvySettings implements Sort
      * @return a new map of strings in which all current ivy variables in values have been
      *         substituted by their value
      */
-    public synchronized Map/*<String, String>*/ substitute(Map/*<String, String>*/ strings) {
+    public synchronized Map/* <String, String> */substitute(Map/* <String, String> */strings) {
         Map substituted = new LinkedHashMap();
         for (Iterator it = strings.entrySet().iterator(); it.hasNext();) {
             Map.Entry entry = (Map.Entry) it.next();
@@ -685,8 +684,9 @@ public class IvySettings implements Sort
             if (classpathURLs.isEmpty()) {
                 classloader = Ivy.class.getClassLoader();
             } else {
-                classloader = new URLClassLoader((URL[]) classpathURLs
-                        .toArray(new URL[classpathURLs.size()]), Ivy.class.getClassLoader());
+                classloader = new URLClassLoader(
+                        (URL[]) classpathURLs.toArray(new URL[classpathURLs.size()]),
+                        Ivy.class.getClassLoader());
             }
         }
         return classloader;
@@ -713,16 +713,16 @@ public class IvySettings implements Sort
     public synchronized void addConfigured(ModuleDescriptorParser parser) {
         ModuleDescriptorParserRegistry.getInstance().addParser(parser);
     }
-    
+
     public synchronized void addConfigured(SignatureGenerator generator) {
         addSignatureGenerator(generator);
     }
-    
+
     public synchronized void addSignatureGenerator(SignatureGenerator generator) {
         init(generator);
         signatureGenerators.put(generator.getName(), generator);
     }
-    
+
     public synchronized SignatureGenerator getSignatureGenerator(String name) {
         return (SignatureGenerator) signatureGenerators.get(name);
     }
@@ -758,7 +758,7 @@ public class IvySettings implements Sort
             if ("default-cache".equals(defaultRepositoryCacheManager.getName())
                     && defaultRepositoryCacheManager instanceof DefaultRepositoryCacheManager) {
                 ((DefaultRepositoryCacheManager) defaultRepositoryCacheManager)
-                    .setBasedir(defaultCache);
+                        .setBasedir(defaultCache);
             }
         }
     }
@@ -781,36 +781,35 @@ public class IvySettings implements Sort
     /**
      * regular expressions as explained in Pattern class may be used in attributes
      */
-    public synchronized void addModuleConfiguration(Map attributes, PatternMatcher matcher, 
+    public synchronized void addModuleConfiguration(Map attributes, PatternMatcher matcher,
             String resolverName, String branch, String conflictManager, String resolveMode) {
         checkResolverName(resolverName);
-        moduleSettings.defineRule(
-            new MapMatcher(attributes, matcher), 
-            new ModuleSettings(resolverName, branch, conflictManager, resolveMode));
+        moduleSettings.defineRule(new MapMatcher(attributes, matcher), new ModuleSettings(
+                resolverName, branch, conflictManager, resolveMode));
     }
-    
+
     /**
      * Return the canonical form of a filename.
      * <p>
-     * If the specified file name is relative it is resolved
-     * with respect to the settings's base directory.
-     *
-     * @param fileName The name of the file to resolve.
-     *                 Must not be <code>null</code>.
-     *
+     * If the specified file name is relative it is resolved with respect to the settings's base
+     * directory.
+     * 
+     * @param fileName
+     *            The name of the file to resolve. Must not be <code>null</code>.
+     * 
      * @return the resolved File.
-     *
+     * 
      */
     public synchronized File resolveFile(String fileName) {
         return FileUtil.resolveFile(baseDir, fileName);
     }
-    
+
     public synchronized void setBaseDir(File baseDir) {
         this.baseDir = baseDir.getAbsoluteFile();
         setVariable("ivy.basedir", this.baseDir.getAbsolutePath());
         setVariable("basedir", this.baseDir.getAbsolutePath(), false);
     }
-    
+
     public synchronized File getBaseDir() {
         return baseDir;
     }
@@ -820,7 +819,7 @@ public class IvySettings implements Sort
             if (getVariable("ivy.home") != null) {
                 setDefaultIvyUserDir(Checks.checkAbsolute(getVariable("ivy.home"), "ivy.home"));
                 Message.verbose("using ivy.default.ivy.user.dir variable for default ivy user dir: "
-                                + defaultUserDir);
+                        + defaultUserDir);
             } else {
                 setDefaultIvyUserDir(new File(System.getProperty("user.home"), ".ivy2"));
                 Message.verbose("no default ivy user dir defined: set to " + defaultUserDir);
@@ -847,26 +846,26 @@ public class IvySettings implements Sort
         }
         return defaultCache;
     }
-    
+
     public synchronized void setDefaultRepositoryCacheBasedir(String repositoryCacheRoot) {
         setVariable("ivy.cache.repository", repositoryCacheRoot, true);
         if (defaultRepositoryCacheManager != null
                 && "default-cache".equals(defaultRepositoryCacheManager.getName())
                 && defaultRepositoryCacheManager instanceof DefaultRepositoryCacheManager) {
             ((DefaultRepositoryCacheManager) defaultRepositoryCacheManager)
-                .setBasedir(getDefaultRepositoryCacheBasedir());
+                    .setBasedir(getDefaultRepositoryCacheBasedir());
         }
     }
-    
+
     public synchronized void setDefaultResolutionCacheBasedir(String resolutionCacheRoot) {
         setVariable("ivy.cache.resolution", resolutionCacheRoot, true);
         if (resolutionCacheManager != null
                 && resolutionCacheManager instanceof DefaultResolutionCacheManager) {
             ((DefaultResolutionCacheManager) resolutionCacheManager)
-                .setBasedir(getDefaultResolutionCacheBasedir());
+                    .setBasedir(getDefaultResolutionCacheBasedir());
         }
     }
-    
+
     public synchronized File getDefaultRepositoryCacheBasedir() {
         String repositoryCacheRoot = getVariable("ivy.cache.repository");
         if (repositoryCacheRoot != null) {
@@ -959,9 +958,8 @@ public class IvySettings implements Sort
         } else {
             ConflictManager cm = getConflictManager(ms.getConflictManager());
             if (cm == null) {
-                throw new IllegalStateException(
-                        "ivy badly configured: unknown conflict manager "
-                                + ms.getConflictManager());
+                throw new IllegalStateException("ivy badly configured: unknown conflict manager "
+                        + ms.getConflictManager());
             }
             return cm;
         }
@@ -979,7 +977,7 @@ public class IvySettings implements Sort
     public synchronized String getDefaultResolveMode() {
         return defaultResolveMode;
     }
-    
+
     public synchronized void setDefaultResolveMode(String defaultResolveMode) {
         this.defaultResolveMode = defaultResolveMode;
     }
@@ -1185,13 +1183,12 @@ public class IvySettings implements Sort
     }
 
     /**
-     * Returns the file names of the files that should be ignored when 
-     * creating a file listing.
+     * Returns the file names of the files that should be ignored when creating a file listing.
      */
     public synchronized String[] getIgnorableFilenames() {
         return (String[]) listingIgnore.toArray(new String[listingIgnore.size()]);
     }
-    
+
     /**
      * Filters the names list by removing all names that should be ignored as defined by the listing
      * ignore list
@@ -1201,7 +1198,7 @@ public class IvySettings implements Sort
     public synchronized void filterIgnore(Collection names) {
         names.removeAll(listingIgnore);
     }
-    
+
     public synchronized boolean isCheckUpToDate() {
         return checkUpToDate;
     }
@@ -1209,7 +1206,7 @@ public class IvySettings implements Sort
     public synchronized void setCheckUpToDate(boolean checkUpToDate) {
         this.checkUpToDate = checkUpToDate;
     }
-    
+
     public synchronized boolean doValidate() {
         return validate;
     }
@@ -1258,9 +1255,8 @@ public class IvySettings implements Sort
 
     public synchronized RepositoryCacheManager getDefaultRepositoryCacheManager() {
         if (defaultRepositoryCacheManager == null) {
-            defaultRepositoryCacheManager 
-                = new DefaultRepositoryCacheManager(
-                    "default-cache", this, getDefaultRepositoryCacheBasedir());
+            defaultRepositoryCacheManager = new DefaultRepositoryCacheManager("default-cache",
+                    this, getDefaultRepositoryCacheBasedir());
             addRepositoryCacheManager(defaultRepositoryCacheManager);
         }
         return defaultRepositoryCacheManager;
@@ -1272,13 +1268,13 @@ public class IvySettings implements Sort
 
     public synchronized ResolutionCacheManager getResolutionCacheManager() {
         if (resolutionCacheManager == null) {
-            resolutionCacheManager 
-                = new DefaultResolutionCacheManager(getDefaultResolutionCacheBasedir());
+            resolutionCacheManager = new DefaultResolutionCacheManager(
+                    getDefaultResolutionCacheBasedir());
             init(resolutionCacheManager);
         }
         return resolutionCacheManager;
     }
-    
+
     public synchronized void setResolutionCacheManager(ResolutionCacheManager resolutionCacheManager) {
         this.resolutionCacheManager = resolutionCacheManager;
     }
@@ -1331,8 +1327,7 @@ public class IvySettings implements Sort
     public synchronized boolean debugLocking() {
         if (debugLocking == null) {
             String var = getVariable("ivy.log.locking");
-            debugLocking = Boolean.valueOf(var != null
-                    && Boolean.valueOf(var).booleanValue());
+            debugLocking = Boolean.valueOf(var != null && Boolean.valueOf(var).booleanValue());
         }
         return debugLocking.booleanValue();
     }
@@ -1340,13 +1335,11 @@ public class IvySettings implements Sort
     public synchronized boolean dumpMemoryUsage() {
         if (dumpMemoryUsage == null) {
             String var = getVariable("ivy.log.memory");
-            dumpMemoryUsage = Boolean.valueOf(var != null
-                    && Boolean.valueOf(var).booleanValue());
+            dumpMemoryUsage = Boolean.valueOf(var != null && Boolean.valueOf(var).booleanValue());
         }
         return dumpMemoryUsage.booleanValue();
     }
 
-
     public synchronized boolean logNotConvertedExclusionRule() {
         return logNotConvertedExclusionRule;
     }
@@ -1372,8 +1365,8 @@ public class IvySettings implements Sort
 
         private String resolveMode;
 
-        public ModuleSettings(
-                String resolver, String branchName, String conflictMgr, String resolveMode) {
+        public ModuleSettings(String resolver, String branchName, String conflictMgr,
+                String resolveMode) {
             this.resolverName = resolver;
             this.branch = branchName;
             this.conflictManager = conflictMgr;
@@ -1382,9 +1375,9 @@ public class IvySettings implements Sort
 
         public String toString() {
             return (resolverName != null ? "resolver: " + resolverName : "")
-                + (branch != null ? "branch: " + branch : "")
-                + (conflictManager != null ? "conflictManager: " + conflictManager : "")
-                + (resolveMode != null ? "resolveMode: " + resolveMode : "");
+                    + (branch != null ? "branch: " + branch : "")
+                    + (conflictManager != null ? "conflictManager: " + conflictManager : "")
+                    + (resolveMode != null ? "resolveMode: " + resolveMode : "");
         }
 
         public String getBranch() {
@@ -1433,7 +1426,6 @@ public class IvySettings implements Sort
         variableContainer = variables;
     }
 
-    
     public synchronized RelativeUrlResolver getRelativeUrlResolver() {
         return new NormalRelativeUrlResolver();
     }
@@ -1442,7 +1434,7 @@ public class IvySettings implements Sort
         CacheUtil.checkCachePattern(defaultCacheIvyPattern);
         this.defaultCacheIvyPattern = defaultCacheIvyPattern;
     }
-    
+
     public synchronized String getDefaultCacheIvyPattern() {
         return defaultCacheIvyPattern;
     }
@@ -1451,7 +1443,7 @@ public class IvySettings implements Sort
         CacheUtil.checkCachePattern(defaultCacheArtifactPattern);
         this.defaultCacheArtifactPattern = defaultCacheArtifactPattern;
     }
-    
+
     public synchronized String getDefaultCacheArtifactPattern() {
         return defaultCacheArtifactPattern;
     }
@@ -1459,18 +1451,18 @@ public class IvySettings implements Sort
     public synchronized void setDefaultUseOrigin(boolean useOrigin) {
         defaultUseOrigin = useOrigin;
     }
-    
+
     public synchronized boolean isDefaultUseOrigin() {
         return defaultUseOrigin;
     }
-    
+
     public synchronized void useDeprecatedUseOrigin() {
         Message.deprecated("useOrigin option is deprecated when calling resolve, use useOrigin"
-            + " setting on the cache implementation instead");
+                + " setting on the cache implementation instead");
         setDefaultUseOrigin(true);
-        
+
     }
-    
+
     /**
      * Validates the settings, throwing an {@link IllegalStateException} if the current state is not
      * valid.

Modified: ant/ivy/core/trunk/src/java/org/apache/ivy/core/settings/IvyVariableContainer.java
URL: http://svn.apache.org/viewvc/ant/ivy/core/trunk/src/java/org/apache/ivy/core/settings/IvyVariableContainer.java?rev=1557968&r1=1557967&r2=1557968&view=diff
==============================================================================
--- ant/ivy/core/trunk/src/java/org/apache/ivy/core/settings/IvyVariableContainer.java (original)
+++ ant/ivy/core/trunk/src/java/org/apache/ivy/core/settings/IvyVariableContainer.java Tue Jan 14 08:27:37 2014
@@ -17,7 +17,6 @@
  */
 package org.apache.ivy.core.settings;
 
-
 /**
  * Store and provide access to the ivy variables.
  */
@@ -28,13 +27,13 @@ public interface IvyVariableContainer ex
     public String getVariable(String name);
 
     /**
-     * Specifies the prefix used to indicate a variable is an environment
-     * variable. If the prefix doesn't end with a '.', it will be added
-     * automatically.
+     * Specifies the prefix used to indicate a variable is an environment variable. If the prefix
+     * doesn't end with a '.', it will be added automatically.
      * 
-     * @param prefix the prefix to use for the environment variables
+     * @param prefix
+     *            the prefix to use for the environment variables
      */
     public void setEnvironmentPrefix(String prefix);
-    
+
     public Object clone();
 }

Modified: ant/ivy/core/trunk/src/java/org/apache/ivy/core/settings/IvyVariableContainerImpl.java
URL: http://svn.apache.org/viewvc/ant/ivy/core/trunk/src/java/org/apache/ivy/core/settings/IvyVariableContainerImpl.java?rev=1557968&r1=1557967&r2=1557968&view=diff
==============================================================================
--- ant/ivy/core/trunk/src/java/org/apache/ivy/core/settings/IvyVariableContainerImpl.java (original)
+++ ant/ivy/core/trunk/src/java/org/apache/ivy/core/settings/IvyVariableContainerImpl.java Tue Jan 14 08:27:37 2014
@@ -26,21 +26,22 @@ import org.apache.ivy.util.Message;
 public class IvyVariableContainerImpl implements IvyVariableContainer {
 
     private Map variables;
+
     private String envPrefix;
 
     public IvyVariableContainerImpl() {
         this.variables = new HashMap();
     }
-    
+
     public IvyVariableContainerImpl(Map variables) {
         this.variables = variables;
     }
-    
+
     /*
      * (non-Javadoc)
      * 
      * @see org.apache.ivy.core.settings.IvyVariableContainer#setVariable(java.lang.String,
-     *      java.lang.String, boolean)
+     * java.lang.String, boolean)
      */
     public void setVariable(String varName, String value, boolean overwrite) {
         if (overwrite || !variables.containsKey(varName)) {
@@ -50,7 +51,7 @@ public class IvyVariableContainerImpl im
             Message.debug("'" + varName + "' already set: discarding '" + value + "'");
         }
     }
-    
+
     public void setEnvironmentPrefix(String prefix) {
         if ((prefix != null) && !prefix.endsWith(".")) {
             this.envPrefix = prefix + ".";
@@ -66,7 +67,7 @@ public class IvyVariableContainerImpl im
     protected Map getVariables() {
         return variables;
     }
-    
+
     protected String getEnvironmentPrefix() {
         return envPrefix;
     }
@@ -83,7 +84,7 @@ public class IvyVariableContainerImpl im
         } else {
             val = (String) variables.get(name);
         }
-        
+
         return val;
     }
 

Modified: ant/ivy/core/trunk/src/java/org/apache/ivy/core/settings/XmlSettingsParser.java
URL: http://svn.apache.org/viewvc/ant/ivy/core/trunk/src/java/org/apache/ivy/core/settings/XmlSettingsParser.java?rev=1557968&r1=1557967&r2=1557968&view=diff
==============================================================================
--- ant/ivy/core/trunk/src/java/org/apache/ivy/core/settings/XmlSettingsParser.java (original)
+++ ant/ivy/core/trunk/src/java/org/apache/ivy/core/settings/XmlSettingsParser.java Tue Jan 14 08:27:37 2014
@@ -65,9 +65,9 @@ public class XmlSettingsParser extends D
      */
     private static final class IvyVariableContainerWrapper implements IvyVariableContainer {
         private static final Collection SETTINGS_VARIABLES = Arrays.asList(new String[] {
-                "ivy.settings.dir", "ivy.settings.url", "ivy.settings.file",
-                "ivy.conf.dir", "ivy.conf.url", "ivy.conf.file"});
-        
+                "ivy.settings.dir", "ivy.settings.url", "ivy.settings.file", "ivy.conf.dir",
+                "ivy.conf.url", "ivy.conf.file"});
+
         private final IvyVariableContainer variables;
 
         private Map localVariables = new HashMap();
@@ -106,8 +106,8 @@ public class XmlSettingsParser extends D
 
     private List configuratorTags = Arrays.asList(new String[] {"resolvers", "namespaces",
             "parsers", "latest-strategies", "conflict-managers", "outputters", "version-matchers",
-            "statuses", "circular-dependency-strategies", "triggers", "lock-strategies",
-            "caches", "signers"});
+            "statuses", "circular-dependency-strategies", "triggers", "lock-strategies", "caches",
+            "signers"});
 
     private IvySettings ivy;
 
@@ -231,8 +231,8 @@ public class XmlSettingsParser extends D
             sax.initCause(ex);
             throw sax;
         } catch (IOException ex) {
-            SAXException sax = new SAXException("io problem while parsing config file: " 
-                        + ex.getMessage(), ex);
+            SAXException sax = new SAXException("io problem while parsing config file: "
+                    + ex.getMessage(), ex);
             sax.initCause(ex);
             throw sax;
         }
@@ -254,14 +254,14 @@ public class XmlSettingsParser extends D
         String resolveMode = (String) attributes.remove("resolveMode");
         String matcher = (String) attributes.remove("matcher");
         matcher = matcher == null ? PatternMatcher.EXACT_OR_REGEXP : matcher;
-        ivy.addModuleConfiguration(attributes, ivy
-                .getMatcher(matcher), resolver, branch, cm, resolveMode);
+        ivy.addModuleConfiguration(attributes, ivy.getMatcher(matcher), resolver, branch, cm,
+            resolveMode);
     }
 
     private void macrodefStarted(String qName, Map attributes) {
         currentConfiguratorTag = qName;
-        Configurator.MacroDef macrodef = configurator.startMacroDef((String) attributes
-                .get("name"));
+        Configurator.MacroDef macrodef = configurator
+                .startMacroDef((String) attributes.get("name"));
         macrodef.addAttribute("name", null);
     }
 
@@ -292,7 +292,7 @@ public class XmlSettingsParser extends D
         anyConfiguratorStarted(qName);
         defaultLock = (String) attributes.get("lockStrategy");
         defaultCacheManager = (String) attributes.get("default");
-        
+
         String cache = (String) attributes.get("defaultCacheDir");
         if (cache != null) {
             ivy.setDefaultCache(Checks.checkAbsolute(cache, "defaultCacheDir"));
@@ -300,7 +300,8 @@ public class XmlSettingsParser extends D
         String up2d = (String) attributes.get("checkUpToDate");
         if (up2d != null) {
             Message.deprecated("'checkUpToDate' is deprecated, "
-                + "use the 'overwriteMode' on the 'ivy:retrieve' task instead (" + settings + ")");
+                    + "use the 'overwriteMode' on the 'ivy:retrieve' task instead (" + settings
+                    + ")");
             ivy.setCheckUpToDate(Boolean.valueOf(up2d).booleanValue());
         }
         String resolutionDir = (String) attributes.get("resolutionCacheDir");
@@ -321,19 +322,18 @@ public class XmlSettingsParser extends D
         }
         String repositoryDir = (String) attributes.get("repositoryCacheDir");
         if (repositoryDir != null) {
-            ivy.setDefaultRepositoryCacheBasedir(repositoryDir); 
+            ivy.setDefaultRepositoryCacheBasedir(repositoryDir);
         }
     }
 
     private void settingsStarted(String qName, Map attributes) {
         if ("conf".equals(qName) && !deprecatedMessagePrinted) {
-            Message.deprecated(
-                "'conf' is deprecated, use 'settings' instead (" + settings + ")");
+            Message.deprecated("'conf' is deprecated, use 'settings' instead (" + settings + ")");
         }
         String cache = (String) attributes.get("defaultCache");
         if (cache != null) {
             Message.deprecated("'defaultCache' is deprecated, "
-                + "use 'caches[@defaultCacheDir]' instead (" + settings + ")");
+                    + "use 'caches[@defaultCacheDir]' instead (" + settings + ")");
             ivy.setDefaultCache(Checks.checkAbsolute(cache, "defaultCache"));
         }
         String defaultBranch = (String) attributes.get("defaultBranch");
@@ -351,26 +351,24 @@ public class XmlSettingsParser extends D
         String up2d = (String) attributes.get("checkUpToDate");
         if (up2d != null) {
             Message.deprecated("'checkUpToDate' is deprecated, "
-                + "use the 'overwriteMode' on the 'ivy:retrieve' task instead (" + settings + ")");
+                    + "use the 'overwriteMode' on the 'ivy:retrieve' task instead (" + settings
+                    + ")");
             ivy.setCheckUpToDate(Boolean.valueOf(up2d).booleanValue());
         }
         String useRemoteConfig = (String) attributes.get("useRemoteConfig");
         if (useRemoteConfig != null) {
-            ivy.setUseRemoteConfig(Boolean.valueOf(useRemoteConfig)
-                    .booleanValue());
+            ivy.setUseRemoteConfig(Boolean.valueOf(useRemoteConfig).booleanValue());
         }
         String cacheIvyPattern = (String) attributes.get("cacheIvyPattern");
         if (cacheIvyPattern != null) {
-            Message.deprecated(
-                "'cacheIvyPattern' is deprecated, use 'caches[@ivyPattern]' instead"
-                + " (" + settings + ")");
+            Message.deprecated("'cacheIvyPattern' is deprecated, use 'caches[@ivyPattern]' instead"
+                    + " (" + settings + ")");
             ivy.setDefaultCacheIvyPattern(cacheIvyPattern);
         }
         String cacheArtPattern = (String) attributes.get("cacheArtifactPattern");
         if (cacheArtPattern != null) {
-            Message.deprecated(
-                "'cacheArtifactPattern' is deprecated, "
-                + "use 'caches[@artifactPattern]' instead (" + settings + ")");
+            Message.deprecated("'cacheArtifactPattern' is deprecated, "
+                    + "use 'caches[@artifactPattern]' instead (" + settings + ")");
             ivy.setDefaultCacheArtifactPattern(cacheArtPattern);
         }
 
@@ -379,15 +377,15 @@ public class XmlSettingsParser extends D
         defaultCM = (String) attributes.get("defaultConflictManager");
         defaultLatest = (String) attributes.get("defaultLatestStrategy");
         defaultCircular = (String) attributes.get("circularDependencyStrategy");
-        
+
         String requestMethod = (String) attributes.get("httpRequestMethod");
         if ("head".equalsIgnoreCase(requestMethod)) {
             URLHandlerRegistry.getHttp().setRequestMethod(URLHandler.REQUEST_METHOD_HEAD);
         } else if ("get".equalsIgnoreCase(requestMethod)) {
             URLHandlerRegistry.getHttp().setRequestMethod(URLHandler.REQUEST_METHOD_GET);
         } else if ((requestMethod != null) && (requestMethod.trim().length() > 0)) {
-            throw new IllegalArgumentException("Invalid httpRequestMethod specified, must be " 
-                + "one of {'HEAD', 'GET'}");
+            throw new IllegalArgumentException("Invalid httpRequestMethod specified, must be "
+                    + "one of {'HEAD', 'GET'}");
         }
     }
 
@@ -401,14 +399,14 @@ public class XmlSettingsParser extends D
                 propFilePath = (String) attributes.get("url");
                 if (propFilePath == null) {
                     throw new IllegalArgumentException(
-                        "bad include tag: specify file or url to include");
+                            "bad include tag: specify file or url to include");
                 } else {
                     try {
-                        //First asume that it is an absolute URL
+                        // First asume that it is an absolute URL
                         settingsURL = new URL(propFilePath);
                     } catch (MalformedURLException e) {
-                        //If that fail, it may be because it is a relative one.
-                        settingsURL = new URL(this.settings , propFilePath);
+                        // If that fail, it may be because it is a relative one.
+                        settingsURL = new URL(this.settings, propFilePath);
                     }
                     Message.verbose("including url: " + settingsURL.toString());
                     ivy.setSettingsVariables(settingsURL);
@@ -424,13 +422,11 @@ public class XmlSettingsParser extends D
                             return;
                         }
 
-                        ivy.setSettingsVariables(
-                            Checks.checkAbsolute(settingsFile, 
+                        ivy.setSettingsVariables(Checks.checkAbsolute(settingsFile,
                             "settings include path"));
                     } catch (URISyntaxException e) {
                         // try to make the best of it...
-                        ivy.setSettingsVariables(
-                            Checks.checkAbsolute(settingsURL.getPath(), 
+                        ivy.setSettingsVariables(Checks.checkAbsolute(settingsURL.getPath(),
                             "settings include path"));
                     }
                 } else {
@@ -443,9 +439,10 @@ public class XmlSettingsParser extends D
         }
     }
 
-    /** Provide an URL referencing the given filepath.  If filePath is an absolute path, then
-     * the resulting URL point to a local file, otherwise, the filepath is evaluated relatively
-     * to the URL of the current settings file (can be local file or remote URL).
+    /**
+     * Provide an URL referencing the given filepath. If filePath is an absolute path, then the
+     * resulting URL point to a local file, otherwise, the filepath is evaluated relatively to the
+     * URL of the current settings file (can be local file or remote URL).
      */
     private URL urlFromFileAttribute(String filePath) throws IOException {
         try {
@@ -453,7 +450,7 @@ public class XmlSettingsParser extends D
         } catch (MalformedURLException e) {
             // ignore, we'll try to create a correct URL below
         }
-        
+
         File incFile = new File(filePath);
         if (incFile.isAbsolute()) {
             if (!incFile.exists()) {
@@ -468,10 +465,10 @@ public class XmlSettingsParser extends D
                 }
                 return new File(settingsFile.getParentFile(), filePath).toURI().toURL();
             } catch (URISyntaxException e) {
-                return new URL(this.settings , filePath);
+                return new URL(this.settings, filePath);
             }
         } else {
-            return new URL(this.settings , filePath);
+            return new URL(this.settings, filePath);
         }
     }
 
@@ -480,8 +477,8 @@ public class XmlSettingsParser extends D
         String environmentPrefix = (String) attributes.get("environment");
         if (propFilePath != null) {
             String overrideStr = (String) attributes.get("override");
-            boolean override = overrideStr == null ? true 
-                                                   : Boolean.valueOf(overrideStr).booleanValue();
+            boolean override = overrideStr == null ? true : Boolean.valueOf(overrideStr)
+                    .booleanValue();
             Message.verbose("loading properties: " + propFilePath);
             try {
                 URL fileUrl = urlFromFileAttribute(propFilePath);
@@ -492,9 +489,8 @@ public class XmlSettingsParser extends D
         } else if (environmentPrefix != null) {
             ivy.getVariableContainer().setEnvironmentPrefix(environmentPrefix);
         } else {
-            throw new IllegalArgumentException(
-                "Didn't find a 'file' or 'environment' attribute " 
-                + "on the 'properties' element");
+            throw new IllegalArgumentException("Didn't find a 'file' or 'environment' attribute "
+                    + "on the 'properties' element");
         }
     }
 
@@ -539,8 +535,7 @@ public class XmlSettingsParser extends D
     }
 
     private void inConfiguratorStarted(String qName, Map attributes) {
-        if ("macrodef".equals(currentConfiguratorTag)
-                && configurator.getTypeDef(qName) != null) {
+        if ("macrodef".equals(currentConfiguratorTag) && configurator.getTypeDef(qName) != null) {
             String name = (String) attributes.get("name");
             if (name == null) {
                 attributes.put("name", "@{name}");
@@ -552,9 +547,8 @@ public class XmlSettingsParser extends D
         }
         if (attributes.get("ref") != null) {
             if (attributes.size() != 1) {
-                throw new IllegalArgumentException(
-                        "ref attribute should be the only one ! found " + attributes.size()
-                                + " in " + qName);
+                throw new IllegalArgumentException("ref attribute should be the only one ! found "
+                        + attributes.size() + " in " + qName);
             }
             String name = (String) attributes.get("ref");
             Object child = null;
@@ -568,14 +562,13 @@ public class XmlSettingsParser extends D
                 child = ivy.getLatestStrategy(name);
                 if (child == null) {
                     throw new IllegalArgumentException("unknown latest strategy " + name
-                           + ": latest strategy should be defined before being referenced");
+                            + ": latest strategy should be defined before being referenced");
                 }
             } else if ("conflict-managers".equals(currentConfiguratorTag)) {
                 child = ivy.getConflictManager(name);
                 if (child == null) {
-                    throw new IllegalArgumentException(
-                         "unknown conflict manager " + name
-                         + ": conflict manager should be defined before being referenced");
+                    throw new IllegalArgumentException("unknown conflict manager " + name
+                            + ": conflict manager should be defined before being referenced");
                 }
             }
             if (child == null) {
@@ -586,8 +579,7 @@ public class XmlSettingsParser extends D
             configurator.startCreateChild(qName);
             for (Iterator iter = attributes.keySet().iterator(); iter.hasNext();) {
                 String attName = (String) iter.next();
-                configurator.setAttribute(attName, (String) attributes
-                        .get(attName));
+                configurator.setAttribute(attName, (String) attributes.get(attName));
             }
         }
     }
@@ -627,8 +619,8 @@ public class XmlSettingsParser extends D
             ivy.setDefaultLatestStrategy(latestStrategy);
         }
         if (defaultCacheManager != null) {
-            RepositoryCacheManager cache = ivy.getRepositoryCacheManager(
-                                                ivy.substitute(defaultCacheManager));
+            RepositoryCacheManager cache = ivy.getRepositoryCacheManager(ivy
+                    .substitute(defaultCacheManager));
             if (cache == null) {
                 throw new IllegalArgumentException("unknown cache manager "
                         + ivy.substitute(defaultCacheManager));

Modified: ant/ivy/core/trunk/src/java/org/apache/ivy/core/sort/CollectionOfModulesToSort.java
URL: http://svn.apache.org/viewvc/ant/ivy/core/trunk/src/java/org/apache/ivy/core/sort/CollectionOfModulesToSort.java?rev=1557968&r1=1557967&r2=1557968&view=diff
==============================================================================
--- ant/ivy/core/trunk/src/java/org/apache/ivy/core/sort/CollectionOfModulesToSort.java (original)
+++ ant/ivy/core/trunk/src/java/org/apache/ivy/core/sort/CollectionOfModulesToSort.java Tue Jan 14 08:27:37 2014
@@ -41,7 +41,7 @@ class CollectionOfModulesToSort implemen
 
     private final VersionMatcher versionMatcher;
 
-    private final Map<ModuleId , Collection<ModuleInSort>> modulesByModuleId;
+    private final Map<ModuleId, Collection<ModuleInSort>> modulesByModuleId;
 
     private final NonMatchingVersionReporter nonMatchingVersionReporter;
 
@@ -53,8 +53,8 @@ class CollectionOfModulesToSort implemen
      *            collection
      * @param nonMatchingVersionReporter
      */
-    public CollectionOfModulesToSort(Collection<ModuleDescriptor> modulesToSort, VersionMatcher matcher,
-            NonMatchingVersionReporter nonMatchingVersionReporter) {
+    public CollectionOfModulesToSort(Collection<ModuleDescriptor> modulesToSort,
+            VersionMatcher matcher, NonMatchingVersionReporter nonMatchingVersionReporter) {
         this.versionMatcher = matcher;
         this.nonMatchingVersionReporter = nonMatchingVersionReporter;
         this.modulesByModuleId = new HashMap<ModuleId, Collection<ModuleInSort>>();
@@ -101,8 +101,8 @@ class CollectionOfModulesToSort implemen
             if (mdInSort.match(descriptor, versionMatcher)) {
                 return mdInSort;
             } else {
-                nonMatchingVersionReporter.reportNonMatchingVersion(descriptor, mdInSort
-                        .getSortedModuleDescriptor());
+                nonMatchingVersionReporter.reportNonMatchingVersion(descriptor,
+                    mdInSort.getSortedModuleDescriptor());
             }
         }
         return null;

Modified: ant/ivy/core/trunk/src/java/org/apache/ivy/core/sort/ModuleDescriptorSorter.java
URL: http://svn.apache.org/viewvc/ant/ivy/core/trunk/src/java/org/apache/ivy/core/sort/ModuleDescriptorSorter.java?rev=1557968&r1=1557967&r2=1557968&view=diff
==============================================================================
--- ant/ivy/core/trunk/src/java/org/apache/ivy/core/sort/ModuleDescriptorSorter.java (original)
+++ ant/ivy/core/trunk/src/java/org/apache/ivy/core/sort/ModuleDescriptorSorter.java Tue Jan 14 08:27:37 2014
@@ -44,8 +44,8 @@ public class ModuleDescriptorSorter {
 
     private final CircularDependencyStrategy circularDepStrategy;
 
-    public ModuleDescriptorSorter(Collection<ModuleDescriptor> modulesDescriptorsToSort, VersionMatcher matcher,
-            NonMatchingVersionReporter nonMatchingVersionReporter,
+    public ModuleDescriptorSorter(Collection<ModuleDescriptor> modulesDescriptorsToSort,
+            VersionMatcher matcher, NonMatchingVersionReporter nonMatchingVersionReporter,
             CircularDependencyStrategy circularDepStrategy) {
         this.circularDepStrategy = circularDepStrategy;
         moduleDescriptors = new CollectionOfModulesToSort(modulesDescriptorsToSort, matcher,
@@ -69,10 +69,10 @@ public class ModuleDescriptorSorter {
     /**
      * If current module has already been added to list, returns, Otherwise invokes
      * sortModuleDescriptorsHelp for all dependencies contained within set of moduleDescriptors.
-     * Then finally adds self to list of sorted.<br/> When a loop is detected by a recursive call,
-     * the moduleDescriptors are not added immediately added to the sorted list. They are added as
-     * loop dependencies of the root, and will be added to the sorted list only when the root itself
-     * will be added.
+     * Then finally adds self to list of sorted.<br/>
+     * When a loop is detected by a recursive call, the moduleDescriptors are not added immediately
+     * added to the sorted list. They are added as loop dependencies of the root, and will be added
+     * to the sorted list only when the root itself will be added.
      * 
      * @param current
      *            Current module to add to sorted list.

Modified: ant/ivy/core/trunk/src/java/org/apache/ivy/core/sort/ModuleInSort.java
URL: http://svn.apache.org/viewvc/ant/ivy/core/trunk/src/java/org/apache/ivy/core/sort/ModuleInSort.java?rev=1557968&r1=1557967&r2=1557968&view=diff
==============================================================================
--- ant/ivy/core/trunk/src/java/org/apache/ivy/core/sort/ModuleInSort.java (original)
+++ ant/ivy/core/trunk/src/java/org/apache/ivy/core/sort/ModuleInSort.java Tue Jan 14 08:27:37 2014
@@ -34,13 +34,12 @@ import org.apache.ivy.util.Message;
  * ModuleInSort can be used in only one ModuleDescriptorSorter at a time.<br>
  * The added fields are : <br>
  * <ul>
- * <li><code>isSorted</code> : is true iff this module has already been added to the sorted list.
- * </li>
+ * <li><code>isSorted</code> : is true iff this module has already been added to the sorted list.</li>
  * <li><code>loopElements</code> : When the module is the root of a loop (=the first element of a
  * loop met during the sort), <code>loopElements</code> contains all ModuleInSort of the loop
  * (excluding the root itself.</li>
- * <li><code>isLoopIntermediateElement</code> : When a loop is detected, all modules included in
- * the loop (except the root) have <code>isLoopIntermediateElement</code> set to true.</li>
+ * <li><code>isLoopIntermediateElement</code> : When a loop is detected, all modules included in the
+ * loop (except the root) have <code>isLoopIntermediateElement</code> set to true.</li>
  * <li><code>caller</code> : During the sort, we traverse recursively the graph. When doing that,
  * caller point to the parent element.
  */
@@ -75,9 +74,10 @@ class ModuleInSort {
         }
     }
 
-    /** This ModuleInSort has already been analyzed.  It is either already added
-     * to the sorted list, either it is included in a loop and will be added
-     * when the root of the loop will be added to the list. 
+    /**
+     * This ModuleInSort has already been analyzed. It is either already added to the sorted list,
+     * either it is included in a loop and will be added when the root of the loop will be added to
+     * the list.
      */
     public boolean isProcessed() {
         if (isSorted || isLoopIntermediateElement) {
@@ -89,7 +89,6 @@ class ModuleInSort {
         }
     }
 
-    
     public void setCaller(ModuleInSort caller) {
         this.caller = caller;
     }

Modified: ant/ivy/core/trunk/src/java/org/apache/ivy/core/sort/SimpleSortEngineSettings.java
URL: http://svn.apache.org/viewvc/ant/ivy/core/trunk/src/java/org/apache/ivy/core/sort/SimpleSortEngineSettings.java?rev=1557968&r1=1557967&r2=1557968&view=diff
==============================================================================
--- ant/ivy/core/trunk/src/java/org/apache/ivy/core/sort/SimpleSortEngineSettings.java (original)
+++ ant/ivy/core/trunk/src/java/org/apache/ivy/core/sort/SimpleSortEngineSettings.java Tue Jan 14 08:27:37 2014
@@ -23,9 +23,9 @@ import org.apache.ivy.plugins.version.Ve
 public class SimpleSortEngineSettings implements SortEngineSettings {
 
     private CircularDependencyStrategy circularStrategy;
-    
+
     private VersionMatcher versionMatcher;
-    
+
     public CircularDependencyStrategy getCircularDependencyStrategy() {
         return circularStrategy;
     }
@@ -34,7 +34,6 @@ public class SimpleSortEngineSettings im
         return versionMatcher;
     }
 
-    
     public void setCircularDependencyStrategy(CircularDependencyStrategy strategy) {
         circularStrategy = strategy;
     }

Modified: ant/ivy/core/trunk/src/java/org/apache/ivy/core/sort/SortEngine.java
URL: http://svn.apache.org/viewvc/ant/ivy/core/trunk/src/java/org/apache/ivy/core/sort/SortEngine.java?rev=1557968&r1=1557967&r2=1557968&view=diff
==============================================================================
--- ant/ivy/core/trunk/src/java/org/apache/ivy/core/sort/SortEngine.java (original)
+++ ant/ivy/core/trunk/src/java/org/apache/ivy/core/sort/SortEngine.java Tue Jan 14 08:27:37 2014
@@ -43,7 +43,8 @@ public class SortEngine {
     }
 
     /**
-     * Same as {@link #sortModuleDescriptors(Collection, SortOptions)} but for <code>IvyNode</code>s.
+     * Same as {@link #sortModuleDescriptors(Collection, SortOptions)} but for <code>IvyNode</code>
+     * s.
      * 
      * @param nodes
      *            a Collection of nodes to sort
@@ -78,7 +79,8 @@ public class SortEngine {
         }
         List<ModuleDescriptor> list = sortModuleDescriptors(dependenciesMap.keySet(), options);
         final double adjustFactor = 1.3;
-        List<IvyNode> ret = new ArrayList<IvyNode>((int) (list.size() * adjustFactor + nulls.size()));
+        List<IvyNode> ret = new ArrayList<IvyNode>(
+                (int) (list.size() * adjustFactor + nulls.size()));
         // attempt to adjust the size to avoid too much list resizing
         for (int i = 0; i < list.size(); i++) {
             ModuleDescriptor md = (ModuleDescriptor) list.get(i);
@@ -108,14 +110,12 @@ public class SortEngine {
             throws CircularDependencyException {
         Checks.checkNotNull(options, "options");
         ModuleDescriptorSorter sorter = new ModuleDescriptorSorter(moduleDescriptors,
-                getVersionMatcher(), options.getNonMatchingVersionReporter(), 
-                options.isUseCircularDependencyStrategy() 
-                    ? getCircularStrategy() : IgnoreCircularDependencyStrategy.getInstance());
+                getVersionMatcher(), options.getNonMatchingVersionReporter(),
+                options.isUseCircularDependencyStrategy() ? getCircularStrategy()
+                        : IgnoreCircularDependencyStrategy.getInstance());
         return sorter.sortModuleDescriptors();
     }
 
-
-
     protected CircularDependencyStrategy getCircularStrategy() {
         return settings.getCircularDependencyStrategy();
     }

Modified: ant/ivy/core/trunk/src/java/org/apache/ivy/core/sort/SortEngineSettings.java
URL: http://svn.apache.org/viewvc/ant/ivy/core/trunk/src/java/org/apache/ivy/core/sort/SortEngineSettings.java?rev=1557968&r1=1557967&r2=1557968&view=diff
==============================================================================
--- ant/ivy/core/trunk/src/java/org/apache/ivy/core/sort/SortEngineSettings.java (original)
+++ ant/ivy/core/trunk/src/java/org/apache/ivy/core/sort/SortEngineSettings.java Tue Jan 14 08:27:37 2014
@@ -26,6 +26,6 @@ import org.apache.ivy.plugins.version.Ve
 public interface SortEngineSettings {
 
     public CircularDependencyStrategy getCircularDependencyStrategy();
-    
+
     public VersionMatcher getVersionMatcher();
 }

Modified: ant/ivy/core/trunk/src/java/org/apache/ivy/core/sort/SortOptions.java
URL: http://svn.apache.org/viewvc/ant/ivy/core/trunk/src/java/org/apache/ivy/core/sort/SortOptions.java?rev=1557968&r1=1557967&r2=1557968&view=diff
==============================================================================
--- ant/ivy/core/trunk/src/java/org/apache/ivy/core/sort/SortOptions.java (original)
+++ ant/ivy/core/trunk/src/java/org/apache/ivy/core/sort/SortOptions.java Tue Jan 14 08:27:37 2014
@@ -19,35 +19,36 @@ package org.apache.ivy.core.sort;
 
 public class SortOptions {
     public static final SortOptions DEFAULT = new SortOptions();
-    public static final SortOptions SILENT = new SortOptions()
-            .setNonMatchingVersionReporter(new SilentNonMatchingVersionReporter())
-            .setUseCircularDependencyStrategy(false);
-    
+
+    public static final SortOptions SILENT = new SortOptions().setNonMatchingVersionReporter(
+        new SilentNonMatchingVersionReporter()).setUseCircularDependencyStrategy(false);
+
     /**
      * Used to report some non matching version (when a modules depends on a specific revision of an
      * other modules present in the of modules to sort with a different revision.
      */
-    private NonMatchingVersionReporter nonMatchingVersionReporter 
-                                            = new WarningNonMatchingVersionReporter();
+    private NonMatchingVersionReporter nonMatchingVersionReporter = new WarningNonMatchingVersionReporter();
 
     /**
      * Should the default circular dependency strategy be used when a circular dependency is found,
      * or should circular dependencies be ignored?
      */
     private boolean useCircularDependencyStrategy = true;
-    
-    
+
     public NonMatchingVersionReporter getNonMatchingVersionReporter() {
         return nonMatchingVersionReporter;
     }
+
     public SortOptions setNonMatchingVersionReporter(
-                                NonMatchingVersionReporter nonMatchingVersionReporter) {
+            NonMatchingVersionReporter nonMatchingVersionReporter) {
         this.nonMatchingVersionReporter = nonMatchingVersionReporter;
         return this;
     }
+
     public boolean isUseCircularDependencyStrategy() {
         return useCircularDependencyStrategy;
     }
+
     public SortOptions setUseCircularDependencyStrategy(boolean useCircularDependencyStrategy) {
         this.useCircularDependencyStrategy = useCircularDependencyStrategy;
         return this;

Modified: ant/ivy/core/trunk/src/java/org/apache/ivy/osgi/core/ExecutionEnvironmentProfileProvider.java
URL: http://svn.apache.org/viewvc/ant/ivy/core/trunk/src/java/org/apache/ivy/osgi/core/ExecutionEnvironmentProfileProvider.java?rev=1557968&r1=1557967&r2=1557968&view=diff
==============================================================================
--- ant/ivy/core/trunk/src/java/org/apache/ivy/osgi/core/ExecutionEnvironmentProfileProvider.java (original)
+++ ant/ivy/core/trunk/src/java/org/apache/ivy/osgi/core/ExecutionEnvironmentProfileProvider.java Tue Jan 14 08:27:37 2014
@@ -120,7 +120,8 @@ public class ExecutionEnvironmentProfile
             for (int i = 0; i < aliases.length; i++) {
                 String alias = aliases[i].trim();
                 if (alias.length() != 0) {
-                    ExecutionEnvironmentProfile profileAlias = new ExecutionEnvironmentProfile(alias);
+                    ExecutionEnvironmentProfile profileAlias = new ExecutionEnvironmentProfile(
+                            alias);
                     profileAlias.pkgNames = profile.pkgNames;
                     profiles.put(alias, profileAlias);
                 }

Modified: ant/ivy/core/trunk/src/java/org/apache/ivy/osgi/filter/AndFilter.java
URL: http://svn.apache.org/viewvc/ant/ivy/core/trunk/src/java/org/apache/ivy/osgi/filter/AndFilter.java?rev=1557968&r1=1557967&r2=1557968&view=diff
==============================================================================
--- ant/ivy/core/trunk/src/java/org/apache/ivy/osgi/filter/AndFilter.java (original)
+++ ant/ivy/core/trunk/src/java/org/apache/ivy/osgi/filter/AndFilter.java Tue Jan 14 08:27:37 2014
@@ -19,7 +19,6 @@ package org.apache.ivy.osgi.filter;
 
 import java.util.Map;
 
-
 public class AndFilter extends MultiOperatorFilter {
 
     public AndFilter() {

Modified: ant/ivy/core/trunk/src/java/org/apache/ivy/osgi/filter/MultiOperatorFilter.java
URL: http://svn.apache.org/viewvc/ant/ivy/core/trunk/src/java/org/apache/ivy/osgi/filter/MultiOperatorFilter.java?rev=1557968&r1=1557967&r2=1557968&view=diff
==============================================================================
--- ant/ivy/core/trunk/src/java/org/apache/ivy/osgi/filter/MultiOperatorFilter.java (original)
+++ ant/ivy/core/trunk/src/java/org/apache/ivy/osgi/filter/MultiOperatorFilter.java Tue Jan 14 08:27:37 2014
@@ -20,7 +20,6 @@ package org.apache.ivy.osgi.filter;
 import java.util.ArrayList;
 import java.util.List;
 
-
 public abstract class MultiOperatorFilter extends OSGiFilter {
 
     private List<OSGiFilter> subFilters = new ArrayList<OSGiFilter>();

Modified: ant/ivy/core/trunk/src/java/org/apache/ivy/osgi/filter/NotFilter.java
URL: http://svn.apache.org/viewvc/ant/ivy/core/trunk/src/java/org/apache/ivy/osgi/filter/NotFilter.java?rev=1557968&r1=1557967&r2=1557968&view=diff
==============================================================================
--- ant/ivy/core/trunk/src/java/org/apache/ivy/osgi/filter/NotFilter.java (original)
+++ ant/ivy/core/trunk/src/java/org/apache/ivy/osgi/filter/NotFilter.java Tue Jan 14 08:27:37 2014
@@ -19,7 +19,6 @@ package org.apache.ivy.osgi.filter;
 
 import java.util.Map;
 
-
 public class NotFilter extends UniOperatorFilter {
 
     public NotFilter(OSGiFilter subFilter) {

Modified: ant/ivy/core/trunk/src/java/org/apache/ivy/osgi/filter/OrFilter.java
URL: http://svn.apache.org/viewvc/ant/ivy/core/trunk/src/java/org/apache/ivy/osgi/filter/OrFilter.java?rev=1557968&r1=1557967&r2=1557968&view=diff
==============================================================================
--- ant/ivy/core/trunk/src/java/org/apache/ivy/osgi/filter/OrFilter.java (original)
+++ ant/ivy/core/trunk/src/java/org/apache/ivy/osgi/filter/OrFilter.java Tue Jan 14 08:27:37 2014
@@ -19,7 +19,6 @@ package org.apache.ivy.osgi.filter;
 
 import java.util.Map;
 
-
 public class OrFilter extends MultiOperatorFilter {
 
     public OrFilter() {

Modified: ant/ivy/core/trunk/src/java/org/apache/ivy/osgi/filter/UniOperatorFilter.java
URL: http://svn.apache.org/viewvc/ant/ivy/core/trunk/src/java/org/apache/ivy/osgi/filter/UniOperatorFilter.java?rev=1557968&r1=1557967&r2=1557968&view=diff
==============================================================================
--- ant/ivy/core/trunk/src/java/org/apache/ivy/osgi/filter/UniOperatorFilter.java (original)
+++ ant/ivy/core/trunk/src/java/org/apache/ivy/osgi/filter/UniOperatorFilter.java Tue Jan 14 08:27:37 2014
@@ -17,7 +17,6 @@
  */
 package org.apache.ivy.osgi.filter;
 
-
 public abstract class UniOperatorFilter extends OSGiFilter {
 
     private final OSGiFilter subFilter;

Modified: ant/ivy/core/trunk/src/java/org/apache/ivy/osgi/obr/xml/OBRXMLWriter.java
URL: http://svn.apache.org/viewvc/ant/ivy/core/trunk/src/java/org/apache/ivy/osgi/obr/xml/OBRXMLWriter.java?rev=1557968&r1=1557967&r2=1557968&view=diff
==============================================================================
--- ant/ivy/core/trunk/src/java/org/apache/ivy/osgi/obr/xml/OBRXMLWriter.java (original)
+++ ant/ivy/core/trunk/src/java/org/apache/ivy/osgi/obr/xml/OBRXMLWriter.java Tue Jan 14 08:27:37 2014
@@ -75,9 +75,11 @@ public class OBRXMLWriter {
             BundleInfo bundleInfo;
             try {
                 bundleInfo = ManifestParser.parseManifest(manifestAndLocation.getManifest());
-                bundleInfo.addArtifact(new BundleArtifact(false, manifestAndLocation.getUri(), null));
+                bundleInfo
+                        .addArtifact(new BundleArtifact(false, manifestAndLocation.getUri(), null));
                 if (manifestAndLocation.getSourceURI() != null) {
-                    bundleInfo.addArtifact(new BundleArtifact(true, manifestAndLocation.getSourceURI(), null));
+                    bundleInfo.addArtifact(new BundleArtifact(true, manifestAndLocation
+                            .getSourceURI(), null));
                 }
                 nbOk++;
             } catch (ParseException e) {
@@ -116,7 +118,8 @@ public class OBRXMLWriter {
         addAttr(atts, ResourceHandler.VERSION, bundleInfo.getRawVersion());
         for (BundleArtifact artifact : bundleInfo.getArtifacts()) {
             if (!artifact.isSource()) {
-                addAttr(atts, ResourceHandler.URI, bundleInfo.getArtifacts().get(0).getUri().toString());
+                addAttr(atts, ResourceHandler.URI, bundleInfo.getArtifacts().get(0).getUri()
+                        .toString());
                 break;
             }
         }

Modified: ant/ivy/core/trunk/src/java/org/apache/ivy/osgi/obr/xml/RequirementAdapter.java
URL: http://svn.apache.org/viewvc/ant/ivy/core/trunk/src/java/org/apache/ivy/osgi/obr/xml/RequirementAdapter.java?rev=1557968&r1=1557967&r2=1557968&view=diff
==============================================================================
--- ant/ivy/core/trunk/src/java/org/apache/ivy/osgi/obr/xml/RequirementAdapter.java (original)
+++ ant/ivy/core/trunk/src/java/org/apache/ivy/osgi/obr/xml/RequirementAdapter.java Tue Jan 14 08:27:37 2014
@@ -50,8 +50,7 @@ public class RequirementAdapter {
         adapter.adapt(info, requirement.isOptional());
     }
 
-    private void extractFilter(OSGiFilter filter) throws UnsupportedFilterException,
-            ParseException {
+    private void extractFilter(OSGiFilter filter) throws UnsupportedFilterException, ParseException {
         if (filter instanceof AndFilter) {
             AndFilter andFilter = (AndFilter) filter;
             for (OSGiFilter subFilter : andFilter.getSubFilters()) {

Modified: ant/ivy/core/trunk/src/java/org/apache/ivy/osgi/p2/P2Descriptor.java
URL: http://svn.apache.org/viewvc/ant/ivy/core/trunk/src/java/org/apache/ivy/osgi/p2/P2Descriptor.java?rev=1557968&r1=1557967&r2=1557968&view=diff
==============================================================================
--- ant/ivy/core/trunk/src/java/org/apache/ivy/osgi/p2/P2Descriptor.java (original)
+++ ant/ivy/core/trunk/src/java/org/apache/ivy/osgi/p2/P2Descriptor.java Tue Jan 14 08:27:37 2014
@@ -127,7 +127,7 @@ public class P2Descriptor extends Editab
     }
 
     private void addArtifact(BundleInfo bundle, BundleArtifact artifact) {
-        // find an existing artifact that might be a duplicate 
+        // find an existing artifact that might be a duplicate
         BundleArtifact same = null;
         for (BundleArtifact a : bundle.getArtifacts()) {
             if (a.isSource() == artifact.isSource()) {

Modified: ant/ivy/core/trunk/src/java/org/apache/ivy/osgi/p2/P2MetadataParser.java
URL: http://svn.apache.org/viewvc/ant/ivy/core/trunk/src/java/org/apache/ivy/osgi/p2/P2MetadataParser.java?rev=1557968&r1=1557967&r2=1557968&view=diff
==============================================================================
--- ant/ivy/core/trunk/src/java/org/apache/ivy/osgi/p2/P2MetadataParser.java (original)
+++ ant/ivy/core/trunk/src/java/org/apache/ivy/osgi/p2/P2MetadataParser.java Tue Jan 14 08:27:37 2014
@@ -67,31 +67,31 @@ public class P2MetadataParser implements
 
     private class RepositoryHandler extends DelegatingHandler {
 
-        //        private static final String P2_TIMESTAMP = "p2.timestamp";
+        // private static final String P2_TIMESTAMP = "p2.timestamp";
 
         private static final String REPOSITORY = "repository";
 
-        //        private static final String NAME = "name";
+        // private static final String NAME = "name";
         //
-        //        private static final String TYPE = "type";
+        // private static final String TYPE = "type";
         //
-        //        private static final String VERSION = "version";
+        // private static final String VERSION = "version";
         //
-        //        private static final String DESCRIPTION = "description";
+        // private static final String DESCRIPTION = "description";
         //
-        //        private static final String PROVIDER = "provider";
+        // private static final String PROVIDER = "provider";
 
         public RepositoryHandler(final P2Descriptor p2Descriptor) {
             super(REPOSITORY);
-            //            addChild(new PropertiesHandler(P2_TIMESTAMP),
-            //                new ChildElementHandler<PropertiesHandler>() {
-            //                    public void childHanlded(PropertiesHandler child) {
-            //                        String timestamp = child.properties.get(P2_TIMESTAMP);
-            //                        if (timestamp != null) {
-            //                            p2Descriptor.setTimestamp(Long.parseLong(timestamp));
-            //                        }
-            //                    }
-            //                });
+            // addChild(new PropertiesHandler(P2_TIMESTAMP),
+            // new ChildElementHandler<PropertiesHandler>() {
+            // public void childHanlded(PropertiesHandler child) {
+            // String timestamp = child.properties.get(P2_TIMESTAMP);
+            // if (timestamp != null) {
+            // p2Descriptor.setTimestamp(Long.parseLong(timestamp));
+            // }
+            // }
+            // });
             addChild(new UnitsHandler(), new ChildElementHandler<UnitsHandler>() {
                 public void childHanlded(UnitsHandler child) {
                     for (BundleInfo bundle : child.bundles) {
@@ -105,13 +105,13 @@ public class P2MetadataParser implements
             });
         }
 
-        //        protected void handleAttributes(Attributes atts) {
-        //            String name = atts.getValue(NAME);
-        //            String type = atts.getValue(TYPE);
-        //            String version = atts.getValue(VERSION);
-        //            String description = atts.getValue(DESCRIPTION);
-        //            String provider = atts.getValue(PROVIDER);
-        //        }
+        // protected void handleAttributes(Attributes atts) {
+        // String name = atts.getValue(NAME);
+        // String type = atts.getValue(TYPE);
+        // String version = atts.getValue(VERSION);
+        // String description = atts.getValue(DESCRIPTION);
+        // String provider = atts.getValue(PROVIDER);
+        // }
     }
 
     private class ReferencesHandler extends DelegatingHandler {
@@ -142,11 +142,11 @@ public class P2MetadataParser implements
 
         private static final String REPOSITORY = "repository";
 
-        //        private static final String TYPE = "type";
+        // private static final String TYPE = "type";
         //
-        //        private static final String OPTIONS = "options";
+        // private static final String OPTIONS = "options";
         //
-        //        private static final String NAME = "name";
+        // private static final String NAME = "name";
 
         private static final String URI = "uri";
 
@@ -156,18 +156,18 @@ public class P2MetadataParser implements
             super(REPOSITORY);
         }
 
-        //        int type;
+        // int type;
         //
-        //        int options;
+        // int options;
         //
-        //        String name;
+        // String name;
 
         URI uri;
 
         protected void handleAttributes(Attributes atts) throws SAXException {
-            //            type = Integer.parseInt(atts.getValue(TYPE));
-            //            options = Integer.parseInt(atts.getValue(OPTIONS));
-            //            name = atts.getValue(NAME);
+            // type = Integer.parseInt(atts.getValue(TYPE));
+            // options = Integer.parseInt(atts.getValue(OPTIONS));
+            // name = atts.getValue(NAME);
 
             String uriAtt = atts.getValue(URI);
             String urlAtt = atts.getValue(URL);
@@ -565,7 +565,7 @@ public class P2MetadataParser implements
 
         private static final String OPTIONAL = "optional";
 
-        //        private static final String GREEDY = "greedy";
+        // private static final String GREEDY = "greedy";
 
         String namespace;
 
@@ -573,19 +573,19 @@ public class P2MetadataParser implements
 
         VersionRange range;
 
-        //        String filter;
+        // String filter;
         //
-        //        boolean greedy;
+        // boolean greedy;
 
         boolean optional;
 
         public RequiredHandler() {
             super(REQUIRED);
-            //            addChild(new FilterHandler(), new ChildElementHandler<FilterHandler>() {
-            //                public void childHanlded(FilterHandler child) {
-            //                    filter = child.getBufferedChars().trim();
-            //                }
-            //            });
+            // addChild(new FilterHandler(), new ChildElementHandler<FilterHandler>() {
+            // public void childHanlded(FilterHandler child) {
+            // filter = child.getBufferedChars().trim();
+            // }
+            // });
         }
 
         protected void handleAttributes(Attributes atts) throws SAXParseException {
@@ -596,7 +596,7 @@ public class P2MetadataParser implements
             } catch (ParseException e) {
                 throw new RuntimeException(e);
             }
-            //            greedy = getOptionalBooleanAttribute(atts, GREEDY, Boolean.TRUE).booleanValue();
+            // greedy = getOptionalBooleanAttribute(atts, GREEDY, Boolean.TRUE).booleanValue();
             optional = getOptionalBooleanAttribute(atts, OPTIONAL, Boolean.FALSE).booleanValue();
         }
 
@@ -676,24 +676,24 @@ public class P2MetadataParser implements
 
     }
 
-    //    private static class TouchpointHandler extends DelegetingHandler {
+    // private static class TouchpointHandler extends DelegetingHandler {
     //
-    //        private static final String TOUCHPOINT = "touchpoint";
+    // private static final String TOUCHPOINT = "touchpoint";
     //
-    //        private static final String ID = "id";
+    // private static final String ID = "id";
     //
-    //        private static final String VERSION = "version";
+    // private static final String VERSION = "version";
     //
-    //        public TouchpointHandler() {
-    //            super(TOUCHPOINT);
-    //        }
+    // public TouchpointHandler() {
+    // super(TOUCHPOINT);
+    // }
     //
-    //        protected void handleAttributes(Attributes atts) {
-    //            String id = atts.getValue(ID);
-    //            String version = atts.getValue(VERSION);
-    //        }
+    // protected void handleAttributes(Attributes atts) {
+    // String id = atts.getValue(ID);
+    // String version = atts.getValue(VERSION);
+    // }
     //
-    //    }
+    // }
 
     private class TouchpointDataHandler extends DelegatingHandler {
 
@@ -772,152 +772,152 @@ public class P2MetadataParser implements
 
     }
 
-    //    private static class LicensesHandler extends DelegetingHandler {
+    // private static class LicensesHandler extends DelegetingHandler {
     //
-    //        private static final String LICENSES = "licenses";
+    // private static final String LICENSES = "licenses";
     //
-    //        private static final String SIZE = "size";
+    // private static final String SIZE = "size";
     //
-    //        public LicensesHandler() {
-    //            super(LICENSES);
-    //            addChild(new LicenseHandler(), new ChildElementHandler() {
-    //                public void childHanlded(DelegetingHandler child) {
-    //                }
-    //            });
-    //        }
+    // public LicensesHandler() {
+    // super(LICENSES);
+    // addChild(new LicenseHandler(), new ChildElementHandler() {
+    // public void childHanlded(DelegetingHandler child) {
+    // }
+    // });
+    // }
     //
-    //        protected void handleAttributes(Attributes atts) {
-    //            String size = atts.getValue(SIZE);
-    //        }
+    // protected void handleAttributes(Attributes atts) {
+    // String size = atts.getValue(SIZE);
+    // }
     //
-    //    }
+    // }
 
-    //    private static class LicenseHandler extends DelegetingHandler {
+    // private static class LicenseHandler extends DelegetingHandler {
     //
-    //        private static final String LICENSE = "license";
+    // private static final String LICENSE = "license";
     //
-    //        private static final String URI = "uri";
+    // private static final String URI = "uri";
     //
-    //        private static final String URL = "url";
+    // private static final String URL = "url";
     //
-    //        public LicenseHandler() {
-    //            super(LICENSE);
-    //            setBufferingChar(true);
-    //        }
+    // public LicenseHandler() {
+    // super(LICENSE);
+    // setBufferingChar(true);
+    // }
     //
-    //        protected void handleAttributes(Attributes atts) {
-    //            String uri = atts.getValue(URI);
-    //            String url = atts.getValue(URL);
-    //        }
+    // protected void handleAttributes(Attributes atts) {
+    // String uri = atts.getValue(URI);
+    // String url = atts.getValue(URL);
+    // }
     //
-    //    }
+    // }
 
-    //    private static class CopyrightHandler extends DelegetingHandler {
+    // private static class CopyrightHandler extends DelegetingHandler {
     //
-    //        private static final String COPYRIGHT = "copyright";
+    // private static final String COPYRIGHT = "copyright";
     //
-    //        private static final String URI = "uri";
+    // private static final String URI = "uri";
     //
-    //        private static final String URL = "url";
+    // private static final String URL = "url";
     //
-    //        public CopyrightHandler() {
-    //            super(COPYRIGHT);
-    //        }
+    // public CopyrightHandler() {
+    // super(COPYRIGHT);
+    // }
     //
-    //        protected void handleAttributes(Attributes atts) {
-    //            String uri = atts.getValue(URI);
-    //            String url = atts.getValue(URL);
-    //        }
+    // protected void handleAttributes(Attributes atts) {
+    // String uri = atts.getValue(URI);
+    // String url = atts.getValue(URL);
+    // }
     //
-    //    }
+    // }
 
-    //    private class ChangesHandler extends DelegetingHandler {
+    // private class ChangesHandler extends DelegetingHandler {
     //
-    //        private static final String CHANGES = "changes";
+    // private static final String CHANGES = "changes";
     //
-    //        private static final String SIZE = "size";
+    // private static final String SIZE = "size";
     //
-    //        public ChangesHandler() {
-    //            super(CHANGES);
-    //            addChild(new ChangeHandler(), new ChildElementHandler<ChangeHandler>() {
-    //                public void childHanlded(ChangeHandler child) {
-    //                }
-    //            });
-    //        }
+    // public ChangesHandler() {
+    // super(CHANGES);
+    // addChild(new ChangeHandler(), new ChildElementHandler<ChangeHandler>() {
+    // public void childHanlded(ChangeHandler child) {
+    // }
+    // });
+    // }
     //
-    //        protected void handleAttributes(Attributes atts) {
-    //            int size = Integer.parseInt(atts.getValue(SIZE));
-    //        }
-    //    }
+    // protected void handleAttributes(Attributes atts) {
+    // int size = Integer.parseInt(atts.getValue(SIZE));
+    // }
+    // }
 
-    //    private class ChangeHandler extends DelegetingHandler {
+    // private class ChangeHandler extends DelegetingHandler {
     //
-    //        private static final String CHANGE = "change";
+    // private static final String CHANGE = "change";
     //
-    //        public ChangeHandler() {
-    //            super(CHANGE);
-    //        }
-    //    }
+    // public ChangeHandler() {
+    // super(CHANGE);
+    // }
+    // }
 
-    //    private class FromHandler extends AbstractRequirementHandler {
+    // private class FromHandler extends AbstractRequirementHandler {
     //
-    //        private static final String FROM = "from";
+    // private static final String FROM = "from";
     //
-    //        public FromHandler() {
-    //            super(FROM);
-    //        }
+    // public FromHandler() {
+    // super(FROM);
+    // }
     //
-    //    }
+    // }
 
-    //    private class ToHandler extends AbstractRequirementHandler {
+    // private class ToHandler extends AbstractRequirementHandler {
     //
-    //        private static final String TO = "to";
+    // private static final String TO = "to";
     //
-    //        public ToHandler() {
-    //            super(TO);
-    //        }
+    // public ToHandler() {
+    // super(TO);
+    // }
     //
-    //    }
+    // }
 
-    //    private class PatchScopeHandler extends DelegetingHandler {
+    // private class PatchScopeHandler extends DelegetingHandler {
     //
-    //        private static final String PATCH_SCOPE = "patchScope";
+    // private static final String PATCH_SCOPE = "patchScope";
     //
-    //        private static final String SIZE = "size";
+    // private static final String SIZE = "size";
     //
-    //        public PatchScopeHandler() {
-    //            super(PATCH_SCOPE);
-    //            addChild(new PatchScopeHandler(), new ChildElementHandler<PatchScopeHandler>() {
-    //                public void childHanlded(PatchScopeHandler child) {
-    //                }
-    //            });
-    //        }
+    // public PatchScopeHandler() {
+    // super(PATCH_SCOPE);
+    // addChild(new PatchScopeHandler(), new ChildElementHandler<PatchScopeHandler>() {
+    // public void childHanlded(PatchScopeHandler child) {
+    // }
+    // });
+    // }
     //
-    //        protected void handleAttributes(Attributes atts) {
-    //            int size = Integer.parseInt(atts.getValue(SIZE));
-    //        }
-    //    }
+    // protected void handleAttributes(Attributes atts) {
+    // int size = Integer.parseInt(atts.getValue(SIZE));
+    // }
+    // }
 
-    //    private class ScopeHandler extends DelegetingHandler {
+    // private class ScopeHandler extends DelegetingHandler {
     //
-    //        private static final String SCOPE = "scope";
+    // private static final String SCOPE = "scope";
     //
-    //        public ScopeHandler() {
-    //            super(SCOPE);
-    //            addChild(new RequiresHandler(), new ChildElementHandler<RequiresHandler>() {
-    //                public void childHanlded(RequiresHandler child) {
-    //                }
-    //            });
-    //        }
-    //    }
+    // public ScopeHandler() {
+    // super(SCOPE);
+    // addChild(new RequiresHandler(), new ChildElementHandler<RequiresHandler>() {
+    // public void childHanlded(RequiresHandler child) {
+    // }
+    // });
+    // }
+    // }
 
-    //    private  class LifeCycleHandler extends AbstractRequirementHandler {
+    // private class LifeCycleHandler extends AbstractRequirementHandler {
     //
-    //        private static final String LIFE_CYCLE = "lifeCycle";
+    // private static final String LIFE_CYCLE = "lifeCycle";
     //
-    //        public LifeCycleHandler() {
-    //            super(LIFE_CYCLE);
-    //        }
-    //    }
+    // public LifeCycleHandler() {
+    // super(LIFE_CYCLE);
+    // }
+    // }
 
 }

Modified: ant/ivy/core/trunk/src/java/org/apache/ivy/osgi/repo/AbstractFSManifestIterable.java
URL: http://svn.apache.org/viewvc/ant/ivy/core/trunk/src/java/org/apache/ivy/osgi/repo/AbstractFSManifestIterable.java?rev=1557968&r1=1557967&r2=1557968&view=diff
==============================================================================
--- ant/ivy/core/trunk/src/java/org/apache/ivy/osgi/repo/AbstractFSManifestIterable.java (original)
+++ ant/ivy/core/trunk/src/java/org/apache/ivy/osgi/repo/AbstractFSManifestIterable.java Tue Jan 14 08:27:37 2014
@@ -72,7 +72,7 @@ public abstract class AbstractFSManifest
         private T currentDir = null;
 
         FSManifestIterator() {
-            dirs.add(Collections.<T>singleton(root).iterator());
+            dirs.add(Collections.<T> singleton(root).iterator());
         }
 
         /**

Modified: ant/ivy/core/trunk/src/java/org/apache/ivy/osgi/repo/AbstractOSGiResolver.java
URL: http://svn.apache.org/viewvc/ant/ivy/core/trunk/src/java/org/apache/ivy/osgi/repo/AbstractOSGiResolver.java?rev=1557968&r1=1557967&r2=1557968&view=diff
==============================================================================
--- ant/ivy/core/trunk/src/java/org/apache/ivy/osgi/repo/AbstractOSGiResolver.java (original)
+++ ant/ivy/core/trunk/src/java/org/apache/ivy/osgi/repo/AbstractOSGiResolver.java Tue Jan 14 08:27:37 2014
@@ -481,7 +481,8 @@ public abstract class AbstractOSGiResolv
                 values.put(IvyPatternHelper.CONF_KEY, BundleInfoAdapter.CONF_USE_PREFIX + module);
                 return Collections.singleton(values);
             }
-            Set<ModuleDescriptorWrapper> bundles = getRepoDescriptor().findModules(osgiType, module);
+            Set<ModuleDescriptorWrapper> bundles = getRepoDescriptor()
+                    .findModules(osgiType, module);
             if (bundles == null) {
                 return Collections.emptySet();
             }

Modified: ant/ivy/core/trunk/src/java/org/apache/ivy/osgi/repo/BundleRepoDescriptor.java
URL: http://svn.apache.org/viewvc/ant/ivy/core/trunk/src/java/org/apache/ivy/osgi/repo/BundleRepoDescriptor.java?rev=1557968&r1=1557967&r2=1557968&view=diff
==============================================================================
--- ant/ivy/core/trunk/src/java/org/apache/ivy/osgi/repo/BundleRepoDescriptor.java (original)
+++ ant/ivy/core/trunk/src/java/org/apache/ivy/osgi/repo/BundleRepoDescriptor.java Tue Jan 14 08:27:37 2014
@@ -59,7 +59,8 @@ public class BundleRepoDescriptor extend
             try {
                 BundleInfo bundleInfo = ManifestParser.parseManifest(manifestAndLocation
                         .getManifest());
-                bundleInfo.addArtifact(new BundleArtifact(false, manifestAndLocation.getUri(), null));
+                bundleInfo
+                        .addArtifact(new BundleArtifact(false, manifestAndLocation.getUri(), null));
                 addBundle(bundleInfo);
             } catch (ParseException e) {
                 Message.error("Rejected " + manifestAndLocation.getUri() + ": " + e.getMessage());

Modified: ant/ivy/core/trunk/src/java/org/apache/ivy/osgi/updatesite/UpdateSiteLoader.java
URL: http://svn.apache.org/viewvc/ant/ivy/core/trunk/src/java/org/apache/ivy/osgi/updatesite/UpdateSiteLoader.java?rev=1557968&r1=1557967&r2=1557968&view=diff
==============================================================================
--- ant/ivy/core/trunk/src/java/org/apache/ivy/osgi/updatesite/UpdateSiteLoader.java (original)
+++ ant/ivy/core/trunk/src/java/org/apache/ivy/osgi/updatesite/UpdateSiteLoader.java Tue Jan 14 08:27:37 2014
@@ -118,8 +118,8 @@ public class UpdateSiteLoader {
         return artifactExists || contentExists;
     }
 
-    private boolean readContent(URI repoUri, P2Descriptor p2Descriptor)
-            throws IOException, ParseException, SAXException {
+    private boolean readContent(URI repoUri, P2Descriptor p2Descriptor) throws IOException,
+            ParseException, SAXException {
         boolean contentExists = readCompositeContent(repoUri, "compositeContent", p2Descriptor);
         if (!contentExists) {
             P2MetadataParser metadataParser = new P2MetadataParser(p2Descriptor);
@@ -129,8 +129,8 @@ public class UpdateSiteLoader {
         return contentExists;
     }
 
-    private boolean readArtifacts(URI repoUri, P2Descriptor p2Descriptor)
-            throws IOException, ParseException, SAXException {
+    private boolean readArtifacts(URI repoUri, P2Descriptor p2Descriptor) throws IOException,
+            ParseException, SAXException {
         boolean artifactExists = readCompositeArtifact(repoUri, "compositeArtifacts", p2Descriptor);
         if (!artifactExists) {
             artifactExists = readJarOrXml(repoUri, "artifacts", new P2ArtifactParser(p2Descriptor,

Modified: ant/ivy/core/trunk/src/java/org/apache/ivy/osgi/updatesite/UpdateSiteResolver.java
URL: http://svn.apache.org/viewvc/ant/ivy/core/trunk/src/java/org/apache/ivy/osgi/updatesite/UpdateSiteResolver.java?rev=1557968&r1=1557967&r2=1557968&view=diff
==============================================================================
--- ant/ivy/core/trunk/src/java/org/apache/ivy/osgi/updatesite/UpdateSiteResolver.java (original)
+++ ant/ivy/core/trunk/src/java/org/apache/ivy/osgi/updatesite/UpdateSiteResolver.java Tue Jan 14 08:27:37 2014
@@ -97,22 +97,22 @@ public class UpdateSiteResolver extends 
                     Message.info("\tdownloading " + rres.getResource().getName());
                 }
             }
-            
+
             public void needArtifact(RepositoryCacheManager cache, Artifact artifact) {
                 if (log <= Message.MSG_VERBOSE) {
                     Message.verbose("\ttrying to download " + artifact);
                 }
             }
-            
+
             public void endArtifactDownload(RepositoryCacheManager cache, Artifact artifact,
                     ArtifactDownloadReport adr, File archiveFile) {
                 if (log <= Message.MSG_VERBOSE) {
                     if (adr.isDownloaded()) {
                         Message.verbose("\tdownloaded to " + archiveFile.getAbsolutePath());
                     } else {
-                        Message.verbose("\tnothing to download");                        
+                        Message.verbose("\tnothing to download");
                     }
-                }                
+                }
             }
         });
         UpdateSiteLoader loader = new UpdateSiteLoader(getRepositoryCacheManager(),