You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@commons.apache.org by tn...@apache.org on 2013/04/30 20:44:22 UTC

svn commit: r1477772 - /commons/proper/collections/trunk/src/main/java/org/apache/commons/collections4/list/

Author: tn
Date: Tue Apr 30 18:44:21 2013
New Revision: 1477772

URL: http://svn.apache.org/r1477772
Log:
Remove trailing spaces.

Modified:
    commons/proper/collections/trunk/src/main/java/org/apache/commons/collections4/list/AbstractLinkedList.java
    commons/proper/collections/trunk/src/main/java/org/apache/commons/collections4/list/AbstractListDecorator.java
    commons/proper/collections/trunk/src/main/java/org/apache/commons/collections4/list/AbstractSerializableListDecorator.java
    commons/proper/collections/trunk/src/main/java/org/apache/commons/collections4/list/CursorableLinkedList.java
    commons/proper/collections/trunk/src/main/java/org/apache/commons/collections4/list/FixedSizeList.java
    commons/proper/collections/trunk/src/main/java/org/apache/commons/collections4/list/LazyList.java
    commons/proper/collections/trunk/src/main/java/org/apache/commons/collections4/list/NodeCachingLinkedList.java
    commons/proper/collections/trunk/src/main/java/org/apache/commons/collections4/list/PredicatedList.java
    commons/proper/collections/trunk/src/main/java/org/apache/commons/collections4/list/SetUniqueList.java
    commons/proper/collections/trunk/src/main/java/org/apache/commons/collections4/list/TransformedList.java
    commons/proper/collections/trunk/src/main/java/org/apache/commons/collections4/list/TreeList.java
    commons/proper/collections/trunk/src/main/java/org/apache/commons/collections4/list/UnmodifiableList.java

Modified: commons/proper/collections/trunk/src/main/java/org/apache/commons/collections4/list/AbstractLinkedList.java
URL: http://svn.apache.org/viewvc/commons/proper/collections/trunk/src/main/java/org/apache/commons/collections4/list/AbstractLinkedList.java?rev=1477772&r1=1477771&r2=1477772&view=diff
==============================================================================
--- commons/proper/collections/trunk/src/main/java/org/apache/commons/collections4/list/AbstractLinkedList.java (original)
+++ commons/proper/collections/trunk/src/main/java/org/apache/commons/collections4/list/AbstractLinkedList.java Tue Apr 30 18:44:21 2013
@@ -101,7 +101,7 @@ public abstract class AbstractLinkedList
     }
 
     //-----------------------------------------------------------------------
-    
+
     public int size() {
         return size;
     }
@@ -116,7 +116,7 @@ public abstract class AbstractLinkedList
     }
 
     //-----------------------------------------------------------------------
-    
+
     public Iterator<E> iterator() {
         return listIterator();
     }
@@ -130,7 +130,7 @@ public abstract class AbstractLinkedList
     }
 
     //-----------------------------------------------------------------------
-    
+
     public int indexOf(final Object value) {
         int i = 0;
         for (Node<E> node = header.next; node != header; node = node.next) {
@@ -167,7 +167,7 @@ public abstract class AbstractLinkedList
     }
 
     //-----------------------------------------------------------------------
-    
+
     public Object[] toArray() {
         return toArray(new Object[size]);
     }
@@ -203,7 +203,7 @@ public abstract class AbstractLinkedList
     }
 
     //-----------------------------------------------------------------------
-    
+
     public boolean add(final E value) {
         addLast(value);
         return true;
@@ -227,7 +227,7 @@ public abstract class AbstractLinkedList
     }
 
     //-----------------------------------------------------------------------
