You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@cassandra.apache.org by sl...@apache.org on 2012/02/27 11:16:00 UTC

[8/28] [3649] Strip end of line whitespace

http://git-wip-us.apache.org/repos/asf/cassandra/blob/2fd3268b/test/unit/org/apache/cassandra/dht/RandomPartitionerTest.java
----------------------------------------------------------------------
diff --git a/test/unit/org/apache/cassandra/dht/RandomPartitionerTest.java b/test/unit/org/apache/cassandra/dht/RandomPartitionerTest.java
index 61e59d8..90501ab 100644
--- a/test/unit/org/apache/cassandra/dht/RandomPartitionerTest.java
+++ b/test/unit/org/apache/cassandra/dht/RandomPartitionerTest.java
@@ -1,6 +1,6 @@
 package org.apache.cassandra.dht;
 /*
- * 
+ *
  * 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
@@ -8,16 +8,16 @@ package org.apache.cassandra.dht;
  * 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.
- * 
+ *
  */
 
 public class RandomPartitionerTest extends PartitionerTestCase<BigIntegerToken>

http://git-wip-us.apache.org/repos/asf/cassandra/blob/2fd3268b/test/unit/org/apache/cassandra/gms/ArrivalWindowTest.java
----------------------------------------------------------------------
diff --git a/test/unit/org/apache/cassandra/gms/ArrivalWindowTest.java b/test/unit/org/apache/cassandra/gms/ArrivalWindowTest.java
index 0b38058..277cae1 100644
--- a/test/unit/org/apache/cassandra/gms/ArrivalWindowTest.java
+++ b/test/unit/org/apache/cassandra/gms/ArrivalWindowTest.java
@@ -1,6 +1,6 @@
 package org.apache.cassandra.gms;
 /*
- * 
+ *
  * 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
@@ -8,16 +8,16 @@ package org.apache.cassandra.gms;
  * 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.
- * 
+ *
  */
 
 
