You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@avro.apache.org by ni...@apache.org on 2017/12/29 17:10:14 UTC

[04/19] avro git commit: AVRO-2117: Cleanup C# - Remove trailing spaces

AVRO-2117: Cleanup C# - Remove trailing spaces


Project: http://git-wip-us.apache.org/repos/asf/avro/repo
Commit: http://git-wip-us.apache.org/repos/asf/avro/commit/42afa621
Tree: http://git-wip-us.apache.org/repos/asf/avro/tree/42afa621
Diff: http://git-wip-us.apache.org/repos/asf/avro/diff/42afa621

Branch: refs/heads/master
Commit: 42afa621c8a3ce6fc2d1de73b15db5f253e5990d
Parents: 706d8ce
Author: Niels Basjes <nb...@bol.com>
Authored: Wed Dec 13 15:25:01 2017 +0100
Committer: Niels Basjes <nb...@bol.com>
Committed: Fri Dec 29 14:43:23 2017 +0100

----------------------------------------------------------------------
 lang/csharp/src/apache/ipc/CallFuture.cs        |  2 +-
 .../csharp/src/apache/ipc/HttpListenerServer.cs |  2 +-
 lang/csharp/src/apache/ipc/HttpTransceiver.cs   |  2 +-
 lang/csharp/src/apache/ipc/Requestor.cs         |  2 +-
 lang/csharp/src/apache/ipc/Responder.cs         |  2 +-
 lang/csharp/src/apache/ipc/SocketServer.cs      |  2 +-
 lang/csharp/src/apache/ipc/SocketTransceiver.cs |  2 +-
 .../src/apache/ipc/org/apache/avro/ipc/MD5.cs   |  2 +-
 lang/csharp/src/apache/main/CodeGen/CodeGen.cs  | 12 ++--
 lang/csharp/src/apache/main/File/Codec.cs       |  6 +-
 lang/csharp/src/apache/main/File/DataBlock.cs   |  2 +-
 .../src/apache/main/File/DataFileConstants.cs   |  6 +-
 .../src/apache/main/File/DataFileReader.cs      | 22 +++----
 .../src/apache/main/File/DataFileWriter.cs      | 30 +++++-----
 lang/csharp/src/apache/main/File/IFileReader.cs |  6 +-
 lang/csharp/src/apache/main/File/IFileWriter.cs |  8 +--
 .../src/apache/main/Generic/DatumReader.cs      |  2 +-
 .../src/apache/main/Generic/GenericFixed.cs     |  2 +-
 .../src/apache/main/Generic/GenericReader.cs    |  2 +-
 .../main/Generic/PreresolvingDatumReader.cs     |  8 +--
 .../main/Generic/PreresolvingDatumWriter.cs     |  2 +-
 lang/csharp/src/apache/main/IO/BinaryDecoder.cs |  4 +-
 lang/csharp/src/apache/main/IO/BinaryEncoder.cs |  8 +--
 .../src/apache/main/IO/ByteBufferInputStream.cs |  2 +-
 .../apache/main/IO/ByteBufferOutputStream.cs    |  2 +-
 lang/csharp/src/apache/main/IO/Decoder.cs       |  4 +-
 lang/csharp/src/apache/main/IO/Encoder.cs       |  2 +-
 lang/csharp/src/apache/main/IO/ICallback.cs     |  2 +-
 lang/csharp/src/apache/main/IO/Resolver.cs      |  2 +-
 .../apache/main/Properties/Settings.Designer.cs |  8 +--
 lang/csharp/src/apache/main/Protocol/Message.cs | 10 ++--
 .../csharp/src/apache/main/Protocol/Protocol.cs | 14 ++---
 .../csharp/src/apache/main/Schema/EnumSchema.cs |  6 +-
 lang/csharp/src/apache/main/Schema/Field.cs     |  4 +-
 .../src/apache/main/Schema/NamedSchema.cs       |  4 +-
 lang/csharp/src/apache/main/Schema/Property.cs  | 12 ++--
 .../src/apache/main/Schema/RecordSchema.cs      | 14 ++---
 lang/csharp/src/apache/main/Schema/Schema.cs    |  8 +--
 .../csharp/src/apache/main/Schema/SchemaName.cs |  4 +-
 .../src/apache/main/Specific/ObjectCreator.cs   | 16 ++---
 .../apache/main/Specific/SpecificDatumReader.cs |  4 +-
 .../apache/main/Specific/SpecificDatumWriter.cs |  8 +--
 .../src/apache/main/Specific/SpecificFixed.cs   |  2 +-
 .../src/apache/main/Specific/SpecificReader.cs  | 10 ++--
 .../src/apache/main/Specific/SpecificWriter.cs  |  4 +-
 lang/csharp/src/apache/perf/PerfTest.cs         |  2 +-
 lang/csharp/src/apache/perf/com/foo/MyFixed.cs  |  2 +-
 .../src/apache/test/CodGen/CodeGenTest.cs       | 16 ++---
 lang/csharp/src/apache/test/File/FileTests.cs   | 34 +++++------
 .../src/apache/test/Generic/GenericTests.cs     |  2 +-
 .../org/apache/avro/test/FixedTest.cs           |  2 +-
 .../GeneratedFiles/org/apache/avro/test/MD5.cs  |  2 +-
 .../Ipc/SocketServerConcurrentExecutionTest.cs  |  4 +-
 .../test/Ipc/SocketServerWithCallbacksTest.cs   | 18 +++---
 .../Ipc/SocketTransceiverWhenServerStopsTest.cs |  2 +-
 .../src/apache/test/Protocol/ProtocolTest.cs    | 22 +++----
 lang/csharp/src/apache/test/Schema/AliasTest.cs | 62 ++++++++++----------
 .../src/apache/test/Schema/SchemaTests.cs       |  6 +-
 .../src/apache/test/Specific/SpecificTests.cs   | 38 ++++++------
 lang/csharp/src/apache/test/Utils/CaseFinder.cs |  2 +-
 60 files changed, 246 insertions(+), 246 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/avro/blob/42afa621/lang/csharp/src/apache/ipc/CallFuture.cs
