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/06/17 23:06:00 UTC

svn commit: r1493938 - in /commons/proper/collections/trunk/src: main/java/org/apache/commons/collections4/ main/java/org/apache/commons/collections4/bag/ test/java/org/apache/commons/collections4/bag/ test/resources/data/test/

Author: tn
Date: Mon Jun 17 21:06:00 2013
New Revision: 1493938

URL: http://svn.apache.org/r1493938
Log:
[COLLECTIONS-468] Added CompliantBag decorator which decorates another bag to comply with the Collection contract.

Added:
    commons/proper/collections/trunk/src/main/java/org/apache/commons/collections4/bag/CompliantBag.java   (with props)
    commons/proper/collections/trunk/src/test/java/org/apache/commons/collections4/bag/CompliantBagTest.java   (with props)
    commons/proper/collections/trunk/src/test/resources/data/test/CompliantBag.emptyCollection.version4.obj   (with props)
    commons/proper/collections/trunk/src/test/resources/data/test/CompliantBag.fullCollection.version4.obj   (with props)
Modified:
    commons/proper/collections/trunk/src/main/java/org/apache/commons/collections4/BagUtils.java
    commons/proper/collections/trunk/src/main/java/org/apache/commons/collections4/bag/package-info.java

Modified: commons/proper/collections/trunk/src/main/java/org/apache/commons/collections4/BagUtils.java
URL: http://svn.apache.org/viewvc/commons/proper/collections/trunk/src/main/java/org/apache/commons/collections4/BagUtils.java?rev=1493938&r1=1493937&r2=1493938&view=diff
==============================================================================
--- commons/proper/collections/trunk/src/main/java/org/apache/commons/collections4/BagUtils.java (original)
+++ commons/proper/collections/trunk/src/main/java/org/apache/commons/collections4/BagUtils.java Mon Jun 17 21:06:00 2013
@@ -16,6 +16,7 @@
  */
 package org.apache.commons.collections4;
 
+import org.apache.commons.collections4.bag.CompliantBag;
 import org.apache.commons.collections4.bag.HashBag;
 import org.apache.commons.collections4.bag.PredicatedBag;
 import org.apache.commons.collections4.bag.PredicatedSortedBag;
@@ -134,6 +135,19 @@ public class BagUtils {
         return TransformedBag.transformingBag(bag, transformer);
     }
 