@@ -27,7 +27,7 @@ import org.junit.Test;
 
 public class ArrivalWindowTest
 {
-    
+
     @Test
     public void test()
     {
@@ -41,7 +41,7 @@ public class ArrivalWindowTest
 
         //all good
         assertEquals(0.4342, window.phi(666), 0.01);
-        
+
         //oh noes, a much higher timestamp, something went wrong!
         assertEquals(9.566, window.phi(3000), 0.01);
     }

http://git-wip-us.apache.org/repos/asf/cassandra/blob/2fd3268b/test/unit/org/apache/cassandra/gms/GossipDigestTest.java
----------------------------------------------------------------------
diff --git a/test/unit/org/apache/cassandra/gms/GossipDigestTest.java b/test/unit/org/apache/cassandra/gms/GossipDigestTest.java
index 46189af..4f3e8e4 100644
--- a/test/unit/org/apache/cassandra/gms/GossipDigestTest.java
+++ b/test/unit/org/apache/cassandra/gms/GossipDigestTest.java
@@ -1,6 +1,6 @@
 package org.apache.cassandra.gms;
 /*
- * 
+ *
  * 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
@@ -8,16 +8,16 @@ package org.apache.cassandra.gms;
  * 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.
- * 
+ *
  */
 
 
@@ -46,11 +46,11 @@ public class GossipDigestTest
         assertEquals(endpoint, expected.getEndpoint());
         assertEquals(generation, expected.getGeneration());
         assertEquals(maxVersion, expected.getMaxVersion());
-        
+
         //test the serialization and equals
         DataOutputBuffer output = new DataOutputBuffer();
         GossipDigest.serializer().serialize(expected, output, MessagingService.current_version);
-        
+
         ByteArrayInputStream input = new ByteArrayInputStream(output.getData(), 0, output.getLength());
         GossipDigest actual = GossipDigest.serializer().deserialize(new DataInputStream(input), MessagingService.current_version);
         assertEquals(0, expected.compareTo(actual));

http://git-wip-us.apache.org/repos/asf/cassandra/blob/2fd3268b/test/unit/org/apache/cassandra/gms/SerializationsTest.java
----------------------------------------------------------------------
diff --git a/test/unit/org/apache/cassandra/gms/SerializationsTest.java b/test/unit/org/apache/cassandra/gms/SerializationsTest.java
index b61c38a..0010465 100644
--- a/test/unit/org/apache/cassandra/gms/SerializationsTest.java
+++ b/test/unit/org/apache/cassandra/gms/SerializationsTest.java
@@ -1,6 +1,6 @@
 package org.apache.cassandra.gms;
 /*
- * 
+ *
  * 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
@@ -8,16 +8,16 @@ package org.apache.cassandra.gms;
  * 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.
- * 
+ *
  */
 
 
@@ -37,7 +37,7 @@ import java.util.Map;
 
 public class SerializationsTest extends AbstractSerializationsTester
 {
-    private void testEndpointStateWrite() throws IOException 
+    private void testEndpointStateWrite() throws IOException
     {
         DataOutputStream out = getOutput("gms.EndpointState.bin");
         HeartBeatState.serializer().serialize(Statics.HeartbeatSt, out, getVersion());
@@ -46,13 +46,13 @@ public class SerializationsTest extends AbstractSerializationsTester
         VersionedValue.serializer.serialize(Statics.vv1, out, getVersion());
         out.close();
     }
-    
+
     @Test
     public void testEndpointStateRead() throws IOException
     {
         if (EXECUTE_WRITES)
             testEndpointStateWrite();
-        
+
         DataInputStream in = getInput("gms.EndpointState.bin");
         assert HeartBeatState.serializer().deserialize(in, getVersion()) != null;
         assert EndpointState.serializer().deserialize(in, getVersion()) != null;
@@ -60,7 +60,7 @@ public class SerializationsTest extends AbstractSerializationsTester
         assert VersionedValue.serializer.deserialize(in, getVersion()) != null;
         in.close();
     }
-     
+
     private void testGossipDigestWrite() throws IOException
     {
         Map<InetAddress, EndpointState> states = new HashMap<InetAddress, EndpointState>();
@@ -69,7 +69,7 @@ public class SerializationsTest extends AbstractSerializationsTester
         GossipDigestAckMessage ack = new GossipDigestAckMessage(Statics.Digests, states);
         GossipDigestAck2Message ack2 = new GossipDigestAck2Message(states);
         GossipDigestSynMessage syn = new GossipDigestSynMessage("Not a real cluster name", Statics.Digests);
-        
+
         DataOutputStream out = getOutput("gms.Gossip.bin");
         for (GossipDigest gd : Statics.Digests)
             GossipDigest.serializer().serialize(gd, out, getVersion());
@@ -78,13 +78,13 @@ public class SerializationsTest extends AbstractSerializationsTester
         GossipDigestSynMessage.serializer().serialize(syn, out, getVersion());
         out.close();
     }
-    
+
     @Test
     public void testGossipDigestRead() throws IOException
     {
         if (EXECUTE_WRITES)
             testGossipDigestWrite();
-        
+
         int count = 0;
         DataInputStream in = getInput("gms.Gossip.bin");
         while (count < Statics.Digests.size())
@@ -94,7 +94,7 @@ public class SerializationsTest extends AbstractSerializationsTester
         assert GossipDigestSynMessage.serializer().deserialize(in, getVersion()) != null;
         in.close();
     }
-    
+
     private static class Statics
     {
         private static HeartBeatState HeartbeatSt = new HeartBeatState(101, 201);
@@ -103,7 +103,7 @@ public class SerializationsTest extends AbstractSerializationsTester
         private static VersionedValue vv0 = vvFact.load(23d);
         private static VersionedValue vv1 = vvFact.bootstrapping(StorageService.getPartitioner().getRandomToken());
         private static List<GossipDigest> Digests = new ArrayList<GossipDigest>();
-        
+
         {
             HeartbeatSt.updateHeartBeat();
             EndpointSt.addApplicationState(ApplicationState.LOAD, vv0);

http://git-wip-us.apache.org/repos/asf/cassandra/blob/2fd3268b/test/unit/org/apache/cassandra/hadoop/ColumnFamilyInputFormatTest.java
----------------------------------------------------------------------
diff --git a/test/unit/org/apache/cassandra/hadoop/ColumnFamilyInputFormatTest.java b/test/unit/org/apache/cassandra/hadoop/ColumnFamilyInputFormatTest.java
index ffe0aa6..d4261bf 100644
--- a/test/unit/org/apache/cassandra/hadoop/ColumnFamilyInputFormatTest.java
+++ b/test/unit/org/apache/cassandra/hadoop/ColumnFamilyInputFormatTest.java
@@ -1,6 +1,6 @@
 package org.apache.cassandra.hadoop;
 /*
- * 
+ *
  * 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
@@ -8,16 +8,16 @@ package org.apache.cassandra.hadoop;
  * 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.
- * 
+ *
  */
 
 

http://git-wip-us.apache.org/repos/asf/cassandra/blob/2fd3268b/test/unit/org/apache/cassandra/io/BloomFilterTrackerTest.java
----------------------------------------------------------------------
diff --git a/test/unit/org/apache/cassandra/io/BloomFilterTrackerTest.java b/test/unit/org/apache/cassandra/io/BloomFilterTrackerTest.java
index 29a1588..6bc3032 100644
--- a/test/unit/org/apache/cassandra/io/BloomFilterTrackerTest.java
+++ b/test/unit/org/apache/cassandra/io/BloomFilterTrackerTest.java
@@ -1,6 +1,6 @@
 package org.apache.cassandra.io;
 /*
- * 
+ *
  * 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
@@ -8,16 +8,16 @@ package org.apache.cassandra.io;
  * 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.
- * 
+ *
  */
 
 

http://git-wip-us.apache.org/repos/asf/cassandra/blob/2fd3268b/test/unit/org/apache/cassandra/io/CompactSerializerTest.java
----------------------------------------------------------------------
diff --git a/test/unit/org/apache/cassandra/io/CompactSerializerTest.java b/test/unit/org/apache/cassandra/io/CompactSerializerTest.java
index befb0d1..64d3980 100644
--- a/test/unit/org/apache/cassandra/io/CompactSerializerTest.java
+++ b/test/unit/org/apache/cassandra/io/CompactSerializerTest.java
@@ -1,6 +1,6 @@
 package org.apache.cassandra.io;
 /*
- * 
+ *
  * 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
@@ -8,16 +8,16 @@ package org.apache.cassandra.io;
  * 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.
- * 
+ *
  */
 
 
@@ -37,7 +37,7 @@ public class CompactSerializerTest extends CleanupHelper
 {
     private static Set<String> expectedClassNames;
     private static List<String> discoveredClassNames;
-    
+
     @BeforeClass
     public static void scanClasspath()
     {
@@ -71,14 +71,14 @@ public class CompactSerializerTest extends CleanupHelper
         expectedClassNames.add("StreamingRepairTaskSerializer");
         expectedClassNames.add("AbstractBoundsSerializer");
         expectedClassNames.add("SnapshotCommandSerializer");
-        
+
         discoveredClassNames = new ArrayList<String>();
         String cp = System.getProperty("java.class.path");
         assert cp != null;
         String[] parts = cp.split(File.pathSeparator, -1);
-        class DirScanner 
+        class DirScanner
         {
-            void scan(File f, String ctx) 
+            void scan(File f, String ctx)
             {
                 String newCtx = ctx == null ? f.getName().equals("org") ? f.getName() : null : ctx + "." + f.getName();
                 if (f.isDirectory())
@@ -114,14 +114,14 @@ public class CompactSerializerTest extends CleanupHelper
                             cls = cls.getSuperclass();
                         }
                     }
-                    catch (ClassNotFoundException ex) 
+                    catch (ClassNotFoundException ex)
                     {
                         throw new RuntimeException(ex);
                     }
                 }
             }
         }
-        
+
         DirScanner dirScanner = new DirScanner();
         for (String cpItem : parts)
         {
@@ -130,7 +130,7 @@ public class CompactSerializerTest extends CleanupHelper
                 dirScanner.scan(f, null);
         }
     }
-    
+
     /** look for classes I expect to find. */
     @Test
     public void verifyAllSimpleNamesTest()
@@ -138,7 +138,7 @@ public class CompactSerializerTest extends CleanupHelper
         for (String clsName : expectedClassNames)
             assert discoveredClassNames.contains(clsName) : clsName + " was not discovered";
     }
-    
+
     /** look for classes I do not expect to find. */
     @Test
     public void noOthersTest()

http://git-wip-us.apache.org/repos/asf/cassandra/blob/2fd3268b/test/unit/org/apache/cassandra/io/LazilyCompactedRowTest.java
----------------------------------------------------------------------
diff --git a/test/unit/org/apache/cassandra/io/LazilyCompactedRowTest.java b/test/unit/org/apache/cassandra/io/LazilyCompactedRowTest.java
index 94e2316..1704248 100644
--- a/test/unit/org/apache/cassandra/io/LazilyCompactedRowTest.java
+++ b/test/unit/org/apache/cassandra/io/LazilyCompactedRowTest.java
@@ -1,6 +1,6 @@
 package org.apache.cassandra.io;
 /*
- * 
+ *
  * 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
@@ -8,16 +8,16 @@ package org.apache.cassandra.io;
  * 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.
- * 
+ *
  */
 
 

http://git-wip-us.apache.org/repos/asf/cassandra/blob/2fd3268b/test/unit/org/apache/cassandra/io/sstable/DescriptorTest.java
----------------------------------------------------------------------
diff --git a/test/unit/org/apache/cassandra/io/sstable/DescriptorTest.java b/test/unit/org/apache/cassandra/io/sstable/DescriptorTest.java
index 31170b9..525ecde 100644
--- a/test/unit/org/apache/cassandra/io/sstable/DescriptorTest.java
+++ b/test/unit/org/apache/cassandra/io/sstable/DescriptorTest.java
@@ -1,6 +1,6 @@
 package org.apache.cassandra.io.sstable;
 /*
- * 
+ *
  * 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
@@ -8,16 +8,16 @@ package org.apache.cassandra.io.sstable;
  * 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.
- * 
+ *
  */
 
 

http://git-wip-us.apache.org/repos/asf/cassandra/blob/2fd3268b/test/unit/org/apache/cassandra/io/sstable/SSTableReaderTest.java
----------------------------------------------------------------------
diff --git a/test/unit/org/apache/cassandra/io/sstable/SSTableReaderTest.java b/test/unit/org/apache/cassandra/io/sstable/SSTableReaderTest.java
index c538219..fede053 100644
--- a/test/unit/org/apache/cassandra/io/sstable/SSTableReaderTest.java
+++ b/test/unit/org/apache/cassandra/io/sstable/SSTableReaderTest.java
@@ -1,6 +1,6 @@
 package org.apache.cassandra.io.sstable;
 /*
- * 
+ *
  * 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
@@ -8,16 +8,16 @@ package org.apache.cassandra.io.sstable;
  * 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.
- * 
+ *
  */
 
 

http://git-wip-us.apache.org/repos/asf/cassandra/blob/2fd3268b/test/unit/org/apache/cassandra/locator/EC2SnitchTest.java
----------------------------------------------------------------------
diff --git a/test/unit/org/apache/cassandra/locator/EC2SnitchTest.java b/test/unit/org/apache/cassandra/locator/EC2SnitchTest.java
index fad5e9e..a72069a 100644
--- a/test/unit/org/apache/cassandra/locator/EC2SnitchTest.java
+++ b/test/unit/org/apache/cassandra/locator/EC2SnitchTest.java
@@ -1,6 +1,6 @@
 package org.apache.cassandra.locator;
 /*
- * 
+ *
  * 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
@@ -8,16 +8,16 @@ package org.apache.cassandra.locator;
  * 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.
- * 
+ *
  */
 
 
@@ -57,15 +57,15 @@ public class EC2SnitchTest
         Ec2Snitch snitch = new TestEC2Snitch();
         InetAddress local = InetAddress.getByName("127.0.0.1");
         InetAddress nonlocal = InetAddress.getByName("127.0.0.7");
-        
+
         Gossiper.instance.addSavedEndpoint(nonlocal);
         Map<ApplicationState,VersionedValue> stateMap = Gossiper.instance.getEndpointStateForEndpoint(nonlocal).getApplicationStateMap();
         stateMap.put(ApplicationState.DC, StorageService.instance.valueFactory.datacenter("us-west"));
         stateMap.put(ApplicationState.RACK, StorageService.instance.valueFactory.datacenter("1a"));
-        
+
         assertEquals("us-west", snitch.getDatacenter(nonlocal));
         assertEquals("1a", snitch.getRack(nonlocal));
-        
+
         assertEquals("us-east", snitch.getDatacenter(local));
         assertEquals("1d", snitch.getRack(local));
     }

http://git-wip-us.apache.org/repos/asf/cassandra/blob/2fd3268b/test/unit/org/apache/cassandra/locator/SimpleStrategyTest.java
----------------------------------------------------------------------
diff --git a/test/unit/org/apache/cassandra/locator/SimpleStrategyTest.java b/test/unit/org/apache/cassandra/locator/SimpleStrategyTest.java
index 78f9022..027469f 100644
--- a/test/unit/org/apache/cassandra/locator/SimpleStrategyTest.java
+++ b/test/unit/org/apache/cassandra/locator/SimpleStrategyTest.java
@@ -103,7 +103,7 @@ public class SimpleStrategyTest extends CleanupHelper
             }
         }
     }
