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

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

http://git-wip-us.apache.org/repos/asf/cassandra/blob/2fd3268b/src/java/org/apache/cassandra/hadoop/BulkRecordWriter.java
----------------------------------------------------------------------
diff --git a/src/java/org/apache/cassandra/hadoop/BulkRecordWriter.java b/src/java/org/apache/cassandra/hadoop/BulkRecordWriter.java
index c18acdf..b87b7af 100644
--- a/src/java/org/apache/cassandra/hadoop/BulkRecordWriter.java
+++ b/src/java/org/apache/cassandra/hadoop/BulkRecordWriter.java
@@ -74,7 +74,7 @@ implements org.apache.hadoop.mapred.RecordWriter<ByteBuffer,List<Mutation>>
     {
         this(context.getConfiguration());
     }
-    
+
     BulkRecordWriter(Configuration conf) throws IOException
     {
         Config.setLoadYaml(false);

http://git-wip-us.apache.org/repos/asf/cassandra/blob/2fd3268b/src/java/org/apache/cassandra/hadoop/ColumnFamilyInputFormat.java
----------------------------------------------------------------------
diff --git a/src/java/org/apache/cassandra/hadoop/ColumnFamilyInputFormat.java b/src/java/org/apache/cassandra/hadoop/ColumnFamilyInputFormat.java
index 028bff0..dc137a5 100644
--- a/src/java/org/apache/cassandra/hadoop/ColumnFamilyInputFormat.java
+++ b/src/java/org/apache/cassandra/hadoop/ColumnFamilyInputFormat.java
@@ -231,10 +231,10 @@ public class ColumnFamilyInputFormat extends InputFormat<ByteBuffer, SortedMap<B
         for (int i = 0; i < range.rpc_endpoints.size(); i++)
         {
             String host = range.rpc_endpoints.get(i);
-            
+
             if (host == null || host.equals("0.0.0.0"))
                 host = range.endpoints.get(i);
-                        
+
             try
             {
                 Cassandra.Client client = ConfigHelper.createConnection(host, ConfigHelper.getInputRpcPort(conf), true);

http://git-wip-us.apache.org/repos/asf/cassandra/blob/2fd3268b/src/java/org/apache/cassandra/hadoop/ColumnFamilyOutputFormat.java
----------------------------------------------------------------------
diff --git a/src/java/org/apache/cassandra/hadoop/ColumnFamilyOutputFormat.java b/src/java/org/apache/cassandra/hadoop/ColumnFamilyOutputFormat.java
index fe25962..ad074eb 100644
--- a/src/java/org/apache/cassandra/hadoop/ColumnFamilyOutputFormat.java
+++ b/src/java/org/apache/cassandra/hadoop/ColumnFamilyOutputFormat.java
@@ -40,7 +40,7 @@ import org.apache.thrift.transport.TSocket;
  * OutputFormat that allows reduce tasks to store keys (and corresponding
  * values) as Cassandra rows (and respective columns) in a given
  * ColumnFamily.
- * 
+ *
  * <p>
  * As is the case with the {@link ColumnFamilyInputFormat}, you need to set the
  * Keyspace and ColumnFamily in your
@@ -48,7 +48,7 @@ import org.apache.thrift.transport.TSocket;
  * {@link ConfigHelper#setOutputColumnFamily} method, is provided to make this
  * simple.
  * </p>
- * 
+ *
  * <p>
  * For the sake of performance, this class employs a lazy write-back caching
  * mechanism, where its record writer batches mutations created based on the
@@ -60,13 +60,13 @@ public class ColumnFamilyOutputFormat extends OutputFormat<ByteBuffer,List<Mutat
     implements org.apache.hadoop.mapred.OutputFormat<ByteBuffer,List<Mutation>>
 {
     private static final Logger logger = LoggerFactory.getLogger(ColumnFamilyOutputFormat.class);
-    
+
     public static final String BATCH_THRESHOLD = "mapreduce.output.columnfamilyoutputformat.batch.threshold";
     public static final String QUEUE_SIZE = "mapreduce.output.columnfamilyoutputformat.queue.size";
 
     /**
      * Check for validity of the output-specification for the job.
-     * 
+     *
      * @param context
      *            information about the job
      * @throws IOException
@@ -92,7 +92,7 @@ public class ColumnFamilyOutputFormat extends OutputFormat<ByteBuffer,List<Mutat
 
     /**
      * The OutputCommitter for this format does not write any data to the DFS.
-     * 
+     *
      * @param context
      *            the task context
      * @return an output committer
@@ -104,7 +104,7 @@ public class ColumnFamilyOutputFormat extends OutputFormat<ByteBuffer,List<Mutat
     {
         return new NullOutputCommitter();
     }
-    
+
     /** Fills the deprecated OutputFormat interface for streaming. */
     @Deprecated
     public void checkOutputSpecs(org.apache.hadoop.fs.FileSystem filesystem, org.apache.hadoop.mapred.JobConf job) throws IOException
@@ -121,7 +121,7 @@ public class ColumnFamilyOutputFormat extends OutputFormat<ByteBuffer,List<Mutat
 
     /**
      * Get the {@link RecordWriter} for the given task.
-     * 
+     *
      * @param context
      *            the information about the current task.
      * @return a {@link RecordWriter} to write the output for the job.

http://git-wip-us.apache.org/repos/asf/cassandra/blob/2fd3268b/src/java/org/apache/cassandra/hadoop/ColumnFamilyRecordReader.java
----------------------------------------------------------------------
diff --git a/src/java/org/apache/cassandra/hadoop/ColumnFamilyRecordReader.java b/src/java/org/apache/cassandra/hadoop/ColumnFamilyRecordReader.java
index aed081c..1d93cf3 100644
--- a/src/java/org/apache/cassandra/hadoop/ColumnFamilyRecordReader.java
+++ b/src/java/org/apache/cassandra/hadoop/ColumnFamilyRecordReader.java
@@ -80,7 +80,7 @@ public class ColumnFamilyRecordReader extends RecordReader<ByteBuffer, SortedMap
         this.keyBufferSize = keyBufferSize;
     }
 
-    public void close() 
+    public void close()
     {
         if (socket != null && socket.isOpen())
         {
@@ -89,7 +89,7 @@ public class ColumnFamilyRecordReader extends RecordReader<ByteBuffer, SortedMap
             client = null;
         }
     }
-    
+
     public ByteBuffer getCurrentKey()
     {
         return currentRow.left;
@@ -99,35 +99,35 @@ public class ColumnFamilyRecordReader extends RecordReader<ByteBuffer, SortedMap
     {
         return currentRow.right;
     }
-    
+
     public float getProgress()
     {
         // TODO this is totally broken for wide rows
         // the progress is likely to be reported slightly off the actual but close enough
         return ((float)iter.rowsRead()) / totalRowCount;
     }
-    
+
     static boolean isEmptyPredicate(SlicePredicate predicate)
     {
         if (predicate == null)
             return true;
-              
+
         if (predicate.isSetColumn_names() && predicate.getSlice_range() == null)
             return false;
-        
+
         if (predicate.getSlice_range() == null)
             return true;
-        
+
         byte[] start  = predicate.getSlice_range().getStart();
-        byte[] finish = predicate.getSlice_range().getFinish(); 
+        byte[] finish = predicate.getSlice_range().getFinish();
         if ( (start == null || start == ArrayUtils.EMPTY_BYTE_ARRAY) &&
              (finish == null || finish == ArrayUtils.EMPTY_BYTE_ARRAY) )
             return true;
-        
-        
-        return false;       
+
+
+        return false;
     }
-    
+
     public void initialize(InputSplit split, TaskAttemptContext context) throws IOException
     {
         this.split = (ColumnFamilySplit) split;
@@ -141,10 +141,10 @@ public class ColumnFamilyRecordReader extends RecordReader<ByteBuffer, SortedMap
         batchSize = ConfigHelper.getRangeBatchSize(conf);
         cfName = ConfigHelper.getInputColumnFamily(conf);
         consistencyLevel = ConsistencyLevel.valueOf(ConfigHelper.getReadConsistencyLevel(conf));
-        
-        
+
+
         keyspace = ConfigHelper.getInputKeyspace(conf);
-        
+
         try
         {
             // only need to connect once
@@ -176,7 +176,7 @@ public class ColumnFamilyRecordReader extends RecordReader<ByteBuffer, SortedMap
 
         iter = widerows ? new WideRowIterator() : new StaticRowIterator();
     }
-    
+
     public boolean nextKeyValue() throws IOException
     {
         if (!iter.hasNext())
@@ -455,7 +455,7 @@ public class ColumnFamilyRecordReader extends RecordReader<ByteBuffer, SortedMap
                     rows = null;
                     return;
                 }
-                    
+
                 // nothing new? reached the end
                 if (lastRow != null && (rows.get(0).key.equals(lastRow.key) || rows.get(0).columns.get(0).column.name.equals(startColumn)))
                 {

http://git-wip-us.apache.org/repos/asf/cassandra/blob/2fd3268b/src/java/org/apache/cassandra/hadoop/ColumnFamilyRecordWriter.java
----------------------------------------------------------------------
diff --git a/src/java/org/apache/cassandra/hadoop/ColumnFamilyRecordWriter.java b/src/java/org/apache/cassandra/hadoop/ColumnFamilyRecordWriter.java
index 6b6d60b..538008a 100644
--- a/src/java/org/apache/cassandra/hadoop/ColumnFamilyRecordWriter.java
+++ b/src/java/org/apache/cassandra/hadoop/ColumnFamilyRecordWriter.java
@@ -43,44 +43,44 @@ import org.apache.thrift.transport.TSocket;
  * pairs to a Cassandra column family. In particular, it applies all mutations
  * in the value, which it associates with the key, and in turn the responsible
  * endpoint.
- * 
+ *
  * <p>
  * Furthermore, this writer groups the mutations by the endpoint responsible for
  * the rows being affected. This allows the mutations to be executed in parallel,
  * directly to a responsible endpoint.
  * </p>
- * 
+ *
  * @see ColumnFamilyOutputFormat
  * @see OutputFormat
- * 
+ *
  */
 final class ColumnFamilyRecordWriter extends RecordWriter<ByteBuffer,List<Mutation>>
 implements org.apache.hadoop.mapred.RecordWriter<ByteBuffer,List<Mutation>>
 {
     // The configuration this writer is associated with.
     private final Configuration conf;
-    
+
     // The ring cache that describes the token ranges each node in the ring is
     // responsible for. This is what allows us to group the mutations by
     // the endpoints they should be targeted at. The targeted endpoint
     // essentially
     // acts as the primary replica for the rows being affected by the mutations.
     private final RingCache ringCache;
-    
+
     // The number of mutations to buffer per endpoint
     private final int queueSize;
 
     // handles for clients for each range running in the threadpool
     private final Map<Range,RangeClient> clients;
     private final long batchThreshold;
-    
+
     private final ConsistencyLevel consistencyLevel;
 
 
     /**
      * Upon construction, obtain the map that this writer will use to collect
      * mutations, and the ring cache for the given keyspace.
-     * 
+     *
      * @param context the task attempt context
      * @throws IOException
      */
@@ -88,7 +88,7 @@ implements org.apache.hadoop.mapred.RecordWriter<ByteBuffer,List<Mutation>>
     {
         this(context.getConfiguration());
     }
-    
+
     ColumnFamilyRecordWriter(Configuration conf) throws IOException
     {
         this.conf = conf;
@@ -106,7 +106,7 @@ implements org.apache.hadoop.mapred.RecordWriter<ByteBuffer,List<Mutation>>
      * {@link Deletion}. Similarly, if the entire value for a key is missing
      * (i.e., null), then the entire key is marked for {@link Deletion}.
      * </p>
-     * 
+     *
      * @param keybuff
      *            the key to write.
      * @param value

http://git-wip-us.apache.org/repos/asf/cassandra/blob/2fd3268b/src/java/org/apache/cassandra/hadoop/ColumnFamilySplit.java
----------------------------------------------------------------------
diff --git a/src/java/org/apache/cassandra/hadoop/ColumnFamilySplit.java b/src/java/org/apache/cassandra/hadoop/ColumnFamilySplit.java
index 74d3176..0c26b19 100644
--- a/src/java/org/apache/cassandra/hadoop/ColumnFamilySplit.java
+++ b/src/java/org/apache/cassandra/hadoop/ColumnFamilySplit.java
@@ -51,7 +51,7 @@ public class ColumnFamilySplit extends InputSplit implements Writable, org.apach
     }
 
     // getLength and getLocations satisfy the InputSplit abstraction
-    
+
     public long getLength()
     {
         // only used for sorting splits. we don't have the capability, yet.

http://git-wip-us.apache.org/repos/asf/cassandra/blob/2fd3268b/src/java/org/apache/cassandra/hadoop/ConfigHelper.java
----------------------------------------------------------------------
diff --git a/src/java/org/apache/cassandra/hadoop/ConfigHelper.java b/src/java/org/apache/cassandra/hadoop/ConfigHelper.java
index 6a2f2c7..8ec215e 100644
--- a/src/java/org/apache/cassandra/hadoop/ConfigHelper.java
+++ b/src/java/org/apache/cassandra/hadoop/ConfigHelper.java
@@ -70,7 +70,7 @@ public class ConfigHelper
     private static final String WRITE_CONSISTENCY_LEVEL = "cassandra.consistencylevel.write";
     private static final String OUTPUT_COMPRESSION_CLASS = "cassandra.output.compression.class";
     private static final String OUTPUT_COMPRESSION_CHUNK_LENGTH = "cassandra.output.compression.length";
-    
+
     private static final Logger logger = LoggerFactory.getLogger(ConfigHelper.class);
 
 
@@ -194,7 +194,7 @@ public class ConfigHelper
         String s = conf.get(INPUT_PREDICATE_CONFIG);
         return s == null ? null : predicateFromString(s);
     }
-    
+
     private static String thriftToString(TBase object)
     {
         assert object != null;
@@ -283,17 +283,17 @@ public class ConfigHelper
     {
         return conf.get(INPUT_KEYSPACE_CONFIG);
     }
-    
+
     public static String getOutputKeyspace(Configuration conf)
     {
         return conf.get(OUTPUT_KEYSPACE_CONFIG);
     }
-    
+
     public static String getInputKeyspaceUserName(Configuration conf)
     {
         return conf.get(INPUT_KEYSPACE_USERNAME_CONFIG);
     }
-    
+
     public static String getInputKeyspacePassword(Configuration conf)
     {
         return conf.get(INPUT_KEYSPACE_PASSWD_CONFIG);
@@ -303,7 +303,7 @@ public class ConfigHelper
     {
         return conf.get(OUTPUT_KEYSPACE_USERNAME_CONFIG);
     }
-    
+
     public static String getOutputKeyspacePassword(Configuration conf)
     {
         return conf.get(OUTPUT_KEYSPACE_PASSWD_CONFIG);
@@ -318,7 +318,7 @@ public class ConfigHelper
     {
         return Boolean.valueOf(conf.get(INPUT_WIDEROWS_CONFIG));
     }
-    
+
     public static String getOutputColumnFamily(Configuration conf)
     {
         return conf.get(OUTPUT_COLUMNFAMILY_CONFIG);
@@ -370,7 +370,7 @@ public class ConfigHelper
             throw new RuntimeException(e);
         }
     }
-    
+
     public static int getOutputRpcPort(Configuration conf)
     {
         return Integer.parseInt(conf.get(OUTPUT_THRIFT_PORT, "9160"));

http://git-wip-us.apache.org/repos/asf/cassandra/blob/2fd3268b/src/java/org/apache/cassandra/hadoop/pig/CassandraStorage.java
----------------------------------------------------------------------
diff --git a/src/java/org/apache/cassandra/hadoop/pig/CassandraStorage.java b/src/java/org/apache/cassandra/hadoop/pig/CassandraStorage.java
index 4cfb50c..b6ac43d 100644
--- a/src/java/org/apache/cassandra/hadoop/pig/CassandraStorage.java
+++ b/src/java/org/apache/cassandra/hadoop/pig/CassandraStorage.java
@@ -80,7 +80,7 @@ public class CassandraStorage extends LoadFunc implements StoreFuncInterface, Lo
 
     private final static String DEFAULT_INPUT_FORMAT = "org.apache.cassandra.hadoop.ColumnFamilyInputFormat";
     private final static String DEFAULT_OUTPUT_FORMAT = "org.apache.cassandra.hadoop.ColumnFamilyOutputFormat";
-    
+
     private final static ByteBuffer BOUND = ByteBufferUtil.EMPTY_BYTE_BUFFER;
     private static final Log logger = LogFactory.getLog(CassandraStorage.class);
 
@@ -114,7 +114,7 @@ public class CassandraStorage extends LoadFunc implements StoreFuncInterface, Lo
         this.limit = limit;
     }
 
-    public int getLimit() 
+    public int getLimit()
     {
         return limit;
     }
@@ -384,7 +384,7 @@ public class CassandraStorage extends LoadFunc implements StoreFuncInterface, Lo
         if (System.getenv(PIG_ALLOW_DELETES) != null)
             allow_deletes = Boolean.valueOf(System.getenv(PIG_ALLOW_DELETES));
     }
-    
+
     private String getFullyQualifiedClassName(String classname)
     {
         return classname.contains(".") ? classname : "org.apache.cassandra.hadoop." + classname;

http://git-wip-us.apache.org/repos/asf/cassandra/blob/2fd3268b/src/java/org/apache/cassandra/io/compress/CompressedSequentialWriter.java
----------------------------------------------------------------------
diff --git a/src/java/org/apache/cassandra/io/compress/CompressedSequentialWriter.java b/src/java/org/apache/cassandra/io/compress/CompressedSequentialWriter.java
index 5134aa2..67ec3f0 100644
--- a/src/java/org/apache/cassandra/io/compress/CompressedSequentialWriter.java
+++ b/src/java/org/apache/cassandra/io/compress/CompressedSequentialWriter.java
@@ -52,7 +52,7 @@ public class CompressedSequentialWriter extends SequentialWriter
     private long originalSize = 0, compressedSize = 0;
 
     private final Collector sstableMetadataCollector;
-    
+
     public CompressedSequentialWriter(File file, String indexFilePath, boolean skipIOCache, CompressionParameters parameters, Collector sstableMetadataCollector) throws IOException
     {
         super(file, parameters.chunkLength(), skipIOCache);
@@ -89,7 +89,7 @@ public class CompressedSequentialWriter extends SequentialWriter
 
         originalSize += validBufferBytes;
         compressedSize += compressedLength;
-        
+
         // update checksum
         checksum.update(buffer, 0, validBufferBytes);
 

http://git-wip-us.apache.org/repos/asf/cassandra/blob/2fd3268b/src/java/org/apache/cassandra/io/sstable/Component.java
----------------------------------------------------------------------
diff --git a/src/java/org/apache/cassandra/io/sstable/Component.java b/src/java/org/apache/cassandra/io/sstable/Component.java
index c4d6362..1f34222 100644
--- a/src/java/org/apache/cassandra/io/sstable/Component.java
+++ b/src/java/org/apache/cassandra/io/sstable/Component.java
@@ -57,7 +57,7 @@ public class Component
         {
             this.repr = repr;
         }
-        
+
         static Type fromRepresentation(String repr)
         {
             for (Type type : TYPES)

http://git-wip-us.apache.org/repos/asf/cassandra/blob/2fd3268b/src/java/org/apache/cassandra/io/sstable/Descriptor.java
----------------------------------------------------------------------
diff --git a/src/java/org/apache/cassandra/io/sstable/Descriptor.java b/src/java/org/apache/cassandra/io/sstable/Descriptor.java
index 3c65208..a4ff975 100644
--- a/src/java/org/apache/cassandra/io/sstable/Descriptor.java
+++ b/src/java/org/apache/cassandra/io/sstable/Descriptor.java
@@ -108,7 +108,7 @@ public class Descriptor
     {
         return filenameFor(component.name());
     }
-    
+
     private String baseFilename()
     {
         StringBuilder buff = new StringBuilder();

http://git-wip-us.apache.org/repos/asf/cassandra/blob/2fd3268b/src/java/org/apache/cassandra/io/sstable/SSTableMetadata.java
----------------------------------------------------------------------
diff --git a/src/java/org/apache/cassandra/io/sstable/SSTableMetadata.java b/src/java/org/apache/cassandra/io/sstable/SSTableMetadata.java
index 2f3d7e1..d1d514f 100644
--- a/src/java/org/apache/cassandra/io/sstable/SSTableMetadata.java
+++ b/src/java/org/apache/cassandra/io/sstable/SSTableMetadata.java
@@ -119,13 +119,13 @@ public class SSTableMetadata
 
         /**
          * Ratio is compressed/uncompressed and it is
-         * if you have 1.x then compression isn't helping 
+         * if you have 1.x then compression isn't helping
          */
         public void addCompressionRatio(long compressed, long uncompressed)
         {
             compressionRatio = (double) compressed/uncompressed;
         }
-        
+
         public void updateMaxTimestamp(long potentialMax)
         {
             maxTimestamp = Math.max(maxTimestamp, potentialMax);

http://git-wip-us.apache.org/repos/asf/cassandra/blob/2fd3268b/src/java/org/apache/cassandra/io/sstable/SSTableWriter.java
----------------------------------------------------------------------
diff --git a/src/java/org/apache/cassandra/io/sstable/SSTableWriter.java b/src/java/org/apache/cassandra/io/sstable/SSTableWriter.java
index cd6d3e6..04a91b6 100644
--- a/src/java/org/apache/cassandra/io/sstable/SSTableWriter.java
+++ b/src/java/org/apache/cassandra/io/sstable/SSTableWriter.java
@@ -101,7 +101,7 @@ public class SSTableWriter extends SSTable
 
         this.sstableMetadataCollector = sstableMetadataCollector;
     }
-    
+
     public void mark()
     {
         dataMark = dataFile.mark();

http://git-wip-us.apache.org/repos/asf/cassandra/blob/2fd3268b/src/java/org/apache/cassandra/io/util/DataOutputBuffer.java
----------------------------------------------------------------------
diff --git a/src/java/org/apache/cassandra/io/util/DataOutputBuffer.java b/src/java/org/apache/cassandra/io/util/DataOutputBuffer.java
index 3643a7e..cd2100d 100644
--- a/src/java/org/apache/cassandra/io/util/DataOutputBuffer.java
+++ b/src/java/org/apache/cassandra/io/util/DataOutputBuffer.java
@@ -30,12 +30,12 @@ public final class DataOutputBuffer extends DataOutputStream
     {
         this(128);
     }
-    
+
     public DataOutputBuffer(int size)
     {
         super(new OutputBuffer(size));
     }
-    
+
     private OutputBuffer buffer()
     {
         return (OutputBuffer)out;
@@ -49,13 +49,13 @@ public final class DataOutputBuffer extends DataOutputStream
     {
         return buffer().getData();
     }
-    
+
     /** Returns the length of the valid data currently in the buffer. */
     public int getLength()
     {
         return buffer().getLength();
     }
-    
+
     /** Resets the buffer to empty. */
     public DataOutputBuffer reset()
     {

http://git-wip-us.apache.org/repos/asf/cassandra/blob/2fd3268b/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 43e480c..0e729b9 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/2fd3268b/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 7dcdb6a..0e95610 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/2fd3268b/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 5834cc9..e264b8a 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/2fd3268b/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 38f1886..4931a6a 100644
--- a/src/java/org/apache/cassandra/io/util/MemoryInputStream.java
+++ b/src/java/org/apache/cassandra/io/util/MemoryInputStream.java
@@ -26,14 +26,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;
     }
 
@@ -47,18 +47,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/2fd3268b/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 e944b60..e6c869d 100644
--- a/src/java/org/apache/cassandra/io/util/MemoryOutputStream.java
+++ b/src/java/org/apache/cassandra/io/util/MemoryOutputStream.java
@@ -25,15 +25,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/2fd3268b/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 5d8ae44..bf6ef63 100644
--- a/src/java/org/apache/cassandra/io/util/OutputBuffer.java
+++ b/src/java/org/apache/cassandra/io/util/OutputBuffer.java
@@ -39,12 +39,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;
@@ -57,7 +57,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/2fd3268b/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 1e91119..e4f154a 100644
--- a/src/java/org/apache/cassandra/locator/DynamicEndpointSnitch.java
+++ b/src/java/org/apache/cassandra/locator/DynamicEndpointSnitch.java
@@ -172,7 +172,7 @@ public class DynamicEndpointSnitch extends AbstractEndpointSnitch implements ILa
     {
         Double scored1 = scores.get(a1);
         Double scored2 = scores.get(a2);
-        
+
         if (scored1 == null)
         {
             scored1 = 0.0;
@@ -211,7 +211,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/2fd3268b/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 aebb249..7f6c4a7 100644
--- a/src/java/org/apache/cassandra/locator/Ec2MultiRegionSnitch.java
+++ b/src/java/org/apache/cassandra/locator/Ec2MultiRegionSnitch.java
@@ -33,15 +33,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.
  */
@@ -61,7 +61,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)
     {
@@ -105,7 +105,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);
@@ -116,7 +116,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/2fd3268b/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 fd1756c..c597a74 100644
--- a/src/java/org/apache/cassandra/locator/Ec2Snitch.java
+++ b/src/java/org/apache/cassandra/locator/Ec2Snitch.java
@@ -56,7 +56,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/2fd3268b/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 9189e2e..0918039 100644
--- a/src/java/org/apache/cassandra/locator/EndpointSnitchInfoMBean.java
+++ b/src/java/org/apache/cassandra/locator/EndpointSnitchInfoMBean.java
@@ -25,7 +25,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/2fd3268b/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 7905575..a3031fa 100644
--- a/src/java/org/apache/cassandra/locator/SimpleSeedProvider.java
+++ b/src/java/org/apache/cassandra/locator/SimpleSeedProvider.java
@@ -30,9 +30,9 @@ import org.slf4j.LoggerFactory;
 public class SimpleSeedProvider implements SeedProvider
 {
     private static final Logger logger = LoggerFactory.getLogger(SimpleSeedProvider.class);
-    
+
     private final List<InetAddress> seeds;
-    
+
     public SimpleSeedProvider(Map<String, String> args)
     {
         String[] hosts = args.get("seeds").split(",", -1);
@@ -50,12 +50,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/2fd3268b/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 dcbbc8d..7e72eb4 100644
--- a/src/java/org/apache/cassandra/locator/TokenMetadata.java
+++ b/src/java/org/apache/cassandra/locator/TokenMetadata.java
@@ -301,7 +301,7 @@ public class TokenMetadata
     {
         assert endpoint != null;
         assert isMember(endpoint); // don't want to return nulls
-        
+
         lock.readLock().lock();
         try
         {
@@ -312,7 +312,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/2fd3268b/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 bb34779..a30cb9f 100644
--- a/src/java/org/apache/cassandra/net/AsyncResult.java
+++ b/src/java/org/apache/cassandra/net/AsyncResult.java
@@ -40,16 +40,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
             {
@@ -64,9 +64,9 @@ class AsyncResult implements IAsyncResult
             {
                 throw new AssertionError(ex);
             }
-            
+
             if (!bVal && !done.get())
-            {                                           
+            {
                 throw new TimeoutException("Operation timed out.");
             }
         }
@@ -78,7 +78,7 @@ class AsyncResult implements IAsyncResult
     }
 
     public void result(Message response)
-    {        
+    {
         try
         {
             lock.lock();
@@ -93,7 +93,7 @@ class AsyncResult implements IAsyncResult
         finally
         {
             lock.unlock();
-        }        
+        }
     }
 
     public boolean isLatencyForSnitch()

http://git-wip-us.apache.org/repos/asf/cassandra/blob/2fd3268b/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 1f1f54d..b21f8cd 100644
--- a/src/java/org/apache/cassandra/net/CachingMessageProducer.java
+++ b/src/java/org/apache/cassandra/net/CachingMessageProducer.java
@@ -28,7 +28,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/2fd3268b/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 b4d2bbd..608df8d 100644
--- a/src/java/org/apache/cassandra/net/CallbackInfo.java
+++ b/src/java/org/apache/cassandra/net/CallbackInfo.java
@@ -23,7 +23,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/2fd3268b/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 113a30b..c42f683 100644
--- a/src/java/org/apache/cassandra/net/CompactEndpointSerializationHelper.java
+++ b/src/java/org/apache/cassandra/net/CompactEndpointSerializationHelper.java
@@ -30,9 +30,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/2fd3268b/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 c668048..e5c9232 100644
--- a/src/java/org/apache/cassandra/net/Header.java
+++ b/src/java/org/apache/cassandra/net/Header.java
@@ -36,9 +36,9 @@ public class Header
 
     static
     {
-        serializer = new HeaderSerializer();        
+        serializer = new HeaderSerializer();
     }
-    
+
     public static IVersionedSerializer<Header> serializer()
     {
         return serializer;
@@ -75,7 +75,7 @@ public class Header
     {
         return verb;
     }
-    
+
     byte[] getDetail(String key)
     {
         return details.get(key);
@@ -116,7 +116,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/2fd3268b/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 d866510..b29e59a 100644
--- a/src/java/org/apache/cassandra/net/HeaderTypes.java
+++ b/src/java/org/apache/cassandra/net/HeaderTypes.java
@@ -17,7 +17,7 @@
  */
 package org.apache.cassandra.net;
 
-public class HeaderTypes 
+public class HeaderTypes
 {
     public final static String TASK_PROFILE_CHAIN = "TASK_PROFILE_CHAIN";
     public static final String TASK_ID = "TASK_ID";

http://git-wip-us.apache.org/repos/asf/cassandra/blob/2fd3268b/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 eb6d4dc..0c0f5cb 100644
--- a/src/java/org/apache/cassandra/net/IAsyncResult.java
+++ b/src/java/org/apache/cassandra/net/IAsyncResult.java
@@ -22,7 +22,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.
@@ -31,7 +31,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/2fd3268b/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 921ae3a..dc8a698 100644
--- a/src/java/org/apache/cassandra/net/IncomingTcpConnection.java
+++ b/src/java/org/apache/cassandra/net/IncomingTcpConnection.java
@@ -34,7 +34,7 @@ public class IncomingTcpConnection extends Thread
     private static final Logger logger = LoggerFactory.getLogger(IncomingTcpConnection.class);
 
     private static final int CHUNK_SIZE = 1024 * 1024;
-    
+
     private final Socket socket;
     public final InetAddress from;
 
@@ -73,7 +73,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.
@@ -83,7 +83,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.
@@ -99,7 +99,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)
             {
@@ -111,12 +111,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/2fd3268b/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 ad86b3d..0a9bcae 100644
--- a/src/java/org/apache/cassandra/net/Message.java
+++ b/src/java/org/apache/cassandra/net/Message.java
@@ -38,22 +38,22 @@ public class Message
         this.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);
@@ -63,7 +63,7 @@ public class Message
     {
         return body;
     }
-    
+
     public int getVersion()
     {
         return version;

http://git-wip-us.apache.org/repos/asf/cassandra/blob/2fd3268b/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 dbd5d15..f5379de 100644
--- a/src/java/org/apache/cassandra/net/MessagingService.java
+++ b/src/java/org/apache/cassandra/net/MessagingService.java
@@ -261,7 +261,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);
@@ -340,7 +340,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/2fd3268b/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 a73706e..4f34358 100644
--- a/src/java/org/apache/cassandra/net/OutboundTcpConnection.java
+++ b/src/java/org/apache/cassandra/net/OutboundTcpConnection.java
@@ -49,7 +49,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/2fd3268b/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 cf63979..ff5e940 100644
--- a/src/java/org/apache/cassandra/net/OutboundTcpConnectionPool.java
+++ b/src/java/org/apache/cassandra/net/OutboundTcpConnectionPool.java
@@ -64,14 +64,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.'
@@ -90,12 +90,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/2fd3268b/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 58fe1d7..3bdd4df 100644
--- a/src/java/org/apache/cassandra/net/ResponseVerbHandler.java
+++ b/src/java/org/apache/cassandra/net/ResponseVerbHandler.java
@@ -25,7 +25,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/2fd3268b/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 bc4488c..798f09e 100644
--- a/src/java/org/apache/cassandra/scheduler/IRequestScheduler.java
+++ b/src/java/org/apache/cassandra/scheduler/IRequestScheduler.java
@@ -26,7 +26,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/2fd3268b/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 adae7bf..d3f4ce8 100644
--- a/src/java/org/apache/cassandra/scheduler/NoScheduler.java
+++ b/src/java/org/apache/cassandra/scheduler/NoScheduler.java
@@ -22,7 +22,7 @@ import org.apache.cassandra.config.RequestSchedulerOptions;
 
 /**
  * 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/2fd3268b/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 fd14ed5..2968672 100644
--- a/src/java/org/apache/cassandra/scheduler/RoundRobinScheduler.java
+++ b/src/java/org/apache/cassandra/scheduler/RoundRobinScheduler.java
@@ -29,8 +29,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.
  */
@@ -131,7 +131,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/2fd3268b/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 34d3cc8..4d21842 100644
--- a/src/java/org/apache/cassandra/security/SSLFactory.java
+++ b/src/java/org/apache/cassandra/security/SSLFactory.java
@@ -123,7 +123,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/2fd3268b/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 e15d781..8c3cc51 100644
--- a/src/java/org/apache/cassandra/service/AbstractCassandraDaemon.java
+++ b/src/java/org/apache/cassandra/service/AbstractCassandraDaemon.java
@@ -52,7 +52,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
 {
@@ -75,7 +75,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);
 
@@ -103,11 +103,11 @@ public abstract class AbstractCassandraDaemon implements CassandraDaemon
     private static final 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.
      *
@@ -174,7 +174,7 @@ public abstract class AbstractCassandraDaemon implements CassandraDaemon
             logger.error("Fatal exception during initialization", e);
             System.exit(100);
         }
-        
+
         // load keyspace descriptions.
         try
         {
@@ -185,7 +185,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())
         {
@@ -243,7 +243,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
@@ -252,7 +252,7 @@ public abstract class AbstractCassandraDaemon implements CassandraDaemon
     {
         setup();
     }
-    
+
     /**
      * Start the Cassandra Daemon, assuming that it has already been
      * initialized via {@link #init(String[])}
@@ -272,7 +272,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.
      *
@@ -332,42 +332,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());
@@ -375,7 +375,7 @@ public abstract class AbstractCassandraDaemon implements CassandraDaemon
             System.exit(3);
         }
     }
-    
+
     /**
      * A convenience method to stop and destroy the daemon in one shot.
      */
@@ -384,7 +384,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.
@@ -392,7 +392,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 final ThreadLocal<ClientState> state;
         public CleaningThreadPool(ThreadLocal<ClientState> state, int minWorkerThread, int maxWorkerThreads)

http://git-wip-us.apache.org/repos/asf/cassandra/blob/2fd3268b/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 1b7fc25..4e91dac 100644
--- a/src/java/org/apache/cassandra/service/AntiEntropyService.java
+++ b/src/java/org/apache/cassandra/service/AntiEntropyService.java
@@ -250,7 +250,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,
@@ -442,9 +442,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
             {
@@ -459,7 +459,7 @@ public class AntiEntropyService
             }
             catch (IOException e)
             {
-                throw new IOError(e);            
+                throw new IOError(e);
             }
         }
     }
@@ -478,9 +478,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)
@@ -510,7 +510,7 @@ public class AntiEntropyService
         }
 
         public void doVerb(Message message, String id)
-        { 
+        {
             byte[] bytes = message.getMessageBody();
             DataInputStream buffer = new DataInputStream(new FastByteArrayInputStream(bytes));
 
@@ -563,7 +563,7 @@ public class AntiEntropyService
         {
             return Objects.hashCode(sessionid, endpoint, cf, range);
         }
-        
+
         @Override
         public final boolean equals(Object o)
         {
@@ -573,7 +573,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/2fd3268b/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 71cf273..e4e23bf 100644
--- a/src/java/org/apache/cassandra/service/CassandraDaemon.java
+++ b/src/java/org/apache/cassandra/service/CassandraDaemon.java
@@ -22,7 +22,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
 {
@@ -30,26 +30,25 @@ 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.
@@ -59,15 +58,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/2fd3268b/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 9e1c4bc..db91cc3 100644
--- a/src/java/org/apache/cassandra/service/ClientState.java
+++ b/src/java/org/apache/cassandra/service/ClientState.java
@@ -158,7 +158,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.
@@ -175,10 +175,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.
@@ -192,12 +192,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);
     }
 
@@ -206,7 +206,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/2fd3268b/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 1b59dae..a08e757 100644
--- a/src/java/org/apache/cassandra/service/DatacenterReadCallback.java
+++ b/src/java/org/apache/cassandra/service/DatacenterReadCallback.java
@@ -72,7 +72,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)
     {

http://git-wip-us.apache.org/repos/asf/cassandra/blob/2fd3268b/src/java/org/apache/cassandra/service/DatacenterWriteResponseHandler.java
----------------------------------------------------------------------
diff --git a/src/java/org/apache/cassandra/service/DatacenterWriteResponseHandler.java b/src/java/org/apache/cassandra/service/DatacenterWriteResponseHandler.java
index 0a32c12..c7b6345 100644
--- a/src/java/org/apache/cassandra/service/DatacenterWriteResponseHandler.java
+++ b/src/java/org/apache/cassandra/service/DatacenterWriteResponseHandler.java
@@ -71,7 +71,7 @@ public class DatacenterWriteResponseHandler extends WriteResponseHandler
                 condition.signal();
         }
     }
-    
+
     @Override
     public void assureSufficientLiveNodes() throws UnavailableException
     {

http://git-wip-us.apache.org/repos/asf/cassandra/blob/2fd3268b/src/java/org/apache/cassandra/service/GCInspector.java
----------------------------------------------------------------------
diff --git a/src/java/org/apache/cassandra/service/GCInspector.java b/src/java/org/apache/cassandra/service/GCInspector.java
index 770dfd4..bca8e1c 100644
--- a/src/java/org/apache/cassandra/service/GCInspector.java
+++ b/src/java/org/apache/cassandra/service/GCInspector.java
@@ -41,7 +41,7 @@ public class GCInspector
     final static long INTERVAL_IN_MS = 1000;
     final static long MIN_DURATION = 200;
     final static long MIN_DURATION_TPSTATS = 1000;
-    
+
     public static final GCInspector instance = new GCInspector();
 
     private final HashMap<String, Long> gctimes = new HashMap<String, Long>();
@@ -74,7 +74,7 @@ public class GCInspector
     {
         // don't bother starting a thread that will do nothing.
         if (beans.size() == 0)
-            return;         
+            return;
         Runnable t = new Runnable()
         {
             public void run()
@@ -100,12 +100,12 @@ public class GCInspector
 
             Long previousCount = gccounts.get(gc.getName());
             Long count = gc.getCollectionCount();
-            
+
             if (previousCount == null)
-                previousCount = 0L;           
+                previousCount = 0L;
             if (count.equals(previousCount))
                 continue;
-            
+
             gccounts.put(gc.getName(), count);
 
             MemoryUsage mu = membean.getHeapMemoryUsage();

http://git-wip-us.apache.org/repos/asf/cassandra/blob/2fd3268b/src/java/org/apache/cassandra/service/StorageProxy.java
----------------------------------------------------------------------
diff --git a/src/java/org/apache/cassandra/service/StorageProxy.java b/src/java/org/apache/cassandra/service/StorageProxy.java
index f2a41fd..34ad195 100644
--- a/src/java/org/apache/cassandra/service/StorageProxy.java
+++ b/src/java/org/apache/cassandra/service/StorageProxy.java
@@ -130,7 +130,7 @@ public class StorageProxy implements StorageProxyMBean
                               Collection<InetAddress> targets,
                               IWriteResponseHandler responseHandler,
                               String localDataCenter,
-                              ConsistencyLevel consistency_level) 
+                              ConsistencyLevel consistency_level)
             throws IOException
             {
                 if (logger.isDebugEnabled())
@@ -268,14 +268,14 @@ public class StorageProxy implements StorageProxyMBean
      * Note about hints:
      *
      * | Hinted Handoff | Consist. Level |
-     * | on             |       >=1      | --> wait for hints. We DO NOT notify the handler with handler.response() for hints; 
+     * | on             |       >=1      | --> wait for hints. We DO NOT notify the handler with handler.response() for hints;
      * | on             |       ANY      | --> wait for hints. Responses count towards consistency.
      * | off            |       >=1      | --> DO NOT fire hints. And DO NOT wait for them to complete.
      * | off            |       ANY      | --> DO NOT fire hints. And DO NOT wait for them to complete.
      *
-     * @throws TimeoutException if the hints cannot be written/enqueued 
+     * @throws TimeoutException if the hints cannot be written/enqueued
      */
-    public static void sendToHintedEndpoints(final RowMutation rm, 
+    public static void sendToHintedEndpoints(final RowMutation rm,
                                               Collection<InetAddress> targets,
                                               IWriteResponseHandler responseHandler,
                                               String localDataCenter,
@@ -542,7 +542,7 @@ public class StorageProxy implements StorageProxyMBean
         return performWrite(cm, cm.consistency(), localDataCenter, counterWriteOnCoordinatorPerformer);
     }
 
-    private static Runnable counterWriteTask(final IMutation mutation, 
+    private static Runnable counterWriteTask(final IMutation mutation,
                                              final Collection<InetAddress> targets,
                                              final IWriteResponseHandler responseHandler,
                                              final String localDataCenter,
@@ -944,8 +944,8 @@ public class StorageProxy implements StorageProxyMBean
         for (InetAddress endpoint : liveHosts)
         {
             Message message = new Message(FBUtilities.getBroadcastAddress(),
-                                          StorageService.Verb.SCHEMA_CHECK, 
-                                          ArrayUtils.EMPTY_BYTE_ARRAY, 
+                                          StorageService.Verb.SCHEMA_CHECK,
+                                          ArrayUtils.EMPTY_BYTE_ARRAY,
                                           Gossiper.instance.getVersion(endpoint));
             MessagingService.instance().sendRR(message, endpoint, cb);
         }
@@ -1145,7 +1145,7 @@ public class StorageProxy implements StorageProxyMBean
     {
         if (!hintedHandoffEnabled)
             return false;
-        
+
         boolean hintWindowExpired = Gossiper.instance.getEndpointDowntime(ep) > maxHintWindow;
         if (hintWindowExpired)
             logger.debug("not hinting {} which has been down {}ms", ep, Gossiper.instance.getEndpointDowntime(ep));

http://git-wip-us.apache.org/repos/asf/cassandra/blob/2fd3268b/src/java/org/apache/cassandra/service/StorageService.java
----------------------------------------------------------------------
diff --git a/src/java/org/apache/cassandra/service/StorageService.java b/src/java/org/apache/cassandra/service/StorageService.java
index 495dfef..3f3779e 100644
--- a/src/java/org/apache/cassandra/service/StorageService.java
+++ b/src/java/org/apache/cassandra/service/StorageService.java
@@ -949,7 +949,7 @@ public class StorageService implements IEndpointStateChangeSubscriber, StorageSe
                 return Lists.newArrayList();
             }
         });
-        
+
         List<Range<Token>> ranges = getAllRanges(tokenMetadata.sortedTokens());
         for (Range<Token> range : ranges)
         {
@@ -2639,20 +2639,20 @@ public class StorageService implements IEndpointStateChangeSubscriber, StorageSe
     }
 
     public Map<String, Float> effectiveOwnership(String keyspace) throws ConfigurationException
-    {   
+    {
         Map<String, Float> effective = Maps.newHashMap();
         if (Schema.instance.getNonSystemTables().size() <= 0)
             throw new ConfigurationException("Couldn't find any Non System Keyspaces to infer replication topology");
         if (keyspace == null && !hasSameReplication(Schema.instance.getNonSystemTables()))
             throw new ConfigurationException("Non System keyspaces doesnt have the same topology");
-        
+
         if (keyspace == null)
             keyspace = Schema.instance.getNonSystemTables().get(0);
-        
+
         List<Token> sortedTokens = new ArrayList<Token>(tokenMetadata.getTokenToEndpointMapForReading().keySet());
         Collections.sort(sortedTokens);
         Map<Token, Float> ownership = getPartitioner().describeOwnership(sortedTokens);
-        
+
         for (Entry<InetAddress, Collection<Range<Token>>> ranges : constructEndpointToRangeMap(keyspace).entrySet())
         {
             Token token = tokenMetadata.getToken(ranges.getKey());
@@ -2664,7 +2664,7 @@ public class StorageService implements IEndpointStateChangeSubscriber, StorageSe
         }
         return effective;
     }
-    
+
     private boolean hasSameReplication(List<String> list)
     {
         if (list.isEmpty())
@@ -2673,8 +2673,8 @@ public class StorageService implements IEndpointStateChangeSubscriber, StorageSe
         {
             KSMetaData ksm1 = Schema.instance.getKSMetaData(Schema.instance.getNonSystemTables().get(i));
             KSMetaData ksm2 = Schema.instance.getKSMetaData(Schema.instance.getNonSystemTables().get(i + 1));
-            if (!ksm1.strategyClass.equals(ksm2.strategyClass) || 
-                    !Iterators.elementsEqual(ksm1.strategyOptions.entrySet().iterator(), 
+            if (!ksm1.strategyClass.equals(ksm2.strategyClass) ||
+                    !Iterators.elementsEqual(ksm1.strategyOptions.entrySet().iterator(),
                                              ksm2.strategyOptions.entrySet().iterator()))
                 return false;
         }
@@ -2756,7 +2756,7 @@ public class StorageService implements IEndpointStateChangeSubscriber, StorageSe
                 latch.countDown();
                 continue;
             }
-            
+
             final String table = entry.getKey();
 
             final Set<Map.Entry<Range<Token>, InetAddress>> pending = new HashSet<Map.Entry<Range<Token>, InetAddress>>(rangesWithEndpoints.entries());
@@ -2969,7 +2969,7 @@ public class StorageService implements IEndpointStateChangeSubscriber, StorageSe
             sampledKeys.add(key.getToken().toString());
         return sampledKeys;
     }
-    
+
     public void rebuildSecondaryIndex(String ksName, String cfName, String... idxNames)
     {
         ColumnFamilyStore.rebuildSecondaryIndex(ksName, cfName, idxNames);

http://git-wip-us.apache.org/repos/asf/cassandra/blob/2fd3268b/src/java/org/apache/cassandra/service/StorageServiceMBean.java
----------------------------------------------------------------------
diff --git a/src/java/org/apache/cassandra/service/StorageServiceMBean.java b/src/java/org/apache/cassandra/service/StorageServiceMBean.java
index 62f5196..849ade3 100644
--- a/src/java/org/apache/cassandra/service/StorageServiceMBean.java
+++ b/src/java/org/apache/cassandra/service/StorageServiceMBean.java
@@ -295,7 +295,7 @@ public interface StorageServiceMBean
     public Map<String, Float> getOwnership();
 
     /**
-     * Effective ownership is % of the data each node owns given the keyspace 
+     * Effective ownership is % of the data each node owns given the keyspace
      * we calculate the percentage using replication factor.
      * If Keyspace == null, this method will try to verify if all the keyspaces
      * in the cluster have the same replication strategies and if yes then we will
@@ -339,7 +339,7 @@ public interface StorageServiceMBean
     public boolean isJoined();
 
     public int getExceptionCount();
-    
+
     public void setStreamThroughputMbPerSec(int value);
     public int getStreamThroughputMbPerSec();
 
@@ -373,7 +373,7 @@ public interface StorageServiceMBean
     /**
      * Return a List of Tokens representing a sample of keys
      * across all ColumnFamilyStores
-     * 
+     *
      * @return set of Tokens as Strings
      */
     public List<String> getRangeKeySample();

http://git-wip-us.apache.org/repos/asf/cassandra/blob/2fd3268b/src/java/org/apache/cassandra/streaming/FileStreamTask.java
----------------------------------------------------------------------
diff --git a/src/java/org/apache/cassandra/streaming/FileStreamTask.java b/src/java/org/apache/cassandra/streaming/FileStreamTask.java
index 23621cf..b343040 100644
--- a/src/java/org/apache/cassandra/streaming/FileStreamTask.java
+++ b/src/java/org/apache/cassandra/streaming/FileStreamTask.java
@@ -44,7 +44,7 @@ import org.slf4j.LoggerFactory;
 public class FileStreamTask extends WrappedRunnable
 {
     private static final Logger logger = LoggerFactory.getLogger(FileStreamTask.class);
-    
+
     public static final int CHUNK_SIZE = 64 * 1024;
     // around 10 minutes at the default rpctimeout
     public static final int MAX_CONNECT_ATTEMPTS = 8;
@@ -83,7 +83,7 @@ public class FileStreamTask extends WrappedRunnable
             }
         });
     }
-    
+
     public void runMayThrow() throws IOException
     {
         try