+    /**
+     * Returns a bag that complies to the Collection contract, backed by the given bag.
+     *
+     * @param <E> the element type
+     * @param bag the bag to decorate, must not be null
+     * @return a Bag that complies to the Collection contract
+     * @throws IllegalArgumentException if bag is null
+     * @since 4.0
+     */
+    public static <E> Bag<E> compliantBag(final Bag<E> bag) {
+        return CompliantBag.compliantBag(bag);
+    }
+
     //-----------------------------------------------------------------------
     /**
      * Returns a synchronized (thread-safe) sorted bag backed by the given

Added: commons/proper/collections/trunk/src/main/java/org/apache/commons/collections4/bag/CompliantBag.java
URL: http://svn.apache.org/viewvc/commons/proper/collections/trunk/src/main/java/org/apache/commons/collections4/bag/CompliantBag.java?rev=1493938&view=auto
==============================================================================
--- commons/proper/collections/trunk/src/main/java/org/apache/commons/collections4/bag/CompliantBag.java (added)
+++ commons/proper/collections/trunk/src/main/java/org/apache/commons/collections4/bag/CompliantBag.java Mon Jun 17 21:06:00 2013
@@ -0,0 +1,161 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *      http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+package org.apache.commons.collections4.bag;
+
+import java.io.IOException;
+import java.io.ObjectInputStream;
+import java.io.ObjectOutputStream;
+import java.io.Serializable;
+import java.util.Collection;
+import java.util.Iterator;
+
+import org.apache.commons.collections4.Bag;
+
+/**
+ * Decorates another {@link Bag} to comply with the Collection contract.
+ *
+ * @since 4.0
+ * @version $Id$
+ */
+public final class CompliantBag<E>
+        extends AbstractBagDecorator<E> implements Serializable {
+
+    /** Serialization version */
+    private static final long serialVersionUID = -2560033712679053143L;
+
+    /**
+     * Factory method to create a bag that complies to the Collection contract.
+     *
+     * @param <E> the type of the elements in the bag
+     * @param bag  the bag to decorate, must not be null
+     * @return a Bag that complies to the Collection contract
+     * @throws IllegalArgumentException if bag is null
+     */
+    public static <E> Bag<E> compliantBag(final Bag<E> bag) {
+        return new CompliantBag<E>(bag);
+    }
+
+    //-----------------------------------------------------------------------
+    /**
+     * Constructor that wraps (not copies).
+     *
+     * @param bag  the bag to decorate, must not be null
+     * @throws IllegalArgumentException if bag is null
+     */
+    public CompliantBag(final Bag<E> bag) {
+        super(bag);
+    }
+
+    //-----------------------------------------------------------------------
+    /**
+     * Write the collection out using a custom routine.
+     *
+     * @param out  the output stream
+     * @throws IOException
+     */
+    private void writeObject(final ObjectOutputStream out) throws IOException {
+        out.defaultWriteObject();
+        out.writeObject(collection);
+    }
+
+    /**
+     * Read the collection in using a custom routine.
+     *
+     * @param in  the input stream
+     * @throws IOException
+     * @throws ClassNotFoundException
+     * @throws ClassCastException if deserialised object has wrong type
+     */
+    @SuppressWarnings("unchecked") // will throw CCE, see Javadoc
+    private void readObject(final ObjectInputStream in) throws IOException, ClassNotFoundException {
+        in.defaultReadObject();
+        collection = (Collection<E>) in.readObject();
+    }
+
+    //-----------------------------------------------------------------------
+    // Collection interface
+    //-----------------------------------------------------------------------
+
+    @Override
+    public boolean containsAll(final Collection<?> coll) {
+        final Iterator<?> e = coll.iterator();
+        while (e.hasNext()) {
+            if(!contains(e.next())) {
+                return false;
+            }
+        }
+        return true;
+    }
+
+    @Override
+    public boolean add(final E object) {
+        return add(object, 1);
+    }
+
+    @Override
+    public boolean addAll(final Collection<? extends E> coll) {
+        boolean changed = false;
+        final Iterator<? extends E> i = coll.iterator();
+        while (i.hasNext()) {
+            final boolean added = add(i.next(), 1);
+            changed = changed || added;
+        }
+        return changed;
+    }
+
+    @Override
+    public boolean remove(final Object object) {
+        return remove(object, 1);
+    }
+
+    @Override
+    public boolean removeAll(final Collection<?> coll) {
+        boolean result = false;
+        if (coll != null) {
+            final Iterator<?> i = coll.iterator();
+            while (i.hasNext()) {
+                final Object obj = i.next();
+                final boolean changed = remove(obj, getCount(obj));
+                result = result || changed;
+            }
+        }
+        return result;
+    }
+
+    @Override
+    public boolean retainAll(final Collection<?> coll) {
+        boolean modified = false;
+        final Iterator<E> e = iterator();
+        while (e.hasNext()) {
+            if (!coll.contains(e.next())) {
+                e.remove();
+                modified = true;
+            }
+        }
+        return modified;
+    }
+
+    //-----------------------------------------------------------------------
+    // Bag interface
+    //-----------------------------------------------------------------------
+
+    public boolean add(final E object, final int count) {
+        decorated().add(object, count);
+        return true;
+    }
+
+}

Propchange: commons/proper/collections/trunk/src/main/java/org/apache/commons/collections4/bag/CompliantBag.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: commons/proper/collections/trunk/src/main/java/org/apache/commons/collections4/bag/CompliantBag.java
------------------------------------------------------------------------------
    svn:keywords = Id Revision HeadURL

Propchange: commons/proper/collections/trunk/src/main/java/org/apache/commons/collections4/bag/CompliantBag.java
------------------------------------------------------------------------------
    svn:mime-type = text/plain