-    
+
     @Test
     public void testGetEndpointsDuringBootstrap() throws UnknownHostException, ConfigurationException
     {
@@ -114,13 +114,13 @@ public class SimpleStrategyTest extends CleanupHelper
 
         Token[] endpointTokens = new Token[RING_SIZE];
         Token[] keyTokens = new Token[RING_SIZE];
-        
+
         for (int i = 0; i < RING_SIZE; i++)
         {
             endpointTokens[i] = new BigIntegerToken(String.valueOf(RING_SIZE * 2 * i));
             keyTokens[i] = new BigIntegerToken(String.valueOf(RING_SIZE * 2 * i + RING_SIZE));
         }
-        
+
         List<InetAddress> hosts = new ArrayList<InetAddress>();
         for (int i = 0; i < endpointTokens.length; i++)
         {

http://git-wip-us.apache.org/repos/asf/cassandra/blob/2fd3268b/test/unit/org/apache/cassandra/net/MessageSerializer.java
----------------------------------------------------------------------
diff --git a/test/unit/org/apache/cassandra/net/MessageSerializer.java b/test/unit/org/apache/cassandra/net/MessageSerializer.java
index f14200a..8efb51e 100644
--- a/test/unit/org/apache/cassandra/net/MessageSerializer.java
+++ b/test/unit/org/apache/cassandra/net/MessageSerializer.java
@@ -1,6 +1,6 @@
 package org.apache.cassandra.net;
 /*
- * 
+ *
  * 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
@@ -8,16 +8,16 @@ package org.apache.cassandra.net;
  * 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.
- * 
+ *
  */
 
 

http://git-wip-us.apache.org/repos/asf/cassandra/blob/2fd3268b/test/unit/org/apache/cassandra/service/AntiEntropyServiceCounterTest.java
----------------------------------------------------------------------
diff --git a/test/unit/org/apache/cassandra/service/AntiEntropyServiceCounterTest.java b/test/unit/org/apache/cassandra/service/AntiEntropyServiceCounterTest.java
index d00f025..af876fc 100644
--- a/test/unit/org/apache/cassandra/service/AntiEntropyServiceCounterTest.java
+++ b/test/unit/org/apache/cassandra/service/AntiEntropyServiceCounterTest.java
@@ -1,6 +1,6 @@
 package org.apache.cassandra.service;
 /*
- * 
+ *
  * 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
@@ -8,16 +8,16 @@ package org.apache.cassandra.service;
  * 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.
- * 
+ *
  */
 
 import java.util.List;

http://git-wip-us.apache.org/repos/asf/cassandra/blob/2fd3268b/test/unit/org/apache/cassandra/service/AntiEntropyServiceStandardTest.java
----------------------------------------------------------------------
diff --git a/test/unit/org/apache/cassandra/service/AntiEntropyServiceStandardTest.java b/test/unit/org/apache/cassandra/service/AntiEntropyServiceStandardTest.java
index 1feac41..f419c37 100644
--- a/test/unit/org/apache/cassandra/service/AntiEntropyServiceStandardTest.java
+++ b/test/unit/org/apache/cassandra/service/AntiEntropyServiceStandardTest.java
@@ -1,6 +1,6 @@
 package org.apache.cassandra.service;
 /*
- * 
+ *
  * 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
@@ -8,16 +8,16 @@ package org.apache.cassandra.service;
  * 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.
- * 
+ *
  */
 
 import java.util.List;

http://git-wip-us.apache.org/repos/asf/cassandra/blob/2fd3268b/test/unit/org/apache/cassandra/service/AntiEntropyServiceTestAbstract.java
----------------------------------------------------------------------
diff --git a/test/unit/org/apache/cassandra/service/AntiEntropyServiceTestAbstract.java b/test/unit/org/apache/cassandra/service/AntiEntropyServiceTestAbstract.java
index f06d769..9a9e459 100644
--- a/test/unit/org/apache/cassandra/service/AntiEntropyServiceTestAbstract.java
+++ b/test/unit/org/apache/cassandra/service/AntiEntropyServiceTestAbstract.java
@@ -129,7 +129,7 @@ public abstract class AntiEntropyServiceTestAbstract extends CleanupHelper
         // and confirm that the tree was split
         assertTrue(validator.tree.size() > 1);
     }
-    
+
     @Test
     public void testValidatorComplete() throws Throwable
     {
@@ -230,7 +230,7 @@ public abstract class AntiEntropyServiceTestAbstract extends CleanupHelper
         AntiEntropyService.TreeResponse r2 = new AntiEntropyService.TreeResponse(REMOTE, rtree);
         AntiEntropyService.RepairSession.Differencer diff = sess.session.new Differencer(cfname, r1, r2);
         diff.run();
-        
+
         // ensure that the changed range was recorded
         assertEquals("Wrong differing ranges", interesting, new HashSet<Range>(diff.differences));
     }
@@ -258,7 +258,7 @@ public abstract class AntiEntropyServiceTestAbstract extends CleanupHelper
                 return true;
             }
         };
-        
+
         // send two tasks through the stage: one to follow existing tasks and a second to follow tasks created by
         // those existing tasks: tasks won't recursively create more tasks
         stage.submit(noop).get(5000, TimeUnit.MILLISECONDS);

http://git-wip-us.apache.org/repos/asf/cassandra/blob/2fd3268b/test/unit/org/apache/cassandra/service/EmbeddedCassandraServiceTest.java
----------------------------------------------------------------------
diff --git a/test/unit/org/apache/cassandra/service/EmbeddedCassandraServiceTest.java b/test/unit/org/apache/cassandra/service/EmbeddedCassandraServiceTest.java
index 1e55516..701dee5 100644
--- a/test/unit/org/apache/cassandra/service/EmbeddedCassandraServiceTest.java
+++ b/test/unit/org/apache/cassandra/service/EmbeddedCassandraServiceTest.java
@@ -74,7 +74,7 @@ public class EmbeddedCassandraServiceTest extends CleanupHelper
         client.set_keyspace("Keyspace1");
 
         ByteBuffer key_user_id = ByteBufferUtil.bytes("1");
-        
+
         long timestamp = System.currentTimeMillis();
         ColumnPath cp = new ColumnPath("Standard1");
         ColumnParent par = new ColumnParent("Standard1");

http://git-wip-us.apache.org/repos/asf/cassandra/blob/2fd3268b/test/unit/org/apache/cassandra/service/InitClientTest.java
----------------------------------------------------------------------
diff --git a/test/unit/org/apache/cassandra/service/InitClientTest.java b/test/unit/org/apache/cassandra/service/InitClientTest.java
index 0047efe..a248ca7 100644
--- a/test/unit/org/apache/cassandra/service/InitClientTest.java
+++ b/test/unit/org/apache/cassandra/service/InitClientTest.java
@@ -14,7 +14,7 @@ import org.apache.cassandra.config.ConfigurationException;
  * 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

http://git-wip-us.apache.org/repos/asf/cassandra/blob/2fd3268b/test/unit/org/apache/cassandra/service/RowResolverTest.java
----------------------------------------------------------------------
diff --git a/test/unit/org/apache/cassandra/service/RowResolverTest.java b/test/unit/org/apache/cassandra/service/RowResolverTest.java
index fdf7ad4..caacfa0 100644
--- a/test/unit/org/apache/cassandra/service/RowResolverTest.java
+++ b/test/unit/org/apache/cassandra/service/RowResolverTest.java
@@ -1,6 +1,6 @@
 package org.apache.cassandra.service;
 /*
- * 
+ *
  * 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
@@ -8,16 +8,16 @@ package org.apache.cassandra.service;
  * 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.
- * 
+ *
  */
 
 

http://git-wip-us.apache.org/repos/asf/cassandra/blob/2fd3268b/test/unit/org/apache/cassandra/service/SerializationsTest.java
----------------------------------------------------------------------
diff --git a/test/unit/org/apache/cassandra/service/SerializationsTest.java b/test/unit/org/apache/cassandra/service/SerializationsTest.java
index 5ee32d5..88de571 100644
--- a/test/unit/org/apache/cassandra/service/SerializationsTest.java
+++ b/test/unit/org/apache/cassandra/service/SerializationsTest.java
@@ -1,6 +1,6 @@
 package org.apache.cassandra.service;
 /*
- * 
+ *
  * 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
@@ -8,16 +8,16 @@ package org.apache.cassandra.service;
  * 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.
- * 
+ *
  */
 
 
@@ -51,19 +51,19 @@ public class SerializationsTest extends AbstractSerializationsTester
         messageSerializer.serialize(AntiEntropyService.TreeRequestVerbHandler.makeVerb(Statics.req, getVersion()), out, getVersion());
         out.close();
     }
-    
+
     @Test
     public void testTreeRequestRead() throws IOException
     {
         if (EXECUTE_WRITES)
             testTreeRequestWrite();
-        
+
         DataInputStream in = getInput("service.TreeRequest.bin");
         assert AntiEntropyService.TreeRequestVerbHandler.SERIALIZER.deserialize(in, getVersion()) != null;
         assert messageSerializer.deserialize(in, getVersion()) != null;
         in.close();
     }
-    
+
     private void testTreeResponseWrite() throws IOException
     {
         AntiEntropyService.Validator v0 = new AntiEntropyService.Validator(Statics.req);
@@ -84,13 +84,13 @@ public class SerializationsTest extends AbstractSerializationsTester
         messageSerializer.serialize(AntiEntropyService.TreeResponseVerbHandler.makeVerb(FBUtilities.getBroadcastAddress(), v1), out, getVersion());
         out.close();
     }
