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:32:02 UTC

[11/16] [3649] Strip end of line whitespaces

http://git-wip-us.apache.org/repos/asf/cassandra/blob/07cdfd07/src/java/org/apache/cassandra/io/util/FastByteArrayInputStream.java
----------------------------------------------------------------------
diff --git a/src/java/org/apache/cassandra/io/util/FastByteArrayInputStream.java b/src/java/org/apache/cassandra/io/util/FastByteArrayInputStream.java
index a302eb3..9515db7 100644
--- a/src/java/org/apache/cassandra/io/util/FastByteArrayInputStream.java
+++ b/src/java/org/apache/cassandra/io/util/FastByteArrayInputStream.java
@@ -26,14 +26,14 @@ import java.io.InputStream;
  * implementation. The synchronized methods of the original have been
  * replaced by non-synchronized methods. This makes this certain operations
  * FASTer, but also *not thread-safe*.
- * 
+ *
  * This file remains formatted the same as the Apache Harmony original to
  * make patching easier if any bug fixes are made to the Harmony version.
  */
 
 /**
  * A specialized {@link InputStream } for reading the contents of a byte array.
- * 
+ *
  * @see ByteArrayInputStream
  */
 public class FastByteArrayInputStream extends InputStream {
@@ -62,7 +62,7 @@ public class FastByteArrayInputStream extends InputStream {
     /**
      * Constructs a new {@code ByteArrayInputStream} on the byte array
      * {@code buf}.
-     * 
+     *
      * @param buf
      *            the byte array to stream over.
      */
@@ -76,7 +76,7 @@ public class FastByteArrayInputStream extends InputStream {
      * Constructs a new {@code ByteArrayInputStream} on the byte array
      * {@code buf} with the initial position set to {@code offset} and the
      * number of bytes available set to {@code offset} + {@code length}.
-     * 
+     *
      * @param buf
      *            the byte array to stream over.
      * @param offset
@@ -95,7 +95,7 @@ public class FastByteArrayInputStream extends InputStream {
      * Returns the number of bytes that are available before this stream will
      * block. This method returns the number of bytes yet to be read from the
      * source byte array.
-     * 
+     *
      * @return the number of bytes available before blocking.
      */
     @Override
@@ -105,7 +105,7 @@ public class FastByteArrayInputStream extends InputStream {
 
     /**
      * Closes this stream and frees resources associated with this stream.
-     * 
+     *
      * @throws IOException
      *             if an I/O error occurs while closing this stream.
      */
@@ -118,7 +118,7 @@ public class FastByteArrayInputStream extends InputStream {
      * Sets a mark position in this ByteArrayInputStream. The parameter
      * {@code readlimit} is ignored. Sending {@code reset()} will reposition the
      * stream back to the marked position.
-     * 
+     *
      * @param readlimit
      *            ignored.
      * @see #markSupported()
@@ -133,7 +133,7 @@ public class FastByteArrayInputStream extends InputStream {
      * Indicates whether this stream supports the {@code mark()} and
      * {@code reset()} methods. Returns {@code true} since this class supports
      * these methods.
-     * 
+     *
      * @return always {@code true}.
      * @see #mark(int)
      * @see #reset()
@@ -147,7 +147,7 @@ public class FastByteArrayInputStream extends InputStream {
      * Reads a single byte from the source byte array and returns it as an
      * integer in the range from 0 to 255. Returns -1 if the end of the source
      * array has been reached.
-     * 
+     *
      * @return the byte read or -1 if the end of this stream has been reached.
      */
     @Override
@@ -159,7 +159,7 @@ public class FastByteArrayInputStream extends InputStream {
      * Reads at most {@code len} bytes from this stream and stores
      * them in byte array {@code b} starting at {@code offset}. This
      * implementation reads bytes from the source byte array.
-     * 
+     *
      * @param b
      *            the byte array in which to store the bytes read.
      * @param offset
@@ -217,7 +217,7 @@ public class FastByteArrayInputStream extends InputStream {
      * {@code read()}s will not return these bytes unless {@code reset()} is
      * used. This implementation skips {@code count} number of bytes in the
      * target stream. It does nothing and returns 0 if {@code n} is negative.
-     * 
+     *
      * @param n
      *            the number of bytes to skip.
      * @return the number of bytes actually skipped.

http://git-wip-us.apache.org/repos/asf/cassandra/blob/07cdfd07/src/java/org/apache/cassandra/io/util/FastByteArrayOutputStream.java
----------------------------------------------------------------------
diff --git a/src/java/org/apache/cassandra/io/util/FastByteArrayOutputStream.java b/src/java/org/apache/cassandra/io/util/FastByteArrayOutputStream.java
index 26d19c2..4ee034d 100644
--- a/src/java/org/apache/cassandra/io/util/FastByteArrayOutputStream.java
+++ b/src/java/org/apache/cassandra/io/util/FastByteArrayOutputStream.java
@@ -27,7 +27,7 @@ import java.io.UnsupportedEncodingException;
  * implementation. The synchronized methods of the original have been
  * replaced by non-synchronized methods. This makes certain operations
  * much FASTer, but also *not thread-safe*.
- * 
+ *
  * This file remains formatted the same as the Apache Harmony original to
  * make patching easier if any bug fixes are made to the Harmony version.
  */
@@ -37,7 +37,7 @@ import java.io.UnsupportedEncodingException;
  * (internal) byte array. As bytes are written to this stream, the byte array
  * may be expanded to hold more bytes. When the writing is considered to be
  * finished, a copy of the byte array can be requested from the class.
- * 
+ *
  * @see ByteArrayOutputStream
  */
 public class FastByteArrayOutputStream extends OutputStream {
@@ -64,7 +64,7 @@ public class FastByteArrayOutputStream extends OutputStream {
      * Constructs a new {@code ByteArrayOutputStream} with a default size of
      * {@code size} bytes. If more than {@code size} bytes are written to this
      * instance, the underlying byte array will expand.
-     * 
+     *
      * @param size
      *            initial size for the underlying byte array, must be
      *            non-negative.
@@ -81,7 +81,7 @@ public class FastByteArrayOutputStream extends OutputStream {
 
     /**
      * Closes this stream. This releases system resources used for this stream.
-     * 
+     *
      * @throws IOException
      *             if an error occurs while attempting to close this stream.
      */
@@ -117,7 +117,7 @@ public class FastByteArrayOutputStream extends OutputStream {
 
     /**
      * Returns the total number of bytes written to this stream so far.
-     * 
+     *
      * @return the number of bytes written to this stream.
      */
     public int size() {
@@ -128,7 +128,7 @@ public class FastByteArrayOutputStream extends OutputStream {
      * Returns the contents of this ByteArrayOutputStream as a byte array. Any
      * changes made to the receiver after returning will not be reflected in the
      * byte array returned to the caller.
-     * 
+     *
      * @return this stream's current contents as a byte array.
      */
     public byte[] toByteArray() {
@@ -141,7 +141,7 @@ public class FastByteArrayOutputStream extends OutputStream {
      * Returns the contents of this ByteArrayOutputStream as a string. Any
      * changes made to the receiver after returning will not be reflected in the
      * string returned to the caller.
-     * 
+     *
      * @return this stream's current contents as a string.
      */
 
@@ -157,7 +157,7 @@ public class FastByteArrayOutputStream extends OutputStream {
      * {@code c == (char)(((hibyte & 0xff) << 8) | (b & 0xff))}. This method is
      * deprecated and either {@link #toString()} or {@link #toString(String)}
      * should be used.
-     * 
+     *
      * @param hibyte
      *            the high byte of each resulting Unicode character.
      * @return this stream's current contents as a string with the high byte set
@@ -176,7 +176,7 @@ public class FastByteArrayOutputStream extends OutputStream {
     /**
      * Returns the contents of this ByteArrayOutputStream as a string converted
      * according to the encoding declared in {@code enc}.
-     * 
+     *
      * @param enc
      *            a string representing the encoding to use when translating
      *            this stream to a string.
@@ -191,7 +191,7 @@ public class FastByteArrayOutputStream extends OutputStream {
     /**
      * Writes {@code count} bytes from the byte array {@code buffer} starting at
      * offset {@code index} to this stream.
-     * 
+     *
      * @param buffer
      *            the buffer to be written.
      * @param offset
@@ -225,7 +225,7 @@ public class FastByteArrayOutputStream extends OutputStream {
     /**
      * Writes the specified byte {@code oneByte} to the OutputStream. Only the
      * low order byte of {@code oneByte} is written.
-     * 
+     *
      * @param oneByte
      *            the byte to be written.
      */
@@ -240,7 +240,7 @@ public class FastByteArrayOutputStream extends OutputStream {
     /**
      * Takes the contents of this stream and writes it to the output stream
      * {@code out}.
-     * 
+     *
      * @param out
      *            an OutputStream on which to write the contents of this stream.
      * @throws IOException

http://git-wip-us.apache.org/repos/asf/cassandra/blob/07cdfd07/src/java/org/apache/cassandra/io/util/FileDataInput.java
----------------------------------------------------------------------
diff --git a/src/java/org/apache/cassandra/io/util/FileDataInput.java b/src/java/org/apache/cassandra/io/util/FileDataInput.java
index 78720fa..0059ce6 100644
--- a/src/java/org/apache/cassandra/io/util/FileDataInput.java
+++ b/src/java/org/apache/cassandra/io/util/FileDataInput.java
@@ -1,6 +1,6 @@
 package org.apache.cassandra.io.util;
 /*
- * 
+ *
  * 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.util;
  * 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/07cdfd07/src/java/org/apache/cassandra/io/util/FileMark.java
----------------------------------------------------------------------
diff --git a/src/java/org/apache/cassandra/io/util/FileMark.java b/src/java/org/apache/cassandra/io/util/FileMark.java
index d45ab42..217c807 100644
--- a/src/java/org/apache/cassandra/io/util/FileMark.java
+++ b/src/java/org/apache/cassandra/io/util/FileMark.java
@@ -1,6 +1,6 @@
 package org.apache.cassandra.io.util;
 /*
- * 
+ *
  * 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.util;
  * 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 interface FileMark {}

http://git-wip-us.apache.org/repos/asf/cassandra/blob/07cdfd07/src/java/org/apache/cassandra/io/util/FileUtils.java
----------------------------------------------------------------------
diff --git a/src/java/org/apache/cassandra/io/util/FileUtils.java b/src/java/org/apache/cassandra/io/util/FileUtils.java
index ff8544f..d1349a2 100644
--- a/src/java/org/apache/cassandra/io/util/FileUtils.java
+++ b/src/java/org/apache/cassandra/io/util/FileUtils.java
@@ -54,7 +54,7 @@ public class FileUtils
             throw new IOException("Failed to delete " + file.getAbsolutePath());
         }
     }
-    
+
     public static void renameWithConfirm(File from, File to) throws IOException
     {
         assert from.exists();
@@ -213,12 +213,12 @@ public class FileUtils
             return val + " KB";
         }
         else
-        {       
+        {
             String val = df_.format(value);
             return val + " bytes";
-        }        
+        }
     }
-    
+
     /**
      * Deletes all files and subdirectories under "dir".
      * @param dir Directory to be deleted

http://git-wip-us.apache.org/repos/asf/cassandra/blob/07cdfd07/src/java/org/apache/cassandra/io/util/IIterableColumns.java
----------------------------------------------------------------------
diff --git a/src/java/org/apache/cassandra/io/util/IIterableColumns.java b/src/java/org/apache/cassandra/io/util/IIterableColumns.java
index cb1b2f0..00b994f 100644
--- a/src/java/org/apache/cassandra/io/util/IIterableColumns.java
+++ b/src/java/org/apache/cassandra/io/util/IIterableColumns.java
@@ -1,6 +1,6 @@
 package org.apache.cassandra.io.util;
 /*
- * 
+ *
  * 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.util;
  * 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/07cdfd07/src/java/org/apache/cassandra/io/util/MemoryInputStream.java
----------------------------------------------------------------------
diff --git a/src/java/org/apache/cassandra/io/util/MemoryInputStream.java b/src/java/org/apache/cassandra/io/util/MemoryInputStream.java
index d8ab08d..0a7ece5 100644
--- a/src/java/org/apache/cassandra/io/util/MemoryInputStream.java
+++ b/src/java/org/apache/cassandra/io/util/MemoryInputStream.java
@@ -1,6 +1,6 @@
 package org.apache.cassandra.io.util;
 /*
- * 
+ *
  * 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.util;
  * 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.
- * 
+ *
  */
 
 
@@ -30,14 +30,14 @@ public class MemoryInputStream extends AbstractDataInput
 {
     private final FreeableMemory mem;
     private int position = 0;
-    
+
     public MemoryInputStream(FreeableMemory mem)
     {
         this.mem = mem;
     }
-    
+
     public int read() throws IOException
-    {       
+    {
         return mem.getByte(position++) & 0xFF;
     }
 
@@ -51,18 +51,18 @@ public class MemoryInputStream extends AbstractDataInput
     {
         position = pos;
     }
-    
+
     protected int getPosition()
     {
         return position;
     }
-    
+
     public int skipBytes(int n) throws IOException
     {
         seekInternal(getPosition() + n);
         return position;
     }
-    
+
     public void close()
     {
         // do nothing.

http://git-wip-us.apache.org/repos/asf/cassandra/blob/07cdfd07/src/java/org/apache/cassandra/io/util/MemoryOutputStream.java
----------------------------------------------------------------------
diff --git a/src/java/org/apache/cassandra/io/util/MemoryOutputStream.java b/src/java/org/apache/cassandra/io/util/MemoryOutputStream.java
index fd5bc33..496bffd6 100644
--- a/src/java/org/apache/cassandra/io/util/MemoryOutputStream.java
+++ b/src/java/org/apache/cassandra/io/util/MemoryOutputStream.java
@@ -1,6 +1,6 @@
 package org.apache.cassandra.io.util;
 /*
- * 
+ *
  * 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.util;
  * 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.
- * 
+ *
  */
 
 
@@ -29,15 +29,15 @@ import java.io.OutputStream;
  */
 public class MemoryOutputStream extends OutputStream
 {
-    
+
     private final Memory mem;
     private int position = 0;
-    
+
     public MemoryOutputStream(Memory mem)
     {
         this.mem = mem;
     }
-    
+
     public void write(int b)
     {
         mem.setByte(position++, (byte) b);

http://git-wip-us.apache.org/repos/asf/cassandra/blob/07cdfd07/src/java/org/apache/cassandra/io/util/MmappedSegmentedFile.java
----------------------------------------------------------------------
diff --git a/src/java/org/apache/cassandra/io/util/MmappedSegmentedFile.java b/src/java/org/apache/cassandra/io/util/MmappedSegmentedFile.java
index 7d3fde7..a933630 100644
--- a/src/java/org/apache/cassandra/io/util/MmappedSegmentedFile.java
+++ b/src/java/org/apache/cassandra/io/util/MmappedSegmentedFile.java
@@ -1,6 +1,6 @@
 package org.apache.cassandra.io.util;
 /*
- * 
+ *
  * 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.util;
  * 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/07cdfd07/src/java/org/apache/cassandra/io/util/OutputBuffer.java
----------------------------------------------------------------------
diff --git a/src/java/org/apache/cassandra/io/util/OutputBuffer.java b/src/java/org/apache/cassandra/io/util/OutputBuffer.java
index ff7ef2d..2a64430 100644
--- a/src/java/org/apache/cassandra/io/util/OutputBuffer.java
+++ b/src/java/org/apache/cassandra/io/util/OutputBuffer.java
@@ -40,12 +40,12 @@ public final class OutputBuffer extends FastByteArrayOutputStream
     {
         return buf;
     }
-    
+
     public int getLength()
     {
         return count;
     }
-    
+
     public void write(DataInput in, int len) throws IOException
     {
         int newcount = count + len;
@@ -58,7 +58,7 @@ public final class OutputBuffer extends FastByteArrayOutputStream
         in.readFully(buf, count, len);
         count = newcount;
     }
-    
+
     /**
      * @return The valid contents of the buffer, possibly by copying: only safe for one-time-use buffers.
      */

http://git-wip-us.apache.org/repos/asf/cassandra/blob/07cdfd07/src/java/org/apache/cassandra/io/util/SegmentedFile.java
----------------------------------------------------------------------
diff --git a/src/java/org/apache/cassandra/io/util/SegmentedFile.java b/src/java/org/apache/cassandra/io/util/SegmentedFile.java
index 2238dc4..12878a4 100644
--- a/src/java/org/apache/cassandra/io/util/SegmentedFile.java
+++ b/src/java/org/apache/cassandra/io/util/SegmentedFile.java
@@ -6,9 +6,9 @@
  * 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

http://git-wip-us.apache.org/repos/asf/cassandra/blob/07cdfd07/src/java/org/apache/cassandra/locator/DynamicEndpointSnitch.java
----------------------------------------------------------------------
diff --git a/src/java/org/apache/cassandra/locator/DynamicEndpointSnitch.java b/src/java/org/apache/cassandra/locator/DynamicEndpointSnitch.java
index 264e554..e442851 100644
--- a/src/java/org/apache/cassandra/locator/DynamicEndpointSnitch.java
+++ b/src/java/org/apache/cassandra/locator/DynamicEndpointSnitch.java
@@ -173,7 +173,7 @@ public class DynamicEndpointSnitch extends AbstractEndpointSnitch implements ILa
     {
         Double scored1 = scores.get(a1);
         Double scored2 = scores.get(a2);
-        
+
         if (scored1 == null)
         {
             scored1 = 0.0;
@@ -212,7 +212,7 @@ public class DynamicEndpointSnitch extends AbstractEndpointSnitch implements ILa
 
     private void updateScores() // this is expensive
     {
-        if (!StorageService.instance.isInitialized()) 
+        if (!StorageService.instance.isInitialized())
             return;
         if (!registered)
         {

http://git-wip-us.apache.org/repos/asf/cassandra/blob/07cdfd07/src/java/org/apache/cassandra/locator/Ec2MultiRegionSnitch.java
----------------------------------------------------------------------
diff --git a/src/java/org/apache/cassandra/locator/Ec2MultiRegionSnitch.java b/src/java/org/apache/cassandra/locator/Ec2MultiRegionSnitch.java
index b5a7deb..68421f9 100644
--- a/src/java/org/apache/cassandra/locator/Ec2MultiRegionSnitch.java
+++ b/src/java/org/apache/cassandra/locator/Ec2MultiRegionSnitch.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.
- * 
+ *
  */
 
 
@@ -37,15 +37,15 @@ import org.apache.cassandra.service.StorageService;
 
 /**
  * 1) Snitch will automatically set the public IP by querying the AWS API
- * 
+ *
  * 2) Snitch will set the private IP as a Gossip application state.
- * 
+ *
  * 3) Snitch implements IESCS and will reset the connection if it is within the
  * same region to communicate via private IP.
- * 
+ *
  * Implements Ec2Snitch to inherit its functionality and extend it for
  * Multi-Region.
- * 
+ *
  * Operational: All the nodes in this cluster needs to be able to (modify the
  * Security group settings in AWS) communicate via Public IP's.
  */
@@ -65,7 +65,7 @@ public class Ec2MultiRegionSnitch extends Ec2Snitch implements IEndpointStateCha
         // use the Public IP to broadcast Address to other nodes.
         DatabaseDescriptor.setBroadcastAddress(public_ip);
     }
-    
+
     @Override
     public void onJoin(InetAddress endpoint, EndpointState epState)
     {
@@ -109,7 +109,7 @@ public class Ec2MultiRegionSnitch extends Ec2Snitch implements IEndpointStateCha
     {
         if (!getDatacenter(endpoint).equals(getDatacenter(public_ip)))
             return; // do nothing return back...
-        
+
         try
         {
             InetAddress remoteIP = InetAddress.getByName(versionedValue.value);
@@ -120,7 +120,7 @@ public class Ec2MultiRegionSnitch extends Ec2Snitch implements IEndpointStateCha
             logger.error("Error in getting the IP address resolved: ", e);
         }
     }
-    
+
     public void gossiperStarting()
     {
         super.gossiperStarting();

http://git-wip-us.apache.org/repos/asf/cassandra/blob/07cdfd07/src/java/org/apache/cassandra/locator/Ec2Snitch.java
----------------------------------------------------------------------
diff --git a/src/java/org/apache/cassandra/locator/Ec2Snitch.java b/src/java/org/apache/cassandra/locator/Ec2Snitch.java
index 3648143..4ffc0e8 100644
--- a/src/java/org/apache/cassandra/locator/Ec2Snitch.java
+++ b/src/java/org/apache/cassandra/locator/Ec2Snitch.java
@@ -57,7 +57,7 @@ public class Ec2Snitch extends AbstractNetworkTopologySnitch
         ec2region = splits.length < 3 ? splits[0] : splits[0] + "-" + splits[1];
         logger.info("EC2Snitch using region: " + ec2region + ", zone: " + ec2zone + ".");
     }
-    
+
     String awsApiCall(String url) throws IOException, ConfigurationException
     {
         // Populate the region and zone by introspection, fail if 404 on metadata

http://git-wip-us.apache.org/repos/asf/cassandra/blob/07cdfd07/src/java/org/apache/cassandra/locator/EndpointSnitchInfoMBean.java
----------------------------------------------------------------------
diff --git a/src/java/org/apache/cassandra/locator/EndpointSnitchInfoMBean.java b/src/java/org/apache/cassandra/locator/EndpointSnitchInfoMBean.java
index c733ffb..7d7b190 100644
--- a/src/java/org/apache/cassandra/locator/EndpointSnitchInfoMBean.java
+++ b/src/java/org/apache/cassandra/locator/EndpointSnitchInfoMBean.java
@@ -27,7 +27,7 @@ import java.net.UnknownHostException;
 public interface EndpointSnitchInfoMBean
 {
     /**
-     * Provides the Rack name depending on the respective snitch used, given the host name/ip 
+     * Provides the Rack name depending on the respective snitch used, given the host name/ip
      * @param host
      * @throws UnknownHostException
      */

http://git-wip-us.apache.org/repos/asf/cassandra/blob/07cdfd07/src/java/org/apache/cassandra/locator/NetworkTopologyStrategy.java
----------------------------------------------------------------------
diff --git a/src/java/org/apache/cassandra/locator/NetworkTopologyStrategy.java b/src/java/org/apache/cassandra/locator/NetworkTopologyStrategy.java
index 382e224..8c85db8 100644
--- a/src/java/org/apache/cassandra/locator/NetworkTopologyStrategy.java
+++ b/src/java/org/apache/cassandra/locator/NetworkTopologyStrategy.java
@@ -1,5 +1,5 @@
 /*
- * 
+ *
  * 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
@@ -7,16 +7,16 @@
  * 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.cassandra.locator;

http://git-wip-us.apache.org/repos/asf/cassandra/blob/07cdfd07/src/java/org/apache/cassandra/locator/SeedProvider.java
----------------------------------------------------------------------
diff --git a/src/java/org/apache/cassandra/locator/SeedProvider.java b/src/java/org/apache/cassandra/locator/SeedProvider.java
index 50737ac..11bddc9 100644
--- a/src/java/org/apache/cassandra/locator/SeedProvider.java
+++ b/src/java/org/apache/cassandra/locator/SeedProvider.java
@@ -6,9 +6,9 @@
  * 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.

http://git-wip-us.apache.org/repos/asf/cassandra/blob/07cdfd07/src/java/org/apache/cassandra/locator/SimpleSeedProvider.java
----------------------------------------------------------------------
diff --git a/src/java/org/apache/cassandra/locator/SimpleSeedProvider.java b/src/java/org/apache/cassandra/locator/SimpleSeedProvider.java
index 7f20da1..ca71aca 100644
--- a/src/java/org/apache/cassandra/locator/SimpleSeedProvider.java
+++ b/src/java/org/apache/cassandra/locator/SimpleSeedProvider.java
@@ -6,9 +6,9 @@
  * 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.
@@ -32,9 +32,9 @@ import org.slf4j.LoggerFactory;
 public class SimpleSeedProvider implements SeedProvider
 {
     private static final Logger logger = LoggerFactory.getLogger(SimpleSeedProvider.class);
-    
+
     private List<InetAddress> seeds;
-    
+
     public SimpleSeedProvider(Map<String, String> args)
     {
         seeds = new ArrayList<InetAddress>();
@@ -52,12 +52,12 @@ public class SimpleSeedProvider implements SeedProvider
             }
         }
     }
-    
+
     public List<InetAddress> getSeeds()
     {
         return Collections.unmodifiableList(seeds);
     }
-    
+
     // future planning?
     public void addSeed(InetAddress addr)
     {

http://git-wip-us.apache.org/repos/asf/cassandra/blob/07cdfd07/src/java/org/apache/cassandra/locator/TokenMetadata.java
----------------------------------------------------------------------
diff --git a/src/java/org/apache/cassandra/locator/TokenMetadata.java b/src/java/org/apache/cassandra/locator/TokenMetadata.java
index 4d89f92..65e6036 100644
--- a/src/java/org/apache/cassandra/locator/TokenMetadata.java
+++ b/src/java/org/apache/cassandra/locator/TokenMetadata.java
@@ -302,7 +302,7 @@ public class TokenMetadata
     {
         assert endpoint != null;
         assert isMember(endpoint); // don't want to return nulls
-        
+
         lock.readLock().lock();
         try
         {
@@ -313,7 +313,7 @@ public class TokenMetadata
             lock.readLock().unlock();
         }
     }
-    
+
     public boolean isMember(InetAddress endpoint)
     {
         assert endpoint != null;

http://git-wip-us.apache.org/repos/asf/cassandra/blob/07cdfd07/src/java/org/apache/cassandra/net/AsyncResult.java
----------------------------------------------------------------------
diff --git a/src/java/org/apache/cassandra/net/AsyncResult.java b/src/java/org/apache/cassandra/net/AsyncResult.java
index daab525..b48fdcc 100644
--- a/src/java/org/apache/cassandra/net/AsyncResult.java
+++ b/src/java/org/apache/cassandra/net/AsyncResult.java
@@ -41,16 +41,16 @@ class AsyncResult implements IAsyncResult
     private InetAddress from;
 
     public AsyncResult()
-    {        
+    {
         condition = lock.newCondition();
         startTime = System.currentTimeMillis();
-    }    
-            
+    }
+
     public byte[] get(long timeout, TimeUnit tu) throws TimeoutException
     {
         lock.lock();
         try
-        {            
+        {
             boolean bVal = true;
             try
             {
@@ -65,9 +65,9 @@ class AsyncResult implements IAsyncResult
             {
                 throw new AssertionError(ex);
             }
-            
+
             if (!bVal && !done.get())
-            {                                           
+            {
                 throw new TimeoutException("Operation timed out.");
             }
         }
@@ -79,7 +79,7 @@ class AsyncResult implements IAsyncResult
     }
 
     public void result(Message response)
-    {        
+    {
         try
         {
             lock.lock();
@@ -94,7 +94,7 @@ class AsyncResult implements IAsyncResult
         finally
         {
             lock.unlock();
-        }        
+        }
     }
 
     public boolean isLatencyForSnitch()

http://git-wip-us.apache.org/repos/asf/cassandra/blob/07cdfd07/src/java/org/apache/cassandra/net/CachingMessageProducer.java
----------------------------------------------------------------------
diff --git a/src/java/org/apache/cassandra/net/CachingMessageProducer.java b/src/java/org/apache/cassandra/net/CachingMessageProducer.java
index e8b5446..708dbbf 100644
--- a/src/java/org/apache/cassandra/net/CachingMessageProducer.java
+++ b/src/java/org/apache/cassandra/net/CachingMessageProducer.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.
- * 
+ *
  */
 
 
@@ -32,7 +32,7 @@ public class CachingMessageProducer implements MessageProducer
 
     public CachingMessageProducer(MessageProducer prod)
     {
-        this.prod = prod;    
+        this.prod = prod;
     }
 
     public synchronized Message getMessage(Integer version) throws IOException

http://git-wip-us.apache.org/repos/asf/cassandra/blob/07cdfd07/src/java/org/apache/cassandra/net/CallbackInfo.java
----------------------------------------------------------------------
diff --git a/src/java/org/apache/cassandra/net/CallbackInfo.java b/src/java/org/apache/cassandra/net/CallbackInfo.java
index 94ea514..d5f698c 100644
--- a/src/java/org/apache/cassandra/net/CallbackInfo.java
+++ b/src/java/org/apache/cassandra/net/CallbackInfo.java
@@ -24,7 +24,7 @@ import org.apache.cassandra.service.StorageProxy;
 
 /**
  * Encapsulates the callback information.
- * The ability to set the message is useful in cases for when a hint needs 
+ * The ability to set the message is useful in cases for when a hint needs
  * to be written due to a timeout in the response from a replica.
  */
 class CallbackInfo

http://git-wip-us.apache.org/repos/asf/cassandra/blob/07cdfd07/src/java/org/apache/cassandra/net/CompactEndpointSerializationHelper.java
----------------------------------------------------------------------
diff --git a/src/java/org/apache/cassandra/net/CompactEndpointSerializationHelper.java b/src/java/org/apache/cassandra/net/CompactEndpointSerializationHelper.java
index 6c1995b..3c331d6 100644
--- a/src/java/org/apache/cassandra/net/CompactEndpointSerializationHelper.java
+++ b/src/java/org/apache/cassandra/net/CompactEndpointSerializationHelper.java
@@ -31,9 +31,9 @@ public class CompactEndpointSerializationHelper
         dos.writeByte(buf.length);
         dos.write(buf);
     }
-    
+
     public static InetAddress deserialize(DataInput dis) throws IOException
-    {     
+    {
         byte[] bytes = new byte[dis.readByte()];
         dis.readFully(bytes, 0, bytes.length);
         return InetAddress.getByAddress(bytes);

http://git-wip-us.apache.org/repos/asf/cassandra/blob/07cdfd07/src/java/org/apache/cassandra/net/Header.java
----------------------------------------------------------------------
diff --git a/src/java/org/apache/cassandra/net/Header.java b/src/java/org/apache/cassandra/net/Header.java
index f07a7f6..8a18398 100644
--- a/src/java/org/apache/cassandra/net/Header.java
+++ b/src/java/org/apache/cassandra/net/Header.java
@@ -37,9 +37,9 @@ public class Header
 
     static
     {
-        serializer_ = new HeaderSerializer();        
+        serializer_ = new HeaderSerializer();
     }
-    
+
     public static IVersionedSerializer<Header> serializer()
     {
         return serializer_;
@@ -76,7 +76,7 @@ public class Header
     {
         return verb_;
     }
-    
+
     byte[] getDetail(String key)
     {
         return details_.get(key);
@@ -117,7 +117,7 @@ public class Header
 class HeaderSerializer implements IVersionedSerializer<Header>
 {
     public void serialize(Header t, DataOutput dos, int version) throws IOException
-    {           
+    {
         CompactEndpointSerializationHelper.serialize(t.getFrom(), dos);
         dos.writeInt(t.getVerb().ordinal());
         dos.writeInt(t.details_.size());

http://git-wip-us.apache.org/repos/asf/cassandra/blob/07cdfd07/src/java/org/apache/cassandra/net/HeaderTypes.java
----------------------------------------------------------------------
diff --git a/src/java/org/apache/cassandra/net/HeaderTypes.java b/src/java/org/apache/cassandra/net/HeaderTypes.java
index 9a6b7ae..3cc5c18 100644
--- a/src/java/org/apache/cassandra/net/HeaderTypes.java
+++ b/src/java/org/apache/cassandra/net/HeaderTypes.java
@@ -18,7 +18,7 @@
 
 package org.apache.cassandra.net;
 
-public class HeaderTypes 
+public class HeaderTypes
 {
     public final static String TASK_PROFILE_CHAIN = "TASK_PROFILE_CHAIN";
     public static String TASK_ID = "TASK_ID";

http://git-wip-us.apache.org/repos/asf/cassandra/blob/07cdfd07/src/java/org/apache/cassandra/net/IAsyncResult.java
----------------------------------------------------------------------
diff --git a/src/java/org/apache/cassandra/net/IAsyncResult.java b/src/java/org/apache/cassandra/net/IAsyncResult.java
index b60ba2b..d20ac24 100644
--- a/src/java/org/apache/cassandra/net/IAsyncResult.java
+++ b/src/java/org/apache/cassandra/net/IAsyncResult.java
@@ -23,7 +23,7 @@ import java.util.concurrent.TimeUnit;
 import java.util.concurrent.TimeoutException;
 
 public interface IAsyncResult extends IMessageCallback
-{    
+{
     /**
      * Same operation as the above get() but allows the calling
      * thread to specify a timeout.
@@ -32,7 +32,7 @@ public interface IAsyncResult extends IMessageCallback
      * @return the result wrapped in an Object[]
     */
     public byte[] get(long timeout, TimeUnit tu) throws TimeoutException;
-        
+
     /**
      * Store the result obtained for the submitted task.
      * @param result the response message

http://git-wip-us.apache.org/repos/asf/cassandra/blob/07cdfd07/src/java/org/apache/cassandra/net/IMessageCallback.java
----------------------------------------------------------------------
diff --git a/src/java/org/apache/cassandra/net/IMessageCallback.java b/src/java/org/apache/cassandra/net/IMessageCallback.java
index d9c57ef..3ae2a22 100644
--- a/src/java/org/apache/cassandra/net/IMessageCallback.java
+++ b/src/java/org/apache/cassandra/net/IMessageCallback.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/07cdfd07/src/java/org/apache/cassandra/net/IncomingTcpConnection.java
----------------------------------------------------------------------
diff --git a/src/java/org/apache/cassandra/net/IncomingTcpConnection.java b/src/java/org/apache/cassandra/net/IncomingTcpConnection.java
index ee44a1c..2a617f2 100644
--- a/src/java/org/apache/cassandra/net/IncomingTcpConnection.java
+++ b/src/java/org/apache/cassandra/net/IncomingTcpConnection.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.
- * 
+ *
  */
 
 
@@ -40,7 +40,7 @@ public class IncomingTcpConnection extends Thread
     private static Logger logger = LoggerFactory.getLogger(IncomingTcpConnection.class);
 
     private static final int CHUNK_SIZE = 1024 * 1024;
-    
+
     private Socket socket;
     public InetAddress from;
 
@@ -79,7 +79,7 @@ public class IncomingTcpConnection extends Thread
                     byte[] headerBytes = new byte[size];
                     input.readFully(headerBytes);
                     stream(StreamHeader.serializer().deserialize(new DataInputStream(new FastByteArrayInputStream(headerBytes)), version), input);
-                } 
+                }
                 else
                 {
                     // streaming connections are per-session and have a fixed version.  we can't do anything with a wrong-version stream connection, so drop it.
@@ -89,7 +89,7 @@ public class IncomingTcpConnection extends Thread
                 // We are done with this connection....
                 return;
             }
-            
+
             // we should buffer
             input = new DataInputStream(new BufferedInputStream(socket.getInputStream(), 4096));
             // Receive the first message to set the version.
@@ -105,7 +105,7 @@ public class IncomingTcpConnection extends Thread
                 Gossiper.instance.setVersion(msg.getFrom(), version);
                 logger.debug("set version for {} to {}", from, version);
             }
-            
+
             // loop to get the next message.
             while (true)
             {
@@ -117,12 +117,12 @@ public class IncomingTcpConnection extends Thread
                 logger.trace("Version is now {}", version);
                 receiveMessage(input, version);
             }
-        } 
+        }
         catch (EOFException e)
         {
             logger.trace("eof reading from socket; closing", e);
             // connection will be reset so no need to throw an exception.
-        } 
+        }
         catch (IOException e)
         {
             logger.debug("IOError reading from socket; closing", e);

http://git-wip-us.apache.org/repos/asf/cassandra/blob/07cdfd07/src/java/org/apache/cassandra/net/Message.java
----------------------------------------------------------------------
diff --git a/src/java/org/apache/cassandra/net/Message.java b/src/java/org/apache/cassandra/net/Message.java
index eb743d1..5765f4c 100644
--- a/src/java/org/apache/cassandra/net/Message.java
+++ b/src/java/org/apache/cassandra/net/Message.java
@@ -39,22 +39,22 @@ public class Message
         body_ = body;
         this.version = version;
     }
-    
+
     public Message(InetAddress from, StorageService.Verb verb, byte[] body, int version)
     {
         this(new Header(from, verb), body, version);
-    } 
-        
+    }
+
     public byte[] getHeader(String key)
     {
         return header_.getDetail(key);
     }
-    
+
     public Message withHeaderAdded(String key, byte[] value)
     {
         return new Message(header_.withDetailsAdded(key, value), body_, version);
     }
-    
+
     public Message withHeaderRemoved(String key)
     {
         return new Message(header_.withDetailsRemoved(key), body_, version);
@@ -64,7 +64,7 @@ public class Message
     {
         return body_;
     }
-    
+
     public int getVersion()
     {
         return version;

http://git-wip-us.apache.org/repos/asf/cassandra/blob/07cdfd07/src/java/org/apache/cassandra/net/MessageProducer.java
----------------------------------------------------------------------
diff --git a/src/java/org/apache/cassandra/net/MessageProducer.java b/src/java/org/apache/cassandra/net/MessageProducer.java
index 4c9bba5..14d652e 100644
--- a/src/java/org/apache/cassandra/net/MessageProducer.java
+++ b/src/java/org/apache/cassandra/net/MessageProducer.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/07cdfd07/src/java/org/apache/cassandra/net/MessagingService.java
----------------------------------------------------------------------
diff --git a/src/java/org/apache/cassandra/net/MessagingService.java b/src/java/org/apache/cassandra/net/MessagingService.java
index b0e7de9..b92b0e4 100644
--- a/src/java/org/apache/cassandra/net/MessagingService.java
+++ b/src/java/org/apache/cassandra/net/MessagingService.java
@@ -264,7 +264,7 @@ public final class MessagingService implements MessagingServiceMBean
             // setReuseAddress happens in the factory.
             logger_.info("Starting Encrypted Messaging Service on SSL port {}", DatabaseDescriptor.getSSLStoragePort());
         }
-        
+
         ServerSocketChannel serverChannel = ServerSocketChannel.open();
         ServerSocket socket = serverChannel.socket();
         socket.setReuseAddress(true);
@@ -343,7 +343,7 @@ public final class MessagingService implements MessagingServiceMBean
     {
         return addCallback(cb, message, to, DEFAULT_CALLBACK_TIMEOUT);
     }
-    
+
     public String addCallback(IMessageCallback cb, Message message, InetAddress to, long timeout)
     {
         String messageId = nextId();

http://git-wip-us.apache.org/repos/asf/cassandra/blob/07cdfd07/src/java/org/apache/cassandra/net/OutboundTcpConnection.java
----------------------------------------------------------------------
diff --git a/src/java/org/apache/cassandra/net/OutboundTcpConnection.java b/src/java/org/apache/cassandra/net/OutboundTcpConnection.java
index f9d866d..e826fe3 100644
--- a/src/java/org/apache/cassandra/net/OutboundTcpConnection.java
+++ b/src/java/org/apache/cassandra/net/OutboundTcpConnection.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.
- * 
+ *
  */
 
 
@@ -53,7 +53,7 @@ public class OutboundTcpConnection extends Thread
     private volatile BlockingQueue<Entry> backlog = new LinkedBlockingQueue<Entry>();
     private volatile BlockingQueue<Entry> active = new LinkedBlockingQueue<Entry>();
 
-    private final OutboundTcpConnectionPool poolReference;    
+    private final OutboundTcpConnectionPool poolReference;
 
     private DataOutputStream out;
     private Socket socket;

http://git-wip-us.apache.org/repos/asf/cassandra/blob/07cdfd07/src/java/org/apache/cassandra/net/OutboundTcpConnectionPool.java
----------------------------------------------------------------------
diff --git a/src/java/org/apache/cassandra/net/OutboundTcpConnectionPool.java b/src/java/org/apache/cassandra/net/OutboundTcpConnectionPool.java
index ed820b6..641767a 100644
--- a/src/java/org/apache/cassandra/net/OutboundTcpConnectionPool.java
+++ b/src/java/org/apache/cassandra/net/OutboundTcpConnectionPool.java
@@ -65,14 +65,14 @@ public class OutboundTcpConnectionPool
         for (OutboundTcpConnection con : new OutboundTcpConnection[] { cmdCon, ackCon })
             con.closeSocket();
     }
-    
+
     public void reset(InetAddress remoteEP)
     {
         resetedEndpoint = remoteEP;
         for (OutboundTcpConnection con : new OutboundTcpConnection[] { cmdCon, ackCon })
             con.softCloseSocket();
     }
-    
+
     public Socket newSocket() throws IOException
     {
         // zero means 'bind on any available port.'
@@ -91,12 +91,12 @@ public class OutboundTcpConnectionPool
                 return new Socket(endPoint(), DatabaseDescriptor.getStoragePort(), FBUtilities.getLocalAddress(), 0);
         }
     }
-    
+
     InetAddress endPoint()
     {
         return resetedEndpoint == null ? id : resetedEndpoint;
     }
-    
+
     boolean isEncryptedChannel()
     {
         switch (DatabaseDescriptor.getEncryptionOptions().internode_encryption)

http://git-wip-us.apache.org/repos/asf/cassandra/blob/07cdfd07/src/java/org/apache/cassandra/net/ResponseVerbHandler.java
----------------------------------------------------------------------
diff --git a/src/java/org/apache/cassandra/net/ResponseVerbHandler.java b/src/java/org/apache/cassandra/net/ResponseVerbHandler.java
index 818f703..b997985 100644
--- a/src/java/org/apache/cassandra/net/ResponseVerbHandler.java
+++ b/src/java/org/apache/cassandra/net/ResponseVerbHandler.java
@@ -26,7 +26,7 @@ public class ResponseVerbHandler implements IVerbHandler
     private static final Logger logger_ = LoggerFactory.getLogger( ResponseVerbHandler.class );
 
     public void doVerb(Message message, String id)
-    {     
+    {
         double age = System.currentTimeMillis() - MessagingService.instance().getRegisteredCallbackAge(id);
         CallbackInfo callbackInfo = MessagingService.instance().removeRegisteredCallback(id);
         if (callbackInfo == null)

http://git-wip-us.apache.org/repos/asf/cassandra/blob/07cdfd07/src/java/org/apache/cassandra/notifications/INotification.java
----------------------------------------------------------------------
diff --git a/src/java/org/apache/cassandra/notifications/INotification.java b/src/java/org/apache/cassandra/notifications/INotification.java
index f37bf1c..934f62b 100644
--- a/src/java/org/apache/cassandra/notifications/INotification.java
+++ b/src/java/org/apache/cassandra/notifications/INotification.java
@@ -1,6 +1,6 @@
 package org.apache.cassandra.notifications;
 /*
- * 
+ *
  * 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.notifications;
  * 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/07cdfd07/src/java/org/apache/cassandra/notifications/INotificationConsumer.java
----------------------------------------------------------------------
diff --git a/src/java/org/apache/cassandra/notifications/INotificationConsumer.java b/src/java/org/apache/cassandra/notifications/INotificationConsumer.java
index 7d5dcb6..3c4e094 100644
--- a/src/java/org/apache/cassandra/notifications/INotificationConsumer.java
+++ b/src/java/org/apache/cassandra/notifications/INotificationConsumer.java
@@ -1,6 +1,6 @@
 package org.apache.cassandra.notifications;
 /*
- * 
+ *
  * 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.notifications;
  * 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/07cdfd07/src/java/org/apache/cassandra/notifications/SSTableAddedNotification.java
----------------------------------------------------------------------
diff --git a/src/java/org/apache/cassandra/notifications/SSTableAddedNotification.java b/src/java/org/apache/cassandra/notifications/SSTableAddedNotification.java
index 7705d0c..0773f6c 100644
--- a/src/java/org/apache/cassandra/notifications/SSTableAddedNotification.java
+++ b/src/java/org/apache/cassandra/notifications/SSTableAddedNotification.java
@@ -1,6 +1,6 @@
 package org.apache.cassandra.notifications;
 /*
- * 
+ *
  * 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.notifications;
  * 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/07cdfd07/src/java/org/apache/cassandra/notifications/SSTableListChangedNotification.java
----------------------------------------------------------------------
diff --git a/src/java/org/apache/cassandra/notifications/SSTableListChangedNotification.java b/src/java/org/apache/cassandra/notifications/SSTableListChangedNotification.java
index 480dcf2..12c0865 100644
--- a/src/java/org/apache/cassandra/notifications/SSTableListChangedNotification.java
+++ b/src/java/org/apache/cassandra/notifications/SSTableListChangedNotification.java
@@ -1,6 +1,6 @@
 package org.apache.cassandra.notifications;
 /*
- * 
+ *
  * 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.notifications;
  * 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/07cdfd07/src/java/org/apache/cassandra/scheduler/IRequestScheduler.java
----------------------------------------------------------------------
diff --git a/src/java/org/apache/cassandra/scheduler/IRequestScheduler.java b/src/java/org/apache/cassandra/scheduler/IRequestScheduler.java
index 8f89bd0..5026c8d 100644
--- a/src/java/org/apache/cassandra/scheduler/IRequestScheduler.java
+++ b/src/java/org/apache/cassandra/scheduler/IRequestScheduler.java
@@ -1,6 +1,6 @@
 package org.apache.cassandra.scheduler;
 /*
- * 
+ *
  * 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.scheduler;
  * 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.concurrent.TimeoutException;
@@ -29,7 +29,7 @@ public interface IRequestScheduler
 {
     /**
      * Queue incoming request threads
-     * 
+     *
      * @param t Thread handing the request
      * @param id    Scheduling parameter, an id to distinguish profiles (users/keyspace)
      * @param timeoutMS   The max time in milliseconds to spend blocking for a slot

http://git-wip-us.apache.org/repos/asf/cassandra/blob/07cdfd07/src/java/org/apache/cassandra/scheduler/NoScheduler.java
----------------------------------------------------------------------
diff --git a/src/java/org/apache/cassandra/scheduler/NoScheduler.java b/src/java/org/apache/cassandra/scheduler/NoScheduler.java
index 7150e1f..75c6027 100644
--- a/src/java/org/apache/cassandra/scheduler/NoScheduler.java
+++ b/src/java/org/apache/cassandra/scheduler/NoScheduler.java
@@ -3,7 +3,7 @@ package org.apache.cassandra.scheduler;
 import org.apache.cassandra.config.RequestSchedulerOptions;
 
 /*
- * 
+ *
  * 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
@@ -11,21 +11,21 @@ import org.apache.cassandra.config.RequestSchedulerOptions;
  * 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.
- * 
+ *
  */
 
 /**
  * This is basically not having a scheduler, the requests are
- * processed as normally would be handled by the JVM. 
+ * processed as normally would be handled by the JVM.
  */
 public class NoScheduler implements IRequestScheduler
 {

http://git-wip-us.apache.org/repos/asf/cassandra/blob/07cdfd07/src/java/org/apache/cassandra/scheduler/RoundRobinScheduler.java
----------------------------------------------------------------------
diff --git a/src/java/org/apache/cassandra/scheduler/RoundRobinScheduler.java b/src/java/org/apache/cassandra/scheduler/RoundRobinScheduler.java
index 38e9b27..47d2157 100644
--- a/src/java/org/apache/cassandra/scheduler/RoundRobinScheduler.java
+++ b/src/java/org/apache/cassandra/scheduler/RoundRobinScheduler.java
@@ -1,7 +1,7 @@
 package org.apache.cassandra.scheduler;
 
 /*
- * 
+ *
  * 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
@@ -9,16 +9,16 @@ package org.apache.cassandra.scheduler;
  * 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.Map;
@@ -32,8 +32,8 @@ import org.apache.cassandra.config.RequestSchedulerOptions;
 import org.cliffc.high_scale_lib.NonBlockingHashMap;
 
 /**
- * A very basic Round Robin implementation of the RequestScheduler. It handles 
- * request groups identified on user/keyspace by placing them in separate 
+ * A very basic Round Robin implementation of the RequestScheduler. It handles
+ * request groups identified on user/keyspace by placing them in separate
  * queues and servicing a request from each queue in a RoundRobin fashion.
  * It optionally adds weights for each round.
  */
@@ -134,7 +134,7 @@ public class RoundRobinScheduler implements IRequestScheduler
     }
 
     /*
-     * Get the Queue for the respective id, if one is not available 
+     * Get the Queue for the respective id, if one is not available
      * create a new queue for that corresponding id and return it
      */
     private WeightedQueue getWeightedQueue(String id)

http://git-wip-us.apache.org/repos/asf/cassandra/blob/07cdfd07/src/java/org/apache/cassandra/scheduler/WeightedQueue.java
----------------------------------------------------------------------
diff --git a/src/java/org/apache/cassandra/scheduler/WeightedQueue.java b/src/java/org/apache/cassandra/scheduler/WeightedQueue.java
index d65f709..d37b923 100644
--- a/src/java/org/apache/cassandra/scheduler/WeightedQueue.java
+++ b/src/java/org/apache/cassandra/scheduler/WeightedQueue.java
@@ -1,7 +1,7 @@
 package org.apache.cassandra.scheduler;
 
 /*
- * 
+ *
  * 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
@@ -9,16 +9,16 @@ package org.apache.cassandra.scheduler;
  * 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.concurrent.SynchronousQueue;

http://git-wip-us.apache.org/repos/asf/cassandra/blob/07cdfd07/src/java/org/apache/cassandra/scheduler/WeightedQueueMBean.java
----------------------------------------------------------------------
diff --git a/src/java/org/apache/cassandra/scheduler/WeightedQueueMBean.java b/src/java/org/apache/cassandra/scheduler/WeightedQueueMBean.java
index 6b1c7f2..1e9aa09 100644
--- a/src/java/org/apache/cassandra/scheduler/WeightedQueueMBean.java
+++ b/src/java/org/apache/cassandra/scheduler/WeightedQueueMBean.java
@@ -1,6 +1,6 @@
 package org.apache.cassandra.scheduler;
 /*
- * 
+ *
  * 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.scheduler;
  * 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/07cdfd07/src/java/org/apache/cassandra/security/SSLFactory.java
----------------------------------------------------------------------
diff --git a/src/java/org/apache/cassandra/security/SSLFactory.java b/src/java/org/apache/cassandra/security/SSLFactory.java
index 794f7d9..b1fa060 100644
--- a/src/java/org/apache/cassandra/security/SSLFactory.java
+++ b/src/java/org/apache/cassandra/security/SSLFactory.java
@@ -126,7 +126,7 @@ public final class SSLFactory
         }
         return ctx;
     }
-    
+
     private static String[] filterCipherSuites(String[] supported, String[] desired)
     {
         Set<String> des = Sets.newHashSet(desired);

http://git-wip-us.apache.org/repos/asf/cassandra/blob/07cdfd07/src/java/org/apache/cassandra/service/AbstractCassandraDaemon.java
----------------------------------------------------------------------
diff --git a/src/java/org/apache/cassandra/service/AbstractCassandraDaemon.java b/src/java/org/apache/cassandra/service/AbstractCassandraDaemon.java
index f124f9f..9f19123 100644
--- a/src/java/org/apache/cassandra/service/AbstractCassandraDaemon.java
+++ b/src/java/org/apache/cassandra/service/AbstractCassandraDaemon.java
@@ -53,7 +53,7 @@ import org.apache.cassandra.utils.Mx4jTool;
  * service, which defines not only a way to activate and deactivate it, but also
  * hooks into its lifecycle methods (see {@link #setup()}, {@link #start()},
  * {@link #stop()} and {@link #setup()}).
- * 
+ *
  */
 public abstract class AbstractCassandraDaemon implements CassandraDaemon
 {
@@ -76,7 +76,7 @@ public abstract class AbstractCassandraDaemon implements CassandraDaemon
                 // then try loading from the classpath.
                 configLocation = AbstractCassandraDaemon.class.getClassLoader().getResource(config);
             }
-        
+
             if (configLocation == null)
                 throw new RuntimeException("Couldn't figure out log4j configuration: "+config);
 
@@ -104,11 +104,11 @@ public abstract class AbstractCassandraDaemon implements CassandraDaemon
     private static Logger logger = LoggerFactory.getLogger(AbstractCassandraDaemon.class);
 
     static final AtomicInteger exceptions = new AtomicInteger();
-    
+
     protected InetAddress listenAddr;
     protected int listenPort;
     protected volatile boolean isRunning = false;
-    
+
     /**
      * This is a hook for concrete daemons to initialize themselves suitably.
      *
@@ -175,7 +175,7 @@ public abstract class AbstractCassandraDaemon implements CassandraDaemon
             logger.error("Fatal exception during initialization", e);
             System.exit(100);
         }
-        
+
         // load keyspace descriptions.
         try
         {
@@ -186,7 +186,7 @@ public abstract class AbstractCassandraDaemon implements CassandraDaemon
             logger.error("Fatal exception during initialization", e);
             System.exit(100);
         }
-        
+
         // clean up debris in the rest of the tables
         for (String table : Schema.instance.getTables())
         {
@@ -244,7 +244,7 @@ public abstract class AbstractCassandraDaemon implements CassandraDaemon
      * Initialize the Cassandra Daemon based on the given <a
      * href="http://commons.apache.org/daemon/jsvc.html">Commons
      * Daemon</a>-specific arguments. To clarify, this is a hook for JSVC.
-     * 
+     *
      * @param arguments
      *            the arguments passed in from JSVC
      * @throws IOException
@@ -253,7 +253,7 @@ public abstract class AbstractCassandraDaemon implements CassandraDaemon
     {
         setup();
     }
-    
+
     /**
      * Start the Cassandra Daemon, assuming that it has already been
      * initialized via {@link #init(String[])}
@@ -273,7 +273,7 @@ public abstract class AbstractCassandraDaemon implements CassandraDaemon
             logger.info("Not starting RPC server as requested. Use JMX (StorageService->startRPCServer()) to start it");
         }
     }
-    
+
     /**
      * Stop the daemon, ideally in an idempotent manner.
      *
@@ -333,42 +333,42 @@ public abstract class AbstractCassandraDaemon implements CassandraDaemon
      */
     protected abstract void stopServer();
 
-    
+
     /**
      * Clean up all resources obtained during the lifetime of the daemon. This
      * is a hook for JSVC.
      */
     public void destroy()
     {}
-    
+
     /**
      * A convenience method to initialize and start the daemon in one shot.
      */
     public void activate()
     {
         String pidFile = System.getProperty("cassandra-pidfile");
-        
+
         try
         {
             setup();
-            
+
             if (pidFile != null)
             {
                 new File(pidFile).deleteOnExit();
             }
-            
+
             if (System.getProperty("cassandra-foreground") == null)
             {
                 System.out.close();
                 System.err.close();
             }
-            
+
             start();
         }
         catch (Throwable e)
         {
             logger.error("Exception encountered during startup", e);
-            
+
             // try to warn user on stdout too, if we haven't already detached
             e.printStackTrace();
             System.out.println("Exception encountered during startup: " + e.getMessage());
@@ -376,7 +376,7 @@ public abstract class AbstractCassandraDaemon implements CassandraDaemon
             System.exit(3);
         }
     }
-    
+
     /**
      * A convenience method to stop and destroy the daemon in one shot.
      */
@@ -385,7 +385,7 @@ public abstract class AbstractCassandraDaemon implements CassandraDaemon
         stop();
         destroy();
     }
-    
+
     /**
      * A subclass of Java's ThreadPoolExecutor which implements Jetty's ThreadPool
      * interface (for integration with Avro), and performs ClientState cleanup.
@@ -393,7 +393,7 @@ public abstract class AbstractCassandraDaemon implements CassandraDaemon
      * (Note that the tasks being executed perform their own while-command-process
      * loop until the client disconnects.)
      */
-    public static class CleaningThreadPool extends ThreadPoolExecutor 
+    public static class CleaningThreadPool extends ThreadPoolExecutor
     {
         private ThreadLocal<ClientState> state;
         public CleaningThreadPool(ThreadLocal<ClientState> state, int minWorkerThread, int maxWorkerThreads)

http://git-wip-us.apache.org/repos/asf/cassandra/blob/07cdfd07/src/java/org/apache/cassandra/service/AbstractRowResolver.java
----------------------------------------------------------------------
diff --git a/src/java/org/apache/cassandra/service/AbstractRowResolver.java b/src/java/org/apache/cassandra/service/AbstractRowResolver.java
index 85cd573..b4e78ff 100644
--- a/src/java/org/apache/cassandra/service/AbstractRowResolver.java
+++ b/src/java/org/apache/cassandra/service/AbstractRowResolver.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/07cdfd07/src/java/org/apache/cassandra/service/AbstractWriteResponseHandler.java
----------------------------------------------------------------------
diff --git a/src/java/org/apache/cassandra/service/AbstractWriteResponseHandler.java b/src/java/org/apache/cassandra/service/AbstractWriteResponseHandler.java
index 0a21676..5c446a1 100644
--- a/src/java/org/apache/cassandra/service/AbstractWriteResponseHandler.java
+++ b/src/java/org/apache/cassandra/service/AbstractWriteResponseHandler.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/07cdfd07/src/java/org/apache/cassandra/service/AntiEntropyService.java
----------------------------------------------------------------------
diff --git a/src/java/org/apache/cassandra/service/AntiEntropyService.java b/src/java/org/apache/cassandra/service/AntiEntropyService.java
index 812c23a..5979860 100644
--- a/src/java/org/apache/cassandra/service/AntiEntropyService.java
+++ b/src/java/org/apache/cassandra/service/AntiEntropyService.java
@@ -260,7 +260,7 @@ public class AntiEntropyService
         private transient DecoratedKey lastKey;
 
         public final static MerkleTree.RowHash EMPTY_ROW = new MerkleTree.RowHash(null, new byte[0]);
-        
+
         Validator(TreeRequest request)
         {
             this(request,
@@ -452,9 +452,9 @@ public class AntiEntropyService
          * Trigger a validation compaction which will return the tree upon completion.
          */
         public void doVerb(Message message, String id)
-        { 
+        {
             byte[] bytes = message.getMessageBody();
-            
+
             DataInputStream buffer = new DataInputStream(new FastByteArrayInputStream(bytes));
             try
             {
@@ -469,7 +469,7 @@ public class AntiEntropyService
             }
             catch (IOException e)
             {
-                throw new IOError(e);            
+                throw new IOError(e);
             }
         }
     }
@@ -488,9 +488,9 @@ public class AntiEntropyService
             	FastByteArrayOutputStream bos = new FastByteArrayOutputStream();
                 DataOutputStream dos = new DataOutputStream(bos);
                 SERIALIZER.serialize(validator, dos, Gossiper.instance.getVersion(validator.request.endpoint));
-                return new Message(local, 
-                                   StorageService.Verb.TREE_RESPONSE, 
-                                   bos.toByteArray(), 
+                return new Message(local,
+                                   StorageService.Verb.TREE_RESPONSE,
+                                   bos.toByteArray(),
                                    Gossiper.instance.getVersion(validator.request.endpoint));
             }
             catch(IOException e)
@@ -520,7 +520,7 @@ public class AntiEntropyService
         }
 
         public void doVerb(Message message, String id)
-        { 
+        {
             byte[] bytes = message.getMessageBody();
             DataInputStream buffer = new DataInputStream(new FastByteArrayInputStream(bytes));
 
@@ -573,7 +573,7 @@ public class AntiEntropyService
         {
             return Objects.hashCode(sessionid, endpoint, cf, range);
         }
-        
+
         @Override
         public final boolean equals(Object o)
         {
@@ -583,7 +583,7 @@ public class AntiEntropyService
             // handles nulls properly
             return Objects.equal(sessionid, that.sessionid) && Objects.equal(endpoint, that.endpoint) && Objects.equal(cf, that.cf) && Objects.equal(range, that.range);
         }
-        
+
         @Override
         public String toString()
         {

http://git-wip-us.apache.org/repos/asf/cassandra/blob/07cdfd07/src/java/org/apache/cassandra/service/AsyncRepairCallback.java
----------------------------------------------------------------------
diff --git a/src/java/org/apache/cassandra/service/AsyncRepairCallback.java b/src/java/org/apache/cassandra/service/AsyncRepairCallback.java
index 72a4b09..b8f46e2 100644
--- a/src/java/org/apache/cassandra/service/AsyncRepairCallback.java
+++ b/src/java/org/apache/cassandra/service/AsyncRepairCallback.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/07cdfd07/src/java/org/apache/cassandra/service/CassandraDaemon.java
----------------------------------------------------------------------
diff --git a/src/java/org/apache/cassandra/service/CassandraDaemon.java b/src/java/org/apache/cassandra/service/CassandraDaemon.java
index bb67a5a..026b931 100644
--- a/src/java/org/apache/cassandra/service/CassandraDaemon.java
+++ b/src/java/org/apache/cassandra/service/CassandraDaemon.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.
- * 
+ *
  */
 
 
@@ -26,7 +26,7 @@ import java.io.IOException;
 /**
  * The <code>CassandraDaemon</code> interface captures the lifecycle of a
  * Cassandra daemon that runs on a single node.
- * 
+ *
  */
 public interface CassandraDaemon
 {
@@ -34,26 +34,26 @@ public interface CassandraDaemon
      * Initialize the Cassandra Daemon based on the given <a
      * href="http://commons.apache.org/daemon/jsvc.html">Commons
      * Daemon</a>-specific arguments. To clarify, this is a hook for JSVC.
-     * 
+     *
      * @param arguments
      *            the arguments passed in from JSVC
      * @throws IOException
      */
     public void init(String[] arguments) throws IOException;
-    
+
     /**
      * Start the Cassandra Daemon, assuming that it has already been
      * initialized (via {@link CassandraDaemon#init(String[])})
-     * 
+     *
      * @throws IOException
      */
     public void start() throws IOException;
-    
+
     /**
      * Stop the daemon, ideally in an idempotent manner.
      */
     public void stop();
-    
+
     /**
      * Clean up all resources obtained during the lifetime of the daemon. Just
      * to clarify, this is a hook for JSVC.
@@ -63,15 +63,15 @@ public interface CassandraDaemon
     public void startRPCServer();
     public void stopRPCServer();
     public boolean isRPCServerRunning();
-    
+
     /**
      * A convenience method to initialize and start the daemon in one shot.
      */
     public void activate();
-    
+
     /**
      * A convenience method to stop and destroy the daemon in one shot.
      */
     public void deactivate();
-    
+
 }

http://git-wip-us.apache.org/repos/asf/cassandra/blob/07cdfd07/src/java/org/apache/cassandra/service/ClientState.java
----------------------------------------------------------------------
diff --git a/src/java/org/apache/cassandra/service/ClientState.java b/src/java/org/apache/cassandra/service/ClientState.java
index 603e51a..3b88a3f 100644
--- a/src/java/org/apache/cassandra/service/ClientState.java
+++ b/src/java/org/apache/cassandra/service/ClientState.java
@@ -159,7 +159,7 @@ public class ClientState
 
         hasAccess(user, perms, perm, resource);
     }
-    
+
     /**
      * Confirms that the client thread has the given Permission for the ColumnFamily list of
      * the current keyspace.
@@ -176,10 +176,10 @@ public class ClientState
         resourceClear();
         resource.add(keyspace);
         Set<Permission> perms = DatabaseDescriptor.getAuthority().authorize(user, resource);
-        
+
         hasAccess(user, perms, perm, resource);
     }
-    
+
     /**
      * Confirms that the client thread has the given Permission in the context of the given
      * ColumnFamily and the current keyspace.
@@ -193,12 +193,12 @@ public class ClientState
     {
         validateLogin();
         validateKeyspace();
-        
+
         resourceClear();
         resource.add(keyspace);
         resource.add(columnFamily);
         Set<Permission> perms = DatabaseDescriptor.getAuthority().authorize(user, resource);
-        
+
         hasAccess(user, perms, perm, resource);
     }
 
@@ -207,7 +207,7 @@ public class ClientState
         if (user == null)
             throw new InvalidRequestException("You have not logged in");
     }
-    
+
     private void validateKeyspace() throws InvalidRequestException
     {
         if (keyspace == null)

http://git-wip-us.apache.org/repos/asf/cassandra/blob/07cdfd07/src/java/org/apache/cassandra/service/DatacenterReadCallback.java
----------------------------------------------------------------------
diff --git a/src/java/org/apache/cassandra/service/DatacenterReadCallback.java b/src/java/org/apache/cassandra/service/DatacenterReadCallback.java
index 00540ca..83225b8 100644
--- a/src/java/org/apache/cassandra/service/DatacenterReadCallback.java
+++ b/src/java/org/apache/cassandra/service/DatacenterReadCallback.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.
- * 
+ *
  */
 
 
@@ -78,7 +78,7 @@ public class DatacenterReadCallback<T> extends ReadCallback<T>
         // version of this method gets called
         return true;
     }
-        
+
     @Override
     public int determineBlockFor(ConsistencyLevel consistency_level, String table)
 	{