Modified: commons/proper/collections/trunk/src/main/java/org/apache/commons/collections4/bag/package-info.java
URL: http://svn.apache.org/viewvc/commons/proper/collections/trunk/src/main/java/org/apache/commons/collections4/bag/package-info.java?rev=1493938&r1=1493937&r2=1493938&view=diff
==============================================================================
--- commons/proper/collections/trunk/src/main/java/org/apache/commons/collections4/bag/package-info.java (original)
+++ commons/proper/collections/trunk/src/main/java/org/apache/commons/collections4/bag/package-info.java Mon Jun 17 21:06:00 2013
@@ -31,6 +31,7 @@
  *   <li>Unmodifiable - ensures the bag cannot be altered
  *   <li>Predicated - ensures that only elements that are valid according to a predicate can be added
  *   <li>Transformed - transforms each element added to the bag
+ *   <li>Compliant - ensures compliance with the java.util.Collection contract
  * </ul>
  *
  * @version $Id$

Added: commons/proper/collections/trunk/src/test/java/org/apache/commons/collections4/bag/CompliantBagTest.java
URL: http://svn.apache.org/viewvc/commons/proper/collections/trunk/src/test/java/org/apache/commons/collections4/bag/CompliantBagTest.java?rev=1493938&view=auto
==============================================================================
--- commons/proper/collections/trunk/src/test/java/org/apache/commons/collections4/bag/CompliantBagTest.java (added)
+++ commons/proper/collections/trunk/src/test/java/org/apache/commons/collections4/bag/CompliantBagTest.java Mon Jun 17 21:06:00 2013
@@ -0,0 +1,553 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *      http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+package org.apache.commons.collections4.bag;
+
+import java.io.IOException;
+import java.io.Serializable;
+import java.util.ArrayList;
+import java.util.Arrays;
+import java.util.Collection;
+import java.util.ConcurrentModificationException;
+import java.util.Iterator;
+import java.util.List;
+import java.util.NoSuchElementException;
+
+import org.apache.commons.collections4.Bag;
+import org.apache.commons.collections4.bag.HashBag;
+import org.apache.commons.collections4.collection.AbstractCollectionTest;
+
+/**
+ * Test class for {@link CompliantBag}.
+ *
+ * @version $Id$
+ * @since 4.0
+ */
+public class CompliantBagTest<T> extends AbstractCollectionTest<T> {
+
+    /**
+     * JUnit constructor.
+     *
+     * @param testName  the test class name
+     */
+    public CompliantBagTest(final String testName) {
+        super(testName);
+    }
+
+    //-----------------------------------------------------------------------
+    
+    @Override
+    public Bag<T> makeObject() {
+        return CompliantBag.compliantBag(new HashBag<T>());
+    }
+
+    /**
+     * Returns an empty List for use in modification testing.
+     *
+     * @return a confirmed empty collection
+     */
+    @Override
+    public Collection<T> makeConfirmedCollection() {
+        return new ArrayList<T>();
+    }
+
+    /**
+     * Returns a full Set for use in modification testing.
+     *
+     * @return a confirmed full collection
+     */
+    @Override
+    public Collection<T> makeConfirmedFullCollection() {
+        final Collection<T> set = makeConfirmedCollection();
+        set.addAll(Arrays.asList(getFullElements()));
+        return set;
+    }
+
+    @Override
+    public String getCompatibilityVersion() {
+        return "4";
+    }
+
+//    public void testCreate() throws Exception {
+//        Bag bag = makeObject();
+//        writeExternalFormToDisk((java.io.Serializable) bag, "src/test/resources/data/test/CompliantBag.emptyCollection.version4.obj");
+//        bag = makeObject();
+//        bag.add("A");
+//        bag.add("A");
+//        bag.add("B");
+//        bag.add("B");
+//        bag.add("C");
+//        writeExternalFormToDisk((java.io.Serializable) bag, "src/test/resources/data/test/CompliantBag.fullCollection.version4.obj");
+//    }
+    
+    //-----------------------------------------------------------------------
+    @SuppressWarnings("unchecked")
+    public void testBagAdd() {
+        final Bag<T> bag = makeObject();
+        bag.add((T) "A");
+        assertTrue("Should contain 'A'", bag.contains("A"));
+        assertEquals("Should have count of 1", 1, bag.getCount("A"));
+        bag.add((T) "A");
+        assertTrue("Should contain 'A'", bag.contains("A"));
+        assertEquals("Should have count of 2", 2, bag.getCount("A"));
+        bag.add((T) "B");
+        assertTrue(bag.contains("A"));
+        assertTrue(bag.contains("B"));
+    }
+
+    @SuppressWarnings("unchecked")
+    public void testBagEqualsSelf() {
+        final Bag<T> bag = makeObject();
+        assertTrue(bag.equals(bag));
+        bag.add((T) "elt");
+        assertTrue(bag.equals(bag));
+        bag.add((T) "elt"); // again
+        assertTrue(bag.equals(bag));
+        bag.add((T) "elt2");
+        assertTrue(bag.equals(bag));
+    }
+
+    @SuppressWarnings("unchecked")
+    public void testRemove() {
+        final Bag<T> bag = makeObject();
+        bag.add((T) "A");
+        assertEquals("Should have count of 1", 1, bag.getCount("A"));
+        bag.remove("A");
+        assertEquals("Should have count of 0", 0, bag.getCount("A"));
+        bag.add((T) "A");
+        bag.add((T) "A");
+        bag.add((T) "A");
+        bag.add((T) "A");
+        assertEquals("Should have count of 4", 4, bag.getCount("A"));
+        bag.remove("A", 0);
+        assertEquals("Should have count of 4", 4, bag.getCount("A"));
+        bag.remove("A", 2);
+        assertEquals("Should have count of 2", 2, bag.getCount("A"));
+        bag.remove("A");
+        assertEquals("Should have count of 1", 1, bag.getCount("A"));
+    }
+
+    @SuppressWarnings("unchecked")
+    public void testRemoveAll() {
+        final Bag<T> bag = makeObject();
+        bag.add((T) "A", 2);
+        assertEquals("Should have count of 2", 2, bag.getCount("A"));
+        bag.add((T) "B");
+        bag.add((T) "C");
+        assertEquals("Should have count of 4", 4, bag.size());
+        final List<String> delete = new ArrayList<String>();
+        delete.add("A");
+        delete.add("B");
+        bag.removeAll(delete);
+        assertEquals("Should have count of 0", 0, bag.getCount("A"));
+        assertEquals("Should have count of 0", 0, bag.getCount("B"));
+        assertEquals("Should have count of 1", 1, bag.getCount("C"));
+        assertEquals("Should have count of 1", 1, bag.size());
+    }
+
+    @SuppressWarnings("unchecked")
+    public void testContains() {
+        final Bag<T> bag = makeObject();
+
+        assertEquals("Bag does not have at least 1 'A'", false, bag.contains("A"));
+        assertEquals("Bag does not have at least 1 'B'", false, bag.contains("B"));
+
+        bag.add((T) "A");  // bag 1A
+        assertEquals("Bag has at least 1 'A'", true, bag.contains("A"));
+        assertEquals("Bag does not have at least 1 'B'", false, bag.contains("B"));
+
+        bag.add((T) "A");  // bag 2A
+        assertEquals("Bag has at least 1 'A'", true, bag.contains("A"));
+        assertEquals("Bag does not have at least 1 'B'", false, bag.contains("B"));
+
+        bag.add((T) "B");  // bag 2A,1B
+        assertEquals("Bag has at least 1 'A'", true, bag.contains("A"));
+        assertEquals("Bag has at least 1 'B'", true, bag.contains("B"));
+    }
+
+    @SuppressWarnings("unchecked")
+    public void testContainsAll() {
+        final Bag<T> bag = makeObject();
+        final List<String> known = new ArrayList<String>();
+        final List<String> known1A = new ArrayList<String>();
+        known1A.add("A");
+        final List<String> known2A = new ArrayList<String>();
+        known2A.add("A");
+        known2A.add("A");
+        final List<String> known1B = new ArrayList<String>();
+        known1B.add("B");
+        final List<String> known1A1B = new ArrayList<String>();
+        known1A1B.add("A");
+        known1A1B.add("B");
+
+        assertEquals("Bag containsAll of empty", true, bag.containsAll(known));
+        assertEquals("Bag does not containsAll of 1 'A'", false, bag.containsAll(known1A));
+        assertEquals("Bag does not containsAll of 2 'A'", false, bag.containsAll(known2A));
+        assertEquals("Bag does not containsAll of 1 'B'", false, bag.containsAll(known1B));
+        assertEquals("Bag does not containsAll of 1 'A' 1 'B'", false, bag.containsAll(known1A1B));
+
+        bag.add((T) "A");  // bag 1A
+        assertEquals("Bag containsAll of empty", true, bag.containsAll(known));
+        assertEquals("Bag containsAll of 1 'A'", true, bag.containsAll(known1A));
+        assertEquals("Bag does containsAll of 2 'A'", true, bag.containsAll(known2A));
+        assertEquals("Bag does not containsAll of 1 'B'", false, bag.containsAll(known1B));
+        assertEquals("Bag does not containsAll of 1 'A' 1 'B'", false, bag.containsAll(known1A1B));
+
+        bag.add((T) "A");  // bag 2A
+        assertEquals("Bag containsAll of empty", true, bag.containsAll(known));
+        assertEquals("Bag containsAll of 1 'A'", true, bag.containsAll(known1A));
+        assertEquals("Bag containsAll of 2 'A'", true, bag.containsAll(known2A));
+        assertEquals("Bag does not containsAll of 1 'B'", false, bag.containsAll(known1B));
+        assertEquals("Bag does not containsAll of 1 'A' 1 'B'", false, bag.containsAll(known1A1B));
+
+        bag.add((T) "A");  // bag 3A
+        assertEquals("Bag containsAll of empty", true, bag.containsAll(known));
+        assertEquals("Bag containsAll of 1 'A'", true, bag.containsAll(known1A));
+        assertEquals("Bag containsAll of 2 'A'", true, bag.containsAll(known2A));
+        assertEquals("Bag does not containsAll of 1 'B'", false, bag.containsAll(known1B));
+        assertEquals("Bag does not containsAll of 1 'A' 1 'B'", false, bag.containsAll(known1A1B));
+
+        bag.add((T) "B");  // bag 3A1B
+        assertEquals("Bag containsAll of empty", true, bag.containsAll(known));
+        assertEquals("Bag containsAll of 1 'A'", true, bag.containsAll(known1A));
+        assertEquals("Bag containsAll of 2 'A'", true, bag.containsAll(known2A));
+        assertEquals("Bag containsAll of 1 'B'", true, bag.containsAll(known1B));
+        assertEquals("Bag containsAll of 1 'A' 1 'B'", true, bag.containsAll(known1A1B));
+    }
+
+    @SuppressWarnings("unchecked")
+    public void testSize() {
+        final Bag<T> bag = makeObject();
+        assertEquals("Should have 0 total items", 0, bag.size());
+        bag.add((T) "A");
+        assertEquals("Should have 1 total items", 1, bag.size());
+        bag.add((T) "A");
+        assertEquals("Should have 2 total items", 2, bag.size());
+        bag.add((T) "A");
+        assertEquals("Should have 3 total items", 3, bag.size());
+        bag.add((T) "B");
+        assertEquals("Should have 4 total items", 4, bag.size());
+        bag.add((T) "B");
+        assertEquals("Should have 5 total items", 5, bag.size());
+        bag.remove("A", 2);
+        assertEquals("Should have 1 'A'", 1, bag.getCount("A"));
+        assertEquals("Should have 3 total items", 3, bag.size());
+        // this should only remove 1 occurrence of B
+        bag.remove("B");
+        assertEquals("Should have 2 total item", 2, bag.size());
+    }
+
+    @SuppressWarnings("unchecked")
+    public void testRetainAll() {
+        final Bag<T> bag = makeObject();
+        bag.add((T) "A");
+        bag.add((T) "A");
+        bag.add((T) "A");
+        bag.add((T) "B");
+        bag.add((T) "B");
+        bag.add((T) "C");
+        final List<String> retains = new ArrayList<String>();
+        retains.add("B");
+        retains.add("C");
+        bag.retainAll(retains);
+        assertEquals("Should have 3 total items", 3, bag.size());
+    }
+
+    @SuppressWarnings("unchecked")
+    public void testIterator() {
+        final Bag<T> bag = makeObject();
+        bag.add((T) "A");
+        bag.add((T) "A");
+        bag.add((T) "B");
+        assertEquals("Bag should have 3 items", 3, bag.size());
+        final Iterator<T> i = bag.iterator();
+
+        boolean foundA = false;
+        while (i.hasNext()) {
+            final String element = (String) i.next();
+            // ignore the first A, remove the second via Iterator.remove()
+            if (element.equals("A")) {
+                if (foundA == false) {
+                    foundA = true;
+                } else {
+                    i.remove();
+                }
+            }
+        }
+
+        assertTrue("Bag should still contain 'A'", bag.contains("A"));
+        assertEquals("Bag should have 2 items", 2, bag.size());
+        assertEquals("Bag should have 1 'A'", 1, bag.getCount("A"));
+    }
+
+    @SuppressWarnings("unchecked")
+    public void testIteratorFail() {
+        final Bag<T> bag = makeObject();
+        bag.add((T) "A");
+        bag.add((T) "A");
+        bag.add((T) "B");
+        final Iterator<T> it = bag.iterator();
+        it.next();
+        bag.remove("A");
+        try {
+            it.next();
+            fail("Should throw ConcurrentModificationException");
+        } catch (final ConcurrentModificationException e) {
+            // expected
+        }
+    }
+
+    @SuppressWarnings("unchecked")
+    public void testIteratorFailNoMore() {
+        final Bag<T> bag = makeObject();
+        bag.add((T) "A");
+        bag.add((T) "A");
+        bag.add((T) "B");
+        final Iterator<T> it = bag.iterator();
+        it.next();
+        it.next();
+        it.next();
+        try {
+            it.next();
+            fail("Should throw NoSuchElementException");
+        } catch (final NoSuchElementException ex) {
+            // expected
+        }
+    }
+
+    @SuppressWarnings("unchecked")
+    public void testIteratorFailDoubleRemove() {
+        final Bag<T> bag = makeObject();
+        bag.add((T) "A");
+        bag.add((T) "A");
+        bag.add((T) "B");
+        final Iterator<T> it = bag.iterator();
+        it.next();
+        it.next();
+        assertEquals(3, bag.size());
+        it.remove();
+        assertEquals(2, bag.size());
+        try {
+            it.remove();
+            fail("Should throw IllegalStateException");
+        } catch (final IllegalStateException ex) {
+            // expected
+        }
+        assertEquals(2, bag.size());
+        it.next();
+        it.remove();
+        assertEquals(1, bag.size());
+    }
+
+    @SuppressWarnings("unchecked")
+    public void testIteratorRemoveProtectsInvariants() {
+        final Bag<T> bag = makeObject();
+        bag.add((T) "A");
+        bag.add((T) "A");
+        assertEquals(2, bag.size());
+        final Iterator<T> it = bag.iterator();
+        assertEquals("A", it.next());
+        assertEquals(true, it.hasNext());
+        it.remove();
+        assertEquals(1, bag.size());
+        assertEquals(true, it.hasNext());
+        assertEquals("A", it.next());
+        assertEquals(false, it.hasNext());
+        it.remove();
+        assertEquals(0, bag.size());
+        assertEquals(false, it.hasNext());
+
+        final Iterator<T> it2 = bag.iterator();
+        assertEquals(false, it2.hasNext());
+    }
+
+    @SuppressWarnings("unchecked")
+    public void testToArray() {
+        final Bag<T> bag = makeObject();
+        bag.add((T) "A");
+        bag.add((T) "A");
+        bag.add((T) "B");
+        bag.add((T) "B");
+        bag.add((T) "C");
+        final Object[] array = bag.toArray();
+        int a = 0, b = 0, c = 0;
+        for (final Object element : array) {
+            a += element.equals("A") ? 1 : 0;
+            b += element.equals("B") ? 1 : 0;
+            c += element.equals("C") ? 1 : 0;
+        }
+        assertEquals(2, a);
+        assertEquals(2, b);
+        assertEquals(1, c);
+    }
+
+    @SuppressWarnings("unchecked")
+    public void testToArrayPopulate() {
+        final Bag<T> bag = makeObject();
+        bag.add((T) "A");
+        bag.add((T) "A");
+        bag.add((T) "B");
+        bag.add((T) "B");
+        bag.add((T) "C");
+        final String[] array = bag.toArray(new String[0]);
+        int a = 0, b = 0, c = 0;
+        for (final String element : array) {
+            a += element.equals("A") ? 1 : 0;
+            b += element.equals("B") ? 1 : 0;
+            c += element.equals("C") ? 1 : 0;
+        }
+        assertEquals(2, a);
+        assertEquals(2, b);
+        assertEquals(1, c);
+    }
+
+    //-----------------------------------------------------------------------
+    @SuppressWarnings("unchecked")
+    public void testEquals() {
+        final Bag<T> bag = makeObject();
+        final Bag<T> bag2 = makeObject();
+        assertEquals(true, bag.equals(bag2));
+        bag.add((T) "A");
+        assertEquals(false, bag.equals(bag2));
+        bag2.add((T) "A");
+        assertEquals(true, bag.equals(bag2));
+        bag.add((T) "A");
+        bag.add((T) "B");
+        bag.add((T) "B");
+        bag.add((T) "C");
+        bag2.add((T) "A");
+        bag2.add((T) "B");
+        bag2.add((T) "B");
+        bag2.add((T) "C");
+        assertEquals(true, bag.equals(bag2));
+    }
+
+    @SuppressWarnings("unchecked")
+    public void testEqualsHashBag() {
+        final Bag<T> bag = makeObject();
+        final Bag<T> bag2 = new HashBag<T>();
+        assertEquals(true, bag.equals(bag2));
+        bag.add((T) "A");
+        assertEquals(false, bag.equals(bag2));
+        bag2.add((T) "A");
+        assertEquals(true, bag.equals(bag2));
+        bag.add((T) "A");
+        bag.add((T) "B");
+        bag.add((T) "B");
+        bag.add((T) "C");
+        bag2.add((T) "A");
+        bag2.add((T) "B");
+        bag2.add((T) "B");
+        bag2.add((T) "C");
+        assertEquals(true, bag.equals(bag2));
+    }
+
+    @SuppressWarnings("unchecked")
+    public void testHashCode() {
+        final Bag<T> bag = makeObject();
+        final Bag<T> bag2 = makeObject();
+        assertEquals(0, bag.hashCode());
+        assertEquals(0, bag2.hashCode());
+        assertEquals(bag.hashCode(), bag2.hashCode());
+        bag.add((T) "A");
+        bag.add((T) "A");
+        bag.add((T) "B");
+        bag.add((T) "B");
+        bag.add((T) "C");
+        bag2.add((T) "A");
+        bag2.add((T) "A");
+        bag2.add((T) "B");
+        bag2.add((T) "B");
+        bag2.add((T) "C");
+        assertEquals(bag.hashCode(), bag2.hashCode());
+
+        int total = 0;
+        total += "A".hashCode() ^ 2;
+        total += "B".hashCode() ^ 2;
+        total += "C".hashCode() ^ 1;
+        assertEquals(total, bag.hashCode());
+        assertEquals(total, bag2.hashCode());
+    }
+
+    //-----------------------------------------------------------------------
+    public void testEmptyBagSerialization() throws IOException, ClassNotFoundException {
+        final Bag<T> bag = makeObject();
+        if (!(bag instanceof Serializable && isTestSerialization())) {
+            return;
+        }
+
+        final byte[] objekt = writeExternalFormToBytes((Serializable) bag);
+        final Bag<?> bag2 = (Bag<?>) readExternalFormFromBytes(objekt);
+
+        assertEquals("Bag should be empty",0, bag.size());
+        assertEquals("Bag should be empty",0, bag2.size());
+    }
+
+    @SuppressWarnings("unchecked")
+    public void testFullBagSerialization() throws IOException, ClassNotFoundException {
+        final Bag<T> bag = makeObject();
+        bag.add((T) "A");
+        bag.add((T) "A");
+        bag.add((T) "B");
+        bag.add((T) "B");
+        bag.add((T) "C");
+        final int size = bag.size();
+        if (!(bag instanceof Serializable && isTestSerialization())) {
+            return;
+        }
+
+        final byte[] objekt = writeExternalFormToBytes((Serializable) bag);
+        final Bag<?> bag2 = (Bag<?>) readExternalFormFromBytes(objekt);
+
+        assertEquals("Bag should be same size", size, bag.size());
+        assertEquals("Bag should be same size", size, bag2.size());
+    }
+
+    /**
+     * Compare the current serialized form of the Bag
+     * against the canonical version in SVN.
+     */
+    public void testEmptyBagCompatibility() throws IOException, ClassNotFoundException {
+        // test to make sure the canonical form has been preserved
+        final Bag<T> bag = makeObject();
+        if (bag instanceof Serializable && !skipSerializedCanonicalTests() && isTestSerialization()) {
+            final Bag<?> bag2 = (Bag<?>) readExternalFormFromDisk(getCanonicalEmptyCollectionName(bag));
+            assertTrue("Bag is empty",bag2.size()  == 0);
+            assertEquals(bag, bag2);
+        }
+    }
+
+    /**
+     * Compare the current serialized form of the Bag
+     * against the canonical version in SVN.
+     */
+    @SuppressWarnings("unchecked")
+    public void testFullBagCompatibility() throws IOException, ClassNotFoundException {
+        // test to make sure the canonical form has been preserved
+        final Bag<T> bag = makeObject();
+        bag.add((T) "A");
+        bag.add((T) "A");
+        bag.add((T) "B");
+        bag.add((T) "B");
+        bag.add((T) "C");
+        if (bag instanceof Serializable && !skipSerializedCanonicalTests() && isTestSerialization()) {
+            final Bag<?> bag2 = (Bag<?>) readExternalFormFromDisk(getCanonicalFullCollectionName(bag));
+            assertEquals("Bag is the right size",bag.size(), bag2.size());
+            assertEquals(bag, bag2);
+        }
+    }
+
+}