-    
+
     @Test
     public void testTreeResponseRead() throws IOException
     {
         if (EXECUTE_WRITES)
             testTreeResponseWrite();
-        
+
         DataInputStream in = getInput("service.TreeResponse.bin");
         assert AntiEntropyService.TreeResponseVerbHandler.SERIALIZER.deserialize(in, getVersion()) != null;
         assert AntiEntropyService.TreeResponseVerbHandler.SERIALIZER.deserialize(in, getVersion()) != null;
@@ -98,7 +98,7 @@ public class SerializationsTest extends AbstractSerializationsTester
         assert messageSerializer.deserialize(in, getVersion()) != null;
         in.close();
     }
-    
+
     private static class Statics
     {
         private static final AntiEntropyService.CFPair pair = new AntiEntropyService.CFPair("Keyspace1", "Standard1");

http://git-wip-us.apache.org/repos/asf/cassandra/blob/2fd3268b/test/unit/org/apache/cassandra/streaming/SerializationsTest.java
----------------------------------------------------------------------
diff --git a/test/unit/org/apache/cassandra/streaming/SerializationsTest.java b/test/unit/org/apache/cassandra/streaming/SerializationsTest.java
index 5ee1294..d549457 100644
--- a/test/unit/org/apache/cassandra/streaming/SerializationsTest.java
+++ b/test/unit/org/apache/cassandra/streaming/SerializationsTest.java
@@ -1,6 +1,6 @@
 package org.apache.cassandra.streaming;
 /*
- * 
+ *
  * 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
@@ -8,16 +8,16 @@ package org.apache.cassandra.streaming;
  * 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.
- * 
+ *
  */
 
 
@@ -62,13 +62,13 @@ public class SerializationsTest extends AbstractSerializationsTester
         PendingFile.serializer().serialize(null, out, getVersion());
         out.close();
     }
-    
+
     @Test
     public void testPendingFileRead() throws IOException
     {
         if (EXECUTE_WRITES)
             testPendingFileWrite();
-        
+
         DataInputStream in = getInput("streaming.PendingFile.bin");
         assert PendingFile.serializer().deserialize(in, getVersion()) != null;
         assert PendingFile.serializer().deserialize(in, getVersion()) != null;
@@ -76,7 +76,7 @@ public class SerializationsTest extends AbstractSerializationsTester
         assert PendingFile.serializer().deserialize(in, getVersion()) == null;
         in.close();
     }
-    
+
     private void testStreamHeaderWrite() throws IOException
     {
         StreamHeader sh0 = new StreamHeader("Keyspace1", 123L, makePendingFile(true, 100, OperationType.BOOTSTRAP));
@@ -96,13 +96,13 @@ public class SerializationsTest extends AbstractSerializationsTester
         StreamHeader.serializer().serialize(sh4, out, getVersion());
         out.close();
     }
-    
+
     @Test
     public void testStreamHeaderRead() throws IOException
     {
         if (EXECUTE_WRITES)
             testStreamHeaderWrite();
-        
+
         DataInputStream in = getInput("streaming.StreamHeader.bin");
         assert StreamHeader.serializer().deserialize(in, getVersion()) != null;
         assert StreamHeader.serializer().deserialize(in, getVersion()) != null;
@@ -111,7 +111,7 @@ public class SerializationsTest extends AbstractSerializationsTester
         assert StreamHeader.serializer().deserialize(in, getVersion()) != null;
         in.close();
     }
-    
+
     private void testStreamReplyWrite() throws IOException
     {
         StreamReply rep = new StreamReply("this is a file", 123L, StreamReply.Status.FILE_FINISHED);
@@ -120,19 +120,19 @@ public class SerializationsTest extends AbstractSerializationsTester
         messageSerializer.serialize(rep.getMessage(getVersion()), out, getVersion());
         out.close();
     }
-    
+
     @Test
     public void testStreamReplyRead() throws IOException
     {
         if (EXECUTE_WRITES)
             testStreamReplyWrite();
-        
+
         DataInputStream in = getInput("streaming.StreamReply.bin");
         assert StreamReply.serializer.deserialize(in, getVersion()) != null;
         assert messageSerializer.deserialize(in, getVersion()) != null;
         in.close();
     }
-    
+
     private static PendingFile makePendingFile(boolean sst, int numSecs, OperationType op)
     {
         Descriptor desc = new Descriptor("z", new File("path/doesn't/matter"), "Keyspace1", "Standard1", 23, false);
@@ -141,7 +141,7 @@ public class SerializationsTest extends AbstractSerializationsTester
             sections.add(new Pair<Long, Long>(new Long(i), new Long(i * i)));
         return new PendingFile(sst ? makeSSTable() : null, desc, SSTable.COMPONENT_DATA, sections, op);
     }
-    
+
     private void testStreamRequestMessageWrite() throws IOException
     {
         Collection<Range<Token>> ranges = new ArrayList<Range<Token>>();
@@ -161,13 +161,13 @@ public class SerializationsTest extends AbstractSerializationsTester
         messageSerializer.serialize(msg2.getMessage(getVersion()), out, getVersion());
         out.close();
     }
-    
+
     @Test
     public void testStreamRequestMessageRead() throws IOException
     {
         if (EXECUTE_WRITES)
             testStreamRequestMessageWrite();
-        
+
         DataInputStream in = getInput("streaming.StreamRequestMessage.bin");
         assert StreamRequestMessage.serializer().deserialize(in, getVersion()) != null;
         assert StreamRequestMessage.serializer().deserialize(in, getVersion()) != null;
@@ -177,7 +177,7 @@ public class SerializationsTest extends AbstractSerializationsTester
         assert messageSerializer.deserialize(in, getVersion()) != null;
         in.close();
     }
-    
+
     private static SSTableReader makeSSTable()
     {
         Table t = Table.open("Keyspace1");
@@ -189,7 +189,7 @@ public class SerializationsTest extends AbstractSerializationsTester
             {
                 rm.apply();
             }
-            catch (IOException ex) 
+            catch (IOException ex)
             {
                 throw new RuntimeException(ex);
             }

http://git-wip-us.apache.org/repos/asf/cassandra/blob/2fd3268b/test/unit/org/apache/cassandra/streaming/StreamUtil.java
----------------------------------------------------------------------
diff --git a/test/unit/org/apache/cassandra/streaming/StreamUtil.java b/test/unit/org/apache/cassandra/streaming/StreamUtil.java
index c71c9d7..66264ca 100644
--- a/test/unit/org/apache/cassandra/streaming/StreamUtil.java
+++ b/test/unit/org/apache/cassandra/streaming/StreamUtil.java
@@ -33,7 +33,7 @@ public class StreamUtil
      * Takes an stream request message and creates an empty status response. Exists here because StreamRequestMessage
      * is package protected.
      */
-    static public void finishStreamRequest(Message msg, InetAddress to) 
+    static public void finishStreamRequest(Message msg, InetAddress to)
     {
         byte[] body = msg.getMessageBody();
         ByteArrayInputStream bufIn = new ByteArrayInputStream(body);
@@ -46,7 +46,7 @@ public class StreamUtil
         }
         catch (Exception e)
         {
-            System.err.println(e); 
+            System.err.println(e);
             e.printStackTrace();
         }
     }

http://git-wip-us.apache.org/repos/asf/cassandra/blob/2fd3268b/test/unit/org/apache/cassandra/streaming/StreamingTransferTest.java
----------------------------------------------------------------------
diff --git a/test/unit/org/apache/cassandra/streaming/StreamingTransferTest.java b/test/unit/org/apache/cassandra/streaming/StreamingTransferTest.java
index 130b8c8..6d720a1 100644
--- a/test/unit/org/apache/cassandra/streaming/StreamingTransferTest.java
+++ b/test/unit/org/apache/cassandra/streaming/StreamingTransferTest.java
@@ -104,7 +104,7 @@ public class StreamingTransferTest extends CleanupHelper
 
         // and that the max timestamp for the file was rediscovered
         assertEquals(timestamp, cfs.getSSTables().iterator().next().getMaxTimestamp());
-        
+
         List<String> keys = new ArrayList<String>();
         for (int off : offs)
             keys.add("key" + off);