-    
+
     public E remove(final int index) {
         final Node<E> node = getNode(index, false);
         final E oldValue = node.getValue();
@@ -247,7 +247,7 @@ public abstract class AbstractLinkedList
 
     /**
      * {@inheritDoc}
-     * <p> 
+     * <p>
      * This implementation iterates over the elements of this list, checking each element in
      * turn to see if it's contained in <code>coll</code>. If it's contained, it's removed
      * from this list. As a consequence, it is advised to use a collection type for
@@ -267,10 +267,10 @@ public abstract class AbstractLinkedList
     }
 
     //-----------------------------------------------------------------------
-    
+
     /**
      * {@inheritDoc}
-     * <p> 
+     * <p>
      * This implementation iterates over the elements of this list, checking each element in
      * turn to see if it's contained in <code>coll</code>. If it's not contained, it's removed
      * from this list. As a consequence, it is advised to use a collection type for
@@ -301,7 +301,7 @@ public abstract class AbstractLinkedList
     }
 
     //-----------------------------------------------------------------------
-    
+
     public E getFirst() {
         final Node<E> node = header.next;
         if (node == header) {
@@ -596,7 +596,7 @@ public abstract class AbstractLinkedList
      * <p>
      * The first serializable subclass must call this method from
      * <code>writeObject</code>.
-     * 
+     *
      * @param outputStream  the stream to write the object to
      * @throws IOException  if anything goes wrong
      */
@@ -613,7 +613,7 @@ public abstract class AbstractLinkedList
      * <p>
      * The first serializable subclass must call this method from
      * <code>readObject</code>.
-     * 
+     *
      * @param inputStream  the stream to read the object from
      * @throws IOException  if any error occurs while reading from the stream
      * @throws ClassNotFoundException  if a class read from the stream can not be loaded

Modified: commons/proper/collections/trunk/src/main/java/org/apache/commons/collections4/list/AbstractListDecorator.java
URL: http://svn.apache.org/viewvc/commons/proper/collections/trunk/src/main/java/org/apache/commons/collections4/list/AbstractListDecorator.java?rev=1477772&r1=1477771&r2=1477772&view=diff
==============================================================================
--- commons/proper/collections/trunk/src/main/java/org/apache/commons/collections4/list/AbstractListDecorator.java (original)
+++ commons/proper/collections/trunk/src/main/java/org/apache/commons/collections4/list/AbstractListDecorator.java Tue Apr 30 18:44:21 2013
@@ -47,7 +47,7 @@ public abstract class AbstractListDecora
 
     /**
      * Constructor that wraps (not copies).
-     * 
+     *
      * @param list  the list to decorate, must not be null
      * @throws IllegalArgumentException if list is null
      */
@@ -57,7 +57,7 @@ public abstract class AbstractListDecora
 
     /**
      * Gets the list being decorated.
-     * 
+     *
      * @return the decorated list
      */
     @Override
@@ -66,7 +66,7 @@ public abstract class AbstractListDecora
     }
 
     //-----------------------------------------------------------------------
-    
+
     public void add(final int index, final E object) {
         decorated().add(index, object);
     }

Modified: commons/proper/collections/trunk/src/main/java/org/apache/commons/collections4/list/AbstractSerializableListDecorator.java
URL: http://svn.apache.org/viewvc/commons/proper/collections/trunk/src/main/java/org/apache/commons/collections4/list/AbstractSerializableListDecorator.java?rev=1477772&r1=1477771&r2=1477772&view=diff
==============================================================================
--- commons/proper/collections/trunk/src/main/java/org/apache/commons/collections4/list/AbstractSerializableListDecorator.java (original)
+++ commons/proper/collections/trunk/src/main/java/org/apache/commons/collections4/list/AbstractSerializableListDecorator.java Tue Apr 30 18:44:21 2013
@@ -49,7 +49,7 @@ public abstract class AbstractSerializab
     //-----------------------------------------------------------------------
     /**
      * Write the list out using a custom routine.
-     * 
+     *
      * @param out  the output stream
      * @throws IOException
      */