Propchange: commons/proper/collections/trunk/src/test/java/org/apache/commons/collections4/bag/CompliantBagTest.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: commons/proper/collections/trunk/src/test/java/org/apache/commons/collections4/bag/CompliantBagTest.java
------------------------------------------------------------------------------
    svn:keywords = Id Revision HeadURL

Propchange: commons/proper/collections/trunk/src/test/java/org/apache/commons/collections4/bag/CompliantBagTest.java
------------------------------------------------------------------------------
    svn:mime-type = text/plain

Added: commons/proper/collections/trunk/src/test/resources/data/test/CompliantBag.emptyCollection.version4.obj
URL: http://svn.apache.org/viewvc/commons/proper/collections/trunk/src/test/resources/data/test/CompliantBag.emptyCollection.version4.obj?rev=1493938&view=auto
==============================================================================
Binary file - no diff available.

Propchange: commons/proper/collections/trunk/src/test/resources/data/test/CompliantBag.emptyCollection.version4.obj
------------------------------------------------------------------------------
    svn:mime-type = application/octet-stream

Added: commons/proper/collections/trunk/src/test/resources/data/test/CompliantBag.fullCollection.version4.obj
URL: http://svn.apache.org/viewvc/commons/proper/collections/trunk/src/test/resources/data/test/CompliantBag.fullCollection.version4.obj?rev=1493938&view=auto
==============================================================================
Binary file - no diff available.

Propchange: commons/proper/collections/trunk/src/test/resources/data/test/CompliantBag.fullCollection.version4.obj
------------------------------------------------------------------------------
    svn:mime-type = application/octet-stream