@@ -129,7 +129,7 @@ public class StreamingTransferTest extends CleanupHelper
     {
         final Table table = Table.open("Keyspace1");
         final ColumnFamilyStore cfs = table.getColumnFamilyStore("Indexed1");
-        
+
         List<String> keys = createAndTransfer(table, cfs, new Mutator()
         {
             public void mutate(String key, String col, long timestamp) throws Exception
@@ -167,7 +167,7 @@ public class StreamingTransferTest extends CleanupHelper
     {
         final Table table = Table.open("Keyspace1");
         final ColumnFamilyStore cfs = table.getColumnFamilyStore("Super1");
-        
+
         createAndTransfer(table, cfs, new Mutator()
         {
             public void mutate(String key, String col, long timestamp) throws Exception
@@ -185,7 +185,7 @@ public class StreamingTransferTest extends CleanupHelper
         final Table table = Table.open("Keyspace1");
         final ColumnFamilyStore cfs = table.getColumnFamilyStore("Counter1");
         final CounterContext cc = new CounterContext();
-        
+
         final Map<String, ColumnFamily> cleanedEntries = new HashMap<String, ColumnFamily>();
 
         List<String> keys = createAndTransfer(table, cfs, new Mutator()

http://git-wip-us.apache.org/repos/asf/cassandra/blob/2fd3268b/test/unit/org/apache/cassandra/thrift/ThriftValidationTest.java
----------------------------------------------------------------------
diff --git a/test/unit/org/apache/cassandra/thrift/ThriftValidationTest.java b/test/unit/org/apache/cassandra/thrift/ThriftValidationTest.java
index e550144..2ab7202 100644
--- a/test/unit/org/apache/cassandra/thrift/ThriftValidationTest.java
+++ b/test/unit/org/apache/cassandra/thrift/ThriftValidationTest.java
@@ -1,6 +1,6 @@
 package org.apache.cassandra.thrift;
 /*
- * 
+ *
  * 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
@@ -8,16 +8,16 @@ package org.apache.cassandra.thrift;
  * 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.
- * 
+ *
  */
 
 

http://git-wip-us.apache.org/repos/asf/cassandra/blob/2fd3268b/test/unit/org/apache/cassandra/tools/SSTableExportTest.java
----------------------------------------------------------------------
diff --git a/test/unit/org/apache/cassandra/tools/SSTableExportTest.java b/test/unit/org/apache/cassandra/tools/SSTableExportTest.java
index ee24124..7aa43fe 100644
--- a/test/unit/org/apache/cassandra/tools/SSTableExportTest.java
+++ b/test/unit/org/apache/cassandra/tools/SSTableExportTest.java
@@ -62,24 +62,24 @@ public class SSTableExportTest extends SchemaLoader
         File tempSS = tempSSTableFile("Keyspace1", "Standard1");
         ColumnFamily cfamily = ColumnFamily.create("Keyspace1", "Standard1");
         SSTableWriter writer = new SSTableWriter(tempSS.getPath(), 2);
-        
+
         // Add rowA
         cfamily.addColumn(new QueryPath("Standard1", null, ByteBufferUtil.bytes("colA")), ByteBufferUtil.bytes("valA"), System.currentTimeMillis());
         writer.append(Util.dk("rowA"), cfamily);
         cfamily.clear();
-        
+
         // Add rowB
         cfamily.addColumn(new QueryPath("Standard1", null, ByteBufferUtil.bytes("colB")), ByteBufferUtil.bytes("valB"), System.currentTimeMillis());
         writer.append(Util.dk("rowB"), cfamily);
         cfamily.clear();
-     
+
         writer.closeAndOpenReader();
-        
+
         // Enumerate and verify
         File temp = File.createTempFile("Standard1", ".txt");
         SSTableExport.enumeratekeys(writer.getFilename(), new PrintStream(temp.getPath()));
 
-        
+
         FileReader file = new FileReader(temp);
         char[] buf = new char[(int) temp.length()];
         file.read(buf);
@@ -95,14 +95,14 @@ public class SSTableExportTest extends SchemaLoader
         File tempSS = tempSSTableFile("Keyspace1", "Standard1");
         ColumnFamily cfamily = ColumnFamily.create("Keyspace1", "Standard1");
         SSTableWriter writer = new SSTableWriter(tempSS.getPath(), 2);
-        
+
         int nowInSec = (int)(System.currentTimeMillis() / 1000) + 42; //live for 42 seconds
         // Add rowA
         cfamily.addColumn(new QueryPath("Standard1", null, ByteBufferUtil.bytes("colA")), ByteBufferUtil.bytes("valA"), System.currentTimeMillis());
         cfamily.addColumn(null, new ExpiringColumn(ByteBufferUtil.bytes("colExp"), ByteBufferUtil.bytes("valExp"), System.currentTimeMillis(), 42, nowInSec));
         writer.append(Util.dk("rowA"), cfamily);
         cfamily.clear();
-        
+
         // Add rowB
         cfamily.addColumn(new QueryPath("Standard1", null, ByteBufferUtil.bytes("colB")), ByteBufferUtil.bytes("valB"), System.currentTimeMillis());
         writer.append(Util.dk("rowB"), cfamily);
@@ -114,13 +114,13 @@ public class SSTableExportTest extends SchemaLoader
         cfamily.clear();
 
         SSTableReader reader = writer.closeAndOpenReader();
-        
+
         // Export to JSON and verify
         File tempJson = File.createTempFile("Standard1", ".json");
         SSTableExport.export(reader, new PrintStream(tempJson.getPath()), new String[]{asHex("rowExclude")});
-        
+
         JSONObject json = (JSONObject)JSONValue.parse(new FileReader(tempJson));
-        
+
         JSONArray rowA = (JSONArray)json.get(asHex("rowA"));
         JSONArray colA = (JSONArray)rowA.get(0);
         assert hexToBytes((String)colA.get(1)).equals(ByteBufferUtil.bytes("valA"));
@@ -128,7 +128,7 @@ public class SSTableExportTest extends SchemaLoader
         JSONArray colExp = (JSONArray)rowA.get(1);
         assert ((Long)colExp.get(4)) == 42;
         assert ((Long)colExp.get(5)) == nowInSec;
-        
+
         JSONArray rowB = (JSONArray)json.get(asHex("rowB"));
         JSONArray colB = (JSONArray)rowB.get(0);
         assert colB.size() == 3;
@@ -143,12 +143,12 @@ public class SSTableExportTest extends SchemaLoader
         File tempSS = tempSSTableFile("Keyspace1", "Super4");
         ColumnFamily cfamily = ColumnFamily.create("Keyspace1", "Super4");
         SSTableWriter writer = new SSTableWriter(tempSS.getPath(), 2);
-        
+
         // Add rowA
         cfamily.addColumn(new QueryPath("Super4", ByteBufferUtil.bytes("superA"), ByteBufferUtil.bytes("colA")), ByteBufferUtil.bytes("valA"), System.currentTimeMillis());
         writer.append(Util.dk("rowA"), cfamily);
         cfamily.clear();
-        
+
         // Add rowB
         cfamily.addColumn(new QueryPath("Super4", ByteBufferUtil.bytes("superB"), ByteBufferUtil.bytes("colB")), ByteBufferUtil.bytes("valB"), System.currentTimeMillis());
         writer.append(Util.dk("rowB"), cfamily);
@@ -160,13 +160,13 @@ public class SSTableExportTest extends SchemaLoader
         cfamily.clear();
 
         SSTableReader reader = writer.closeAndOpenReader();
-        
+
         // Export to JSON and verify
         File tempJson = File.createTempFile("Super4", ".json");
         SSTableExport.export(reader, new PrintStream(tempJson.getPath()), new String[]{asHex("rowExclude")});
-        
+
         JSONObject json = (JSONObject)JSONValue.parse(new FileReader(tempJson));
-        
+
         JSONObject rowA = (JSONObject)json.get(asHex("rowA"));
         JSONObject superA = (JSONObject)rowA.get(cfamily.getComparator().getString(ByteBufferUtil.bytes("superA")));
         JSONArray subColumns = (JSONArray)superA.get("subColumns");
@@ -176,14 +176,14 @@ public class SSTableExportTest extends SchemaLoader
         assert colA.size() == 3;
         assert rowExclude == null;
     }
-    
+
     @Test
     public void testRoundTripStandardCf() throws IOException, ParseException
     {
         File tempSS = tempSSTableFile("Keyspace1", "Standard1");
         ColumnFamily cfamily = ColumnFamily.create("Keyspace1", "Standard1");
         SSTableWriter writer = new SSTableWriter(tempSS.getPath(), 2);
-        
+
         // Add rowA
         cfamily.addColumn(new QueryPath("Standard1", null, ByteBufferUtil.bytes("name")), ByteBufferUtil.bytes("val"), System.currentTimeMillis());
         writer.append(Util.dk("rowA"), cfamily);
@@ -195,11 +195,11 @@ public class SSTableExportTest extends SchemaLoader
         cfamily.clear();
 
         SSTableReader reader = writer.closeAndOpenReader();
-        
+
         // Export to JSON and verify
         File tempJson = File.createTempFile("Standard1", ".json");
         SSTableExport.export(reader, new PrintStream(tempJson.getPath()), new String[]{asHex("rowExclude")});
-        
+
         // Import JSON to another SSTable file
         File tempSS2 = tempSSTableFile("Keyspace1", "Standard1");
         SSTableImport.importJson(tempJson.getPath(), "Keyspace1", "Standard1", tempSS2.getPath());

http://git-wip-us.apache.org/repos/asf/cassandra/blob/2fd3268b/test/unit/org/apache/cassandra/tools/SSTableImportTest.java
----------------------------------------------------------------------
diff --git a/test/unit/org/apache/cassandra/tools/SSTableImportTest.java b/test/unit/org/apache/cassandra/tools/SSTableImportTest.java
index aca395e..a092511 100644
--- a/test/unit/org/apache/cassandra/tools/SSTableImportTest.java
+++ b/test/unit/org/apache/cassandra/tools/SSTableImportTest.java
@@ -48,7 +48,7 @@ import org.json.simple.parser.ParseException;
 import org.junit.Test;
 
 public class SSTableImportTest extends SchemaLoader
-{   
+{
     @Test
     public void testImportSimpleCf() throws IOException, URISyntaxException
     {
@@ -106,7 +106,7 @@ public class SSTableImportTest extends SchemaLoader
         String jsonUrl = resourcePath("SuperCF.json");
         File tempSS = tempSSTableFile("Keyspace1", "Super4");
         SSTableImport.importJson(jsonUrl, "Keyspace1", "Super4", tempSS.getPath());
-        
+
         // Verify results
         SSTableReader reader = SSTableReader.open(Descriptor.fromFilename(tempSS.getPath()));
         QueryFilter qf = QueryFilter.getNamesFilter(Util.dk("rowA"), new QueryPath("Super4", null, null), ByteBufferUtil.bytes("superA"));

http://git-wip-us.apache.org/repos/asf/cassandra/blob/2fd3268b/test/unit/org/apache/cassandra/utils/BoundedStatsDequeTest.java
----------------------------------------------------------------------
diff --git a/test/unit/org/apache/cassandra/utils/BoundedStatsDequeTest.java b/test/unit/org/apache/cassandra/utils/BoundedStatsDequeTest.java
index 9ead13c..fabb462 100644
--- a/test/unit/org/apache/cassandra/utils/BoundedStatsDequeTest.java
+++ b/test/unit/org/apache/cassandra/utils/BoundedStatsDequeTest.java
@@ -1,6 +1,6 @@
 package org.apache.cassandra.utils;
 /*
- * 
+ *
  * 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
@@ -8,16 +8,16 @@ package org.apache.cassandra.utils;
  * 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.
- * 
+ *
  */
 
 
@@ -34,7 +34,7 @@ public class BoundedStatsDequeTest
     public void test()
     {
         int size = 4;
-        
+
         BoundedStatsDeque bsd = new BoundedStatsDeque(size);
         //check the values for an empty result
         assertEquals(0, bsd.size());
@@ -43,13 +43,13 @@ public class BoundedStatsDequeTest
         assertEquals(Double.NaN, bsd.variance(), 0.001d);
         assertEquals(Double.NaN, bsd.stdev(), 0.001d);
         assertEquals(0, bsd.sumOfDeviations(), 0.001d);
-        
+
         bsd.add(1d); //this one falls out, over limit
         bsd.add(2d);
         bsd.add(3d);
         bsd.add(4d);
         bsd.add(5d);
-        
+
         //verify that everything is in there
         Iterator<Double> iter = bsd.iterator();
         assertTrue(iter.hasNext());
@@ -61,7 +61,7 @@ public class BoundedStatsDequeTest
         assertTrue(iter.hasNext());
         assertEquals(5d, iter.next(), 0);
         assertFalse(iter.hasNext());
-        
+
         //check results
         assertEquals(size, bsd.size());
         assertEquals(14, bsd.sum(), 0.001d);
@@ -69,7 +69,7 @@ public class BoundedStatsDequeTest
         assertEquals(1.25, bsd.variance(), 0.001d);
         assertEquals(1.1180d, bsd.stdev(), 0.001d);
         assertEquals(5, bsd.sumOfDeviations(), 0.001d);
-        
+
         //check that it clears properly
         bsd.clear();
         assertFalse(bsd.iterator().hasNext());

http://git-wip-us.apache.org/repos/asf/cassandra/blob/2fd3268b/test/unit/org/apache/cassandra/utils/FBUtilitiesTest.java
----------------------------------------------------------------------
diff --git a/test/unit/org/apache/cassandra/utils/FBUtilitiesTest.java b/test/unit/org/apache/cassandra/utils/FBUtilitiesTest.java
index fab911b..e91cbd1 100644
--- a/test/unit/org/apache/cassandra/utils/FBUtilitiesTest.java
+++ b/test/unit/org/apache/cassandra/utils/FBUtilitiesTest.java
@@ -27,7 +27,7 @@ import com.google.common.base.Charsets;
 import com.google.common.primitives.Ints;
 import org.junit.Test;
 
-public class FBUtilitiesTest 
+public class FBUtilitiesTest
 {
     @Test
     public void testCompareByteSubArrays()
@@ -75,5 +75,5 @@ public class FBUtilitiesTest
     {
         ByteBuffer bytes = ByteBuffer.wrap(new byte[]{(byte)0xff, (byte)0xfe});
         ByteBufferUtil.string(bytes, Charsets.UTF_8);
-    } 
+    }
 }

http://git-wip-us.apache.org/repos/asf/cassandra/blob/2fd3268b/test/unit/org/apache/cassandra/utils/HexTest.java
----------------------------------------------------------------------
diff --git a/test/unit/org/apache/cassandra/utils/HexTest.java b/test/unit/org/apache/cassandra/utils/HexTest.java
index ece4be5..ad64668 100644
--- a/test/unit/org/apache/cassandra/utils/HexTest.java
+++ b/test/unit/org/apache/cassandra/utils/HexTest.java
@@ -58,7 +58,7 @@ public class HexTest
             new byte[] { 0x0f },
             new byte[] { (byte)0x000000ff }
         };
-        
+
         for (int i = 0; i < values.length; i++)
             assert Arrays.equals(Hex.hexToBytes(values[i]), expected[i]);
     }

http://git-wip-us.apache.org/repos/asf/cassandra/blob/2fd3268b/test/unit/org/apache/cassandra/utils/IntervalTest.java
----------------------------------------------------------------------
diff --git a/test/unit/org/apache/cassandra/utils/IntervalTest.java b/test/unit/org/apache/cassandra/utils/IntervalTest.java
index 1e5080e..1141dd9 100644
--- a/test/unit/org/apache/cassandra/utils/IntervalTest.java
+++ b/test/unit/org/apache/cassandra/utils/IntervalTest.java
@@ -1,6 +1,6 @@
 package org.apache.cassandra.utils;
 /*
- * 
+ *
  * 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
@@ -8,16 +8,16 @@ package org.apache.cassandra.utils;
  * 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.
- * 
+ *
  */
 
 

http://git-wip-us.apache.org/repos/asf/cassandra/blob/2fd3268b/test/unit/org/apache/cassandra/utils/IntervalTreeTest.java
----------------------------------------------------------------------
diff --git a/test/unit/org/apache/cassandra/utils/IntervalTreeTest.java b/test/unit/org/apache/cassandra/utils/IntervalTreeTest.java
index ccb5df6..cdf85dd 100644
--- a/test/unit/org/apache/cassandra/utils/IntervalTreeTest.java
+++ b/test/unit/org/apache/cassandra/utils/IntervalTreeTest.java
@@ -1,6 +1,6 @@
 package org.apache.cassandra.utils;
 /*
- * 
+ *
  * 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
@@ -8,16 +8,16 @@ package org.apache.cassandra.utils;
  * 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.
- * 
+ *
  */
 
 

http://git-wip-us.apache.org/repos/asf/cassandra/blob/2fd3268b/test/unit/org/apache/cassandra/utils/LegacyBloomFilterTest.java
----------------------------------------------------------------------
diff --git a/test/unit/org/apache/cassandra/utils/LegacyBloomFilterTest.java b/test/unit/org/apache/cassandra/utils/LegacyBloomFilterTest.java
index 0d289c2..fe52dda 100644
--- a/test/unit/org/apache/cassandra/utils/LegacyBloomFilterTest.java
+++ b/test/unit/org/apache/cassandra/utils/LegacyBloomFilterTest.java
@@ -47,7 +47,7 @@ public class LegacyBloomFilterTest
 
         ByteArrayInputStream in = new ByteArrayInputStream(out.getData(), 0, out.getLength());
         LegacyBloomFilter f2 = f.serializer().deserialize(new DataInputStream(in));
-        
+
         assert f2.isPresent(ByteBufferUtil.bytes("a"));
         assert !f2.isPresent(ByteBufferUtil.bytes("b"));
         return f2;

http://git-wip-us.apache.org/repos/asf/cassandra/blob/2fd3268b/test/unit/org/apache/cassandra/utils/MergeIteratorTest.java
----------------------------------------------------------------------
diff --git a/test/unit/org/apache/cassandra/utils/MergeIteratorTest.java b/test/unit/org/apache/cassandra/utils/MergeIteratorTest.java
index 01e8c97..3544955 100644
--- a/test/unit/org/apache/cassandra/utils/MergeIteratorTest.java
+++ b/test/unit/org/apache/cassandra/utils/MergeIteratorTest.java
@@ -55,7 +55,7 @@ public class MergeIteratorTest
             {
                 concatted += value;
             }
-            
+
             public String getReduced()
             {
                 String tmp = concatted;
@@ -80,13 +80,13 @@ public class MergeIteratorTest
         {
             this.iter = Arrays.asList(items).iterator();
         }
-        
+
         protected E computeNext()
         {
             if (!iter.hasNext()) return endOfData();
             return iter.next();
         }
-        
+
         public void close()
         {
             assert !this.closed;

http://git-wip-us.apache.org/repos/asf/cassandra/blob/2fd3268b/test/unit/org/apache/cassandra/utils/MerkleTreeTest.java
----------------------------------------------------------------------
diff --git a/test/unit/org/apache/cassandra/utils/MerkleTreeTest.java b/test/unit/org/apache/cassandra/utils/MerkleTreeTest.java
index 911feb7..ebb52ec 100644
--- a/test/unit/org/apache/cassandra/utils/MerkleTreeTest.java
+++ b/test/unit/org/apache/cassandra/utils/MerkleTreeTest.java
@@ -147,7 +147,7 @@ public class MerkleTreeTest
         assertTrue(mt.split(tok(4)));
         assertTrue(mt.split(tok(2)));
         assertEquals(3, mt.size());
-        
+
         // should fail to split below hashdepth
         assertFalse(mt.split(tok(1)));
         assertEquals(3, mt.size());
@@ -163,7 +163,7 @@ public class MerkleTreeTest
 
         assertTrue(mt.split(tok(4)));
         assertEquals(2, mt.size());
-        
+
         // should fail to split above maxsize
         assertFalse(mt.split(tok(2)));
         assertEquals(2, mt.size());
@@ -175,7 +175,7 @@ public class MerkleTreeTest
     public void testInvalids()
     {
         Iterator<TreeRange> ranges;
-        
+
         // (zero, zero]
         ranges = mt.invalids();
         assertEquals(new Range(tok(-1), tok(-1)), ranges.next());
@@ -207,10 +207,10 @@ public class MerkleTreeTest
 
         // (zero, zero]
         assertNull(mt.hash(range));
-        
+
         // validate the range
         mt.get(tok(-1)).hash(val);
-        
+
         assertHashEquals(val, mt.hash(range));
     }
 
@@ -234,12 +234,12 @@ public class MerkleTreeTest
         assertNull(mt.hash(right));
         assertNull(mt.hash(linvalid));
         assertNull(mt.hash(rinvalid));
-        
+
         // validate the range
         mt.get(tok(2)).hash(val);
         mt.get(tok(4)).hash(val);
         mt.get(tok(-1)).hash(val);
-        
+
         assertHashEquals(leftval, mt.hash(left));
         assertHashEquals(partialval, mt.hash(partial));
         assertHashEquals(val, mt.hash(right));
@@ -268,14 +268,14 @@ public class MerkleTreeTest
         assertNull(mt.hash(lchild));
         assertNull(mt.hash(rchild));
         assertNull(mt.hash(invalid));
-        
+
         // validate the range
         mt.get(tok(1)).hash(val);
         mt.get(tok(2)).hash(val);
         mt.get(tok(4)).hash(val);
         mt.get(tok(6)).hash(val);
         mt.get(tok(-1)).hash(val);
-        
+
         assertHashEquals(fullval, mt.hash(full));
         assertHashEquals(lchildval, mt.hash(lchild));
         assertHashEquals(rchildval, mt.hash(rchild));
@@ -303,7 +303,7 @@ public class MerkleTreeTest
         assertNull(mt.hash(full));
         assertNull(mt.hash(childfull));
         assertNull(mt.hash(invalid));
-        
+
         // validate the range
         mt.get(tok(1)).hash(val);
         mt.get(tok(2)).hash(val);
@@ -360,7 +360,7 @@ public class MerkleTreeTest
         mt.split(tok(12));
         mt.split(tok(6));
         mt.split(tok(10));
-        
+
         ranges = mt.invalids();
         ranges.next().addAll(new HIterator(2, 4)); // (-1,4]: depth 2
         ranges.next().addAll(new HIterator(6)); // (4,6]
@@ -399,7 +399,7 @@ public class MerkleTreeTest
         Range full = new Range(tok(-1), tok(-1));
         ByteArrayOutputStream bout = new ByteArrayOutputStream();
         ObjectOutputStream oout = new ObjectOutputStream(bout);
-    
+
         // populate and validate the tree
         mt.maxsize(256);
         mt.init();
@@ -413,7 +413,7 @@ public class MerkleTreeTest
         ByteArrayInputStream bin = new ByteArrayInputStream(bout.toByteArray());
         ObjectInputStream oin = new ObjectInputStream(bin);
         MerkleTree restored = (MerkleTree)oin.readObject();
-    
+
         // restore partitioner after serialization
         restored.partitioner(partitioner);
         restored.fullRange = fullRange();
@@ -500,12 +500,12 @@ public class MerkleTreeTest
                 tlist.add(tok(token));
             this.tokens = tlist.iterator();
         }
-    
+
         public HIterator(Token... tokens)
         {
             this.tokens = Arrays.asList(tokens).iterator();
         }
-    
+
         public RowHash computeNext()
         {
             if (tokens.hasNext())

http://git-wip-us.apache.org/repos/asf/cassandra/blob/2fd3268b/test/unit/org/apache/cassandra/utils/SerializationsTest.java
----------------------------------------------------------------------
diff --git a/test/unit/org/apache/cassandra/utils/SerializationsTest.java b/test/unit/org/apache/cassandra/utils/SerializationsTest.java
index eebed99..d2c85c0 100644
--- a/test/unit/org/apache/cassandra/utils/SerializationsTest.java
+++ b/test/unit/org/apache/cassandra/utils/SerializationsTest.java
@@ -1,6 +1,6 @@
 package org.apache.cassandra.utils;
 /*
- * 
+ *
  * 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
@@ -8,16 +8,16 @@ package org.apache.cassandra.utils;
  * 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.
- * 
+ *
  */
 
 
@@ -32,7 +32,7 @@ import java.nio.ByteBuffer;
 
 public class SerializationsTest extends AbstractSerializationsTester
 {
-    
+
     private void testBloomFilterWrite() throws IOException
     {
         BloomFilter bf = BloomFilter.getFilter(1000000, 0.0001);
@@ -42,25 +42,25 @@ public class SerializationsTest extends AbstractSerializationsTester
         BloomFilter.serializer().serialize(bf, out);
         out.close();
     }
-    
+
     @Test
     public void testBloomFilterRead() throws IOException
     {
         if (EXECUTE_WRITES)
             testBloomFilterWrite();
-        
+
         DataInputStream in = getInput("utils.BloomFilter.bin");
         assert BloomFilter.serializer().deserialize(in) != null;
         in.close();
     }
-    
+
     private void testLegacyBloomFilterWrite() throws IOException
     {
         LegacyBloomFilter a = LegacyBloomFilter.getFilter(1000000, 1000);
         LegacyBloomFilter b = LegacyBloomFilter.getFilter(1000000, 0.0001);
         for (int i = 0; i < 100; i++)
         {
-            ByteBuffer key = StorageService.getPartitioner().getTokenFactory().toByteArray(StorageService.getPartitioner().getRandomToken()); 
+            ByteBuffer key = StorageService.getPartitioner().getTokenFactory().toByteArray(StorageService.getPartitioner().getRandomToken());
             a.add(key);
             b.add(key);
         }
@@ -69,18 +69,18 @@ public class SerializationsTest extends AbstractSerializationsTester
         LegacyBloomFilter.serializer().serialize(b, out);
         out.close();
     }
-    
+
     @Test
     public void testLegacyBloomFilterRead() throws IOException
     {
         if (EXECUTE_WRITES)
             testLegacyBloomFilterWrite();
-        
+
         DataInputStream in = getInput("utils.LegacyBloomFilter.bin");
         assert LegacyBloomFilter.serializer().deserialize(in) != null;
         in.close();
     }
-    
+
     private void testEstimatedHistogramWrite() throws IOException
     {
         EstimatedHistogram hist0 = new EstimatedHistogram();
@@ -94,20 +94,20 @@ public class SerializationsTest extends AbstractSerializationsTester
         }
         data[offsets.length] = 100000;
         EstimatedHistogram hist2 = new EstimatedHistogram(offsets, data);
-        
+
         DataOutputStream out = getOutput("utils.EstimatedHistogram.bin");
         EstimatedHistogram.serializer.serialize(hist0, out);
         EstimatedHistogram.serializer.serialize(hist1, out);
         EstimatedHistogram.serializer.serialize(hist2, out);
         out.close();
     }
-    
+
     @Test
     public void testEstimatedHistogramRead() throws IOException
     {
         if (EXECUTE_WRITES)
             testEstimatedHistogramWrite();
-        
+
         DataInputStream in = getInput("utils.EstimatedHistogram.bin");
         assert EstimatedHistogram.serializer.deserialize(in) != null;
         assert EstimatedHistogram.serializer.deserialize(in) != null;

http://git-wip-us.apache.org/repos/asf/cassandra/blob/2fd3268b/test/unit/org/apache/cassandra/utils/UUIDTests.java
----------------------------------------------------------------------
diff --git a/test/unit/org/apache/cassandra/utils/UUIDTests.java b/test/unit/org/apache/cassandra/utils/UUIDTests.java
index 6d299ed..bbfe5e1 100644
--- a/test/unit/org/apache/cassandra/utils/UUIDTests.java
+++ b/test/unit/org/apache/cassandra/utils/UUIDTests.java
@@ -1,6 +1,6 @@
 package org.apache.cassandra.utils;
 /*
- * 
+ *
  * 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
@@ -8,16 +8,16 @@ package org.apache.cassandra.utils;
  * 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.
- * 
+ *
  */
 
 
@@ -36,7 +36,7 @@ public class UUIDTests
     @Test
     public void verifyType1() throws UnknownHostException
     {
-        
+
         UUID uuid = UUIDGen.makeType1UUIDFromHost(InetAddress.getByName("127.0.0.1"));
         assert uuid.version() == 1;
     }

http://git-wip-us.apache.org/repos/asf/cassandra/blob/2fd3268b/tools/stress/src/org/apache/cassandra/stress/operations/CqlCounterAdder.java
----------------------------------------------------------------------
diff --git a/tools/stress/src/org/apache/cassandra/stress/operations/CqlCounterAdder.java b/tools/stress/src/org/apache/cassandra/stress/operations/CqlCounterAdder.java
index 049bc1e..fa82d57 100644
--- a/tools/stress/src/org/apache/cassandra/stress/operations/CqlCounterAdder.java
+++ b/tools/stress/src/org/apache/cassandra/stress/operations/CqlCounterAdder.java
@@ -1,6 +1,6 @@
 package org.apache.cassandra.stress.operations;
 /*
- * 
+ *
  * 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
@@ -8,16 +8,16 @@ package org.apache.cassandra.stress.operations;
  * 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.
- * 
+ *
  */
 
 

http://git-wip-us.apache.org/repos/asf/cassandra/blob/2fd3268b/tools/stress/src/org/apache/cassandra/stress/operations/CqlCounterGetter.java
----------------------------------------------------------------------
diff --git a/tools/stress/src/org/apache/cassandra/stress/operations/CqlCounterGetter.java b/tools/stress/src/org/apache/cassandra/stress/operations/CqlCounterGetter.java
index f78e177..1044c6d 100644
--- a/tools/stress/src/org/apache/cassandra/stress/operations/CqlCounterGetter.java
+++ b/tools/stress/src/org/apache/cassandra/stress/operations/CqlCounterGetter.java
@@ -1,6 +1,6 @@
 package org.apache.cassandra.stress.operations;
 /*
- * 
+ *
  * 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
@@ -8,16 +8,16 @@ package org.apache.cassandra.stress.operations;
  * 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.
- * 
+ *
  */
 
 

http://git-wip-us.apache.org/repos/asf/cassandra/blob/2fd3268b/tools/stress/src/org/apache/cassandra/stress/operations/CqlIndexedRangeSlicer.java
----------------------------------------------------------------------
diff --git a/tools/stress/src/org/apache/cassandra/stress/operations/CqlIndexedRangeSlicer.java b/tools/stress/src/org/apache/cassandra/stress/operations/CqlIndexedRangeSlicer.java
index 9d8d2a8..978c1c4 100644
--- a/tools/stress/src/org/apache/cassandra/stress/operations/CqlIndexedRangeSlicer.java
+++ b/tools/stress/src/org/apache/cassandra/stress/operations/CqlIndexedRangeSlicer.java
@@ -1,6 +1,6 @@
 package org.apache.cassandra.stress.operations;
 /*
- * 
+ *
  * 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
@@ -8,16 +8,16 @@ package org.apache.cassandra.stress.operations;
  * 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.
- * 
+ *
  */
 
 

http://git-wip-us.apache.org/repos/asf/cassandra/blob/2fd3268b/tools/stress/src/org/apache/cassandra/stress/operations/CqlInserter.java
----------------------------------------------------------------------
diff --git a/tools/stress/src/org/apache/cassandra/stress/operations/CqlInserter.java b/tools/stress/src/org/apache/cassandra/stress/operations/CqlInserter.java
index 57c7419..d7a7641 100644
--- a/tools/stress/src/org/apache/cassandra/stress/operations/CqlInserter.java
+++ b/tools/stress/src/org/apache/cassandra/stress/operations/CqlInserter.java
@@ -1,6 +1,6 @@
 package org.apache.cassandra.stress.operations;
 /*
- * 
+ *
  * 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
@@ -8,16 +8,16 @@ package org.apache.cassandra.stress.operations;
  * 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.
- * 
+ *
  */
 
 
@@ -35,7 +35,7 @@ import org.apache.cassandra.utils.UUIDGen;
 public class CqlInserter extends Operation
 {
     private static List<ByteBuffer> values;
-    
+
     public CqlInserter(Session client, int idx)
     {
         super(client, idx);
@@ -45,13 +45,13 @@ public class CqlInserter extends Operation
     {
         if (session.getColumnFamilyType() == ColumnFamilyType.Super)
             throw new RuntimeException("Super columns are not implemented for CQL");
-        
+
         if (values == null)
             values = generateValues();
-        
+
         StringBuilder query = new StringBuilder("UPDATE Standard1 USING CONSISTENCY ")
                 .append(session.getConsistencyLevel().toString()).append(" SET ");
-        
+
         for (int i = 0; i < session.getColumnsPerKey(); i++)
         {
             if (i > 0)
@@ -66,10 +66,10 @@ public class CqlInserter extends Operation
             // Column value
             query.append('=').append(getQuotedCqlBlob(values.get(i % values.size()).array()));
         }
-        
+
         String key = String.format("%0" + session.getTotalKeysLength() + "d", index);
         query.append(" WHERE KEY=").append(getQuotedCqlBlob(key));
-        
+
         long start = System.currentTimeMillis();
 
         boolean success = false;

http://git-wip-us.apache.org/repos/asf/cassandra/blob/2fd3268b/tools/stress/src/org/apache/cassandra/stress/operations/CqlMultiGetter.java
----------------------------------------------------------------------
diff --git a/tools/stress/src/org/apache/cassandra/stress/operations/CqlMultiGetter.java b/tools/stress/src/org/apache/cassandra/stress/operations/CqlMultiGetter.java
index 9b51635..3125cff 100644
--- a/tools/stress/src/org/apache/cassandra/stress/operations/CqlMultiGetter.java
+++ b/tools/stress/src/org/apache/cassandra/stress/operations/CqlMultiGetter.java
@@ -1,6 +1,6 @@
 package org.apache.cassandra.stress.operations;
 /*
- * 
+ *
  * 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
@@ -8,16 +8,16 @@ package org.apache.cassandra.stress.operations;
  * 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.
- * 
+ *
  */
 
 

http://git-wip-us.apache.org/repos/asf/cassandra/blob/2fd3268b/tools/stress/src/org/apache/cassandra/stress/operations/CqlRangeSlicer.java
----------------------------------------------------------------------
diff --git a/tools/stress/src/org/apache/cassandra/stress/operations/CqlRangeSlicer.java b/tools/stress/src/org/apache/cassandra/stress/operations/CqlRangeSlicer.java
index 864db5b..e57a9ac 100644
--- a/tools/stress/src/org/apache/cassandra/stress/operations/CqlRangeSlicer.java
+++ b/tools/stress/src/org/apache/cassandra/stress/operations/CqlRangeSlicer.java
@@ -1,6 +1,6 @@
 package org.apache.cassandra.stress.operations;
 /*
- * 
+ *
  * 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
@@ -8,16 +8,16 @@ package org.apache.cassandra.stress.operations;
  * 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.
- * 
+ *
  */
 
 
@@ -42,12 +42,12 @@ public class CqlRangeSlicer extends Operation
     {
         if (session.getColumnFamilyType() == ColumnFamilyType.Super)
             throw new RuntimeException("Super columns are not implemented for CQL");
-        
+
         String key = String.format("%0" +  session.getTotalKeysLength() + "d", index);
         StringBuilder query = new StringBuilder("SELECT FIRST ").append(session.getColumnsPerKey())
                 .append(" ''..'' FROM Standard1 USING CONSISTENCY ").append(session.getConsistencyLevel().toString())
                 .append(" WHERE KEY > ").append(getQuotedCqlBlob(key));
-        
+
         long startTime = System.currentTimeMillis();
 
         boolean success = false;

http://git-wip-us.apache.org/repos/asf/cassandra/blob/2fd3268b/tools/stress/src/org/apache/cassandra/stress/operations/CqlReader.java
----------------------------------------------------------------------
diff --git a/tools/stress/src/org/apache/cassandra/stress/operations/CqlReader.java b/tools/stress/src/org/apache/cassandra/stress/operations/CqlReader.java
index b879a52..93a5c79 100644
--- a/tools/stress/src/org/apache/cassandra/stress/operations/CqlReader.java
+++ b/tools/stress/src/org/apache/cassandra/stress/operations/CqlReader.java
@@ -1,6 +1,6 @@
 package org.apache.cassandra.stress.operations;
 /*
- * 
+ *
  * 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
@@ -8,16 +8,16 @@ package org.apache.cassandra.stress.operations;
  * 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.
- * 
+ *
  */