----------------------------------------------------------------------
diff --git a/lang/csharp/src/apache/ipc/CallFuture.cs b/lang/csharp/src/apache/ipc/CallFuture.cs
index 15400d2..2ab56ec 100644
--- a/lang/csharp/src/apache/ipc/CallFuture.cs
+++ b/lang/csharp/src/apache/ipc/CallFuture.cs
@@ -21,7 +21,7 @@ using Avro.IO;
 
 namespace Avro.ipc
 {
-    public class CallFuture<T> : ICallback<T>, IDisposable 
+    public class CallFuture<T> : ICallback<T>, IDisposable
     {
         private readonly ICallback<T> chainedCallback;
         private CountdownLatch latch = new CountdownLatch(1);

http://git-wip-us.apache.org/repos/asf/avro/blob/42afa621/lang/csharp/src/apache/ipc/HttpListenerServer.cs
----------------------------------------------------------------------
diff --git a/lang/csharp/src/apache/ipc/HttpListenerServer.cs b/lang/csharp/src/apache/ipc/HttpListenerServer.cs
index 66de091..4e78b19 100644
--- a/lang/csharp/src/apache/ipc/HttpListenerServer.cs
+++ b/lang/csharp/src/apache/ipc/HttpListenerServer.cs
@@ -44,7 +44,7 @@ namespace Avro.ipc
         protected void HttpListenerCallback(IAsyncResult result)
         {
             try
-            {                
+            {
                 HttpListener listener = (HttpListener)result.AsyncState;
                 if (_listener != listener) //the server which began this callback was stopped - just exit
                     return;

http://git-wip-us.apache.org/repos/asf/avro/blob/42afa621/lang/csharp/src/apache/ipc/HttpTransceiver.cs
----------------------------------------------------------------------
diff --git a/lang/csharp/src/apache/ipc/HttpTransceiver.cs b/lang/csharp/src/apache/ipc/HttpTransceiver.cs
index 48851f1..ce8eda0 100644
--- a/lang/csharp/src/apache/ipc/HttpTransceiver.cs
+++ b/lang/csharp/src/apache/ipc/HttpTransceiver.cs
@@ -112,7 +112,7 @@ namespace Avro.ipc
         protected HttpWebRequest CreateAvroHttpRequest(long contentLength)
         {
             HttpWebRequest wr = (HttpWebRequest)WebRequest.Create(_modelRequest.RequestUri);
-            
+
             //TODO: what else to copy from model request?
             wr.AllowAutoRedirect = _modelRequest.AllowAutoRedirect;
             wr.AllowWriteStreamBuffering = _modelRequest.AllowWriteStreamBuffering;

http://git-wip-us.apache.org/repos/asf/avro/blob/42afa621/lang/csharp/src/apache/ipc/Requestor.cs
----------------------------------------------------------------------
diff --git a/lang/csharp/src/apache/ipc/Requestor.cs b/lang/csharp/src/apache/ipc/Requestor.cs
index 29ba211..cf8118b 100644
--- a/lang/csharp/src/apache/ipc/Requestor.cs
+++ b/lang/csharp/src/apache/ipc/Requestor.cs
@@ -357,7 +357,7 @@ namespace Avro.ipc
         }
 
 
-        private class TransceiverCallback<T> : ICallback<IList<MemoryStream>> 
+        private class TransceiverCallback<T> : ICallback<IList<MemoryStream>>
         {
             private readonly Requestor requestor;
             private readonly RpcRequest request;

http://git-wip-us.apache.org/repos/asf/avro/blob/42afa621/lang/csharp/src/apache/ipc/Responder.cs
----------------------------------------------------------------------
diff --git a/lang/csharp/src/apache/ipc/Responder.cs b/lang/csharp/src/apache/ipc/Responder.cs
index a108393..1c5199f 100644
--- a/lang/csharp/src/apache/ipc/Responder.cs
+++ b/lang/csharp/src/apache/ipc/Responder.cs
@@ -60,7 +60,7 @@ namespace Avro.ipc
                 protocols[localHash.Schema] = local;
             }
         }
-        
+
         public Protocol Local
         {
             get { return local; }

http://git-wip-us.apache.org/repos/asf/avro/blob/42afa621/lang/csharp/src/apache/ipc/SocketServer.cs
----------------------------------------------------------------------
diff --git a/lang/csharp/src/apache/ipc/SocketServer.cs b/lang/csharp/src/apache/ipc/SocketServer.cs
index 60a3a56..6e49697 100644
--- a/lang/csharp/src/apache/ipc/SocketServer.cs
+++ b/lang/csharp/src/apache/ipc/SocketServer.cs
@@ -78,7 +78,7 @@ namespace Avro.ipc
         public void Stop()
         {
             cancellationRequested = true;
-            
+
             while (serverThread.IsAlive)
             {
                 Thread.Sleep(10);

http://git-wip-us.apache.org/repos/asf/avro/blob/42afa621/lang/csharp/src/apache/ipc/SocketTransceiver.cs
----------------------------------------------------------------------
diff --git a/lang/csharp/src/apache/ipc/SocketTransceiver.cs b/lang/csharp/src/apache/ipc/SocketTransceiver.cs
index a6ea2a0..5beea47 100644
--- a/lang/csharp/src/apache/ipc/SocketTransceiver.cs
+++ b/lang/csharp/src/apache/ipc/SocketTransceiver.cs
@@ -196,7 +196,7 @@ namespace Avro.ipc
         {
             if (length == 0)
                 return;
-            
+
             int numReceived = 0;
             do
             {

http://git-wip-us.apache.org/repos/asf/avro/blob/42afa621/lang/csharp/src/apache/ipc/org/apache/avro/ipc/MD5.cs
----------------------------------------------------------------------
diff --git a/lang/csharp/src/apache/ipc/org/apache/avro/ipc/MD5.cs b/lang/csharp/src/apache/ipc/org/apache/avro/ipc/MD5.cs
index afbb251..af9cafe 100644
--- a/lang/csharp/src/apache/ipc/org/apache/avro/ipc/MD5.cs
+++ b/lang/csharp/src/apache/ipc/org/apache/avro/ipc/MD5.cs
@@ -17,7 +17,7 @@ namespace org.apache.avro.ipc
 	{
 		private static Schema _SCHEMA = Avro.Schema.Parse("{\"type\":\"fixed\",\"name\":\"MD5\",\"namespace\":\"org.apache.avro.ipc\",\"size\":16}");
 		private static uint fixedSize = 16;
-		public MD5() : 
+		public MD5() :
 				base(fixedSize)
 		{
 		}

http://git-wip-us.apache.org/repos/asf/avro/blob/42afa621/lang/csharp/src/apache/main/CodeGen/CodeGen.cs
----------------------------------------------------------------------
diff --git a/lang/csharp/src/apache/main/CodeGen/CodeGen.cs b/lang/csharp/src/apache/main/CodeGen/CodeGen.cs
index aa31920..7e70a02 100644
--- a/lang/csharp/src/apache/main/CodeGen/CodeGen.cs
+++ b/lang/csharp/src/apache/main/CodeGen/CodeGen.cs
@@ -45,7 +45,7 @@ namespace Avro
         public IList<Protocol> Protocols { get; private set; }
 
         /// <summary>
-        /// List of generated namespaces 
+        /// List of generated namespaces
         /// </summary>
         protected Dictionary<string, CodeNamespace> namespaceLookup = new Dictionary<string, CodeNamespace>(StringComparer.Ordinal);
 
@@ -83,7 +83,7 @@ namespace Avro
         /// <returns></returns>
         protected virtual CodeNamespace addNamespace(string name)
         {
-            if (string.IsNullOrEmpty(name)) 
+            if (string.IsNullOrEmpty(name))
                 throw new ArgumentNullException("name", "name cannot be null.");
 
             CodeNamespace ns = null;
@@ -318,7 +318,7 @@ namespace Avro
             if (string.IsNullOrEmpty(nspace))
                 throw new CodeGenException("Namespace required for enum schema " + enumschema.Name);
             CodeNamespace codens = addNamespace(nspace);
-            
+
             codens.Types.Add(ctd);
         }
 
@@ -407,7 +407,7 @@ namespace Avro
             ctd.BaseTypes.Add(protocolNameMangled);
 
             // Need to override
-            
+
 
 
             AddProtocolDocumentation(protocol, ctd);
@@ -648,7 +648,7 @@ namespace Avro
         }
 
         /// <summary>
-        /// Gets the string representation of the schema's data type 
+        /// Gets the string representation of the schema's data type
         /// </summary>
         /// <param name="schema">schema</param>
         /// <param name="nullible">flag to indicate union with null</param>
@@ -756,7 +756,7 @@ namespace Avro
         /// <param name="ctd">CodeTypeDeclaration for the class</param>
         protected virtual void createSchemaField(Schema schema, CodeTypeDeclaration ctd, bool overrideFlag)
         {
-            // create schema field 
+            // create schema field
             var ctrfield = new CodeTypeReference("Schema");
             string schemaFname = "_SCHEMA";
             var codeField = new CodeMemberField(ctrfield, schemaFname);

http://git-wip-us.apache.org/repos/asf/avro/blob/42afa621/lang/csharp/src/apache/main/File/Codec.cs
----------------------------------------------------------------------
diff --git a/lang/csharp/src/apache/main/File/Codec.cs b/lang/csharp/src/apache/main/File/Codec.cs
index 60453ae..a82a379 100644
--- a/lang/csharp/src/apache/main/File/Codec.cs
+++ b/lang/csharp/src/apache/main/File/Codec.cs
@@ -65,13 +65,13 @@ namespace Avro.File
         public enum Type
         {
             Deflate,
-            //Snappy 
+            //Snappy
             Null
         };
 
         /// <summary>
         /// Factory method to return child
-        /// codec instance based on Codec.Type  
+        /// codec instance based on Codec.Type
         /// </summary>
         /// <param name="codecType"></param>
         /// <returns></returns>
@@ -88,7 +88,7 @@ namespace Avro.File
 
         /// <summary>
         /// Factory method to return child
-        /// codec instance based on string type  
+        /// codec instance based on string type
         /// </summary>
         /// <param name="codecType"></param>
         /// <returns></returns>

http://git-wip-us.apache.org/repos/asf/avro/blob/42afa621/lang/csharp/src/apache/main/File/DataBlock.cs
----------------------------------------------------------------------
diff --git a/lang/csharp/src/apache/main/File/DataBlock.cs b/lang/csharp/src/apache/main/File/DataBlock.cs
index 8dfe39c..cadeec4 100644
--- a/lang/csharp/src/apache/main/File/DataBlock.cs
+++ b/lang/csharp/src/apache/main/File/DataBlock.cs
@@ -27,7 +27,7 @@ namespace Avro.File
         public byte[] Data { get;  set; }
         public long NumberOfEntries { get; set; }
         public long BlockSize { get; set; }
-       
+
         public DataBlock(long numberOfEntries, long blockSize)
         {
             this.NumberOfEntries = numberOfEntries;

http://git-wip-us.apache.org/repos/asf/avro/blob/42afa621/lang/csharp/src/apache/main/File/DataFileConstants.cs
----------------------------------------------------------------------
diff --git a/lang/csharp/src/apache/main/File/DataFileConstants.cs b/lang/csharp/src/apache/main/File/DataFileConstants.cs
index cb4b482..e3afdc5 100644
--- a/lang/csharp/src/apache/main/File/DataFileConstants.cs
+++ b/lang/csharp/src/apache/main/File/DataFileConstants.cs
@@ -32,9 +32,9 @@ namespace Avro.File
         public const string MetaDataReserved = "avro";
 
         public const int Version = 1;
-        public static byte[] Magic = { (byte)'O', 
-                                       (byte)'b', 
-                                       (byte)'j', 
+        public static byte[] Magic = { (byte)'O',
+                                       (byte)'b',
+                                       (byte)'j',
                                        (byte)Version };
 
         public const int NullCodecHash = 2;

http://git-wip-us.apache.org/repos/asf/avro/blob/42afa621/lang/csharp/src/apache/main/File/DataFileReader.cs
----------------------------------------------------------------------
diff --git a/lang/csharp/src/apache/main/File/DataFileReader.cs b/lang/csharp/src/apache/main/File/DataFileReader.cs
index e96686d..0e81d9f 100644
--- a/lang/csharp/src/apache/main/File/DataFileReader.cs
+++ b/lang/csharp/src/apache/main/File/DataFileReader.cs
@@ -104,7 +104,7 @@ namespace Avro.File
             inStream.Seek(0, SeekOrigin.Begin);
 
             if (magic.SequenceEqual(DataFileConstants.Magic))   // current format
-                return new DataFileReader<T>(inStream, readerSchema, datumReaderFactory);         // (not supporting 1.2 or below, format) 
+                return new DataFileReader<T>(inStream, readerSchema, datumReaderFactory);         // (not supporting 1.2 or below, format)
 
             throw new AvroRuntimeException("Not an Avro data file");
         }
@@ -140,7 +140,7 @@ namespace Avro.File
             }
             catch (KeyNotFoundException)
             {
-                return null; 
+                return null;
             }
         }
 
@@ -158,7 +158,7 @@ namespace Avro.File
             }
             try
             {
-                return System.Text.Encoding.UTF8.GetString(value);          
+                return System.Text.Encoding.UTF8.GetString(value);
             }
             catch (Exception e)
             {
@@ -179,7 +179,7 @@ namespace Avro.File
         {
             Seek(position);
             // work around an issue where 1.5.4 C stored sync in metadata
-            if ((position == 0) && (GetMeta(DataFileConstants.MetaDataSync) != null)) 
+            if ((position == 0) && (GetMeta(DataFileConstants.MetaDataSync) != null))
             {
                 Init(_stream); // re-init to skip header
                 return;
@@ -236,7 +236,7 @@ namespace Avro.File
                 if (_blockRemaining == 0)
                 {
                     // TODO: Check that the (block) stream is not partially read
-                    /*if (_datumDecoder != null) 
+                    /*if (_datumDecoder != null)
                     { }*/
                     if (HasNextBlock())
                     {
@@ -270,7 +270,7 @@ namespace Avro.File
             _decoder = new BinaryDecoder(stream);
             _syncBuffer = new byte[DataFileConstants.SyncSize];
 
-            // read magic 
+            // read magic
             byte[] firstBytes = new byte[DataFileConstants.Magic.Length];
             try
             {
@@ -283,7 +283,7 @@ namespace Avro.File
             if (!firstBytes.SequenceEqual(DataFileConstants.Magic))
                 throw new AvroRuntimeException("Not a valid data file!");
 
-            // read meta data 
+            // read meta data
             long len = _decoder.ReadMapStart();
             if (len > 0)
             {
@@ -298,10 +298,10 @@ namespace Avro.File
                 } while ((len = _decoder.ReadMapNext()) != 0);
             }
 
-            // read in sync data 
+            // read in sync data
             _decoder.ReadFixed(_header.SyncData);
 
-            // parse schema and set codec 
+            // parse schema and set codec
             _header.Schema = Schema.Parse(GetMetaString(DataFileConstants.MetaDataSchema));
             _reader = _datumReaderFactory(_header.Schema, _readerSchema ?? _header.Schema);
             _codec = ResolveCodec();
@@ -398,11 +398,11 @@ namespace Avro.File
         {
             try
             {
-                // block currently being read 
+                // block currently being read
                 if (_availableBlock)
                     return true;
 
-                // check to ensure still data to read 
+                // check to ensure still data to read
                 if (!DataLeft())
                     return false;
 

http://git-wip-us.apache.org/repos/asf/avro/blob/42afa621/lang/csharp/src/apache/main/File/DataFileWriter.cs
----------------------------------------------------------------------
diff --git a/lang/csharp/src/apache/main/File/DataFileWriter.cs b/lang/csharp/src/apache/main/File/DataFileWriter.cs
index a26d224..825e4b3 100644
--- a/lang/csharp/src/apache/main/File/DataFileWriter.cs
+++ b/lang/csharp/src/apache/main/File/DataFileWriter.cs
@@ -41,7 +41,7 @@ namespace Avro.File
         private IDictionary<string, byte[]> _metaData;
 
         /// <summary>
-        /// Open a new writer instance to write  
+        /// Open a new writer instance to write
         /// to a file path, using a Null codec
         /// </summary>
         /// <param name="writer"></param>
@@ -53,7 +53,7 @@ namespace Avro.File
         }
 
         /// <summary>
-        /// Open a new writer instance to write  
+        /// Open a new writer instance to write
         /// to an output stream, using a Null codec
         /// </summary>
         /// <param name="writer"></param>
@@ -65,7 +65,7 @@ namespace Avro.File
         }
 
         /// <summary>
-        /// Open a new writer instance to write  
+        /// Open a new writer instance to write
         /// to a file path with a specified codec
         /// </summary>
         /// <param name="writer"></param>
@@ -143,7 +143,7 @@ namespace Avro.File
             _syncInterval = syncInterval;
         }
 
-        public void Append(T datum) 
+        public void Append(T datum)
         {
             AssertOpen();
             EnsureHeader();
@@ -238,8 +238,8 @@ namespace Avro.File
             //SetMetaInternal(DataFileConstants.MetaDataSync, _syncData); - Avro 1.5.4 C
             SetMetaInternal(DataFileConstants.MetaDataCodec, GetByteValue(_codec.GetName()));
             SetMetaInternal(DataFileConstants.MetaDataSchema, GetByteValue(_schema.ToString()));
-            
-            // write metadata 
+
+            // write metadata
             int size = _metaData.Count;
             _encoder.WriteInt(size);
 
@@ -262,21 +262,21 @@ namespace Avro.File
             return _blockStream.Position;
         }
 
-        private void WriteBlock() 
-        { 
-            if (_blockCount > 0) 
+        private void WriteBlock()
+        {
+            if (_blockCount > 0)
             {
                 byte[] dataToWrite = _blockStream.ToArray();
 
-                // write count 
+                // write count
                 _encoder.WriteLong(_blockCount);
 
-                // write data 
+                // write data
                 _encoder.WriteBytes(_codec.Compress(dataToWrite));
-                    
-                // write sync marker 
+
+                // write sync marker
                 _encoder.WriteFixed(_syncData);
-            
+
                 // reset / re-init block
                 _blockCount = 0;
                 _blockStream = new MemoryStream();
@@ -301,7 +301,7 @@ namespace Avro.File
         {
             _metaData.Add(key, value);
         }
-  
+
         private byte[] GetByteValue(string value)
         {
             return System.Text.Encoding.UTF8.GetBytes(value);

http://git-wip-us.apache.org/repos/asf/avro/blob/42afa621/lang/csharp/src/apache/main/File/IFileReader.cs
----------------------------------------------------------------------
diff --git a/lang/csharp/src/apache/main/File/IFileReader.cs b/lang/csharp/src/apache/main/File/IFileReader.cs
index 4984fa3..6e4fdf7 100644
--- a/lang/csharp/src/apache/main/File/IFileReader.cs
+++ b/lang/csharp/src/apache/main/File/IFileReader.cs
@@ -25,14 +25,14 @@ namespace Avro.File
     public interface IFileReader<T> : IDisposable
     {
         /// <summary>
-        /// Return the header for the input 
+        /// Return the header for the input
         /// file / stream
         /// </summary>
         /// <returns></returns>
         Header GetHeader();
 
         /// <summary>
-        /// Return the schema as read from 
+        /// Return the schema as read from
         /// the input file / stream
         /// </summary>
         /// <returns></returns>
@@ -97,7 +97,7 @@ namespace Avro.File
         long PreviousSync();
 
         /// <summary>
-        /// Move to a specific, known synchronization point, 
+        /// Move to a specific, known synchronization point,
         /// one returned from IFileWriter.Sync() while writing
         /// </summary>
         /// <param name="position"></param>

http://git-wip-us.apache.org/repos/asf/avro/blob/42afa621/lang/csharp/src/apache/main/File/IFileWriter.cs
----------------------------------------------------------------------
diff --git a/lang/csharp/src/apache/main/File/IFileWriter.cs b/lang/csharp/src/apache/main/File/IFileWriter.cs
index d727b21..346ec62 100644
--- a/lang/csharp/src/apache/main/File/IFileWriter.cs
+++ b/lang/csharp/src/apache/main/File/IFileWriter.cs
@@ -66,9 +66,9 @@ namespace Avro.File
         void SetMeta(String key, string value);
 
         /// <summary>
-        /// Set the synchronization interval for this 
-        /// file / stream, in bytes. Valid values range 
-        /// from 32 to 2^30. Suggested values are 
+        /// Set the synchronization interval for this
+        /// file / stream, in bytes. Valid values range
+        /// from 32 to 2^30. Suggested values are
         /// between 2K and 2M
         /// </summary>
         /// <param name="syncInterval"></param>
@@ -76,7 +76,7 @@ namespace Avro.File
         void SetSyncInterval(int syncInterval);
 
         /// <summary>
-        /// Forces the end of the current block, 
+        /// Forces the end of the current block,
         /// emitting a synchronization marker
         /// </summary>
         /// <returns></returns>

http://git-wip-us.apache.org/repos/asf/avro/blob/42afa621/lang/csharp/src/apache/main/Generic/DatumReader.cs
----------------------------------------------------------------------
diff --git a/lang/csharp/src/apache/main/Generic/DatumReader.cs b/lang/csharp/src/apache/main/Generic/DatumReader.cs
index 954aa40..3f79062 100644
--- a/lang/csharp/src/apache/main/Generic/DatumReader.cs
+++ b/lang/csharp/src/apache/main/Generic/DatumReader.cs
@@ -30,7 +30,7 @@ namespace Avro.Generic
         /// Read a datum.  Traverse the schema, depth-first, reading all leaf values
         /// in the schema into a datum that is returned.  If the provided datum is
         /// non-null it may be reused and returned.
-        /// </summary>        
+        /// </summary>
         T Read(T reuse, Decoder decoder);
     }
 }

http://git-wip-us.apache.org/repos/asf/avro/blob/42afa621/lang/csharp/src/apache/main/Generic/GenericFixed.cs
----------------------------------------------------------------------
diff --git a/lang/csharp/src/apache/main/Generic/GenericFixed.cs b/lang/csharp/src/apache/main/Generic/GenericFixed.cs
index 8b94a52..dec0877 100644
--- a/lang/csharp/src/apache/main/Generic/GenericFixed.cs
+++ b/lang/csharp/src/apache/main/Generic/GenericFixed.cs
@@ -62,7 +62,7 @@ namespace Avro.Generic
             Value = value;
         }
 
-        protected GenericFixed(uint size) 
+        protected GenericFixed(uint size)
         {
             this.value = new byte[size];
         }

http://git-wip-us.apache.org/repos/asf/avro/blob/42afa621/lang/csharp/src/apache/main/Generic/GenericReader.cs
----------------------------------------------------------------------
diff --git a/lang/csharp/src/apache/main/Generic/GenericReader.cs b/lang/csharp/src/apache/main/Generic/GenericReader.cs
index d57c6c2..35bbaaf 100644
--- a/lang/csharp/src/apache/main/Generic/GenericReader.cs
+++ b/lang/csharp/src/apache/main/Generic/GenericReader.cs
@@ -259,7 +259,7 @@ namespace Avro.Generic
             foreach (Field rf in rs)
             {
                 if (writerSchema.Contains(rf.Name)) continue;
-                
+
                 defaultStream.Position = 0; // reset for writing
                 Resolver.EncodeDefaultValue(defaultEncoder, rf.Schema, rf.DefaultValue);
                 defaultStream.Flush();

http://git-wip-us.apache.org/repos/asf/avro/blob/42afa621/lang/csharp/src/apache/main/Generic/PreresolvingDatumReader.cs
----------------------------------------------------------------------
diff --git a/lang/csharp/src/apache/main/Generic/PreresolvingDatumReader.cs b/lang/csharp/src/apache/main/Generic/PreresolvingDatumReader.cs
index e0ef409..5f7f9d1 100644
--- a/lang/csharp/src/apache/main/Generic/PreresolvingDatumReader.cs
+++ b/lang/csharp/src/apache/main/Generic/PreresolvingDatumReader.cs
@@ -32,7 +32,7 @@ namespace Avro.Generic
         public Schema WriterSchema { get; private set; }
 
         protected delegate object ReadItem(object reuse, Decoder dec);
-        
+
         // read a specific field from a decoder
         private delegate object DecoderRead(Decoder dec);
         // skip specific field(s) from a decoder
@@ -42,7 +42,7 @@ namespace Avro.Generic
 
         private readonly ReadItem _reader;
         private readonly Dictionary<SchemaPair,ReadItem> _recordReaders = new Dictionary<SchemaPair,ReadItem>();
-        
+
         protected PreresolvingDatumReader(Schema writerSchema, Schema readerSchema)
         {
             ReaderSchema = readerSchema;
@@ -306,7 +306,7 @@ namespace Avro.Generic
         {
             var rs = readerSchema.ValueSchema;
             var ws = writerSchema.ValueSchema;
-            
+
             var reader = ResolveReader(ws, rs);
             var mapAccess = GetMapAccess(readerSchema);
 
@@ -527,7 +527,7 @@ namespace Avro.Generic
             /// <param name="reuse">If appropriate use this instead of creating a new one.</param>
             /// <returns>An object suitable to deserialize an avro array</returns>
             object Create(object reuse);
-            
+
             /// <summary>
             /// Hint that the array should be able to handle at least targetSize elements. The array
             /// is not required to be resized

http://git-wip-us.apache.org/repos/asf/avro/blob/42afa621/lang/csharp/src/apache/main/Generic/PreresolvingDatumWriter.cs
----------------------------------------------------------------------
diff --git a/lang/csharp/src/apache/main/Generic/PreresolvingDatumWriter.cs b/lang/csharp/src/apache/main/Generic/PreresolvingDatumWriter.cs
index 39e68f6..7f9e264 100644
--- a/lang/csharp/src/apache/main/Generic/PreresolvingDatumWriter.cs
+++ b/lang/csharp/src/apache/main/Generic/PreresolvingDatumWriter.cs
@@ -129,7 +129,7 @@ namespace Avro.Generic
             }
             var writeSteps = new RecordFieldWriter[recordSchema.Fields.Count];
             recordResolver = (v, e) => WriteRecordFields(v, writeSteps, e);
-            
+
             _recordWriters.Add(recordSchema, recordResolver);
 
             int index = 0;

http://git-wip-us.apache.org/repos/asf/avro/blob/42afa621/lang/csharp/src/apache/main/IO/BinaryDecoder.cs
----------------------------------------------------------------------
diff --git a/lang/csharp/src/apache/main/IO/BinaryDecoder.cs b/lang/csharp/src/apache/main/IO/BinaryDecoder.cs
index a8afed8..d8741f4 100644
--- a/lang/csharp/src/apache/main/IO/BinaryDecoder.cs
+++ b/lang/csharp/src/apache/main/IO/BinaryDecoder.cs
@@ -41,7 +41,7 @@ namespace Avro.IO
         }
 
         /// <summary>
-        /// a boolean is written as a single byte 
+        /// a boolean is written as a single byte
         /// whose value is either 0 (false) or 1 (true).
         /// </summary>
         /// <returns></returns>
@@ -125,7 +125,7 @@ namespace Avro.IO
         }
 
         /// <summary>
-        /// Bytes are encoded as a long followed by that many bytes of data. 
+        /// Bytes are encoded as a long followed by that many bytes of data.
         /// </summary>
         /// <returns></returns>
         public byte[] ReadBytes()

http://git-wip-us.apache.org/repos/asf/avro/blob/42afa621/lang/csharp/src/apache/main/IO/BinaryEncoder.cs
----------------------------------------------------------------------
diff --git a/lang/csharp/src/apache/main/IO/BinaryEncoder.cs b/lang/csharp/src/apache/main/IO/BinaryEncoder.cs
index 8cee9a6..6376a71 100644
--- a/lang/csharp/src/apache/main/IO/BinaryEncoder.cs
+++ b/lang/csharp/src/apache/main/IO/BinaryEncoder.cs
@@ -43,7 +43,7 @@ namespace Avro.IO
         public void WriteNull()
         {
         }
-        
+
         /// <summary>
         /// true is written as 1 and false 0.
         /// </summary>
@@ -97,7 +97,7 @@ namespace Avro.IO
         public void WriteDouble(double value)
         {
             long bits = BitConverter.DoubleToInt64Bits(value);
-            
+
             writeByte((byte)((bits) & 0xFF));
             writeByte((byte)((bits >> 8) & 0xFF));
             writeByte((byte)((bits >> 16) & 0xFF));
@@ -106,14 +106,14 @@ namespace Avro.IO
             writeByte((byte)((bits >> 40) & 0xFF));
             writeByte((byte)((bits >> 48) & 0xFF));
             writeByte((byte)((bits >> 56) & 0xFF));
-            
+
         }
 
         /// <summary>
         /// Bytes are encoded as a long followed by that many bytes of data.
         /// </summary>
         /// <param name="value"></param>
-        /// 
+        ///
         public void WriteBytes(byte[] value)
         {
             WriteLong(value.Length);

http://git-wip-us.apache.org/repos/asf/avro/blob/42afa621/lang/csharp/src/apache/main/IO/ByteBufferInputStream.cs
----------------------------------------------------------------------
diff --git a/lang/csharp/src/apache/main/IO/ByteBufferInputStream.cs b/lang/csharp/src/apache/main/IO/ByteBufferInputStream.cs
index 27b3859..79b9d35 100644
--- a/lang/csharp/src/apache/main/IO/ByteBufferInputStream.cs
+++ b/lang/csharp/src/apache/main/IO/ByteBufferInputStream.cs
@@ -25,7 +25,7 @@ namespace Avro.IO
     {
         private readonly IList<MemoryStream> _buffers;
         private int _currentBuffer;
-        
+
         public ByteBufferInputStream(IList<MemoryStream> buffers)
         {
             _buffers = buffers;

http://git-wip-us.apache.org/repos/asf/avro/blob/42afa621/lang/csharp/src/apache/main/IO/ByteBufferOutputStream.cs
----------------------------------------------------------------------
diff --git a/lang/csharp/src/apache/main/IO/ByteBufferOutputStream.cs b/lang/csharp/src/apache/main/IO/ByteBufferOutputStream.cs
index 2faa71a..fa35a2b 100644
--- a/lang/csharp/src/apache/main/IO/ByteBufferOutputStream.cs
+++ b/lang/csharp/src/apache/main/IO/ByteBufferOutputStream.cs
@@ -84,7 +84,7 @@ namespace Avro.IO
         public List<MemoryStream> GetBufferList()
         {
             List<MemoryStream> result = _buffers;
-            
+
             Reset();
 
             foreach (MemoryStream b in result)

http://git-wip-us.apache.org/repos/asf/avro/blob/42afa621/lang/csharp/src/apache/main/IO/Decoder.cs
----------------------------------------------------------------------
diff --git a/lang/csharp/src/apache/main/IO/Decoder.cs b/lang/csharp/src/apache/main/IO/Decoder.cs
index e3fdec6..61a401c 100644
--- a/lang/csharp/src/apache/main/IO/Decoder.cs
+++ b/lang/csharp/src/apache/main/IO/Decoder.cs
@@ -84,7 +84,7 @@ namespace Avro.IO
         /// items from Avro array. This returns the number of entries in the initial chunk. After consuming
         /// the chunk, the client should call ReadArrayNext() to get the number of entries in the next
         /// chunk. The client should repeat the procedure until there are no more entries in the array.
-        /// 
+        ///
         /// for (int n = decoder.ReadArrayStart(); n > 0; n = decoder.ReadArrayNext())
         /// {
         ///     // Read one array entry.
@@ -152,7 +152,7 @@ namespace Avro.IO
         ///  Skips a int Avro type on the stream.
         /// </summary>
         void SkipInt();
-        
+
         /// <summary>
         ///  Skips a long Avro type on the stream.
         /// </summary>

http://git-wip-us.apache.org/repos/asf/avro/blob/42afa621/lang/csharp/src/apache/main/IO/Encoder.cs
----------------------------------------------------------------------
diff --git a/lang/csharp/src/apache/main/IO/Encoder.cs b/lang/csharp/src/apache/main/IO/Encoder.cs
index 010d334..2cfcada 100644
--- a/lang/csharp/src/apache/main/IO/Encoder.cs
+++ b/lang/csharp/src/apache/main/IO/Encoder.cs
@@ -36,7 +36,7 @@ namespace Avro.IO
 
         void SetItemCount(long value);
         void StartItem();
-        
+
         void WriteArrayStart();
         void WriteArrayEnd();
 

http://git-wip-us.apache.org/repos/asf/avro/blob/42afa621/lang/csharp/src/apache/main/IO/ICallback.cs
----------------------------------------------------------------------
diff --git a/lang/csharp/src/apache/main/IO/ICallback.cs b/lang/csharp/src/apache/main/IO/ICallback.cs
index 70a6a5f..7fdece4 100644
--- a/lang/csharp/src/apache/main/IO/ICallback.cs
+++ b/lang/csharp/src/apache/main/IO/ICallback.cs
@@ -20,7 +20,7 @@ using System;
 
 namespace Avro.IO
 {
-    public interface ICallback<in T> 
+    public interface ICallback<in T>
     {
         /**
          * Receives a callback result.

http://git-wip-us.apache.org/repos/asf/avro/blob/42afa621/lang/csharp/src/apache/main/IO/Resolver.cs
----------------------------------------------------------------------
diff --git a/lang/csharp/src/apache/main/IO/Resolver.cs b/lang/csharp/src/apache/main/IO/Resolver.cs
index e06bea7..fa5e199 100644
--- a/lang/csharp/src/apache/main/IO/Resolver.cs
+++ b/lang/csharp/src/apache/main/IO/Resolver.cs
@@ -25,7 +25,7 @@ namespace Avro.IO
     static class Resolver
     {
         /// <summary>
-        /// Reads the passed JToken default value field and writes it in the specified encoder 
+        /// Reads the passed JToken default value field and writes it in the specified encoder
         /// </summary>
         /// <param name="enc">encoder to use for writing</param>
         /// <param name="schema">schema object for the current field</param>

http://git-wip-us.apache.org/repos/asf/avro/blob/42afa621/lang/csharp/src/apache/main/Properties/Settings.Designer.cs
----------------------------------------------------------------------
diff --git a/lang/csharp/src/apache/main/Properties/Settings.Designer.cs b/lang/csharp/src/apache/main/Properties/Settings.Designer.cs
index 2e7908b..dc7cb6d 100644
--- a/lang/csharp/src/apache/main/Properties/Settings.Designer.cs
+++ b/lang/csharp/src/apache/main/Properties/Settings.Designer.cs
@@ -27,14 +27,14 @@
  */
 
 namespace Avro.Properties {
-    
-    
+
+
     [global::System.Runtime.CompilerServices.CompilerGeneratedAttribute()]
     [global::System.CodeDom.Compiler.GeneratedCodeAttribute("Microsoft.VisualStudio.Editors.SettingsDesigner.SettingsSingleFileGenerator", "10.0.0.0")]
     internal sealed partial class Settings : global::System.Configuration.ApplicationSettingsBase {
-        
+
         private static Settings defaultInstance = ((Settings)(global::System.Configuration.ApplicationSettingsBase.Synchronized(new Settings())));
-        
+
         public static Settings Default {
             get {
                 return defaultInstance;

http://git-wip-us.apache.org/repos/asf/avro/blob/42afa621/lang/csharp/src/apache/main/Protocol/Message.cs
----------------------------------------------------------------------
diff --git a/lang/csharp/src/apache/main/Protocol/Message.cs b/lang/csharp/src/apache/main/Protocol/Message.cs
index 80912d2..3ae9528 100644
--- a/lang/csharp/src/apache/main/Protocol/Message.cs
+++ b/lang/csharp/src/apache/main/Protocol/Message.cs
@@ -169,15 +169,15 @@ namespace Avro
         /// </summary>
         /// <param name="obj"></param>
         /// <returns></returns>
-        public override bool Equals(Object obj) 
+        public override bool Equals(Object obj)
         {
           if (obj == this) return true;
           if (!(obj is Message)) return false;
 
           Message that = obj as Message;
-          return this.Name.Equals(that.Name) && 
+          return this.Name.Equals(that.Name) &&
                  this.Request.Equals(that.Request) &&
-                 areEqual(this.Response, that.Response) && 
+                 areEqual(this.Response, that.Response) &&
                  areEqual(this.Error, that.Error);
         }
 
@@ -185,7 +185,7 @@ namespace Avro
         /// Returns the hash code of this Message object
         /// </summary>
         /// <returns></returns>
-        public override int GetHashCode() 
+        public override int GetHashCode()
         {
             return Name.GetHashCode() +
                    Request.GetHashCode() +
@@ -194,7 +194,7 @@ namespace Avro
         }
 
         /// <summary>
-        /// Tests equality of two objects taking null values into account 
+        /// Tests equality of two objects taking null values into account
         /// </summary>
         /// <param name="o1"></param>
         /// <param name="o2"></param>

http://git-wip-us.apache.org/repos/asf/avro/blob/42afa621/lang/csharp/src/apache/main/Protocol/Protocol.cs
----------------------------------------------------------------------
diff --git a/lang/csharp/src/apache/main/Protocol/Protocol.cs b/lang/csharp/src/apache/main/Protocol/Protocol.cs
index e9645a5..68f2d89 100644
--- a/lang/csharp/src/apache/main/Protocol/Protocol.cs
+++ b/lang/csharp/src/apache/main/Protocol/Protocol.cs
@@ -54,7 +54,7 @@ namespace Avro
         private byte[] md5;
         public byte[] MD5
         {
-            get 
+            get
             {
                 try
                 {
@@ -65,7 +65,7 @@ namespace Avro
                 {
                     throw new AvroRuntimeException("MD5 get exception", ex);
                 }
-                return md5; 
+                return md5;
             }
         }
 
@@ -218,7 +218,7 @@ namespace Avro
 
             Protocol that = obj as Protocol;
 
-            return this.Name.Equals(that.Name) && this.Namespace.Equals(that.Namespace) && 
+            return this.Name.Equals(that.Name) && this.Namespace.Equals(that.Namespace) &&
                     TypesEquals(that.Types) && MessagesEquals(that.Messages);
         }
 
@@ -247,13 +247,13 @@ namespace Avro
         private bool MessagesEquals(IDictionary<string, Message> that)
         {
             if (Messages.Count != that.Count) return false;
-            foreach (KeyValuePair<string, Message> pair in Messages) 
-            { 
+            foreach (KeyValuePair<string, Message> pair in Messages)
+            {
                 if (!that.ContainsKey(pair.Key))
                     return false;
                 if (!pair.Value.Equals(that[pair.Key]))
-                    return false; 
-            } 
+                    return false;
+            }
             return true;
         }
 

http://git-wip-us.apache.org/repos/asf/avro/blob/42afa621/lang/csharp/src/apache/main/Schema/EnumSchema.cs
----------------------------------------------------------------------
diff --git a/lang/csharp/src/apache/main/Schema/EnumSchema.cs b/lang/csharp/src/apache/main/Schema/EnumSchema.cs
index d346ecf..fc21d14 100644
--- a/lang/csharp/src/apache/main/Schema/EnumSchema.cs
+++ b/lang/csharp/src/apache/main/Schema/EnumSchema.cs
@@ -96,7 +96,7 @@ namespace Avro
         /// <param name="writer">JSON writer</param>
         /// <param name="names">list of named schema already written</param>
         /// <param name="encspace">enclosing namespace of the enum schema</param>
-        protected internal override void WriteJsonFields(Newtonsoft.Json.JsonTextWriter writer, 
+        protected internal override void WriteJsonFields(Newtonsoft.Json.JsonTextWriter writer,
                                                             SchemaNames names, string encspace)
         {
             base.WriteJsonFields(writer, names, encspace);
@@ -108,7 +108,7 @@ namespace Avro
         }
 
         /// <summary>
-        /// Returns the position of the given symbol within this enum. 
+        /// Returns the position of the given symbol within this enum.
         /// Throws AvroException if the symbol is not found in this enum.
         /// </summary>
         /// <param name="symbol">name of the symbol to find</param>
@@ -197,7 +197,7 @@ namespace Avro
             if (!that.SchemaName.Equals(SchemaName))
                 if (!InAliases(that.SchemaName)) return false;
 
-            // we defer checking of symbols. Writer may have a symbol missing from the reader, 
+            // we defer checking of symbols. Writer may have a symbol missing from the reader,
             // but if writer never used the missing symbol, then reader should still be able to read the data
 
             return true;

http://git-wip-us.apache.org/repos/asf/avro/blob/42afa621/lang/csharp/src/apache/main/Schema/Field.cs
----------------------------------------------------------------------
diff --git a/lang/csharp/src/apache/main/Schema/Field.cs b/lang/csharp/src/apache/main/Schema/Field.cs
index 740c44d..85d5563 100644
--- a/lang/csharp/src/apache/main/Schema/Field.cs
+++ b/lang/csharp/src/apache/main/Schema/Field.cs
@@ -76,8 +76,8 @@ namespace Avro
 
         /// <summary>
         /// Custom properties for the field. We don't store the fields custom properties in
-        /// the field type's schema because if the field type is only a reference to the schema 
-        /// instead of an actual schema definition, then the schema could already have it's own set 
+        /// the field type's schema because if the field type is only a reference to the schema
+        /// instead of an actual schema definition, then the schema could already have it's own set
         /// of custom properties when it was previously defined.
         /// </summary>
         private readonly PropertyMap Props;

http://git-wip-us.apache.org/repos/asf/avro/blob/42afa621/lang/csharp/src/apache/main/Schema/NamedSchema.cs
----------------------------------------------------------------------
diff --git a/lang/csharp/src/apache/main/Schema/NamedSchema.cs b/lang/csharp/src/apache/main/Schema/NamedSchema.cs
index 02beb79..e0bfab0 100644
--- a/lang/csharp/src/apache/main/Schema/NamedSchema.cs
+++ b/lang/csharp/src/apache/main/Schema/NamedSchema.cs
@@ -101,7 +101,7 @@ namespace Avro
         {
             this.SchemaName = name;
             this.aliases = aliases;
-            if (null != name.Name)  // Added this check for anonymous records inside Message 
+            if (null != name.Name)  // Added this check for anonymous records inside Message
                 if (!names.Add(name, this))
                     throw new AvroException("Duplicate schema name " + name.Fullname);
         }
@@ -115,7 +115,7 @@ namespace Avro
         /// <returns>new SchemaName object</returns>
         protected static SchemaName GetName(JToken jtok, string encspace)
         {
-            String n = JsonHelper.GetOptionalString(jtok, "name");      // Changed this to optional string for anonymous records in messages 
+            String n = JsonHelper.GetOptionalString(jtok, "name");      // Changed this to optional string for anonymous records in messages
             String ns = JsonHelper.GetOptionalString(jtok, "namespace");
             return new SchemaName(n, ns, encspace);
         }

http://git-wip-us.apache.org/repos/asf/avro/blob/42afa621/lang/csharp/src/apache/main/Schema/Property.cs
----------------------------------------------------------------------
diff --git a/lang/csharp/src/apache/main/Schema/Property.cs b/lang/csharp/src/apache/main/Schema/Property.cs
index 3901623..521cfd1 100644
--- a/lang/csharp/src/apache/main/Schema/Property.cs
+++ b/lang/csharp/src/apache/main/Schema/Property.cs
@@ -94,15 +94,15 @@ namespace Avro
             if (obj != null && obj is PropertyMap)
             {
                 var that = obj as PropertyMap;
-                if (this.Count != that.Count) 
-                    return false; 
-                foreach (KeyValuePair<string, string> pair in this) 
-                { 
+                if (this.Count != that.Count)
+                    return false;
+                foreach (KeyValuePair<string, string> pair in this)
+                {
                     if (!that.ContainsKey(pair.Key))
                         return false;
                     if (!pair.Value.Equals(that[pair.Key]))
-                        return false; 
-                } 
+                        return false;
+                }
                 return true;
             }
             return false;

http://git-wip-us.apache.org/repos/asf/avro/blob/42afa621/lang/csharp/src/apache/main/Schema/RecordSchema.cs
----------------------------------------------------------------------
diff --git a/lang/csharp/src/apache/main/Schema/RecordSchema.cs b/lang/csharp/src/apache/main/Schema/RecordSchema.cs
index ab2440f..8c32b69 100644
--- a/lang/csharp/src/apache/main/Schema/RecordSchema.cs
+++ b/lang/csharp/src/apache/main/Schema/RecordSchema.cs
@@ -103,8 +103,8 @@ namespace Avro
         /// <param name="request">true if this is an anonymous record with 'request' instead of 'fields'</param>
         /// <param name="fieldMap">map of field names and field objects</param>
         /// <param name="names">list of named schema already read</param>
-        private RecordSchema(Type type, SchemaName name, IList<SchemaName> aliases,  PropertyMap props, 
-                                List<Field> fields, bool request, IDictionary<string, Field> fieldMap, 
+        private RecordSchema(Type type, SchemaName name, IList<SchemaName> aliases,  PropertyMap props,
+                                List<Field> fields, bool request, IDictionary<string, Field> fieldMap,
                                 IDictionary<string, Field> fieldAliasMap, SchemaNames names)
                                 : base(type, name, aliases, props, names)
         {
@@ -138,7 +138,7 @@ namespace Avro
             var defaultValue = jfield["default"];
 
             JToken jtype = jfield["type"];
-            if (null == jtype) 
+            if (null == jtype)
                 throw new SchemaParseException("'type' was not found for field: " + name);
             var schema = Schema.ParseJson(jtype, names, encspace);
 
@@ -272,7 +272,7 @@ namespace Avro
             return protect(() => true, () =>
             {
                 if (!that.SchemaName.Equals(SchemaName))
-                    if (!InAliases(that.SchemaName)) 
+                    if (!InAliases(that.SchemaName))
                         return false;
 
                 foreach (Field f in this)
@@ -316,7 +316,7 @@ namespace Avro
          * to see if we have been into this if so, we execute the bypass function otherwise we execute the main function.
          * Before executing the main function, we ensure that we create a marker so that if we come back here recursively
          * we can detect it.
-         * 
+         *
          * The infinite loop happens in ToString(), Equals() and GetHashCode() methods.
          * Though it does not happen for CanRead() because of the current implemenation of UnionSchema's can read,
          * it could potenitally happen.
@@ -324,10 +324,10 @@ namespace Avro
          */
         private T protect<T>(Function<T> bypass, Function<T> main, RecordSchema that)
         {
-            if (seen == null) 
+            if (seen == null)
                 seen = new List<RecordSchemaPair>();
 
-            else if (seen.Find((RecordSchemaPair rs) => rs.first == this && rs.second == that) != null) 
+            else if (seen.Find((RecordSchemaPair rs) => rs.first == this && rs.second == that) != null)
                 return bypass();
 
             RecordSchemaPair p = new RecordSchemaPair(this, that);

http://git-wip-us.apache.org/repos/asf/avro/blob/42afa621/lang/csharp/src/apache/main/Schema/Schema.cs
----------------------------------------------------------------------
diff --git a/lang/csharp/src/apache/main/Schema/Schema.cs b/lang/csharp/src/apache/main/Schema/Schema.cs
index fc0e237..a9de877 100644
--- a/lang/csharp/src/apache/main/Schema/Schema.cs
+++ b/lang/csharp/src/apache/main/Schema/Schema.cs
@@ -86,7 +86,7 @@ namespace Avro
         internal static Schema ParseJson(JToken jtok, SchemaNames names, string encspace)
         {
             if (null == jtok) throw new ArgumentNullException("j", "j cannot be null.");
-            
+
             if (jtok.Type == JTokenType.String) // primitive schema with no 'type' property or primitive or named type of a record field
             {
                 string value = (string)jtok;
@@ -117,11 +117,11 @@ namespace Avro
                 {
                     string type = (string)jtype;
 
-                    if (type.Equals("array")) 
+                    if (type.Equals("array"))
                         return ArraySchema.NewInstance(jtok, props, names, encspace);
                     if (type.Equals("map"))
                         return MapSchema.NewInstance(jtok, props, names, encspace);
-                    
+
                     Schema schema = PrimitiveSchema.NewInstance((string)type, props);
                     if (null != schema) return schema;
 
@@ -208,7 +208,7 @@ namespace Avro
         }
 
         /// <summary>
-        /// Writes opening { and 'type' property 
+        /// Writes opening { and 'type' property
         /// </summary>
         /// <param name="writer">JSON writer</param>
         private void writeStartObject(JsonTextWriter writer)

http://git-wip-us.apache.org/repos/asf/avro/blob/42afa621/lang/csharp/src/apache/main/Schema/SchemaName.cs
----------------------------------------------------------------------
diff --git a/lang/csharp/src/apache/main/Schema/SchemaName.cs b/lang/csharp/src/apache/main/Schema/SchemaName.cs
index dda77e6..41d50c9 100644
--- a/lang/csharp/src/apache/main/Schema/SchemaName.cs
+++ b/lang/csharp/src/apache/main/Schema/SchemaName.cs
@@ -49,7 +49,7 @@ namespace Avro
         /// <summary>
         /// Namespace of the schema
         /// </summary>
-        public String Namespace { get { return string.IsNullOrEmpty(this.Space) ? this.EncSpace : this.Space; } } 
+        public String Namespace { get { return string.IsNullOrEmpty(this.Space) ? this.EncSpace : this.Space; } }
 
         /// <summary>
         /// Constructor for SchemaName
@@ -132,7 +132,7 @@ namespace Avro
         {
             return obj1 == null ? obj2 == null : obj1.Equals(obj2);
         }
-    
+
         public override int GetHashCode()
         {
             return string.IsNullOrEmpty(Fullname) ? 0 : 29 * Fullname.GetHashCode();

http://git-wip-us.apache.org/repos/asf/avro/blob/42afa621/lang/csharp/src/apache/main/Specific/ObjectCreator.cs
----------------------------------------------------------------------
diff --git a/lang/csharp/src/apache/main/Specific/ObjectCreator.cs b/lang/csharp/src/apache/main/Specific/ObjectCreator.cs
index 5435adb..ae43c84 100644
--- a/lang/csharp/src/apache/main/Specific/ObjectCreator.cs
+++ b/lang/csharp/src/apache/main/Specific/ObjectCreator.cs
@@ -30,7 +30,7 @@ namespace Avro.Specific
         public static ObjectCreator Instance { get { return instance; } }
 
         /// <summary>
-        /// Static generic dictionary type used for creating new dictionary instances 
+        /// Static generic dictionary type used for creating new dictionary instances
         /// </summary>
         private Type GenericMapType = typeof(Dictionary<,>);
 
@@ -43,7 +43,7 @@ namespace Avro.Specific
         /// Static generic nullable type used for creating new nullable instances
         /// </summary>
         private Type GenericNullableType = typeof(Nullable<>);
-        
+
         private readonly Assembly execAssembly;
         private readonly Assembly entryAssembly;
         private readonly bool diffAssembly;
@@ -110,7 +110,7 @@ namespace Avro.Specific
         /// <param name="name">the object type to locate</param>
         /// <param name="throwError">whether or not to throw an error if the type wasn't found</param>
         /// <returns>the object type, or <c>null</c> if not found</returns>
-        private Type FindType(string name,bool throwError) 
+        private Type FindType(string name,bool throwError)
         {
             Type type;
 
@@ -149,7 +149,7 @@ namespace Avro.Specific
                     {
                         if (name == t.Name || name == t.FullName) type = t;
                     }
-                    
+
                     if (type != null)
                         break;
                 }
@@ -185,7 +185,7 @@ namespace Avro.Specific
             case Schema.Type.Double:
                 return typeof(double);
             case Schema.Type.Bytes:
-                return typeof(byte[]); 
+                return typeof(byte[]);
             case Schema.Type.String:
                 return typeof(string);
             case Schema.Type.Union:
@@ -207,7 +207,7 @@ namespace Avro.Specific
                             itemType = GetType(s1);
                         }
 
-                        if (null != itemType ) 
+                        if (null != itemType )
                         {
                             if (itemType.IsValueType && !itemType.IsEnum)
                             {
@@ -217,7 +217,7 @@ namespace Avro.Specific
                                 }
                                 catch (Exception) { }
                             }
-                            
+
                             return itemType;
                         }
                     }
@@ -303,7 +303,7 @@ namespace Avro.Specific
         public object New(string name, Schema.Type schemaType)
         {
             NameCtorKey key = new NameCtorKey(name, schemaType);
-            
+
             CtorDelegate ctor;
             lock(ctors)
             {

http://git-wip-us.apache.org/repos/asf/avro/blob/42afa621/lang/csharp/src/apache/main/Specific/SpecificDatumReader.cs
----------------------------------------------------------------------
diff --git a/lang/csharp/src/apache/main/Specific/SpecificDatumReader.cs b/lang/csharp/src/apache/main/Specific/SpecificDatumReader.cs
index 5611a9c..d54f3ca 100644
--- a/lang/csharp/src/apache/main/Specific/SpecificDatumReader.cs
+++ b/lang/csharp/src/apache/main/Specific/SpecificDatumReader.cs
@@ -146,7 +146,7 @@ namespace Avro.Specific
                 string type = Avro.CodeGen.getType(readerSchema, false, ref nEnum);
                 type = type.Remove(0, 6);              // remove IList<
                 type = type.Remove(type.Length - 1);   // remove >
-        
+
                 objCreator = GetConstructor(type, Schema.Type.Array);
             }
 
@@ -198,7 +198,7 @@ namespace Avro.Specific
                 string type = Avro.CodeGen.getType(readerSchema, false, ref nEnum);
                 type = type.Remove(0, 19);             // remove IDictionary<string,
                 type = type.Remove(type.Length - 1);   // remove >
-        
+
                 objCreator = GetConstructor(type, Schema.Type.Map);
             }
 

http://git-wip-us.apache.org/repos/asf/avro/blob/42afa621/lang/csharp/src/apache/main/Specific/SpecificDatumWriter.cs
----------------------------------------------------------------------
diff --git a/lang/csharp/src/apache/main/Specific/SpecificDatumWriter.cs b/lang/csharp/src/apache/main/Specific/SpecificDatumWriter.cs
index a359938..a8820d7 100644
--- a/lang/csharp/src/apache/main/Specific/SpecificDatumWriter.cs
+++ b/lang/csharp/src/apache/main/Specific/SpecificDatumWriter.cs
@@ -56,7 +56,7 @@ namespace Avro.Specific
         protected override WriteItem ResolveEnum(EnumSchema es)
         {
             var type = ObjectCreator.Instance.GetType(es);
-            
+
             var enumNames = Enum.GetNames(type);
             var translator = new int[enumNames.Length];
             for(int i = 0; i < enumNames.Length; i++)
@@ -80,7 +80,7 @@ namespace Avro.Specific
                                int translated = translator[(int)v];
                                if (translated == -1)
                                {
-                                   throw new AvroTypeException("Unknown enum value:" + v.ToString());   
+                                   throw new AvroTypeException("Unknown enum value:" + v.ToString());
                                }
                                else
                                {
@@ -126,7 +126,7 @@ namespace Avro.Specific
                     return obj is string;
                 case Schema.Type.Error:
                 case Schema.Type.Record:
-                    return obj is ISpecificRecord && 
+                    return obj is ISpecificRecord &&
                            (((obj as ISpecificRecord).Schema) as RecordSchema).SchemaName.Equals((sc as RecordSchema).SchemaName);
                 case Schema.Type.Enumeration:
                     return obj.GetType().IsEnum && (sc as EnumSchema).Symbols.Contains(obj.ToString());
@@ -137,7 +137,7 @@ namespace Avro.Specific
                 case Schema.Type.Union:
                     return false;   // Union directly within another union not allowed!
                 case Schema.Type.Fixed:
-                    return obj is SpecificFixed && 
+                    return obj is SpecificFixed &&
                            (((obj as SpecificFixed).Schema) as FixedSchema).SchemaName.Equals((sc as FixedSchema).SchemaName);
                 default:
                     throw new AvroException("Unknown schema type: " + sc.Tag);

http://git-wip-us.apache.org/repos/asf/avro/blob/42afa621/lang/csharp/src/apache/main/Specific/SpecificFixed.cs
----------------------------------------------------------------------
diff --git a/lang/csharp/src/apache/main/Specific/SpecificFixed.cs b/lang/csharp/src/apache/main/Specific/SpecificFixed.cs
index 0c1be6d..f55f287 100644
--- a/lang/csharp/src/apache/main/Specific/SpecificFixed.cs
+++ b/lang/csharp/src/apache/main/Specific/SpecificFixed.cs
@@ -24,7 +24,7 @@ using Avro.Generic;
 namespace Avro.Specific
 {
     /// <summary>
-    /// Base class for all generated classes 
+    /// Base class for all generated classes
     /// </summary>
     public abstract class SpecificFixed : GenericFixed
     {

http://git-wip-us.apache.org/repos/asf/avro/blob/42afa621/lang/csharp/src/apache/main/Specific/SpecificReader.cs
----------------------------------------------------------------------
diff --git a/lang/csharp/src/apache/main/Specific/SpecificReader.cs b/lang/csharp/src/apache/main/Specific/SpecificReader.cs
index b3d96b9..384465b 100644
--- a/lang/csharp/src/apache/main/Specific/SpecificReader.cs
+++ b/lang/csharp/src/apache/main/Specific/SpecificReader.cs
@@ -81,7 +81,7 @@ namespace Avro.Specific
     public class SpecificDefaultReader : DefaultReader
     {
         /// <summary>
-        /// Static dictionary of type names and its corresponding assembly type. 
+        /// Static dictionary of type names and its corresponding assembly type.
         /// This is used to prevent multiple reflection for the same type name.
         /// </summary>
         private static IDictionary<string, Type> TypeName = new Dictionary<string, Type>();
@@ -91,7 +91,7 @@ namespace Avro.Specific
         /// </summary>
         /// <param name="writerSchema">schema of the object that wrote the data</param>
         /// <param name="readerSchema">schema of the object that will store the data</param>
-        public SpecificDefaultReader(Schema writerSchema, Schema readerSchema) : base(writerSchema,readerSchema) 
+        public SpecificDefaultReader(Schema writerSchema, Schema readerSchema) : base(writerSchema,readerSchema)
         {
         }
 
@@ -130,7 +130,7 @@ namespace Avro.Specific
                     throw new AvroException(ex.Message + " in field " + wf.Name);
                 }
             }
-            
+
             var defaultStream = new MemoryStream();
             var defaultEncoder = new BinaryEncoder(defaultStream);
             var defaultDecoder = new BinaryDecoder(defaultStream);
@@ -146,7 +146,7 @@ namespace Avro.Specific
                 obj = rec.Get(rf.Pos);
                 rec.Put(rf.Pos, Read(obj, rf.Schema, rf.Schema, defaultDecoder));
             }
-            
+
             return rec;
         }
 
@@ -210,7 +210,7 @@ namespace Avro.Specific
             }
             else
                 array = ObjectCreator.Instance.New(getTargetType(readerSchema), Schema.Type.Array) as System.Collections.IList;
-            
+
             int i = 0;
             for (int n = (int)dec.ReadArrayStart(); n != 0; n = (int)dec.ReadArrayNext())
             {

http://git-wip-us.apache.org/repos/asf/avro/blob/42afa621/lang/csharp/src/apache/main/Specific/SpecificWriter.cs
----------------------------------------------------------------------
diff --git a/lang/csharp/src/apache/main/Specific/SpecificWriter.cs b/lang/csharp/src/apache/main/Specific/SpecificWriter.cs
index 5800714..f2573a0 100644
--- a/lang/csharp/src/apache/main/Specific/SpecificWriter.cs
+++ b/lang/csharp/src/apache/main/Specific/SpecificWriter.cs
@@ -195,7 +195,7 @@ namespace Avro.Specific
                     return obj is string;
                 case Schema.Type.Error:
                 case Schema.Type.Record:
-                    return obj is ISpecificRecord && 
+                    return obj is ISpecificRecord &&
                            (((obj as ISpecificRecord).Schema) as RecordSchema).SchemaName.Equals((sc as RecordSchema).SchemaName);
                 case Schema.Type.Enumeration:
                     return obj.GetType().IsEnum && (sc as EnumSchema).Symbols.Contains(obj.ToString());
@@ -206,7 +206,7 @@ namespace Avro.Specific
                 case Schema.Type.Union:
                     return false;   // Union directly within another union not allowed!
                 case Schema.Type.Fixed:
-                    return obj is SpecificFixed && 
+                    return obj is SpecificFixed &&
                            (((obj as SpecificFixed).Schema) as FixedSchema).SchemaName.Equals((sc as FixedSchema).SchemaName);
                 default:
                     throw new AvroException("Unknown schema type: " + sc.Tag);

http://git-wip-us.apache.org/repos/asf/avro/blob/42afa621/lang/csharp/src/apache/perf/PerfTest.cs
----------------------------------------------------------------------
diff --git a/lang/csharp/src/apache/perf/PerfTest.cs b/lang/csharp/src/apache/perf/PerfTest.cs
index e3aefd3..4110bbf 100644
--- a/lang/csharp/src/apache/perf/PerfTest.cs
+++ b/lang/csharp/src/apache/perf/PerfTest.cs
@@ -202,7 +202,7 @@ namespace Avro.perf
             var decoder = new BinaryDecoder( stream );
 
             var totalItems = 1000000;
-            
+
             foreach (int itemsPerBatch in new List<int> { 1000 } )
             {
                 int serialized = 0;

http://git-wip-us.apache.org/repos/asf/avro/blob/42afa621/lang/csharp/src/apache/perf/com/foo/MyFixed.cs
----------------------------------------------------------------------
diff --git a/lang/csharp/src/apache/perf/com/foo/MyFixed.cs b/lang/csharp/src/apache/perf/com/foo/MyFixed.cs
index 3255e75..4aed204 100644
--- a/lang/csharp/src/apache/perf/com/foo/MyFixed.cs
+++ b/lang/csharp/src/apache/perf/com/foo/MyFixed.cs
@@ -17,7 +17,7 @@ namespace com.foo
 	{
 		public static Schema _SCHEMA = Avro.Schema.Parse("{\"type\":\"fixed\",\"name\":\"MyFixed\",\"namespace\":\"com.foo\",\"size\":16}");
 		private static uint fixedSize = 16;
-		public MyFixed() : 
+		public MyFixed() :
 				base(fixedSize)
 		{
 		}

http://git-wip-us.apache.org/repos/asf/avro/blob/42afa621/lang/csharp/src/apache/test/CodGen/CodeGenTest.cs
----------------------------------------------------------------------
diff --git a/lang/csharp/src/apache/test/CodGen/CodeGenTest.cs b/lang/csharp/src/apache/test/CodGen/CodeGenTest.cs
index 7e1d9e5..c5428b3 100644
--- a/lang/csharp/src/apache/test/CodGen/CodeGenTest.cs
+++ b/lang/csharp/src/apache/test/CodGen/CodeGenTest.cs
@@ -27,14 +27,14 @@ using Avro.Specific;
 namespace Avro.Test
 {
     [TestFixture]
- 
+
     class CodeGenTest
     {
         [TestCase(@"{
 ""type"" : ""record"",
 ""name"" : ""ClassKeywords"",
 ""namespace"" : ""com.base"",
-""fields"" : 
+""fields"" :
 		[ 	
 			{ ""name"" : ""int"", ""type"" : ""int"" },
 			{ ""name"" : ""base"", ""type"" : ""long"" },
@@ -53,14 +53,14 @@ namespace Avro.Test
 ""type"" : ""record"",
 ""name"" : ""SchemaObject"",
 ""namespace"" : ""schematest"",
-""fields"" : 
+""fields"" :
 	[ 	
-		{ ""name"" : ""myobject"", ""type"" : 
-			[ 
-				""null"", 
-				{""type"" : ""array"", ""items"" : [ ""null"", 
+		{ ""name"" : ""myobject"", ""type"" :
+			[
+				""null"",
+				{""type"" : ""array"", ""items"" : [ ""null"",
 											{ ""type"" : ""enum"", ""name"" : ""MyEnum"", ""symbols"" : [ ""A"", ""B"" ] },
-											{ ""type"": ""fixed"", ""size"": 16, ""name"": ""MyFixed"" } 
+											{ ""type"": ""fixed"", ""size"": 16, ""name"": ""MyFixed"" }
 											]
 				}
 			]

http://git-wip-us.apache.org/repos/asf/avro/blob/42afa621/lang/csharp/src/apache/test/File/FileTests.cs
----------------------------------------------------------------------
diff --git a/lang/csharp/src/apache/test/File/FileTests.cs b/lang/csharp/src/apache/test/File/FileTests.cs
index c565c56..b3dbfb2 100644
--- a/lang/csharp/src/apache/test/File/FileTests.cs
+++ b/lang/csharp/src/apache/test/File/FileTests.cs
@@ -319,7 +319,7 @@ namespace Avro.Test.File
         }
 
         /// <summary>
-        /// Partial reading of file / stream from 
+        /// Partial reading of file / stream from
         /// position in stream
         /// </summary>
         /// <param name="schemaStr"></param>
@@ -366,7 +366,7 @@ namespace Avro.Test.File
                 // move to next block from position
                 reader.Sync(position);
 
-                // read records from synced position 
+                // read records from synced position
                 foreach (Foo rec in reader.NextEntries)
                     readRecords.Add(rec);
             }
@@ -455,7 +455,7 @@ namespace Avro.Test.File
             reader.Sync( position );
 
             int readRecords = 0;
-            // read records from synced position 
+            // read records from synced position
             foreach( Foo rec in reader.NextEntries )
             {
                 readRecords++;
@@ -464,7 +464,7 @@ namespace Avro.Test.File
         }
 
         /// <summary>
-        /// Reading all sync positions and 
+        /// Reading all sync positions and
         /// verifying them with subsequent seek
         /// positions
         /// </summary>
@@ -499,7 +499,7 @@ namespace Avro.Test.File
 
             MemoryStream dataFileInputStream = new MemoryStream(dataFileOutputStream.ToArray());
 
-            // read syncs 
+            // read syncs
             IList<long> syncs = new List<long>();
             using (IFileReader<Foo> reader = DataFileReader<Foo>.OpenReader(dataFileInputStream))
             {
@@ -507,7 +507,7 @@ namespace Avro.Test.File
 
                 foreach (Foo foo in reader.NextEntries)
                 {
-                    if (reader.PreviousSync() != previousSync 
+                    if (reader.PreviousSync() != previousSync
                      && reader.Tell() != reader.PreviousSync()) // EOF
                     {
                         previousSync = reader.PreviousSync();
@@ -520,7 +520,7 @@ namespace Avro.Test.File
                 Assert.AreEqual(reader.PreviousSync(), syncs[0],
                               string.Format("Error syncing reader to position: {0}", syncs[0]));
 
-                foreach (long sync in syncs) // the rest 
+                foreach (long sync in syncs) // the rest
                 {
                     reader.Seek(sync);
                     Foo foo = reader.Next();
@@ -567,7 +567,7 @@ namespace Avro.Test.File
             {
                 readFoos.Add(foo);
             }
-            return (readFoos.Count > 0 && 
+            return (readFoos.Count > 0 &&
                 CheckPrimitiveEquals(value, readFoos[0]));
         }
 
@@ -630,9 +630,9 @@ namespace Avro.Test.File
             return records;
         }
 
-        private bool ValidateMetaData<T>(IFileReader<T> reader, 
-                                         string key, 
-                                         object expected, 
+        private bool ValidateMetaData<T>(IFileReader<T> reader,
+                                         string key,
+                                         object expected,
                                          bool useTypeGetter)
         {
             byte[] valueBytes = reader.GetMeta(key);
@@ -643,7 +643,7 @@ namespace Avro.Test.File
                 expectedBytes = (byte[])expected;
                 return Enumerable.SequenceEqual(expectedBytes, valueBytes);
             }
-            else if (expected is long)  
+            else if (expected is long)
             {
                 if (useTypeGetter)
                     return ((long)expected == reader.GetMetaLong(key));
@@ -689,7 +689,7 @@ namespace Avro.Test.File
             yield return new ReaderWriterPair<T>
                              {
                                  CreateReader = (stream, schema) => DataFileReader<T>.OpenReader(stream, schema),
-                                 CreateWriter = (stream, schema, codec) => 
+                                 CreateWriter = (stream, schema, codec) =>
                                      DataFileWriter<T>.OpenWriter(new SpecificWriter<T>(schema), stream, codec )
                              };
 
@@ -697,7 +697,7 @@ namespace Avro.Test.File
                              {
                                  CreateReader = (stream, schema) => DataFileReader<T>.OpenReader(stream, schema,
                                      (ws, rs) => new SpecificDatumReader<T>(ws, rs)),
-                                 CreateWriter = (stream, schema, codec) => 
+                                 CreateWriter = (stream, schema, codec) =>
                                      DataFileWriter<T>.OpenWriter(new SpecificDatumWriter<T>(schema), stream, codec )
                              };
         }
@@ -707,7 +707,7 @@ namespace Avro.Test.File
             yield return new ReaderWriterPair<T>
                              {
                                  CreateReader = (stream, schema) => DataFileReader<T>.OpenReader(stream, schema),
-                                 CreateWriter = (stream, schema, codec) => 
+                                 CreateWriter = (stream, schema, codec) =>
                                      DataFileWriter<T>.OpenWriter(new GenericWriter<T>(schema), stream, codec )
                              };
 
@@ -715,7 +715,7 @@ namespace Avro.Test.File
                              {
                                  CreateReader = (stream, schema) => DataFileReader<T>.OpenReader(stream, schema,
                                      (ws, rs) => new GenericDatumReader<T>(ws, rs)),
-                                 CreateWriter = (stream, schema, codec) => 
+                                 CreateWriter = (stream, schema, codec) =>
                                      DataFileWriter<T>.OpenWriter(new GenericDatumWriter<T>(schema), stream, codec )
                              };
         }
@@ -741,7 +741,7 @@ namespace Avro.Test.File
         {
             get
             {
-                return Schema.Parse("{\"type\":\"record\",\"name\":\"Foo\",\"namespace\":\"Avro.Test.File\"," + 
+                return Schema.Parse("{\"type\":\"record\",\"name\":\"Foo\",\"namespace\":\"Avro.Test.File\"," +
                                     "\"fields\":[{\"name\":\"name\",\"type\":\"string\"},{\"name\":\"age\",\"type\":\"int\"}]}");
             }
         }

http://git-wip-us.apache.org/repos/asf/avro/blob/42afa621/lang/csharp/src/apache/test/Generic/GenericTests.cs
----------------------------------------------------------------------
diff --git a/lang/csharp/src/apache/test/Generic/GenericTests.cs b/lang/csharp/src/apache/test/Generic/GenericTests.cs
index d08e7ba..19951fd 100644
--- a/lang/csharp/src/apache/test/Generic/GenericTests.cs
+++ b/lang/csharp/src/apache/test/Generic/GenericTests.cs
@@ -485,7 +485,7 @@ namespace Avro.Test.Generic
             writer.Write(value, e);
             writer.Write(value, e);
             var output = ms.ToArray();
-            
+
             Assert.AreEqual(expected.Length, output.Length);
             Assert.True(expected.SequenceEqual(output));
         }

http://git-wip-us.apache.org/repos/asf/avro/blob/42afa621/lang/csharp/src/apache/test/Ipc/GeneratedFiles/org/apache/avro/test/FixedTest.cs
----------------------------------------------------------------------
diff --git a/lang/csharp/src/apache/test/Ipc/GeneratedFiles/org/apache/avro/test/FixedTest.cs b/lang/csharp/src/apache/test/Ipc/GeneratedFiles/org/apache/avro/test/FixedTest.cs
index edcc444..426c59d 100644
--- a/lang/csharp/src/apache/test/Ipc/GeneratedFiles/org/apache/avro/test/FixedTest.cs
+++ b/lang/csharp/src/apache/test/Ipc/GeneratedFiles/org/apache/avro/test/FixedTest.cs
@@ -17,7 +17,7 @@ namespace org.apache.avro.test
 	{
 		private static Schema _SCHEMA = Avro.Schema.Parse("{\"type\":\"fixed\",\"name\":\"FixedTest\",\"namespace\":\"org.apache.avro.test\",\"size\":10}");
 		private static uint fixedSize = 10;
-		public FixedTest() : 
+		public FixedTest() :
 				base(fixedSize)
 		{
 		}

http://git-wip-us.apache.org/repos/asf/avro/blob/42afa621/lang/csharp/src/apache/test/Ipc/GeneratedFiles/org/apache/avro/test/MD5.cs
----------------------------------------------------------------------
diff --git a/lang/csharp/src/apache/test/Ipc/GeneratedFiles/org/apache/avro/test/MD5.cs b/lang/csharp/src/apache/test/Ipc/GeneratedFiles/org/apache/avro/test/MD5.cs
index bc80a1b..cf243aa 100644
--- a/lang/csharp/src/apache/test/Ipc/GeneratedFiles/org/apache/avro/test/MD5.cs
+++ b/lang/csharp/src/apache/test/Ipc/GeneratedFiles/org/apache/avro/test/MD5.cs
@@ -18,7 +18,7 @@ namespace org.apache.avro.test
 		private static Schema _SCHEMA = Avro.Schema.Parse("{\"type\":\"fixed\",\"name\":\"MD5\",\"namespace\":\"org.apache.avro.test\",\"size\":16,\"javaAn" +
 				"notation\":\"org.apache.avro.TestAnnotation\"}");
 		private static uint fixedSize = 16;
-		public MD5() : 
+		public MD5() :
 				base(fixedSize)
 		{
 		}

http://git-wip-us.apache.org/repos/asf/avro/blob/42afa621/lang/csharp/src/apache/test/Ipc/SocketServerConcurrentExecutionTest.cs
----------------------------------------------------------------------
diff --git a/lang/csharp/src/apache/test/Ipc/SocketServerConcurrentExecutionTest.cs b/lang/csharp/src/apache/test/Ipc/SocketServerConcurrentExecutionTest.cs
index b0847ca..942711e 100644
--- a/lang/csharp/src/apache/test/Ipc/SocketServerConcurrentExecutionTest.cs
+++ b/lang/csharp/src/apache/test/Ipc/SocketServerConcurrentExecutionTest.cs
@@ -57,7 +57,7 @@ namespace Avro.Test.Ipc
             }
         }
 
-        // AVRO-625 [Test] 
+        // AVRO-625 [Test]
         // Currently, SocketTransceiver does not permit out-of-order requests on a stateful connection.
         public void Test()
         {
@@ -98,7 +98,7 @@ namespace Avro.Test.Ipc
             var response = (string)proxy.Request("hello", request);
 
             // 4. If control reaches here, both RPCs have executed concurrently
-            Assert.AreEqual("wait", response); 
+            Assert.AreEqual("wait", response);
         }
 
         private class SimpleResponder : GenericResponder

http://git-wip-us.apache.org/repos/asf/avro/blob/42afa621/lang/csharp/src/apache/test/Ipc/SocketServerWithCallbacksTest.cs
----------------------------------------------------------------------
diff --git a/lang/csharp/src/apache/test/Ipc/SocketServerWithCallbacksTest.cs b/lang/csharp/src/apache/test/Ipc/SocketServerWithCallbacksTest.cs
index 29d2b63..c625e63 100644
--- a/lang/csharp/src/apache/test/Ipc/SocketServerWithCallbacksTest.cs
+++ b/lang/csharp/src/apache/test/Ipc/SocketServerWithCallbacksTest.cs
@@ -36,7 +36,7 @@ namespace Avro.Test.Ipc
         private SocketServer server;
         private SocketTransceiver transceiver;
         private SimpleCallback simpleClient;
-        
+
         [TestFixtureSetUp]
         public void Init()
         {
@@ -75,7 +75,7 @@ namespace Avro.Test.Ipc
         // AVRO-625 [Test]
         public void CancelPendingRequestsOnTransceiverClose()
         {
-            // Start up a second server so that closing the server doesn't 
+            // Start up a second server so that closing the server doesn't
             // interfere with the other unit tests:
             var blockingSimpleImpl = new BlockingSimpleImpl();
 
@@ -104,7 +104,7 @@ namespace Avro.Test.Ipc
                 }
                 finally
                 {
-                    // When the transceiver is closed, the CallFuture should get 
+                    // When the transceiver is closed, the CallFuture should get
                     // an IOException
                     transceiver2.Close();
                 }
@@ -456,7 +456,7 @@ namespace Avro.Test.Ipc
         [Test]
         public void ClientReconnectAfterServerRestart()
         {
-            // Start up a second server so that closing the server doesn't 
+            // Start up a second server so that closing the server doesn't
             // interfere with the other unit tests:
             SimpleImpl simpleImpl = new BlockingSimpleImpl();
 
@@ -494,7 +494,7 @@ namespace Avro.Test.Ipc
 
                 server2.Start();
 
-                // Invoke an RPC using the same client, which should reestablish the 
+                // Invoke an RPC using the same client, which should reestablish the
                 // connection to the server:
                 Assert.AreEqual(3, simpleClient2.add(1, 2));
             }
@@ -563,7 +563,7 @@ namespace Avro.Test.Ipc
         public void Error(bool systemError)
         {
             Type expected;
-            
+
             if(systemError)
             {
                 expected = typeof(Exception);
@@ -691,7 +691,7 @@ namespace Avro.Test.Ipc
         [Test]
         public void TestSendAfterChannelClose()
         {
-            // Start up a second server so that closing the server doesn't 
+            // Start up a second server so that closing the server doesn't
             // interfere with the other unit tests:
 
             var responder = new SpecificResponder<Simple>(new SimpleImpl());
@@ -718,7 +718,7 @@ namespace Avro.Test.Ipc
                     // Shut down server:
                     server2.Stop();
 
-                    // Send a new RPC, and verify that it throws an Exception that 
+                    // Send a new RPC, and verify that it throws an Exception that
                     // can be detected by the client:
                     bool ioeCaught = false;
                     try
@@ -733,7 +733,7 @@ namespace Avro.Test.Ipc
 
                     Assert.IsTrue(ioeCaught, "Expected IOException");
 
-                    // Send a new RPC with callback, and verify that the correct Exception 
+                    // Send a new RPC with callback, and verify that the correct Exception
                     // is thrown:
                     ioeCaught = false;
                     try

http://git-wip-us.apache.org/repos/asf/avro/blob/42afa621/lang/csharp/src/apache/test/Ipc/SocketTransceiverWhenServerStopsTest.cs
----------------------------------------------------------------------
diff --git a/lang/csharp/src/apache/test/Ipc/SocketTransceiverWhenServerStopsTest.cs b/lang/csharp/src/apache/test/Ipc/SocketTransceiverWhenServerStopsTest.cs
index ee1d1e5..fb854f2 100644
--- a/lang/csharp/src/apache/test/Ipc/SocketTransceiverWhenServerStopsTest.cs
+++ b/lang/csharp/src/apache/test/Ipc/SocketTransceiverWhenServerStopsTest.cs
@@ -170,7 +170,7 @@ namespace Avro.Test.Ipc
 
                 if (threads.Count > 0)
                     Thread.Sleep(1000);
-                else 
+                else
                     break;
             }
 

http://git-wip-us.apache.org/repos/asf/avro/blob/42afa621/lang/csharp/src/apache/test/Protocol/ProtocolTest.cs
----------------------------------------------------------------------
diff --git a/lang/csharp/src/apache/test/Protocol/ProtocolTest.cs b/lang/csharp/src/apache/test/Protocol/ProtocolTest.cs
index 3c6c00b..19eeee8 100644
--- a/lang/csharp/src/apache/test/Protocol/ProtocolTest.cs
+++ b/lang/csharp/src/apache/test/Protocol/ProtocolTest.cs
@@ -53,7 +53,7 @@ namespace Avro.Test
         [TestCase(@"{
   ""protocol"" : ""MyProtocol"",
   ""namespace"" : ""com.foo"",
-  ""types"" : [ 
+  ""types"" : [
    {
 	""type"" : ""record"",
 	""name"" : ""A"",
@@ -65,14 +65,14 @@ namespace Avro.Test
 	""symbols"" : [ ""A"", ""B"", ""C"" ]
    },
    {
-   ""type"": ""fixed"", 
-   ""size"": 16, 
+   ""type"": ""fixed"",
+   ""size"": 16,
    ""name"": ""MyFixed""
    },
    {
 	""type"" : ""record"",
 	""name"" : ""Z"",
-	""fields"" : 
+	""fields"" :
 			[ 	
 				{ ""name"" : ""myUInt"", ""type"" : [ ""int"", ""null"" ] },
 				{ ""name"" : ""myULong"", ""type"" : [ ""long"", ""null"" ] },
@@ -111,12 +111,12 @@ namespace Avro.Test
         [TestCase(@"{
   ""protocol"" : ""MyProtocol"",
   ""namespace"" : ""com.bar"",
-  ""types"" : [ 
+  ""types"" : [
    {
 	""type"" : ""record"",
 	""name"" : ""A"",
-	""fields"" : 
-		[ 
+	""fields"" :
+		[
 			{ ""name"" : ""f1"", ""type"" : ""long"" }
 		]
    },
@@ -126,14 +126,14 @@ namespace Avro.Test
 	""symbols"" : [ ""A"", ""B"", ""C"" ]
    },
    {
-   ""type"": ""fixed"", 
-   ""size"": 16, 
+   ""type"": ""fixed"",
+   ""size"": 16,
    ""name"": ""MyFixed""
    },
    {
 	""type"" : ""record"",
 	""name"" : ""Z"",
-	""fields"" : 
+	""fields"" :
 			[ 	
 				{ ""name"" : ""myUInt"", ""type"" : [ ""int"", ""null"" ], ""default"" : 1 },
 				{ ""name"" : ""myULong"", ""type"" : [ ""long"", ""null"" ], ""default"" : 2 },
@@ -201,7 +201,7 @@ namespace Avro.Test
       ""errors"": [""Curse""]
     }
   }
-}", 
+}",
 @"{
   ""protocol"": ""TestProtocol"",
   ""namespace"": ""com.acme"",