@@ -60,7 +60,7 @@ public abstract class AbstractSerializab
 
     /**
      * Read the list in using a custom routine.
-     * 
+     *
      * @param in  the input stream
      * @throws IOException
      * @throws ClassNotFoundException

Modified: commons/proper/collections/trunk/src/main/java/org/apache/commons/collections4/list/CursorableLinkedList.java
URL: http://svn.apache.org/viewvc/commons/proper/collections/trunk/src/main/java/org/apache/commons/collections4/list/CursorableLinkedList.java?rev=1477772&r1=1477771&r2=1477772&view=diff
==============================================================================
--- commons/proper/collections/trunk/src/main/java/org/apache/commons/collections4/list/CursorableLinkedList.java (original)
+++ commons/proper/collections/trunk/src/main/java/org/apache/commons/collections4/list/CursorableLinkedList.java Tue Apr 30 18:44:21 2013
@@ -74,7 +74,7 @@ public class CursorableLinkedList<E> ext
 
     /**
      * Constructor that copies the specified collection
-     * 
+     *
      * @param coll  the collection to copy
      */
     public CursorableLinkedList(final Collection<E> coll) {
@@ -98,7 +98,7 @@ public class CursorableLinkedList<E> ext
      * If the underlying list is modified while iterating using this iterator
      * a ConcurrentModificationException will occur.
      * The cursor behaviour is available via {@link #listIterator()}.
-     * 
+     *
      * @return a new iterator that does <b>not</b> support concurrent modification
      */
     @Override
@@ -118,7 +118,7 @@ public class CursorableLinkedList<E> ext
      * or {@link ListIterator#previous}) element of the list is removed,
      * the cursor automatically adjusts to the change (invalidating the
      * last returned value such that it cannot be removed).
-     * 
+     *
      * @return a new cursor iterator
      */
     @Override
@@ -138,7 +138,7 @@ public class CursorableLinkedList<E> ext
      * or {@link ListIterator#previous}) element of the list is removed,
      * the cursor automatically adjusts to the change (invalidating the
      * last returned value such that it cannot be removed).
-     * 
+     *
      * @param fromIndex  the index to start from
      * @return a new cursor iterator
      */
@@ -212,7 +212,7 @@ public class CursorableLinkedList<E> ext
      * Updates the node with a new value.
      * This implementation sets the value on the node.
      * Subclasses can override this to record the change.
-     * 
+     *
      * @param node  node to update
      * @param value  new value of the node
      */
@@ -234,7 +234,7 @@ public class CursorableLinkedList<E> ext
         super.addNode(nodeToInsert, insertBeforeNode);
         broadcastNodeInserted(nodeToInsert);
     }
-    
+
     /**
      * Removes the specified node from the list.
      *
@@ -265,7 +265,7 @@ public class CursorableLinkedList<E> ext
     //-----------------------------------------------------------------------
     /**
      * Registers a cursor to be notified of changes to this list.
-     * 
+     *
      * @param cursor  the cursor to register
      */
     protected void registerCursor(final Cursor<E> cursor) {
@@ -282,7 +282,7 @@ public class CursorableLinkedList<E> ext
 
     /**
      * Deregisters a cursor from the list to be notified of changes.
-     * 
+     *
      * @param cursor  the cursor to deregister
      */
     protected void unregisterCursor(final Cursor<E> cursor) {
@@ -290,7 +290,7 @@ public class CursorableLinkedList<E> ext
             final WeakReference<Cursor<E>> ref = it.next();
             final Cursor<E> cur = ref.get();
             if (cur == null) {
-                // some other unrelated cursor object has been 
+                // some other unrelated cursor object has been
                 // garbage-collected; let's take the opportunity to
                 // clean up the cursors list anyway..
                 it.remove();
@@ -306,7 +306,7 @@ public class CursorableLinkedList<E> ext
     /**
      * Informs all of my registered cursors that the specified
      * element was changed.
-     * 
+     *
      * @param node  the node that was changed
      */
     protected void broadcastNodeChanged(final Node<E> node) {
@@ -325,7 +325,7 @@ public class CursorableLinkedList<E> ext
     /**
      * Informs all of my registered cursors that the specified
      * element was just removed from my list.
-     * 
+     *
      * @param node  the node that was changed
      */
     protected void broadcastNodeRemoved(final Node<E> node) {
@@ -344,7 +344,7 @@ public class CursorableLinkedList<E> ext
     /**
      * Informs all of my registered cursors that the specified
      * element was just added to my list.
-     * 
+     *
      * @param node  the node that was changed
      */
     protected void broadcastNodeInserted(final Node<E> node) {
@@ -380,7 +380,7 @@ public class CursorableLinkedList<E> ext
     //-----------------------------------------------------------------------
     /**
      * Creates a list iterator for the sublist.
-     * 
+     *
      * @param subList  the sublist to get an iterator for
      * @param fromIndex  the index to start from, relative to the sublist
      * @return the list iterator for the sublist
@@ -404,10 +404,10 @@ public class CursorableLinkedList<E> ext
         boolean nextIndexValid = true;
         /** Flag to indicate if the current element was removed by another object. */
         boolean currentRemovedByAnother = false;
-        
+
         /**
          * Constructs a new cursor.
-         * 
+         *
          * @param parent  the parent list
          * @param index  the index to start from
          */
@@ -446,7 +446,7 @@ public class CursorableLinkedList<E> ext
         /**
          * Adds an object to the list.
          * The object added here will be the new 'previous' in the iterator.
-         * 
+         *
          * @param obj  the object to add
          */
         @Override
@@ -457,7 +457,7 @@ public class CursorableLinkedList<E> ext
             // thus next gets changed - reset it again here
             next = next.next;
         }
-        
+
         // set is not overridden, as it works ok
         // note that we want it to throw an exception if the element being
         // set has been removed from the real list (compare this with the
@@ -465,7 +465,7 @@ public class CursorableLinkedList<E> ext
 
         /**
          * Gets the index of the next element to be returned.
-         * 
+         *
          * @return the next index
          */
         @Override
@@ -489,7 +489,7 @@ public class CursorableLinkedList<E> ext
 
         /**
          * Handle event from the list when a node has changed.
-         * 
+         *
          * @param node  the node that changed
          */
         protected void nodeChanged(final Node<E> node) {
@@ -498,7 +498,7 @@ public class CursorableLinkedList<E> ext
 
         /**
          * Handle event from the list when a node has been removed.
-         * 
+         *
          * @param node  the node that was removed
          */
         protected void nodeRemoved(final Node<E> node) {
@@ -526,7 +526,7 @@ public class CursorableLinkedList<E> ext
 
         /**
          * Handle event from the list when a node has been added.
-         * 
+         *
          * @param node  the node that was added
          */
         protected void nodeInserted(final Node<E> node) {
@@ -578,7 +578,7 @@ public class CursorableLinkedList<E> ext
 
         /**
          * Constructs a new cursor.
-         * 
+         *
          * @param sub  the sub list
          * @param index  the index to start from
          */

Modified: commons/proper/collections/trunk/src/main/java/org/apache/commons/collections4/list/FixedSizeList.java
URL: http://svn.apache.org/viewvc/commons/proper/collections/trunk/src/main/java/org/apache/commons/collections4/list/FixedSizeList.java?rev=1477772&r1=1477771&r2=1477772&view=diff
==============================================================================
--- commons/proper/collections/trunk/src/main/java/org/apache/commons/collections4/list/FixedSizeList.java (original)
+++ commons/proper/collections/trunk/src/main/java/org/apache/commons/collections4/list/FixedSizeList.java Tue Apr 30 18:44:21 2013
@@ -45,7 +45,7 @@ public class FixedSizeList<E>
 
     /**
      * Factory method to create a fixed size list.
-     * 
+     *
      * @param <E> the type of the elements in the list
      * @param list  the list to decorate, must not be null
      * @return a new fixed size list
@@ -58,7 +58,7 @@ public class FixedSizeList<E>
     //-----------------------------------------------------------------------
     /**
      * Constructor that wraps (not copies).
-     * 
+     *
      * @param list  the list to decorate, must not be null
      * @throws IllegalArgumentException if list is null
      */

Modified: commons/proper/collections/trunk/src/main/java/org/apache/commons/collections4/list/LazyList.java
URL: http://svn.apache.org/viewvc/commons/proper/collections/trunk/src/main/java/org/apache/commons/collections4/list/LazyList.java?rev=1477772&r1=1477771&r2=1477772&view=diff
==============================================================================
--- commons/proper/collections/trunk/src/main/java/org/apache/commons/collections4/list/LazyList.java (original)
+++ commons/proper/collections/trunk/src/main/java/org/apache/commons/collections4/list/LazyList.java Tue Apr 30 18:44:21 2013
@@ -44,7 +44,7 @@ import org.apache.commons.collections4.F
  *
  * After the above code is executed, <code>date</code> will contain
  * a new <code>Date</code> instance.  Furthermore, that <code>Date</code>
- * instance is the fourth element in the list.  The first, second, 
+ * instance is the fourth element in the list.  The first, second,
  * and third element are all set to <code>null</code>.
  * <p>
  * This class differs from {@link GrowthList} because here growth occurs on
@@ -67,7 +67,7 @@ public class LazyList<E> extends Abstrac
 
     /**
      * Factory method to create a lazily instantiating list.
-     * 
+     *
      * @param <E> the type of the elements in the list
      * @param list  the list to decorate, must not be null
      * @param factory  the factory to use for creation, must not be null
@@ -77,11 +77,11 @@ public class LazyList<E> extends Abstrac
     public static <E> LazyList<E> lazyList(final List<E> list, final Factory<? extends E> factory) {
         return new LazyList<E>(list, factory);
     }
-    
+
     //-----------------------------------------------------------------------
     /**
      * Constructor that wraps (not copies).
-     * 
+     *
      * @param list  the list to decorate, must not be null
      * @param factory  the factory to use for creation, must not be null
      * @throws IllegalArgumentException if list or factory is null
@@ -98,11 +98,11 @@ public class LazyList<E> extends Abstrac
     /**
      * Decorate the get method to perform the lazy behaviour.
      * <p>
-     * If the requested index is greater than the current size, the list will 
+     * If the requested index is greater than the current size, the list will
      * grow to the new size and a new object will be returned from the factory.
-     * Indexes in-between the old size and the requested size are left with a 
+     * Indexes in-between the old size and the requested size are left with a
      * placeholder that is replaced with a factory object when requested.
-     * 
+     *
      * @param index  the index to retrieve
      * @return the element at the given index
      */

Modified: commons/proper/collections/trunk/src/main/java/org/apache/commons/collections4/list/NodeCachingLinkedList.java
URL: http://svn.apache.org/viewvc/commons/proper/collections/trunk/src/main/java/org/apache/commons/collections4/list/NodeCachingLinkedList.java?rev=1477772&r1=1477771&r2=1477772&view=diff
==============================================================================
--- commons/proper/collections/trunk/src/main/java/org/apache/commons/collections4/list/NodeCachingLinkedList.java (original)
+++ commons/proper/collections/trunk/src/main/java/org/apache/commons/collections4/list/NodeCachingLinkedList.java Tue Apr 30 18:44:21 2013
@@ -55,7 +55,7 @@ public class NodeCachingLinkedList<E> ex
      * <code>next</code> pointing to the next element.
      */
     private transient Node<E> firstCachedNode;
-    
+
     /**
      * The size of the cache.
      */
@@ -76,14 +76,14 @@ public class NodeCachingLinkedList<E> ex
 
     /**
      * Constructor that copies the specified collection
-     * 
+     *
      * @param coll  the collection to copy
      */
     public NodeCachingLinkedList(final Collection<E> coll) {
         super(coll);
         this.maximumCacheSize = DEFAULT_MAXIMUM_CACHE_SIZE;
     }
-    
+
     /**
      * Constructor that species the maximum cache size.
      *
@@ -98,7 +98,7 @@ public class NodeCachingLinkedList<E> ex
     //-----------------------------------------------------------------------
     /**
      * Gets the maximum size of the cache.
-     * 
+     *
      * @return the maximum cache size
      */
     protected int getMaximumCacheSize() {
@@ -107,7 +107,7 @@ public class NodeCachingLinkedList<E> ex
 
     /**
      * Sets the maximum size of the cache.
-     * 
+     *
      * @param maximumCacheSize  the new maximum cache size
      */
     protected void setMaximumCacheSize(final int maximumCacheSize) {
@@ -124,7 +124,7 @@ public class NodeCachingLinkedList<E> ex
             getNodeFromCache();
         }
     }
-    
+
     /**
      * Gets a node from the cache. If a node is returned, then the value of
      * {@link #cacheSize} is decreased accordingly. The node that is returned
@@ -139,24 +139,24 @@ public class NodeCachingLinkedList<E> ex
         final Node<E> cachedNode = firstCachedNode;
         firstCachedNode = cachedNode.next;
         cachedNode.next = null; // This should be changed anyway, but defensively
-                                // set it to null.                    
+                                // set it to null.
         cacheSize--;
         return cachedNode;
     }
-    
+
     /**
      * Checks whether the cache is full.
-     * 
+     *
      * @return true if the cache is full
      */
     protected boolean isCacheFull() {
         return cacheSize >= maximumCacheSize;
     }
-    
+
     /**
      * Adds a node to the cache, if the cache isn't full.
      * The node's contents are cleared to so they can be garbage collected.
-     * 
+     *
      * @param node  the node to add to the cache
      */
     protected void addNodeToCache(final Node<E> node) {
@@ -173,11 +173,11 @@ public class NodeCachingLinkedList<E> ex
         cacheSize++;
     }
 
-    //-----------------------------------------------------------------------    
+    //-----------------------------------------------------------------------
     /**
      * Creates a new node, either by reusing one from the cache or creating
      * a new one.
-     * 
+     *
      * @param value  value of the new node
      * @return the newly created node
      */
@@ -194,7 +194,7 @@ public class NodeCachingLinkedList<E> ex
     /**
      * Removes the node from the list, storing it in the cache for reuse
      * if the cache is not yet full.
-     * 
+     *
      * @param node  the node to remove
      */
     @Override
@@ -202,11 +202,11 @@ public class NodeCachingLinkedList<E> ex
         super.removeNode(node);
         addNodeToCache(node);
     }
-    
+
     /**
      * Removes all the nodes from the list, storing as many as required in the
      * cache for reuse.
-     * 
+     *
      */
     @Override
     protected void removeAllNodes() {
@@ -221,7 +221,7 @@ public class NodeCachingLinkedList<E> ex
             node = node.next;
             addNodeToCache(oldNode);
         }
-        super.removeAllNodes();        
+        super.removeAllNodes();
     }
 
     //-----------------------------------------------------------------------

Modified: commons/proper/collections/trunk/src/main/java/org/apache/commons/collections4/list/PredicatedList.java
URL: http://svn.apache.org/viewvc/commons/proper/collections/trunk/src/main/java/org/apache/commons/collections4/list/PredicatedList.java?rev=1477772&r1=1477771&r2=1477772&view=diff
==============================================================================
--- commons/proper/collections/trunk/src/main/java/org/apache/commons/collections4/list/PredicatedList.java (original)
+++ commons/proper/collections/trunk/src/main/java/org/apache/commons/collections4/list/PredicatedList.java Tue Apr 30 18:44:21 2013
@@ -50,7 +50,7 @@ public class PredicatedList<E> extends P
      * <p>
      * If there are any elements already in the list being decorated, they
      * are validated.
-     * 
+     *
      * @param <T> the type of the elements in the list
      * @param list  the list to decorate, must not be null
      * @param predicate  the predicate to use for validation, must not be null
@@ -68,7 +68,7 @@ public class PredicatedList<E> extends P
      * <p>
      * If there are any elements already in the list being decorated, they
      * are validated.
-     * 
+     *
      * @param list  the list to decorate, must not be null
      * @param predicate  the predicate to use for validation, must not be null
      * @throws IllegalArgumentException if list or predicate is null
@@ -80,7 +80,7 @@ public class PredicatedList<E> extends P
 
     /**
      * Gets the list being decorated.
-     * 
+     *
      * @return the decorated list
      */
     @Override
@@ -89,7 +89,7 @@ public class PredicatedList<E> extends P
     }
 
     //-----------------------------------------------------------------------
-    
+
     public E get(final int index) {
         return decorated().get(index);
     }
@@ -107,7 +107,7 @@ public class PredicatedList<E> extends P
     }
 
     //-----------------------------------------------------------------------
-    
+
     public void add(final int index, final E object) {
         validate(object);
         decorated().add(index, object);
@@ -142,22 +142,22 @@ public class PredicatedList<E> extends P
      * Inner class Iterator for the PredicatedList
      */
     protected class PredicatedListIterator extends AbstractListIteratorDecorator<E> {
-        
+
         /**
          * Create a new predicated list iterator.
-         * 
+         *
          * @param iterator  the list iterator to decorate
          */
         protected PredicatedListIterator(final ListIterator<E> iterator) {
             super(iterator);
         }
-        
+
         @Override
         public void add(final E object) {
             validate(object);
             getListIterator().add(object);
         }
-        
+
         @Override
         public void set(final E object) {
             validate(object);

Modified: commons/proper/collections/trunk/src/main/java/org/apache/commons/collections4/list/SetUniqueList.java
URL: http://svn.apache.org/viewvc/commons/proper/collections/trunk/src/main/java/org/apache/commons/collections4/list/SetUniqueList.java?rev=1477772&r1=1477771&r2=1477772&view=diff
==============================================================================
--- commons/proper/collections/trunk/src/main/java/org/apache/commons/collections4/list/SetUniqueList.java (original)
+++ commons/proper/collections/trunk/src/main/java/org/apache/commons/collections4/list/SetUniqueList.java Tue Apr 30 18:44:21 2013
@@ -44,7 +44,7 @@ import org.apache.commons.collections4.i
  * retaining insertion order in the iterator.
  * <p>
  * This class is Serializable from Commons Collections 3.1.
- * 
+ *
  * @since 3.0
  * @version $Id$
  */
@@ -57,12 +57,11 @@ public class SetUniqueList<E> extends Ab
     private final Set<E> set;
 
     /**
-     * Factory method to create a SetList using the supplied list to retain
-     * order.
+     * Factory method to create a SetList using the supplied list to retain order.
      * <p>
      * If the list contains duplicates, these are removed (first indexed one
      * kept). A <code>HashSet</code> is used for the set behaviour.
-     * 
+     *
      * @param <E>
      *            the element type
      * @param list
@@ -91,7 +90,7 @@ public class SetUniqueList<E> extends Ab
      * use.
      * <p>
      * The set and list must both be correctly initialised to the same elements.
-     * 
+     *
      * @param set
      *            the set to decorate, must not be null
      * @param list
@@ -110,7 +109,7 @@ public class SetUniqueList<E> extends Ab
     // -----------------------------------------------------------------------
     /**
      * Gets an unmodifiable view as a Set.
-     * 
+     *
      * @return an unmodifiable set view
      */
     public Set<E> asSet() {
@@ -124,7 +123,7 @@ public class SetUniqueList<E> extends Ab
      * <i>(Violation)</i> The <code>List</code> interface requires that this
      * method returns <code>true</code> always. However this class may return
      * <code>false</code> because of the <code>Set</code> behaviour.
-     * 
+     *
      * @param object
      *            the object to add
      * @return true if object was added
@@ -148,7 +147,7 @@ public class SetUniqueList<E> extends Ab
      * <i>(Violation)</i> The <code>List</code> interface makes the assumption
      * that the element is always inserted. This may not happen with this
      * implementation.
-     * 
+     *
      * @param index
      *            the index to insert at
      * @param object
@@ -172,7 +171,7 @@ public class SetUniqueList<E> extends Ab
      * <i>(Violation)</i> The <code>List</code> interface makes the assumption
      * that the elements are always inserted. This may not happen with this
      * implementation.
-     * 
+     *
      * @param coll
      *            the collection to add in iterator order
      * @return true if this collection changed
@@ -192,7 +191,7 @@ public class SetUniqueList<E> extends Ab
      * <i>(Violation)</i> The <code>List</code> interface makes the assumption
      * that the elements are always inserted. This may not happen with this
      * implementation.
-     * 
+     *
      * @param index
      *            the index to insert at
      * @param coll
@@ -217,7 +216,7 @@ public class SetUniqueList<E> extends Ab
      * The object is set into the specified index. Afterwards, any previous
      * duplicate is removed. If the object is not already in the list then a
      * normal set occurs. If it is present, then the old version is removed.
-     * 
+     *
      * @param index
      *            the index to insert at
      * @param object
@@ -324,7 +323,7 @@ public class SetUniqueList<E> extends Ab
      * {@inheritDoc}
      * <p>
      * NOTE: from 4.0, an unmodifiable list will be returned, as changes to the
-     * subList can invalidate the parent list. 
+     * subList can invalidate the parent list.
      */
     @Override
     public List<E> subList(final int fromIndex, final int toIndex) {
@@ -336,7 +335,7 @@ public class SetUniqueList<E> extends Ab
     /**
      * Create a new {@link Set} with the same type as the provided {@code set}
      * and populate it with all elements of {@code list}.
-     * 
+     *
      * @param set
      *            the {@link Set} to be used as return type, must not be null
      * @param list

Modified: commons/proper/collections/trunk/src/main/java/org/apache/commons/collections4/list/TransformedList.java
URL: http://svn.apache.org/viewvc/commons/proper/collections/trunk/src/main/java/org/apache/commons/collections4/list/TransformedList.java?rev=1477772&r1=1477771&r2=1477772&view=diff
==============================================================================
--- commons/proper/collections/trunk/src/main/java/org/apache/commons/collections4/list/TransformedList.java (original)
+++ commons/proper/collections/trunk/src/main/java/org/apache/commons/collections4/list/TransformedList.java Tue Apr 30 18:44:21 2013
@@ -48,7 +48,7 @@ public class TransformedList<E> extends 
      * If there are any elements already in the list being decorated, they
      * are NOT transformed.
      * Contrast this with {@link #transformedList(List, Transformer)}.
-     * 
+     *
      * @param <E> the type of the elements in the list
      * @param list  the list to decorate, must not be null
      * @param transformer  the transformer to use for conversion, must not be null
@@ -59,7 +59,7 @@ public class TransformedList<E> extends 
                                                           final Transformer<? super E, ? extends E> transformer) {
         return new TransformedList<E>(list, transformer);
     }
-    
+
     /**
      * Factory method to create a transforming list that will transform
      * existing contents of the specified list.
@@ -67,7 +67,7 @@ public class TransformedList<E> extends 
      * If there are any elements already in the list being decorated, they
      * will be transformed by this method.
      * Contrast this with {@link #transformingList(List, Transformer)}.
-     * 
+     *
      * @param <E> the type of the elements in the list
      * @param list  the list to decorate, must not be null
      * @param transformer  the transformer to use for conversion, must not be null
@@ -95,7 +95,7 @@ public class TransformedList<E> extends 
      * <p>
      * If there are any elements already in the list being decorated, they
      * are NOT transformed.
-     * 
+     *
      * @param list  the list to decorate, must not be null
      * @param transformer  the transformer to use for conversion, must not be null
      * @throws IllegalArgumentException if list or transformer is null
@@ -106,7 +106,7 @@ public class TransformedList<E> extends 
 
     /**
      * Gets the decorated list.
-     * 
+     *
      * @return the decorated list
      */
     protected List<E> getList() {
@@ -114,7 +114,7 @@ public class TransformedList<E> extends 
     }
 
     //-----------------------------------------------------------------------
-    
+
     public E get(final int index) {
         return getList().get(index);
     }
@@ -132,7 +132,7 @@ public class TransformedList<E> extends 
     }
 
     //-----------------------------------------------------------------------
-    
+
     public void add(final int index, E object) {
         object = transform(object);
         getList().add(index, object);
@@ -168,7 +168,7 @@ public class TransformedList<E> extends 
 
         /**
          * Create a new transformed list iterator.
-         * 
+         *
          * @param iterator  the list iterator to decorate
          */
         protected TransformedListIterator(final ListIterator<E> iterator) {

Modified: commons/proper/collections/trunk/src/main/java/org/apache/commons/collections4/list/TreeList.java
URL: http://svn.apache.org/viewvc/commons/proper/collections/trunk/src/main/java/org/apache/commons/collections4/list/TreeList.java?rev=1477772&r1=1477771&r2=1477772&view=diff
==============================================================================
--- commons/proper/collections/trunk/src/main/java/org/apache/commons/collections4/list/TreeList.java (original)
+++ commons/proper/collections/trunk/src/main/java/org/apache/commons/collections4/list/TreeList.java Tue Apr 30 18:44:21 2013
@@ -86,7 +86,7 @@ public class TreeList<E> extends Abstrac
         if (!coll.isEmpty()) {
             root = new AVLNode<E>(coll);
             size = coll.size();
-        }        
+        }
     }
 
     //-----------------------------------------------------------------------
@@ -800,7 +800,7 @@ public class TreeList<E> extends Abstrac
          * Appends the elements of another tree list to this tree list by efficiently
          * merging the two AVL trees. This operation is destructive to both trees and
          * runs in O(log(m + n)) time.
-         * 
+         *
          * @param otherTree
          *            the root of the AVL tree to merge with this one
          * @param currentSize

Modified: commons/proper/collections/trunk/src/main/java/org/apache/commons/collections4/list/UnmodifiableList.java
URL: http://svn.apache.org/viewvc/commons/proper/collections/trunk/src/main/java/org/apache/commons/collections4/list/UnmodifiableList.java?rev=1477772&r1=1477771&r2=1477772&view=diff
==============================================================================
--- commons/proper/collections/trunk/src/main/java/org/apache/commons/collections4/list/UnmodifiableList.java (original)
+++ commons/proper/collections/trunk/src/main/java/org/apache/commons/collections4/list/UnmodifiableList.java Tue Apr 30 18:44:21 2013
@@ -30,7 +30,7 @@ import org.apache.commons.collections4.i
  * <p>
  * This class is Serializable from Commons Collections 3.1.
  * <p>
- * Attempts to modify it will result in an UnsupportedOperationException. 
+ * Attempts to modify it will result in an UnsupportedOperationException.
  *
  * @since 3.0
  * @version $Id$
@@ -44,7 +44,7 @@ public final class UnmodifiableList<E>
 
     /**
      * Factory method to create an unmodifiable list.
-     * 
+     *
      * @param <E> the type of the elements in the list
      * @param list  the list to decorate, must not be null
      * @return a new unmodifiable list
@@ -60,7 +60,7 @@ public final class UnmodifiableList<E>
     //-----------------------------------------------------------------------
     /**
      * Constructor that wraps (not copies).
-     * 
+     *
      * @param list  the list to decorate, must not be null
      * @throws IllegalArgumentException if list is null
      * @since Commons Collection 5