You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@reef.apache.org by ma...@apache.org on 2015/11/24 20:31:38 UTC

[6/6] incubator-reef git commit: [REEF-979] Enable StyleCop.CSharp.SpacingRules and fix violations

[REEF-979] Enable StyleCop.CSharp.SpacingRules and fix violations

This also:
 * converts StyleCop violations to build breaks,
 * excludes .cs files generated from Avro and Proto schemes from check.

JIRA:
  [REEF-979](https://issues.apache.org/jira/browse/REEF-979)

Pull Request:
  This closes #660


Project: http://git-wip-us.apache.org/repos/asf/incubator-reef/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-reef/commit/dd07dc3e
Tree: http://git-wip-us.apache.org/repos/asf/incubator-reef/tree/dd07dc3e
Diff: http://git-wip-us.apache.org/repos/asf/incubator-reef/diff/dd07dc3e

Branch: refs/heads/master
Commit: dd07dc3ef92203ae66530082bfa6c67c0d397f80
Parents: e7a5606
Author: Dongjoon Hyun <do...@apache.org>
Authored: Fri Nov 20 03:07:29 2015 +0900
Committer: Mariia Mykhailova <ma...@apache.org>
Committed: Tue Nov 24 11:25:05 2015 -0800

----------------------------------------------------------------------
 .../Org.Apache.REEF.All.csproj                  |   3 +-
 .../Org.Apache.REEF.Client.Tests.csproj         |   3 +-
 .../WindowsHadoopEmulatorYarnClientTests.cs     |   2 +-
 .../Org.Apache.REEF.Client/Common/FileSets.cs   |   2 +-
 .../Common/JobSubmissionResult.cs               |   4 +-
 .../Common/ResourceArchiveFileGenerator.cs      |   2 +-
 .../Common/ResourceHelper.cs                    |   2 +-
 .../Org.Apache.REEF.Client/Local/LocalClient.cs |   2 +-
 .../Org.Apache.REEF.Client.csproj               |   3 +-
 .../YARN/Parameters/SecurityTokenParameters.cs  |   2 +-
 .../RESTClient/FileSystemJobResourceUploader.cs |   2 +-
 .../YARN/RESTClient/MultipleRMUrlProvider.cs    |   4 +-
 .../YARN/RESTClient/YarnClient.cs               |   3 +-
 .../YARN/YARNREEFClient.cs                      |   2 +-
 .../Org.Apache.REEF.Common.Tests.csproj         |   3 +-
 .../Avro/AvroHttpSerializer.cs                  |   2 +-
 lang/cs/Org.Apache.REEF.Common/Constants.cs     |   2 +-
 .../Org.Apache.REEF.Common.csproj               |  39 +++--
 .../Evaluator/Context/ContextLifeCycle.cs       |  22 +--
 .../Runtime/Evaluator/Context/ContextManager.cs |   4 +-
 .../Runtime/Evaluator/Context/ContextRuntime.cs |  98 ++++++------
 .../Evaluator/Context/RootContextLauncher.cs    |  36 ++---
 .../Runtime/Evaluator/Task/TaskStartImpl.cs     |   2 +-
 .../Runtime/Evaluator/Task/TaskStatus.cs        |   6 +-
 .../Runtime/Evaluator/Task/TaskStopImpl.cs      |   2 +-
 .../Tasks/IDriverMessageHandler.cs              |   2 +-
 .../Bridge/BridgeConfigurationProvider.cs       |   3 +-
 .../Bridge/ClrSystemHandlerWrapper.cs           |   9 +-
 .../Bridge/DriverBridgeConfigurationOptions.cs  |   4 +-
 .../Bridge/Events/AllocatedEvaluator.cs         |   2 +-
 .../Bridge/Events/FailedEvaluator.cs            |   6 +-
 lang/cs/Org.Apache.REEF.Driver/Constants.cs     |   2 +-
 .../Defaults/DefaultTaskFailureHandler.cs       |   2 +-
 .../DriverConfigGenerator.cs                    |   4 +-
 .../Evaluator/EvaluatorDescriptorImpl.cs        |   6 +-
 .../Evaluator/EvaluatorRequestBuilder.cs        |   2 +-
 .../Org.Apache.REEF.Driver.csproj               |   3 +-
 .../EvaluatorTests.cs                           |   4 +-
 .../Org.Apache.REEF.Evaluator.Tests.csproj      |   3 +-
 lang/cs/Org.Apache.REEF.Evaluator/Evaluator.cs  |   2 +-
 .../Org.Apache.REEF.Evaluator.csproj            |   3 +-
 .../HelloHttpHandler.cs                         |   7 +-
 .../HelloTraceListener.cs                       |   2 +-
 .../Org.Apache.REEF.Examples.AllHandlers.csproj |   3 +-
 ...rg.Apache.REEF.Examples.DriverRestart.csproj |   3 +-
 .../Org.Apache.REEF.Examples.HelloREEF.csproj   |   3 +-
 .../Org.Apache.REEF.Examples.csproj             |   3 +-
 .../Tasks/StreamingTasks/StreamTask1.cs         |   4 +-
 .../Tasks/StreamingTasks/StreamTask2.cs         |   4 +-
 .../Org.Apache.REEF.IMRU.Examples.csproj        |   3 +-
 .../BroadcastReceiverReduceSenderMapFunction.cs |   2 +-
 ...oadcastSenderReduceReceiverUpdateFunction.cs |  11 +-
 .../PipelinedBroadcastAndReduce.cs              |  10 +-
 .../MapInputWithControlMessageTests.cs          |   4 +-
 .../MapperCountTest.cs                          |   3 +-
 .../Org.Apache.REEF.IMRU.Tests.csproj           |   3 +-
 .../API/IMRUJobDefinitionBuilder.cs             |   2 +-
 .../InProcess/IMRURunner.cs                     |   4 +-
 .../InProcess/InProcessIMRUClient.cs            |   4 +-
 .../OnREEF/Client/REEFIMRUClient.cs             |   4 +-
 .../OnREEF/Driver/ConfigurationManager.cs       |   2 +-
 .../OnREEF/Driver/IMRUDriver.cs                 |  30 ++--
 .../ServiceAndContextConfigurationProvider.cs   |  16 +-
 .../OnREEF/IMRUTasks/MapTaskHost.cs             |   2 +-
 .../OnREEF/IMRUTasks/UpdateTaskHost.cs          |   2 +-
 .../MapControlMessage.cs                        |   4 +-
 .../MapInputWithControlMessageCodec.cs          |   8 +-
 .../OnREEF/ResultHandler/WriteResultHandler.cs  |   2 +-
 .../Org.Apache.REEF.IMRU.csproj                 |   3 +-
 .../HadoopFileInputPartitionTest.cs             |   2 +-
 .../Org.Apache.REEF.IO.TestClient.csproj        |   3 +-
 lang/cs/Org.Apache.REEF.IO.TestClient/Run.cs    |   4 +-
 .../Org.Apache.REEF.IO.Tests.csproj             |   3 +-
 .../TestAzureBlockBlobFileSystemE2E.cs          |   2 +-
 .../TestFilePartitionInputDataSet.cs            |   6 +-
 .../TestLocalFileSystem.cs                      |   2 +-
 .../TestRandomInputDataSet.cs                   |   2 +-
 .../AzureBlob/AzureBlockBlobFileSystem.cs       |   2 +-
 .../RetryPolicy/DefaultAzureBlobRetryPolicy.cs  |   2 +-
 .../Org.Apache.REEF.IO.csproj                   |   3 +-
 .../FileSystem/FileSystemInputPartition.cs      |   4 +-
 .../FileSystemPartitionInputDataSet.cs          |   7 +-
 .../Random/RandomInputPartition.cs              |   4 +-
 ...g.Apache.REEF.Network.Examples.Client.csproj |   3 +-
 .../BroadcastReduceDriverAndTasks/MasterTask.cs |   4 +-
 .../PipelinedBroadcastReduceDriver.cs           |  16 +-
 .../PipelinedMasterTask.cs                      |   8 +-
 .../PipelinedSlaveTask.cs                       |   4 +-
 .../Org.Apache.REEF.Network.Examples.csproj     |   3 +-
 .../GroupCommunication/GroupCommuDriverTests.cs |   6 +-
 .../GroupCommunicationTests.cs                  |  24 +--
 .../GroupCommunicationTreeTopologyTests.cs      |   4 +-
 .../GroupCommunication/StreamingCodecTests.cs   |   2 +-
 .../StreamingNetworkServiceTests.cs             |   2 +-
 .../Org.Apache.REEF.Network.Tests.csproj        |   3 +-
 .../Config/GroupCommConfigurationOptions.cs     |   2 +-
 .../Driver/Impl/CommunicationGroupDriver.cs     |   8 +-
 .../GroupCommunicationMessageStreamingCodec.cs  |   6 +-
 .../Group/Operators/Impl/BroadcastSender.cs     |   2 +-
 .../Group/Operators/Impl/ReduceSender.cs        |   2 +-
 .../Group/Operators/Impl/ScatterSender.cs       |   2 +-
 .../Group/Pipelining/IPipelineDataConverter.cs  |   2 +-
 .../Pipelining/StreamingPipelineMessageCodec.cs |  10 +-
 .../Group/Task/Impl/CommunicationGroupClient.cs |   2 +-
 .../Group/Task/Impl/OperatorTopology.cs         |   2 +-
 .../Group/Topology/TreeTopology.cs              |   4 +-
 .../Org.Apache.REEF.Network/Naming/NameCache.cs |  12 +-
 .../Naming/NameClient.cs                        |   6 +-
 .../NetworkService/Codec/ControlMessageCodec.cs |   4 +-
 .../Codec/NsMessageStreamingCodec.cs            |  18 +--
 .../Codec/StreamingCodecFunctionCache.cs        |  24 +--
 .../Org.Apache.REEF.Network.csproj              |   3 +-
 .../AnonymousType.cs                            |   4 +-
 .../Org.Apache.REEF.Tang.Examples/CheckChild.cs |   2 +-
 .../ForksInjectorInConstructor.cs               |   2 +-
 .../Org.Apache.REEF.Tang.Examples.csproj        |   3 +-
 .../ShortNameFooAB.cs                           |   2 +-
 .../TweetExample.cs                             |   2 +-
 .../ClassHierarchy/TestAvroSerialization.cs     |  12 +-
 .../ClassHierarchy/TestClassHierarchy.cs        |  16 +-
 .../ClassHierarchy/TestNamedParameter.cs        |   3 +-
 .../ClassHierarchy/TestParameterParser.cs       |  12 +-
 .../ClassHierarchy/TestSerilization.cs          |  16 +-
 .../Configuration/TestConfiguration.cs          |  82 +++++-----
 .../TestCsConfigurationBuilderExtension.cs      |   4 +-
 .../Format/TestConfigurationModule.cs           |   4 +-
 .../Format/TestConfigurationModuleForList.cs    |   6 +-
 .../Injection/TestAmbigousConstructors.cs       |  10 +-
 .../Injection/TestInjection.cs                  |   8 +-
 .../Injection/TestListInjection.cs              |  74 ++++-----
 .../Injection/TestMissingParameters.cs          |  30 ++--
 .../Injection/TestMissingParamtersInNested.cs   |  18 +--
 .../Injection/TestMultipleConstructors.cs       | 159 +++++++++----------
 .../Injection/TestSetInjection.cs               |   8 +-
 .../Org.Apache.REEF.Tang.Tests.csproj           |   3 +-
 .../ScenarioTest/JettyHandler.cs                |   2 +-
 .../ScenarioTest/TestHttpService.cs             |   2 +-
 .../SmokeTest/RootImplementation.cs             |  16 +-
 .../Tang/TestLegacyConstructors.cs              |   2 +-
 .../Org.Apache.REEF.Tang.Tests/Tang/TestTang.cs | 104 ++++++------
 .../Utilities/AssemblyLoaderTests.cs            |   4 +-
 .../Utilities/TestUtilities.cs                  |   2 +-
 .../Org.Apache.REEF.Tang.Tools.csproj           |   3 +-
 .../Exceptions/BindException.cs                 |   2 +-
 .../Exceptions/ClassHierarchyException.cs       |   2 +-
 .../Exceptions/NameResolutionException.cs       |   2 +-
 .../Formats/AvroConfigurationSerializer.cs      |   3 -
 .../Formats/ConfigurationFile.cs                |  10 +-
 .../Formats/ConfigurationModule.cs              |  12 +-
 .../Formats/ConfigurationModuleBuilder.cs       |  10 +-
 .../ClassHierarchy/AbstractNode.cs              |  12 +-
 .../AvroClassHierarchySerializer.cs             |   6 +-
 .../ClassHierarchy/ClassHierarchyImpl.cs        |  62 ++++----
 .../ClassHierarchy/ConstructorArgImpl.cs        |   8 +-
 .../ClassHierarchy/ConstructorDefImpl.cs        |   4 +-
 .../ClassHierarchy/NodeFactory.cs               |  44 ++---
 .../ClassHierarchy/ParameterParser.cs           |  24 +--
 .../Configuration/ConfigurationBuilderImpl.cs   |  12 +-
 .../Configuration/CsConfigurationBuilderImpl.cs |  25 +--
 .../InjectionPlan/Constructor.cs                |  30 ++--
 .../Implementations/InjectionPlan/CsInstance.cs |   8 +-
 .../InjectionPlan/InjectionFuture.cs            |  42 ++---
 .../InjectionPlan/InjectionFuturePlan.cs        |  12 +-
 .../InjectionPlan/InjectionPlan.cs              |  12 +-
 .../InjectionPlan/InjectorImpl.cs               |  85 +++++-----
 .../InjectionPlan/SetInjectionPlan.cs           |  12 +-
 .../Implementations/InjectionPlan/Subplan.cs    |  22 +--
 .../Implementations/Tang/TangImpl.cs            |  23 ++-
 .../Interface/IConfiguration.cs                 |   4 +-
 .../Interface/IConfigurationBuilder.cs          |   2 +-
 .../Interface/ICsConfigurationBuilder.cs        |   8 +-
 .../Org.Apache.REEF.Tang.csproj                 |  35 ++--
 .../Protobuf/ProtocolBufferClassHierarchy.cs    |   9 +-
 .../Protobuf/ProtocolBufferInjectionPlan.cs     |   8 +-
 .../Org.Apache.REEF.Tang/Util/MonotonicSet.cs   |  12 +-
 .../Util/MonotonicTreeMap.cs                    |   4 +-
 .../Util/ReflectionUtilities.cs                 |  44 ++---
 .../Bridge/HelloSimpleEventHandlers.cs          |   2 +-
 .../Functional/Bridge/TestBridgeClient.cs       |   4 +-
 .../Org.Apache.REEF.Tests.csproj                |   3 +-
 .../Org.Apache.REEF.Utilities/IIdentifiable.cs  |   2 +-
 .../Org.Apache.Reef.Utilities.csproj            |   3 +-
 lang/cs/Org.Apache.REEF.Wake.Tests/ClockTest.cs |   2 +-
 .../Org.Apache.REEF.Wake.Tests.csproj           |   3 +-
 lang/cs/Org.Apache.REEF.Wake/IStage.cs          |   2 +-
 lang/cs/Org.Apache.REEF.Wake/Impl/TimerStage.cs |   2 +-
 .../Org.Apache.REEF.Wake.csproj                 |   7 +-
 .../Org.Apache.REEF.Wake/RX/AbstractRxStage.cs  |   6 +-
 .../RX/IStaticObservable.cs                     |   2 +-
 .../RX/Impl/PubSubSubject.cs                    |   2 +-
 .../cs/Org.Apache.REEF.Wake/Remote/Impl/Link.cs |   4 +-
 .../Remote/Impl/MultiDecoder.cs                 |   2 +-
 .../Remote/Impl/MultiEncoder.cs                 |   2 +-
 .../Remote/Impl/RemoteEventStreamingCodec.cs    |   4 +-
 .../Remote/Impl/StreamDataReader.cs             |  10 +-
 .../Remote/Impl/StreamingLink.cs                |   6 +-
 .../Remote/Impl/StreamingTransportServer.cs     |   5 +-
 .../Remote/Impl/TransportServer.cs              |   3 +-
 .../Remote/Parameters/TcpPortRangeSeed.cs       |   2 +-
 .../Remote/TcpPortProvider.cs                   |   3 +-
 .../DoubleArrayStreamingCodec.cs                |  12 +-
 .../DoubleStreamingCodec.cs                     |  10 +-
 .../FloatArrayStreamingCodec.cs                 |  12 +-
 .../FloatStreamingCodec.cs                      |  10 +-
 .../IntArrayStreamingCodec.cs                   |  12 +-
 .../CommonStreamingCodecs/IntStreamingCodec.cs  |  10 +-
 .../StringStreamingCodec.cs                     |  10 +-
 .../StreamingCodec/IStreamingCodec.cs           |  10 +-
 .../Time/Runtime/RuntimeClock.cs                |   2 +-
 lang/cs/Settings.StyleCop                       |  58 +++----
 lang/cs/build.props                             |   2 +-
 211 files changed, 1098 insertions(+), 1047 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/dd07dc3e/lang/cs/Org.Apache.REEF.All/Org.Apache.REEF.All.csproj
----------------------------------------------------------------------
diff --git a/lang/cs/Org.Apache.REEF.All/Org.Apache.REEF.All.csproj b/lang/cs/Org.Apache.REEF.All/Org.Apache.REEF.All.csproj
index 9feecdb..34e0a7c 100644
--- a/lang/cs/Org.Apache.REEF.All/Org.Apache.REEF.All.csproj
+++ b/lang/cs/Org.Apache.REEF.All/Org.Apache.REEF.All.csproj
@@ -79,6 +79,7 @@ under the License.
   </ItemGroup>
   <Import Project="$(MSBuildToolsPath)\Microsoft.CSharp.targets" />
   <Import Project="$(SolutionDir)\.nuget\NuGet.targets" Condition="Exists('$(SolutionDir)\.nuget\NuGet.targets')" />
+  <Import Project="$(PackagesDir)\StyleCop.MSBuild.4.7.49.1\build\StyleCop.MSBuild.Targets" Condition="Exists('$(PackagesDir)\StyleCop.MSBuild.4.7.49.1\build\StyleCop.MSBuild.Targets')" />
   <!-- To modify your build process, add your task inside one of the targets below and uncomment it. 
        Other similar extension points exist, see Microsoft.Common.targets.
   <Target Name="BeforeBuild">
@@ -86,4 +87,4 @@ under the License.
   <Target Name="AfterBuild">
   </Target>
   -->
-</Project>
\ No newline at end of file
+</Project>

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/dd07dc3e/lang/cs/Org.Apache.REEF.Client.Tests/Org.Apache.REEF.Client.Tests.csproj
----------------------------------------------------------------------
diff --git a/lang/cs/Org.Apache.REEF.Client.Tests/Org.Apache.REEF.Client.Tests.csproj b/lang/cs/Org.Apache.REEF.Client.Tests/Org.Apache.REEF.Client.Tests.csproj
index 8c86d89..fd464d5 100644
--- a/lang/cs/Org.Apache.REEF.Client.Tests/Org.Apache.REEF.Client.Tests.csproj
+++ b/lang/cs/Org.Apache.REEF.Client.Tests/Org.Apache.REEF.Client.Tests.csproj
@@ -93,6 +93,7 @@ under the License.
   </ItemGroup>
   <Import Project="$(MSBuildToolsPath)\Microsoft.CSharp.targets" />
   <Import Project="$(SolutionDir)\.nuget\NuGet.targets" Condition="Exists('$(SolutionDir)\.nuget\NuGet.targets')" />
+  <Import Project="$(PackagesDir)\StyleCop.MSBuild.4.7.49.1\build\StyleCop.MSBuild.Targets" Condition="Exists('$(PackagesDir)\StyleCop.MSBuild.4.7.49.1\build\StyleCop.MSBuild.Targets')" />
   <Target Name="EnsureNuGetPackageBuildImports" BeforeTargets="PrepareForBuild">
     <PropertyGroup>
       <ErrorText>This project references NuGet package(s) that are missing on this computer. Enable NuGet Package Restore to download them.  For more information, see http://go.microsoft.com/fwlink/?LinkID=322105. The missing file is {0}.</ErrorText>
@@ -108,4 +109,4 @@ under the License.
   <Target Name="AfterBuild">
   </Target>
   -->
-</Project>
\ No newline at end of file
+</Project>

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/dd07dc3e/lang/cs/Org.Apache.REEF.Client.Tests/WindowsHadoopEmulatorYarnClientTests.cs
----------------------------------------------------------------------
diff --git a/lang/cs/Org.Apache.REEF.Client.Tests/WindowsHadoopEmulatorYarnClientTests.cs b/lang/cs/Org.Apache.REEF.Client.Tests/WindowsHadoopEmulatorYarnClientTests.cs
index 31b7382..1e273f7 100644
--- a/lang/cs/Org.Apache.REEF.Client.Tests/WindowsHadoopEmulatorYarnClientTests.cs
+++ b/lang/cs/Org.Apache.REEF.Client.Tests/WindowsHadoopEmulatorYarnClientTests.cs
@@ -40,7 +40,7 @@ namespace Org.Apache.REEF.Client.Tests
             ServiceController[] serviceControllers = ServiceController.GetServices();
             IEnumerable<string> actualServices = serviceControllers.Select(x => x.ServiceName);
 
-            string[] expectedServices = {"datanode", "namenode", "nodemanager", "resourcemanager"};
+            string[] expectedServices = { "datanode", "namenode", "nodemanager", "resourcemanager" };
 
             bool allServicesExist = expectedServices.All(expectedService => actualServices.Contains(expectedService));
 

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/dd07dc3e/lang/cs/Org.Apache.REEF.Client/Common/FileSets.cs
----------------------------------------------------------------------
diff --git a/lang/cs/Org.Apache.REEF.Client/Common/FileSets.cs b/lang/cs/Org.Apache.REEF.Client/Common/FileSets.cs
index cb154b3..3a01aaa 100644
--- a/lang/cs/Org.Apache.REEF.Client/Common/FileSets.cs
+++ b/lang/cs/Org.Apache.REEF.Client/Common/FileSets.cs
@@ -31,7 +31,7 @@ namespace Org.Apache.REEF.Client.Common
     /// </summary>
     internal sealed class FileSets
     {
-        private static readonly Logger Logger = Logger.GetLogger(typeof (FileSets));
+        private static readonly Logger Logger = Logger.GetLogger(typeof(FileSets));
         private readonly REEFFileNames _fileNames;
 
         private readonly ISet<string> _globalFileSet =

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/dd07dc3e/lang/cs/Org.Apache.REEF.Client/Common/JobSubmissionResult.cs
----------------------------------------------------------------------
diff --git a/lang/cs/Org.Apache.REEF.Client/Common/JobSubmissionResult.cs b/lang/cs/Org.Apache.REEF.Client/Common/JobSubmissionResult.cs
index 80bad49..45ff252 100644
--- a/lang/cs/Org.Apache.REEF.Client/Common/JobSubmissionResult.cs
+++ b/lang/cs/Org.Apache.REEF.Client/Common/JobSubmissionResult.cs
@@ -34,7 +34,7 @@ namespace Org.Apache.REEF.Client.Common
 {
     internal abstract class JobSubmissionResult : IJobSubmissionResult
     {
-        private static readonly Logger LOGGER = Logger.GetLogger(typeof (JobSubmissionResult));
+        private static readonly Logger LOGGER = Logger.GetLogger(typeof(JobSubmissionResult));
         private const int MaxConnectAttemptCount = 20;
         private const int MilliSecondsToWaitBeforeNextConnectAttempt = 1000;
         private const int SecondsForHttpClientTimeout = 120;
@@ -124,7 +124,7 @@ namespace Org.Apache.REEF.Client.Common
             }
         }
 
-        internal async Task<string> CallUrl (string url)
+        internal async Task<string> CallUrl(string url)
         {
             var result = await TryGetUri(url);
             if (HasCommandFailed(result))

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/dd07dc3e/lang/cs/Org.Apache.REEF.Client/Common/ResourceArchiveFileGenerator.cs
----------------------------------------------------------------------
diff --git a/lang/cs/Org.Apache.REEF.Client/Common/ResourceArchiveFileGenerator.cs b/lang/cs/Org.Apache.REEF.Client/Common/ResourceArchiveFileGenerator.cs
index e343be3..97a47dc 100644
--- a/lang/cs/Org.Apache.REEF.Client/Common/ResourceArchiveFileGenerator.cs
+++ b/lang/cs/Org.Apache.REEF.Client/Common/ResourceArchiveFileGenerator.cs
@@ -34,7 +34,7 @@ namespace Org.Apache.REEF.Client.Common
         private readonly REEFFileNames _reefFileNames;
 
         [Inject]
-        private ResourceArchiveFileGenerator (REEFFileNames reefFileNames)
+        private ResourceArchiveFileGenerator(REEFFileNames reefFileNames)
         {
             _reefFileNames = reefFileNames;
         }

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/dd07dc3e/lang/cs/Org.Apache.REEF.Client/Common/ResourceHelper.cs
----------------------------------------------------------------------
diff --git a/lang/cs/Org.Apache.REEF.Client/Common/ResourceHelper.cs b/lang/cs/Org.Apache.REEF.Client/Common/ResourceHelper.cs
index 008a236..e6eeefc 100644
--- a/lang/cs/Org.Apache.REEF.Client/Common/ResourceHelper.cs
+++ b/lang/cs/Org.Apache.REEF.Client/Common/ResourceHelper.cs
@@ -65,7 +65,7 @@ namespace Org.Apache.REEF.Client.Common
             {
                 throw new ApplicationException(string.Format(CouldNotRetrieveResource, resourceName));
             }
-            return (T) resource;
+            return (T)resource;
         }
 
         /// <summary>

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/dd07dc3e/lang/cs/Org.Apache.REEF.Client/Local/LocalClient.cs
----------------------------------------------------------------------
diff --git a/lang/cs/Org.Apache.REEF.Client/Local/LocalClient.cs b/lang/cs/Org.Apache.REEF.Client/Local/LocalClient.cs
index b11bf87..2c54259 100644
--- a/lang/cs/Org.Apache.REEF.Client/Local/LocalClient.cs
+++ b/lang/cs/Org.Apache.REEF.Client/Local/LocalClient.cs
@@ -161,7 +161,7 @@ namespace Org.Apache.REEF.Client.Local
         /// Return current Job status
         /// </summary>
         /// <returns></returns>
-        /// //TODO: REEF-889
+        /// TODO: REEF-889
         [Unstable("0.14", "Working in progress for rest API status returned")]
         public async Task<FinalState> GetJobFinalStatus(string appId)
         {

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/dd07dc3e/lang/cs/Org.Apache.REEF.Client/Org.Apache.REEF.Client.csproj
----------------------------------------------------------------------
diff --git a/lang/cs/Org.Apache.REEF.Client/Org.Apache.REEF.Client.csproj b/lang/cs/Org.Apache.REEF.Client/Org.Apache.REEF.Client.csproj
index 622f8f1..e32d265 100644
--- a/lang/cs/Org.Apache.REEF.Client/Org.Apache.REEF.Client.csproj
+++ b/lang/cs/Org.Apache.REEF.Client/Org.Apache.REEF.Client.csproj
@@ -201,6 +201,7 @@ under the License.
   </ItemGroup>
   <Import Project="$(MSBuildToolsPath)\Microsoft.CSharp.targets" />
   <Import Project="$(SolutionDir)\.nuget\NuGet.targets" Condition="Exists('$(SolutionDir)\.nuget\NuGet.targets')" />
+  <Import Project="$(PackagesDir)\StyleCop.MSBuild.4.7.49.1\build\StyleCop.MSBuild.Targets" Condition="Exists('$(PackagesDir)\StyleCop.MSBuild.4.7.49.1\build\StyleCop.MSBuild.Targets')" />
   <Target Name="EnsureNuGetPackageBuildImports" BeforeTargets="PrepareForBuild">
     <PropertyGroup>
       <ErrorText>This project references NuGet package(s) that are missing on this computer. Enable NuGet Package Restore to download them.  For more information, see http://go.microsoft.com/fwlink/?LinkID=322105. The missing file is {0}.</ErrorText>
@@ -302,4 +303,4 @@ under the License.
   </Target>
   <Target Name="BeforeBuild" DependsOnTargets="$(BeforeBuildDependsOn);RewriteClientResources">
   </Target>
-</Project>
\ No newline at end of file
+</Project>

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/dd07dc3e/lang/cs/Org.Apache.REEF.Client/YARN/Parameters/SecurityTokenParameters.cs
----------------------------------------------------------------------
diff --git a/lang/cs/Org.Apache.REEF.Client/YARN/Parameters/SecurityTokenParameters.cs b/lang/cs/Org.Apache.REEF.Client/YARN/Parameters/SecurityTokenParameters.cs
index 5d97088..a6a8092 100644
--- a/lang/cs/Org.Apache.REEF.Client/YARN/Parameters/SecurityTokenParameters.cs
+++ b/lang/cs/Org.Apache.REEF.Client/YARN/Parameters/SecurityTokenParameters.cs
@@ -19,7 +19,7 @@ using Org.Apache.REEF.Tang.Annotations;
 
 namespace Org.Apache.REEF.Client.YARN.Parameters
 {
-    [NamedParameter("Security token kind.", defaultValue:"NULL")]
+    [NamedParameter("Security token kind.", defaultValue: "NULL")]
     public sealed class SecurityTokenKindParameter : Name<string>
     {
     }

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/dd07dc3e/lang/cs/Org.Apache.REEF.Client/YARN/RESTClient/FileSystemJobResourceUploader.cs
----------------------------------------------------------------------
diff --git a/lang/cs/Org.Apache.REEF.Client/YARN/RESTClient/FileSystemJobResourceUploader.cs b/lang/cs/Org.Apache.REEF.Client/YARN/RESTClient/FileSystemJobResourceUploader.cs
index cfa83b0..5e1b4c2 100644
--- a/lang/cs/Org.Apache.REEF.Client/YARN/RESTClient/FileSystemJobResourceUploader.cs
+++ b/lang/cs/Org.Apache.REEF.Client/YARN/RESTClient/FileSystemJobResourceUploader.cs
@@ -75,7 +75,7 @@ namespace Org.Apache.REEF.Client.YARN.RestClient
 
         private long DateTimeToUnixTimestamp(DateTime dateTime)
         {
-            return (long) (dateTime - Epoch).TotalSeconds;
+            return (long)(dateTime - Epoch).TotalSeconds;
         }
     }
 }
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/dd07dc3e/lang/cs/Org.Apache.REEF.Client/YARN/RESTClient/MultipleRMUrlProvider.cs
----------------------------------------------------------------------
diff --git a/lang/cs/Org.Apache.REEF.Client/YARN/RESTClient/MultipleRMUrlProvider.cs b/lang/cs/Org.Apache.REEF.Client/YARN/RESTClient/MultipleRMUrlProvider.cs
index 5ce3bb8..4429279 100644
--- a/lang/cs/Org.Apache.REEF.Client/YARN/RESTClient/MultipleRMUrlProvider.cs
+++ b/lang/cs/Org.Apache.REEF.Client/YARN/RESTClient/MultipleRMUrlProvider.cs
@@ -61,8 +61,8 @@ namespace Org.Apache.REEF.Client.YARN.RestClient
             var configRoot = XElement.Load(yarnConfigurationFile);
             var address = configRoot.Elements("property")
                 .Where(x =>
-                    ((string) x.Element("name")).ToUpper().StartsWith(RmConfigKeyPrefix.ToUpper()))
-                .Select(x => (string) x.Element("value"));
+                    ((string)x.Element("name")).ToUpper().StartsWith(RmConfigKeyPrefix.ToUpper()))
+                .Select(x => (string)x.Element("value"));
             _yarnRmUri =
                 address.Select(x => x.TrimEnd('/') + @"/")
                     .Select(x => string.Format("http://{0}", x))

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/dd07dc3e/lang/cs/Org.Apache.REEF.Client/YARN/RESTClient/YarnClient.cs
----------------------------------------------------------------------
diff --git a/lang/cs/Org.Apache.REEF.Client/YARN/RESTClient/YarnClient.cs b/lang/cs/Org.Apache.REEF.Client/YARN/RESTClient/YarnClient.cs
index a649594..32930dc 100644
--- a/lang/cs/Org.Apache.REEF.Client/YARN/RESTClient/YarnClient.cs
+++ b/lang/cs/Org.Apache.REEF.Client/YARN/RESTClient/YarnClient.cs
@@ -55,8 +55,7 @@ namespace Org.Apache.REEF.Client.Yarn.RestClient
         {
             await new RemoveSynchronizationContextAwaiter();
 
-            IRestRequest request = CreateRestRequest( ClusterInfo.Resource, Method.GET, ClusterInfo.RootElement
-            );
+            IRestRequest request = CreateRestRequest(ClusterInfo.Resource, Method.GET, ClusterInfo.RootElement);
 
             return
                 await GenerateUrlAndExecuteRequestAsync<ClusterInfo>(request, cancellationToken);

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/dd07dc3e/lang/cs/Org.Apache.REEF.Client/YARN/YARNREEFClient.cs
----------------------------------------------------------------------
diff --git a/lang/cs/Org.Apache.REEF.Client/YARN/YARNREEFClient.cs b/lang/cs/Org.Apache.REEF.Client/YARN/YARNREEFClient.cs
index ce242bc..760b303 100644
--- a/lang/cs/Org.Apache.REEF.Client/YARN/YARNREEFClient.cs
+++ b/lang/cs/Org.Apache.REEF.Client/YARN/YARNREEFClient.cs
@@ -122,7 +122,7 @@ namespace Org.Apache.REEF.Client.Yarn
         {
             _driverFolderPreparationHelper.PrepareDriverFolder(jobSubmission, driverFolderPath);
 
-            //TODO: Remove this when we have a generalized way to pass config to java
+            // TODO: Remove this when we have a generalized way to pass config to java
             var paramInjector = TangFactory.GetTang().NewInjector(jobSubmission.DriverConfigurations.ToArray());
                 
 

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/dd07dc3e/lang/cs/Org.Apache.REEF.Common.Tests/Org.Apache.REEF.Common.Tests.csproj
----------------------------------------------------------------------
diff --git a/lang/cs/Org.Apache.REEF.Common.Tests/Org.Apache.REEF.Common.Tests.csproj b/lang/cs/Org.Apache.REEF.Common.Tests/Org.Apache.REEF.Common.Tests.csproj
index af3b1ca..9aa36ba 100644
--- a/lang/cs/Org.Apache.REEF.Common.Tests/Org.Apache.REEF.Common.Tests.csproj
+++ b/lang/cs/Org.Apache.REEF.Common.Tests/Org.Apache.REEF.Common.Tests.csproj
@@ -84,6 +84,7 @@ under the License.
   </ItemGroup>
   <Import Project="$(MSBuildToolsPath)\Microsoft.CSharp.targets" />
   <Import Project="$(SolutionDir)\.nuget\NuGet.targets" Condition="Exists('$(SolutionDir)\.nuget\NuGet.targets')" />
+  <Import Project="$(PackagesDir)\StyleCop.MSBuild.4.7.49.1\build\StyleCop.MSBuild.Targets" Condition="Exists('$(PackagesDir)\StyleCop.MSBuild.4.7.49.1\build\StyleCop.MSBuild.Targets')" />
   <Target Name="EnsureNuGetPackageBuildImports" BeforeTargets="PrepareForBuild">
     <PropertyGroup>
       <ErrorText>This project references NuGet package(s) that are missing on this computer. Enable NuGet Package Restore to download them.  For more information, see http://go.microsoft.com/fwlink/?LinkID=322105. The missing file is {0}.</ErrorText>
@@ -98,4 +99,4 @@ under the License.
   <Target Name="AfterBuild">
   </Target>
   -->
-</Project>
\ No newline at end of file
+</Project>

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/dd07dc3e/lang/cs/Org.Apache.REEF.Common/Avro/AvroHttpSerializer.cs
----------------------------------------------------------------------
diff --git a/lang/cs/Org.Apache.REEF.Common/Avro/AvroHttpSerializer.cs b/lang/cs/Org.Apache.REEF.Common/Avro/AvroHttpSerializer.cs
index 24d9628..1812002 100644
--- a/lang/cs/Org.Apache.REEF.Common/Avro/AvroHttpSerializer.cs
+++ b/lang/cs/Org.Apache.REEF.Common/Avro/AvroHttpSerializer.cs
@@ -119,7 +119,7 @@ namespace Org.Apache.REEF.Common.Avro
             var bytes = ToBytes(avroHttprequest);
             using (var file = File.OpenWrite(fileName))
             {
-                file.Write(bytes,0,bytes.Length);
+                file.Write(bytes, 0, bytes.Length);
             }
         }
     }

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/dd07dc3e/lang/cs/Org.Apache.REEF.Common/Constants.cs
----------------------------------------------------------------------
diff --git a/lang/cs/Org.Apache.REEF.Common/Constants.cs b/lang/cs/Org.Apache.REEF.Common/Constants.cs
index 913d810..fae0b21 100644
--- a/lang/cs/Org.Apache.REEF.Common/Constants.cs
+++ b/lang/cs/Org.Apache.REEF.Common/Constants.cs
@@ -23,7 +23,7 @@ namespace Org.Apache.REEF.Common
 {
     public class Constants
     {
-        [Obsolete(message:"Use REEFFileNames instead.")]
+        [Obsolete(message: "Use REEFFileNames instead.")]
         public const string ClrBridgeRuntimeConfiguration = "clrBridge.config";
 
         // if 8080 port is not used, then query would fail, 

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/dd07dc3e/lang/cs/Org.Apache.REEF.Common/Org.Apache.REEF.Common.csproj
----------------------------------------------------------------------
diff --git a/lang/cs/Org.Apache.REEF.Common/Org.Apache.REEF.Common.csproj b/lang/cs/Org.Apache.REEF.Common/Org.Apache.REEF.Common.csproj
index eb303ed..7f63053 100644
--- a/lang/cs/Org.Apache.REEF.Common/Org.Apache.REEF.Common.csproj
+++ b/lang/cs/Org.Apache.REEF.Common/Org.Apache.REEF.Common.csproj
@@ -55,12 +55,20 @@ under the License.
     <Compile Include="Api\IAbstractFailure.cs" />
     <Compile Include="Api\IFailure.cs" />
     <Compile Include="Attributes\UnstableAttribute.cs" />
-    <Compile Include="Avro\AvroDriverInfo.cs" />
-    <Compile Include="Avro\AvroHttpRequest.cs" />
+    <Compile Include="Avro\AvroDriverInfo.cs">
+        <ExcludeFromStyleCop>true</ExcludeFromStyleCop>
+    </Compile>
+    <Compile Include="Avro\AvroHttpRequest.cs">
+        <ExcludeFromStyleCop>true</ExcludeFromStyleCop>
+    </Compile>
     <Compile Include="Avro\AvroHttpSerializer.cs" />
     <Compile Include="Avro\AvroJsonSerializer.cs" />
-    <Compile Include="Avro\AvroReefServiceInfo.cs" />
-    <Compile Include="Avro\HeaderEntry.cs" />
+    <Compile Include="Avro\AvroReefServiceInfo.cs">
+        <ExcludeFromStyleCop>true</ExcludeFromStyleCop>
+    </Compile>
+    <Compile Include="Avro\HeaderEntry.cs">
+        <ExcludeFromStyleCop>true</ExcludeFromStyleCop>
+    </Compile>
     <Compile Include="Catalog\Capabilities\CPU.cs" />
     <Compile Include="Catalog\Capabilities\ICapability.cs" />
     <Compile Include="Catalog\Capabilities\RAM.cs" />
@@ -98,13 +106,23 @@ under the License.
     <Compile Include="ITaskSubmittable.cs" />
     <Compile Include="Client\Parameters\DriverConfigurationProviders.cs" />
     <Compile Include="Properties\AssemblyInfo.cs" />
-    <Compile Include="Protobuf\ReefProtocol\ClientRuntime.pb.cs" />
-    <Compile Include="Protobuf\ReefProtocol\DriverRuntime.pb.cs" />
+    <Compile Include="Protobuf\ReefProtocol\ClientRuntime.pb.cs">
+        <ExcludeFromStyleCop>true</ExcludeFromStyleCop>
+    </Compile>
+    <Compile Include="Protobuf\ReefProtocol\DriverRuntime.pb.cs">
+        <ExcludeFromStyleCop>true</ExcludeFromStyleCop>
+    </Compile>
     <Compile Include="Protobuf\ReefProtocol\EvaluatorHeartbeatProtoCodec.cs" />
-    <Compile Include="Protobuf\ReefProtocol\EvaluatorRunTime.pb.cs" />
+    <Compile Include="Protobuf\ReefProtocol\EvaluatorRunTime.pb.cs">
+        <ExcludeFromStyleCop>true</ExcludeFromStyleCop>
+    </Compile>
     <Compile Include="Protobuf\ReefProtocol\REEFMessageCodec.cs" />
-    <Compile Include="Protobuf\ReefProtocol\ReefProtocol.pb.cs" />
-    <Compile Include="Protobuf\ReefProtocol\ReefService.pb.cs" />
+    <Compile Include="Protobuf\ReefProtocol\ReefProtocol.pb.cs">
+        <ExcludeFromStyleCop>true</ExcludeFromStyleCop>
+    </Compile>
+    <Compile Include="Protobuf\ReefProtocol\ReefService.pb.cs">
+        <ExcludeFromStyleCop>true</ExcludeFromStyleCop>
+    </Compile>
     <Compile Include="Protobuf\ReefProtocol\Serializer.cs" />
     <Compile Include="Files\REEFFileNames.cs" />
     <Compile Include="Runtime\Evaluator\Constants.cs" />
@@ -180,6 +198,7 @@ under the License.
   </ItemGroup>
   <Import Project="$(MSBuildToolsPath)\Microsoft.CSharp.targets" />
   <Import Project="$(SolutionDir)\.nuget\NuGet.targets" Condition="Exists('$(SolutionDir)\.nuget\NuGet.targets')" />
+  <Import Project="$(PackagesDir)\StyleCop.MSBuild.4.7.49.1\build\StyleCop.MSBuild.Targets" Condition="Exists('$(PackagesDir)\StyleCop.MSBuild.4.7.49.1\build\StyleCop.MSBuild.Targets')" />
   <!-- To modify your build process, add your task inside one of the targets below and uncomment it. 
        Other similar extension points exist, see Microsoft.Common.targets.
   <Target Name="BeforeBuild">
@@ -187,4 +206,4 @@ under the License.
   <Target Name="AfterBuild">
   </Target>
   -->
-</Project>
\ No newline at end of file
+</Project>

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/dd07dc3e/lang/cs/Org.Apache.REEF.Common/Runtime/Evaluator/Context/ContextLifeCycle.cs
----------------------------------------------------------------------
diff --git a/lang/cs/Org.Apache.REEF.Common/Runtime/Evaluator/Context/ContextLifeCycle.cs b/lang/cs/Org.Apache.REEF.Common/Runtime/Evaluator/Context/ContextLifeCycle.cs
index 25ae343..210f452 100644
--- a/lang/cs/Org.Apache.REEF.Common/Runtime/Evaluator/Context/ContextLifeCycle.cs
+++ b/lang/cs/Org.Apache.REEF.Common/Runtime/Evaluator/Context/ContextLifeCycle.cs
@@ -70,11 +70,11 @@ namespace Org.Apache.REEF.Common.Runtime.Evaluator.Context
         {
             IContextStart contextStart = new ContextStartImpl(Id);
             
-            // TODO: enable
-            //foreach (IObserver<IContextStart> startHandler in _contextStartHandlers)
-            //{
-            //    startHandler.OnNext(contextStart);
-            //}
+            ////TODO: enable
+            ////foreach (IObserver<IContextStart> startHandler in _contextStartHandlers)
+            ////{
+            ////   startHandler.OnNext(contextStart);
+            ////}
         }
 
         /// <summary>
@@ -82,16 +82,16 @@ namespace Org.Apache.REEF.Common.Runtime.Evaluator.Context
         /// </summary>
         public void Close()
         {
-            //IContextStop contextStop = new ContextStopImpl(Id);
-            //foreach (IObserver<IContextStop> startHandler in _contextStopHandlers)
-            //{
-            //    startHandler.OnNext(contextStop);
-            //}
+            ////IContextStop contextStop = new ContextStopImpl(Id);
+            ////foreach (IObserver<IContextStop> startHandler in _contextStopHandlers)
+            ////{
+            ////   startHandler.OnNext(contextStop);
+            ////}
         }
 
         public void HandleContextMessage(byte[] message)
         {
-            //contextMessageHandler.onNext(message);
+            // contextMessageHandler.onNext(message);
         }
 
         /// <summary>

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/dd07dc3e/lang/cs/Org.Apache.REEF.Common/Runtime/Evaluator/Context/ContextManager.cs
----------------------------------------------------------------------
diff --git a/lang/cs/Org.Apache.REEF.Common/Runtime/Evaluator/Context/ContextManager.cs b/lang/cs/Org.Apache.REEF.Common/Runtime/Evaluator/Context/ContextManager.cs
index e3fbb08..47301aa 100644
--- a/lang/cs/Org.Apache.REEF.Common/Runtime/Evaluator/Context/ContextManager.cs
+++ b/lang/cs/Org.Apache.REEF.Common/Runtime/Evaluator/Context/ContextManager.cs
@@ -195,7 +195,7 @@ namespace Org.Apache.REEF.Common.Runtime.Evaluator.Context
             {
                 return Optional<TaskStatusProto>.Empty();
 
-                //throw new InvalidOperationException("Asked for an Task status while there isn't even a context running.");
+                // throw new InvalidOperationException("Asked for an Task status while there isn't even a context running.");
             }
             return _contextStack.Peek().GetTaskStatus();
         }
@@ -300,7 +300,7 @@ namespace Org.Apache.REEF.Common.Runtime.Evaluator.Context
                 }
                 _contextStack.Pop();
             }
-            //  System.gc(); // TODO: garbage collect?
+            // System.gc(); // TODO: garbage collect?
         }
 
         /// <summary>

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/dd07dc3e/lang/cs/Org.Apache.REEF.Common/Runtime/Evaluator/Context/ContextRuntime.cs
----------------------------------------------------------------------
diff --git a/lang/cs/Org.Apache.REEF.Common/Runtime/Evaluator/Context/ContextRuntime.cs b/lang/cs/Org.Apache.REEF.Common/Runtime/Evaluator/Context/ContextRuntime.cs
index 352a8be..1b8854c 100644
--- a/lang/cs/Org.Apache.REEF.Common/Runtime/Evaluator/Context/ContextRuntime.cs
+++ b/lang/cs/Org.Apache.REEF.Common/Runtime/Evaluator/Context/ContextRuntime.cs
@@ -34,7 +34,7 @@ namespace Org.Apache.REEF.Common.Runtime.Evaluator.Context
         private static readonly Logger LOGGER = Logger.GetLogger(typeof(ContextRuntime));
         // Context-local injector. This contains information that will not be available in child injectors.
         private readonly IInjector _contextInjector;
-        //// Service injector. State in this injector moves to child injectors.
+        // Service injector. State in this injector moves to child injectors.
         private readonly IInjector _serviceInjector;
 
         // Convenience class to hold all the event handlers for the context as well as the service instances.
@@ -444,52 +444,52 @@ namespace Org.Apache.REEF.Common.Runtime.Evaluator.Context
         }
     }
 }
-        ///// <summary>
-        ///// TODO: remove and use parameterless GetContextStatus above
-        ///// </summary>
-        ///// <returns>this context's status in protocol buffer form.</returns>
-        //public ContextStatusProto GetContextStatus(string contextId)
-        //{
-        //    ContextStatusProto contextStatusProto = new ContextStatusProto()
-        //    {
-        //        context_id = contextId,
-        //        context_state = _contextState,
-        //    };
-        //    return contextStatusProto;
-        //}
+        ////<summary>
+        ////TODO: remove and use parameterless GetContextStatus above
+        ////</summary>
+        ////<returns>this context's status in protocol buffer form.</returns>
+        ////public ContextStatusProto GetContextStatus(string contextId)
+        ////{
+        ////   ContextStatusProto contextStatusProto = new ContextStatusProto()
+        ////   {
+        ////       context_id = contextId,
+        ////       context_state = _contextState,
+        ////   };
+        ////   return contextStatusProto;
+        ////}
 
-        ////// TODO: remove and use injection
-        //public void StartTask(ITask task, HeartBeatManager heartBeatManager, string taskId, string contextId)
-        //{
-        //    lock (_contextLifeCycle)
-        //    {
-        //        if (_task.IsPresent() && _task.Value.HasEnded())
-        //        {
-        //            // clean up state
-        //            _task = Optional<TaskRuntime>.Empty();
-        //        }
-        //        if (_task.IsPresent())
-        //        {
-        //            throw new InvalidOperationException(
-        //                string.Format(CultureInfo.InvariantCulture, "Attempting to spawn a child context when an Task with id '{0}' is running", _task.Value.TaskId)); // note: java code is putting thread id here
-        //        }
-        //        if (_childContext.IsPresent())
-        //        {
-        //            throw new InvalidOperationException("Attempting to instantiate a child context on a context that is not the topmost active context.");
-        //        }
-        //        try
-        //        {
-        //            // final Injector taskInjector = contextInjector.forkInjector(taskConfiguration);
-        //            TaskRuntime taskRuntime  // taskInjector.getInstance(TaskRuntime.class);
-        //                = new TaskRuntime(task, heartBeatManager);
-        //            LOGGER.Log(Level.Info, string.Format(CultureInfo.InvariantCulture, "Starting task '{0}'", taskId));
-        //            taskRuntime.Initialize(taskId, contextId);
-        //            taskRuntime.Start();
-        //            _task = Optional<TaskRuntime>.Of(taskRuntime);
-        //        }
-        //        catch (Exception e)
-        //        {
-        //            throw new InvalidOperationException("Unable to instantiate the new task");
-        //        }
-        //    }
-        //}
\ No newline at end of file
+        ////TODO: remove and use injection
+        ////public void StartTask(ITask task, HeartBeatManager heartBeatManager, string taskId, string contextId)
+        ////{
+        ////  lock (_contextLifeCycle)
+        ////  {
+        ////      if (_task.IsPresent() && _task.Value.HasEnded())
+        ////      {
+        ////          // clean up state
+        ////          _task = Optional<TaskRuntime>.Empty();
+        ////      }
+        ////      if (_task.IsPresent())
+        ////      {
+        ////          throw new InvalidOperationException(
+        ////              string.Format(CultureInfo.InvariantCulture, "Attempting to spawn a child context when an Task with id '{0}' is running", _task.Value.TaskId)); // note: java code is putting thread id here
+        ////      }
+        ////      if (_childContext.IsPresent())
+        ////      {
+        ////          throw new InvalidOperationException("Attempting to instantiate a child context on a context that is not the topmost active context.");
+        ////      }
+        ////      try
+        ////      {
+        ////          // final Injector taskInjector = contextInjector.forkInjector(taskConfiguration);
+        ////          TaskRuntime taskRuntime  // taskInjector.getInstance(TaskRuntime.class);
+        ////              = new TaskRuntime(task, heartBeatManager);
+        ////          LOGGER.Log(Level.Info, string.Format(CultureInfo.InvariantCulture, "Starting task '{0}'", taskId));
+        ////          taskRuntime.Initialize(taskId, contextId);
+        ////          taskRuntime.Start();
+        ////          _task = Optional<TaskRuntime>.Of(taskRuntime);
+        ////      }
+        ////      catch (Exception e)
+        ////      {
+        ////          throw new InvalidOperationException("Unable to instantiate the new task");
+        ////      }
+        ////   }
+        ////}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/dd07dc3e/lang/cs/Org.Apache.REEF.Common/Runtime/Evaluator/Context/RootContextLauncher.cs
----------------------------------------------------------------------
diff --git a/lang/cs/Org.Apache.REEF.Common/Runtime/Evaluator/Context/RootContextLauncher.cs b/lang/cs/Org.Apache.REEF.Common/Runtime/Evaluator/Context/RootContextLauncher.cs
index 2dd417a..151ce0e 100644
--- a/lang/cs/Org.Apache.REEF.Common/Runtime/Evaluator/Context/RootContextLauncher.cs
+++ b/lang/cs/Org.Apache.REEF.Common/Runtime/Evaluator/Context/RootContextLauncher.cs
@@ -104,21 +104,21 @@ namespace Org.Apache.REEF.Common.Runtime.Evaluator.Context
         }
     }
 }
-//if (rootServiceInjector != null)
-//{
-//    try
-//    {
-//        rootServiceInjector = rootServiceInjector.ForkInjector(serviceConfigs);
-//    }
-//    catch (Exception e)
-//    {
-//        throw new ContextClientCodeException(ContextClientCodeException.GetId(rootContextConfiguration),
-//                                             Optional<String>.Empty(),
-//                                             "Unable to instatiate the root context", e);
-//    }
-//    result = new ContextRuntime(rootServiceInjector, rootContextConfiguration);
-//}
-//else
-//{
-//    result = new ContextRuntime(rootServiceInjector.ForkInjector(), rootContextConfiguration);
-//}
\ No newline at end of file
+////if (rootServiceInjector != null)
+////{
+////   try
+////   {
+////       rootServiceInjector = rootServiceInjector.ForkInjector(serviceConfigs);
+////   }
+////   catch (Exception e)
+////   {
+////       throw new ContextClientCodeException(ContextClientCodeException.GetId(rootContextConfiguration),
+////                                            Optional<String>.Empty(),
+////                                            "Unable to instatiate the root context", e);
+////   }
+////   result = new ContextRuntime(rootServiceInjector, rootContextConfiguration);
+////}
+////else
+////{
+////   result = new ContextRuntime(rootServiceInjector.ForkInjector(), rootContextConfiguration);
+////}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/dd07dc3e/lang/cs/Org.Apache.REEF.Common/Runtime/Evaluator/Task/TaskStartImpl.cs
----------------------------------------------------------------------
diff --git a/lang/cs/Org.Apache.REEF.Common/Runtime/Evaluator/Task/TaskStartImpl.cs b/lang/cs/Org.Apache.REEF.Common/Runtime/Evaluator/Task/TaskStartImpl.cs
index 1c3c734..ea1c4e3 100644
--- a/lang/cs/Org.Apache.REEF.Common/Runtime/Evaluator/Task/TaskStartImpl.cs
+++ b/lang/cs/Org.Apache.REEF.Common/Runtime/Evaluator/Task/TaskStartImpl.cs
@@ -23,7 +23,7 @@ namespace Org.Apache.REEF.Common.Runtime.Evaluator.Task
 {
     public class TaskStartImpl : ITaskStart
     {        
-        //INJECT
+        // INJECT
         public TaskStartImpl(string id)
         {
             Id = id;

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/dd07dc3e/lang/cs/Org.Apache.REEF.Common/Runtime/Evaluator/Task/TaskStatus.cs
----------------------------------------------------------------------
diff --git a/lang/cs/Org.Apache.REEF.Common/Runtime/Evaluator/Task/TaskStatus.cs b/lang/cs/Org.Apache.REEF.Common/Runtime/Evaluator/Task/TaskStatus.cs
index 5b1c4dc..844e3ef 100644
--- a/lang/cs/Org.Apache.REEF.Common/Runtime/Evaluator/Task/TaskStatus.cs
+++ b/lang/cs/Org.Apache.REEF.Common/Runtime/Evaluator/Task/TaskStatus.cs
@@ -179,8 +179,8 @@ namespace Org.Apache.REEF.Common.Runtime.Evaluator.Task
             }
             else if (_lastException.IsPresent())
             {
-                //final Encoder<Throwable> codec = new ObjectSerializableCodec<>();
-                //final byte[] error = codec.encode(_lastException.get());
+                // final Encoder<Throwable> codec = new ObjectSerializableCodec<>();
+                // final byte[] error = codec.encode(_lastException.get());
                 byte[] error = ByteUtilities.StringToByteArrays(_lastException.Value.ToString());
                 taskStatusProto.result = ByteUtilities.CopyBytesFrom(error);
             }
@@ -307,7 +307,7 @@ namespace Org.Apache.REEF.Common.Runtime.Evaluator.Task
                     Org.Apache.REEF.Utilities.Diagnostics.Exceptions.Throw(new InvalidOperationException("Unknown state: " + _state), LOGGER);
                     break;
             }
-            return Protobuf.ReefProtocol.State.FAILED; //this line should not be reached as default case will throw exception
+            return Protobuf.ReefProtocol.State.FAILED; // this line should not be reached as default case will throw exception
         }
 
         private ICollection<TaskMessage> GetMessages()

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/dd07dc3e/lang/cs/Org.Apache.REEF.Common/Runtime/Evaluator/Task/TaskStopImpl.cs
----------------------------------------------------------------------
diff --git a/lang/cs/Org.Apache.REEF.Common/Runtime/Evaluator/Task/TaskStopImpl.cs b/lang/cs/Org.Apache.REEF.Common/Runtime/Evaluator/Task/TaskStopImpl.cs
index 8ad8a5b..f459324 100644
--- a/lang/cs/Org.Apache.REEF.Common/Runtime/Evaluator/Task/TaskStopImpl.cs
+++ b/lang/cs/Org.Apache.REEF.Common/Runtime/Evaluator/Task/TaskStopImpl.cs
@@ -23,7 +23,7 @@ namespace Org.Apache.REEF.Common.Runtime.Evaluator.Task
 {
     public class TaskStopImpl : ITaskStop
     {
-        //INJECT
+        // INJECT
         public TaskStopImpl(string id)
         {
             Id = id;

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/dd07dc3e/lang/cs/Org.Apache.REEF.Common/Tasks/IDriverMessageHandler.cs
----------------------------------------------------------------------
diff --git a/lang/cs/Org.Apache.REEF.Common/Tasks/IDriverMessageHandler.cs b/lang/cs/Org.Apache.REEF.Common/Tasks/IDriverMessageHandler.cs
index 0b8e7e7..6b905b3 100644
--- a/lang/cs/Org.Apache.REEF.Common/Tasks/IDriverMessageHandler.cs
+++ b/lang/cs/Org.Apache.REEF.Common/Tasks/IDriverMessageHandler.cs
@@ -21,7 +21,7 @@ using Org.Apache.REEF.Common.Tasks.Events;
 
 namespace Org.Apache.REEF.Common.Tasks
 {
-    //[DefaultImplementation(typeof(DefaultTaskMessageSource))]
+    // [DefaultImplementation(typeof(DefaultTaskMessageSource))]
     public interface IDriverMessageHandler
     {
         void Handle(IDriverMessage message);

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/dd07dc3e/lang/cs/Org.Apache.REEF.Driver/Bridge/BridgeConfigurationProvider.cs
----------------------------------------------------------------------
diff --git a/lang/cs/Org.Apache.REEF.Driver/Bridge/BridgeConfigurationProvider.cs b/lang/cs/Org.Apache.REEF.Driver/Bridge/BridgeConfigurationProvider.cs
index c1eb9f5..d68d150 100644
--- a/lang/cs/Org.Apache.REEF.Driver/Bridge/BridgeConfigurationProvider.cs
+++ b/lang/cs/Org.Apache.REEF.Driver/Bridge/BridgeConfigurationProvider.cs
@@ -77,8 +77,7 @@ namespace Org.Apache.REEF.Driver.Bridge
                 Logger.Log(Level.Warning, "Found configurations in both the legacy location (" +
                                           legacyBridgeConfigurationPath + ") and the new location (" +
                                           newBridgeConfigurationPath +
-                                          "). Loading only the one found in the new location."
-                    );
+                                          "). Loading only the one found in the new location.");
             }
             if (newExists)
             {

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/dd07dc3e/lang/cs/Org.Apache.REEF.Driver/Bridge/ClrSystemHandlerWrapper.cs
----------------------------------------------------------------------
diff --git a/lang/cs/Org.Apache.REEF.Driver/Bridge/ClrSystemHandlerWrapper.cs b/lang/cs/Org.Apache.REEF.Driver/Bridge/ClrSystemHandlerWrapper.cs
index d67d8f4..9e2078f 100644
--- a/lang/cs/Org.Apache.REEF.Driver/Bridge/ClrSystemHandlerWrapper.cs
+++ b/lang/cs/Org.Apache.REEF.Driver/Bridge/ClrSystemHandlerWrapper.cs
@@ -164,20 +164,21 @@ namespace Org.Apache.REEF.Driver.Bridge
             {
                 try
                 {
-                    GCHandle gc = GCHandle.FromIntPtr((IntPtr) handle);
+                    GCHandle gc = GCHandle.FromIntPtr((IntPtr)handle);
                     if (!gc.IsAllocated)
                     {
                         LOGGER.Log(Level.Warning, "gc is not allocated.");
                     } 
-                    ClrSystemHandler<IHttpMessage> obj = (ClrSystemHandler<IHttpMessage>) gc.Target;
+                    ClrSystemHandler<IHttpMessage> obj = (ClrSystemHandler<IHttpMessage>)gc.Target;
                     obj.OnNext(new HttpMessage(clr2Java));
                 }
                 catch (Exception ex)
                 {
                   
-                    LOGGER.Log(Level.Info, "Caught exception: " + ex.Message + ex.StackTrace );
+                    LOGGER.Log(Level.Info, "Caught exception: " + ex.Message + ex.StackTrace);
                     Exceptions.CaughtAndThrow(ex, Level.Warning,  LOGGER);
-                }}
+                }
+            }
         }
 
         public static void Call_ClrSystemClosedContext_OnNext(ulong handle, IClosedContextClr2Java clr2Java)

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/dd07dc3e/lang/cs/Org.Apache.REEF.Driver/Bridge/DriverBridgeConfigurationOptions.cs
----------------------------------------------------------------------
diff --git a/lang/cs/Org.Apache.REEF.Driver/Bridge/DriverBridgeConfigurationOptions.cs b/lang/cs/Org.Apache.REEF.Driver/Bridge/DriverBridgeConfigurationOptions.cs
index 16940d2..7ceb851 100644
--- a/lang/cs/Org.Apache.REEF.Driver/Bridge/DriverBridgeConfigurationOptions.cs
+++ b/lang/cs/Org.Apache.REEF.Driver/Bridge/DriverBridgeConfigurationOptions.cs
@@ -40,7 +40,7 @@ namespace Org.Apache.REEF.Driver.Bridge
         // Level.Verbose (since enum is not suppoted for TANG, we use a string here)
         private const string _verboseLevel = "Verbose";
 
-        [NamedParameter(documentation:"The start point for application logic. Event fired after the Driver is done initializing.")]
+        [NamedParameter(documentation: "The start point for application logic. Event fired after the Driver is done initializing.")]
         public class DriverStartedHandlers : Name<ISet<IObserver<IDriverStarted>>>
         {
         }
@@ -50,7 +50,7 @@ namespace Org.Apache.REEF.Driver.Bridge
         {
         }
 
-        [NamedParameter(documentation: "Called when driver restart is completed.", defaultClasses: new[] { typeof (DefaultDriverRestartCompletedHandler) })]
+        [NamedParameter(documentation: "Called when driver restart is completed.", defaultClasses: new[] { typeof(DefaultDriverRestartCompletedHandler) })]
         public class DriverRestartCompletedHandlers : Name<ISet<IObserver<IDriverRestartCompleted>>>
         {
         }

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/dd07dc3e/lang/cs/Org.Apache.REEF.Driver/Bridge/Events/AllocatedEvaluator.cs
----------------------------------------------------------------------
diff --git a/lang/cs/Org.Apache.REEF.Driver/Bridge/Events/AllocatedEvaluator.cs b/lang/cs/Org.Apache.REEF.Driver/Bridge/Events/AllocatedEvaluator.cs
index d64816e..5968734 100644
--- a/lang/cs/Org.Apache.REEF.Driver/Bridge/Events/AllocatedEvaluator.cs
+++ b/lang/cs/Org.Apache.REEF.Driver/Bridge/Events/AllocatedEvaluator.cs
@@ -93,7 +93,7 @@ namespace Org.Apache.REEF.Driver.Bridge.Events
         {
             LOGGER.Log(Level.Info, "AllocatedEvaluator::SubmitContextAndTask");
 
-            //TODO: Change this to service configuration when REEF-289(https://issues.apache.org/jira/browse/REEF-289) is fixed.
+            // TODO: Change this to service configuration when REEF-289(https://issues.apache.org/jira/browse/REEF-289) is fixed.
             taskConfiguration = MergeWithConfigurationProviders(taskConfiguration);
             string context = _serializer.ToString(contextConfiguration);
             string task = _serializer.ToString(taskConfiguration);

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/dd07dc3e/lang/cs/Org.Apache.REEF.Driver/Bridge/Events/FailedEvaluator.cs
----------------------------------------------------------------------
diff --git a/lang/cs/Org.Apache.REEF.Driver/Bridge/Events/FailedEvaluator.cs b/lang/cs/Org.Apache.REEF.Driver/Bridge/Events/FailedEvaluator.cs
index 9915a2f..2f4a7f2 100644
--- a/lang/cs/Org.Apache.REEF.Driver/Bridge/Events/FailedEvaluator.cs
+++ b/lang/cs/Org.Apache.REEF.Driver/Bridge/Events/FailedEvaluator.cs
@@ -53,18 +53,18 @@ namespace Org.Apache.REEF.Driver.Bridge.Events
             get { return _id; }
         }
 
-        //TODO[REEF-769]: Implement
+        // TODO[REEF-769]: Implement
         public EvaluatorException EvaluatorException
         {
             get { return null; }
         }
 
-        //TODO[REEF-769]: Implement
+        // TODO[REEF-769]: Implement
         public IList<IFailedContext> FailedContexts
         {
             get { return new List<IFailedContext>(0); }
         }
-        //TODO[REEF-769]: Implement
+        // TODO[REEF-769]: Implement
         public Optional<IFailedTask> FailedTask
         {
             get { return Optional<IFailedTask>.Empty(); }

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/dd07dc3e/lang/cs/Org.Apache.REEF.Driver/Constants.cs
----------------------------------------------------------------------
diff --git a/lang/cs/Org.Apache.REEF.Driver/Constants.cs b/lang/cs/Org.Apache.REEF.Driver/Constants.cs
index 79c3f96..bb0fac8 100644
--- a/lang/cs/Org.Apache.REEF.Driver/Constants.cs
+++ b/lang/cs/Org.Apache.REEF.Driver/Constants.cs
@@ -50,7 +50,7 @@ namespace Org.Apache.REEF.Driver
         /// </summary>
         public const int DefaultMemoryGranularity = 1024;
 
-        [Obsolete(message:"Use REEFFileNames instead.")]
+        [Obsolete(message: "Use REEFFileNames instead.")]
         public const string DriverBridgeConfiguration = Common.Constants.ClrBridgeRuntimeConfiguration;
 
         /// <summary>

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/dd07dc3e/lang/cs/Org.Apache.REEF.Driver/Defaults/DefaultTaskFailureHandler.cs
----------------------------------------------------------------------
diff --git a/lang/cs/Org.Apache.REEF.Driver/Defaults/DefaultTaskFailureHandler.cs b/lang/cs/Org.Apache.REEF.Driver/Defaults/DefaultTaskFailureHandler.cs
index e1249cf..a315e23 100644
--- a/lang/cs/Org.Apache.REEF.Driver/Defaults/DefaultTaskFailureHandler.cs
+++ b/lang/cs/Org.Apache.REEF.Driver/Defaults/DefaultTaskFailureHandler.cs
@@ -36,7 +36,7 @@ namespace Org.Apache.REEF.Driver.Defaults
 
         public void OnNext(IFailedTask value)
         {
-            throw new InvalidOperationException(string.Format(CultureInfo.InvariantCulture, "Task {0} has failed, and no handler was bound for IFailedTask", value.Id) );
+            throw new InvalidOperationException(string.Format(CultureInfo.InvariantCulture, "Task {0} has failed, and no handler was bound for IFailedTask", value.Id));
         }
 
         public void OnError(Exception error)

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/dd07dc3e/lang/cs/Org.Apache.REEF.Driver/DriverConfigGenerator.cs
----------------------------------------------------------------------
diff --git a/lang/cs/Org.Apache.REEF.Driver/DriverConfigGenerator.cs b/lang/cs/Org.Apache.REEF.Driver/DriverConfigGenerator.cs
index 89bb34f..c9ade09 100644
--- a/lang/cs/Org.Apache.REEF.Driver/DriverConfigGenerator.cs
+++ b/lang/cs/Org.Apache.REEF.Driver/DriverConfigGenerator.cs
@@ -107,7 +107,7 @@ namespace Org.Apache.REEF.Driver
             b.Bind("org.apache.reef.driver.parameters.DriverMemory", driverConfigurationSettings.DriverMemory.ToString(CultureInfo.CurrentCulture));
             b.Bind("org.apache.reef.driver.parameters.DriverJobSubmissionDirectory", driverConfigurationSettings.SubmissionDirectory);
 
-            //add for all the globallibaries
+            // add for all the globallibaries
             if (File.Exists(UserSuppliedGlobalLibraries))
             {
                 var globalLibString = File.ReadAllText(UserSuppliedGlobalLibraries);
@@ -131,7 +131,7 @@ namespace Org.Apache.REEF.Driver
 
             Log.Log(Level.Info, string.Format(CultureInfo.CurrentCulture, "driver.config is written to: {0} {1}.", Directory.GetCurrentDirectory(), DriverConfigFile));
 
-            //additional file for easy to read
+            // additional file for easy to read
             using (StreamWriter outfile = new StreamWriter(DriverConfigFile + ".txt"))
             {
                 outfile.Write(serializer.ToString(c));

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/dd07dc3e/lang/cs/Org.Apache.REEF.Driver/Evaluator/EvaluatorDescriptorImpl.cs
----------------------------------------------------------------------
diff --git a/lang/cs/Org.Apache.REEF.Driver/Evaluator/EvaluatorDescriptorImpl.cs b/lang/cs/Org.Apache.REEF.Driver/Evaluator/EvaluatorDescriptorImpl.cs
index 319ba08..0ddee20 100644
--- a/lang/cs/Org.Apache.REEF.Driver/Evaluator/EvaluatorDescriptorImpl.cs
+++ b/lang/cs/Org.Apache.REEF.Driver/Evaluator/EvaluatorDescriptorImpl.cs
@@ -104,7 +104,7 @@ namespace Org.Apache.REEF.Driver.Evaluator
 
             var ipEndPoint = new IPEndPoint(IPAddress.Parse(ipAddress), portNumber);
 
-            _nodeDescriptor = new NodeDescriptorImpl {InetSocketAddress = ipEndPoint, HostName = hostName};
+            _nodeDescriptor = new NodeDescriptorImpl { InetSocketAddress = ipEndPoint, HostName = hostName };
             _evaluatorType = EvaluatorType.CLR;
             _megaBytes = memoryInMegaBytes;
             _core = vCore;
@@ -158,8 +158,8 @@ namespace Org.Apache.REEF.Driver.Evaluator
             var granularity = ClrHandlerHelper.MemoryGranularity == 0
                 ? Constants.DefaultMemoryGranularity
                 : ClrHandlerHelper.MemoryGranularity;
-            var m1 = (Memory - 1)/granularity;
-            var m2 = (other.Memory - 1)/granularity;
+            var m1 = (Memory - 1) / granularity;
+            var m2 = (other.Memory - 1) / granularity;
             return (m1 == m2);
         }
     }

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/dd07dc3e/lang/cs/Org.Apache.REEF.Driver/Evaluator/EvaluatorRequestBuilder.cs
----------------------------------------------------------------------
diff --git a/lang/cs/Org.Apache.REEF.Driver/Evaluator/EvaluatorRequestBuilder.cs b/lang/cs/Org.Apache.REEF.Driver/Evaluator/EvaluatorRequestBuilder.cs
index 897adb1..0f4c97c 100644
--- a/lang/cs/Org.Apache.REEF.Driver/Evaluator/EvaluatorRequestBuilder.cs
+++ b/lang/cs/Org.Apache.REEF.Driver/Evaluator/EvaluatorRequestBuilder.cs
@@ -111,7 +111,7 @@ namespace Org.Apache.REEF.Driver.Evaluator
         public IEvaluatorRequest Build()
         {
 #pragma warning disable 618
-            return new EvaluatorRequest(Number, MegaBytes, VirtualCore, rack:_rackName, evaluatorBatchId:_evaluatorBatchId);
+            return new EvaluatorRequest(Number, MegaBytes, VirtualCore, rack: _rackName, evaluatorBatchId: _evaluatorBatchId);
 #pragma warning restore 618
         }
     }

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/dd07dc3e/lang/cs/Org.Apache.REEF.Driver/Org.Apache.REEF.Driver.csproj
----------------------------------------------------------------------
diff --git a/lang/cs/Org.Apache.REEF.Driver/Org.Apache.REEF.Driver.csproj b/lang/cs/Org.Apache.REEF.Driver/Org.Apache.REEF.Driver.csproj
index 0c0a47e..ef4bca8 100644
--- a/lang/cs/Org.Apache.REEF.Driver/Org.Apache.REEF.Driver.csproj
+++ b/lang/cs/Org.Apache.REEF.Driver/Org.Apache.REEF.Driver.csproj
@@ -177,6 +177,7 @@ under the License.
   </ItemGroup>
   <Import Project="$(MSBuildToolsPath)\Microsoft.CSharp.targets" />
   <Import Project="$(SolutionDir)\.nuget\NuGet.targets" Condition="Exists('$(SolutionDir)\.nuget\NuGet.targets')" />
+  <Import Project="$(PackagesDir)\StyleCop.MSBuild.4.7.49.1\build\StyleCop.MSBuild.Targets" Condition="Exists('$(PackagesDir)\StyleCop.MSBuild.4.7.49.1\build\StyleCop.MSBuild.Targets')" />
   <!-- To modify your build process, add your task inside one of the targets below and uncomment it. 
        Other similar extension points exist, see Microsoft.Common.targets.
   <Target Name="BeforeBuild">
@@ -184,4 +185,4 @@ under the License.
   <Target Name="AfterBuild">
   </Target>
   -->
-</Project>
\ No newline at end of file
+</Project>

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/dd07dc3e/lang/cs/Org.Apache.REEF.Evaluator.Tests/EvaluatorTests.cs
----------------------------------------------------------------------
diff --git a/lang/cs/Org.Apache.REEF.Evaluator.Tests/EvaluatorTests.cs b/lang/cs/Org.Apache.REEF.Evaluator.Tests/EvaluatorTests.cs
index a6c55fb..9a8afcc 100644
--- a/lang/cs/Org.Apache.REEF.Evaluator.Tests/EvaluatorTests.cs
+++ b/lang/cs/Org.Apache.REEF.Evaluator.Tests/EvaluatorTests.cs
@@ -39,7 +39,7 @@ namespace Org.Apache.REEF.Evaluator.Tests
         [Description("Parse Evaluator configuration from Java, inject and execute Shell task with DIR command based on the configuration")]
         public void CanInjectAndExecuteTask()
         {
-            //To enforce that shell task dll be copied to output directory.
+            // to enforce that shell task dll be copied to output directory.
             ShellTask tmpTask = new ShellTask("invalid");
             Assert.IsNotNull(tmpTask);
 
@@ -77,7 +77,7 @@ namespace Org.Apache.REEF.Evaluator.Tests
             byte[] bytes = task.Call(null);
             string result = System.Text.Encoding.Default.GetString(bytes);
 
-            //a dir command is executed in the container directory, which includes the file "evaluator.conf"
+            // a dir command is executed in the container directory, which includes the file "evaluator.conf"
             Assert.IsTrue(result.Contains("evaluator.conf"));
         }
 

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/dd07dc3e/lang/cs/Org.Apache.REEF.Evaluator.Tests/Org.Apache.REEF.Evaluator.Tests.csproj
----------------------------------------------------------------------
diff --git a/lang/cs/Org.Apache.REEF.Evaluator.Tests/Org.Apache.REEF.Evaluator.Tests.csproj b/lang/cs/Org.Apache.REEF.Evaluator.Tests/Org.Apache.REEF.Evaluator.Tests.csproj
index 118d26a..ee5cc85 100644
--- a/lang/cs/Org.Apache.REEF.Evaluator.Tests/Org.Apache.REEF.Evaluator.Tests.csproj
+++ b/lang/cs/Org.Apache.REEF.Evaluator.Tests/Org.Apache.REEF.Evaluator.Tests.csproj
@@ -110,6 +110,7 @@ under the License.
   <Import Project="$(VSToolsPath)\TeamTest\Microsoft.TestTools.targets" Condition="Exists('$(VSToolsPath)\TeamTest\Microsoft.TestTools.targets')" />
   <Import Project="$(MSBuildToolsPath)\Microsoft.CSharp.targets" />
   <Import Project="$(SolutionDir)\.nuget\NuGet.targets" Condition="Exists('$(SolutionDir)\.nuget\NuGet.targets')" />
+  <Import Project="$(PackagesDir)\StyleCop.MSBuild.4.7.49.1\build\StyleCop.MSBuild.Targets" Condition="Exists('$(PackagesDir)\StyleCop.MSBuild.4.7.49.1\build\StyleCop.MSBuild.Targets')" />
   <Target Name="EnsureNuGetPackageBuildImports" BeforeTargets="PrepareForBuild">
     <PropertyGroup>
       <ErrorText>This project references NuGet package(s) that are missing on this computer. Enable NuGet Package Restore to download them.  For more information, see http://go.microsoft.com/fwlink/?LinkID=322105. The missing file is {0}.</ErrorText>
@@ -118,4 +119,4 @@ under the License.
     <Error Condition="!Exists('$(PackagesDir)\xunit.core.2.1.0\build\portable-net45+win8+wp8+wpa81\xunit.core.props')" Text="$([System.String]::Format('$(ErrorText)', '$(PackagesDir)\xunit.core.2.1.0\build\portable-net45+win8+wp8+wpa81\xunit.core.props'))" />
     <Error Condition="!Exists('$(PackagesDir)\xunit.runner.visualstudio.2.1.0\build\net20\xunit.runner.visualstudio.props')" Text="$([System.String]::Format('$(ErrorText)', '$(PackagesDir)\xunit.runner.visualstudio.2.1.0\build\net20\xunit.runner.visualstudio.props'))" />
   </Target>
-</Project>
\ No newline at end of file
+</Project>

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/dd07dc3e/lang/cs/Org.Apache.REEF.Evaluator/Evaluator.cs
----------------------------------------------------------------------
diff --git a/lang/cs/Org.Apache.REEF.Evaluator/Evaluator.cs b/lang/cs/Org.Apache.REEF.Evaluator/Evaluator.cs
index 721d85d..0ffce12 100644
--- a/lang/cs/Org.Apache.REEF.Evaluator/Evaluator.cs
+++ b/lang/cs/Org.Apache.REEF.Evaluator/Evaluator.cs
@@ -326,7 +326,7 @@ namespace Org.Apache.REEF.Evaluator
         // we only need runtimestart and runtimestop handlers now
         private static void SetRuntimeHandlers(EvaluatorRuntime evaluatorRuntime, RuntimeClock clock)
         {
-            ISet<IObserver<RuntimeStart>> runtimeStarts = new HashSet<IObserver<RuntimeStart>> {evaluatorRuntime};
+            ISet<IObserver<RuntimeStart>> runtimeStarts = new HashSet<IObserver<RuntimeStart>> { evaluatorRuntime };
             InjectionFutureImpl<ISet<IObserver<RuntimeStart>>> injectRuntimeStart = new InjectionFutureImpl<ISet<IObserver<RuntimeStart>>>(runtimeStarts);
             clock.InjectedRuntimeStartHandler = injectRuntimeStart;
 

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/dd07dc3e/lang/cs/Org.Apache.REEF.Evaluator/Org.Apache.REEF.Evaluator.csproj
----------------------------------------------------------------------
diff --git a/lang/cs/Org.Apache.REEF.Evaluator/Org.Apache.REEF.Evaluator.csproj b/lang/cs/Org.Apache.REEF.Evaluator/Org.Apache.REEF.Evaluator.csproj
index 672b612..6cfdc20 100644
--- a/lang/cs/Org.Apache.REEF.Evaluator/Org.Apache.REEF.Evaluator.csproj
+++ b/lang/cs/Org.Apache.REEF.Evaluator/Org.Apache.REEF.Evaluator.csproj
@@ -89,6 +89,7 @@ under the License.
   </ItemGroup>
   <Import Project="$(MSBuildToolsPath)\Microsoft.CSharp.targets" />
   <Import Project="$(SolutionDir)\.nuget\NuGet.targets" Condition="Exists('$(SolutionDir)\.nuget\NuGet.targets')" />
+  <Import Project="$(PackagesDir)\StyleCop.MSBuild.4.7.49.1\build\StyleCop.MSBuild.Targets" Condition="Exists('$(PackagesDir)\StyleCop.MSBuild.4.7.49.1\build\StyleCop.MSBuild.Targets')" />
   <!-- To modify your build process, add your task inside one of the targets below and uncomment it. 
        Other similar extension points exist, see Microsoft.Common.targets.
   <Target Name="BeforeBuild">
@@ -96,4 +97,4 @@ under the License.
   <Target Name="AfterBuild">
   </Target>
   -->
-</Project>
\ No newline at end of file
+</Project>

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/dd07dc3e/lang/cs/Org.Apache.REEF.Examples.AllHandlers/HelloHttpHandler.cs
----------------------------------------------------------------------
diff --git a/lang/cs/Org.Apache.REEF.Examples.AllHandlers/HelloHttpHandler.cs b/lang/cs/Org.Apache.REEF.Examples.AllHandlers/HelloHttpHandler.cs
index afb5101..5f4992f 100644
--- a/lang/cs/Org.Apache.REEF.Examples.AllHandlers/HelloHttpHandler.cs
+++ b/lang/cs/Org.Apache.REEF.Examples.AllHandlers/HelloHttpHandler.cs
@@ -40,7 +40,7 @@ namespace Org.Apache.REEF.Examples.AllHandlers
 
         public string GetSpecification()
         {
-            return "NRT"; //Client Example 
+            return "NRT"; // Client Example 
         }
 
         /// <summary>
@@ -50,7 +50,10 @@ namespace Org.Apache.REEF.Examples.AllHandlers
         /// <param name="response"></param>
         public void OnHttpRequest(ReefHttpRequest request, ReefHttpResponse response)  
         {
-            Logger.Log(Level.Info, string.Format(CultureInfo.CurrentCulture, "HelloHttpHandler OnHttpRequest: URL: {0}, QueryString: {1}, inputStream: {2}.", request.Url, request.Querystring, ByteUtilities.ByteArraysToString(request.InputStream)));response.Status = HttpStatusCode.OK;
+            Logger.Log(Level.Info, string.Format(CultureInfo.CurrentCulture, 
+                "HelloHttpHandler OnHttpRequest: URL: {0}, QueryString: {1}, inputStream: {2}.", 
+                request.Url, request.Querystring, ByteUtilities.ByteArraysToString(request.InputStream)));
+            response.Status = HttpStatusCode.OK;
             response.OutputStream =
                 ByteUtilities.StringToByteArrays("Byte array returned from HelloHttpHandler in CLR!!!");
         }

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/dd07dc3e/lang/cs/Org.Apache.REEF.Examples.AllHandlers/HelloTraceListener.cs
----------------------------------------------------------------------
diff --git a/lang/cs/Org.Apache.REEF.Examples.AllHandlers/HelloTraceListener.cs b/lang/cs/Org.Apache.REEF.Examples.AllHandlers/HelloTraceListener.cs
index bd97549..e198dab 100644
--- a/lang/cs/Org.Apache.REEF.Examples.AllHandlers/HelloTraceListener.cs
+++ b/lang/cs/Org.Apache.REEF.Examples.AllHandlers/HelloTraceListener.cs
@@ -37,7 +37,7 @@ namespace Org.Apache.REEF.Examples.AllHandlers
 
         public override void Write(string message)
         {
-            _listener.Write("[helloTrace]" + message );
+            _listener.Write("[helloTrace]" + message);
         }
 
         public override void WriteLine(string message)

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/dd07dc3e/lang/cs/Org.Apache.REEF.Examples.AllHandlers/Org.Apache.REEF.Examples.AllHandlers.csproj
----------------------------------------------------------------------
diff --git a/lang/cs/Org.Apache.REEF.Examples.AllHandlers/Org.Apache.REEF.Examples.AllHandlers.csproj b/lang/cs/Org.Apache.REEF.Examples.AllHandlers/Org.Apache.REEF.Examples.AllHandlers.csproj
index 541ac19..9503a7a 100644
--- a/lang/cs/Org.Apache.REEF.Examples.AllHandlers/Org.Apache.REEF.Examples.AllHandlers.csproj
+++ b/lang/cs/Org.Apache.REEF.Examples.AllHandlers/Org.Apache.REEF.Examples.AllHandlers.csproj
@@ -122,6 +122,7 @@ under the License.
   </PropertyGroup>
   <Target Name="AfterBuild" DependsOnTargets="$(AfterBuildDependsOn);" />
   <Import Project="$(SolutionDir)\.nuget\NuGet.targets" Condition="Exists('$(SolutionDir)\.nuget\NuGet.targets')" />
+  <Import Project="$(PackagesDir)\StyleCop.MSBuild.4.7.49.1\build\StyleCop.MSBuild.Targets" Condition="Exists('$(PackagesDir)\StyleCop.MSBuild.4.7.49.1\build\StyleCop.MSBuild.Targets')" />
   <Target Name="EnsureNuGetPackageBuildImports" BeforeTargets="PrepareForBuild">
     <PropertyGroup>
       <ErrorText>This project references NuGet package(s) that are missing on this computer. Enable NuGet Package Restore to download them.  For more information, see http://go.microsoft.com/fwlink/?LinkID=322105. The missing file is {0}.</ErrorText>
@@ -129,4 +130,4 @@ under the License.
     <Error Condition="!Exists('$(SolutionDir)\.nuget\NuGet.targets')" Text="$([System.String]::Format('$(ErrorText)', '$(SolutionDir)\.nuget\NuGet.targets'))" />
   </Target>
   <!--end jar reference-->
-</Project>
\ No newline at end of file
+</Project>

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/dd07dc3e/lang/cs/Org.Apache.REEF.Examples.DriverRestart/Org.Apache.REEF.Examples.DriverRestart.csproj
----------------------------------------------------------------------
diff --git a/lang/cs/Org.Apache.REEF.Examples.DriverRestart/Org.Apache.REEF.Examples.DriverRestart.csproj b/lang/cs/Org.Apache.REEF.Examples.DriverRestart/Org.Apache.REEF.Examples.DriverRestart.csproj
index 3200eb9..4425c49 100644
--- a/lang/cs/Org.Apache.REEF.Examples.DriverRestart/Org.Apache.REEF.Examples.DriverRestart.csproj
+++ b/lang/cs/Org.Apache.REEF.Examples.DriverRestart/Org.Apache.REEF.Examples.DriverRestart.csproj
@@ -74,10 +74,11 @@
   </ItemGroup>
   <Import Project="$(MSBuildToolsPath)\Microsoft.CSharp.targets" />
   <Import Project="$(SolutionDir)\.nuget\NuGet.targets" Condition="Exists('$(SolutionDir)\.nuget\NuGet.targets')" />
+  <Import Project="$(PackagesDir)\StyleCop.MSBuild.4.7.49.1\build\StyleCop.MSBuild.Targets" Condition="Exists('$(PackagesDir)\StyleCop.MSBuild.4.7.49.1\build\StyleCop.MSBuild.Targets')" />
   <Target Name="EnsureNuGetPackageBuildImports" BeforeTargets="PrepareForBuild">
     <PropertyGroup>
       <ErrorText>This project references NuGet package(s) that are missing on this computer. Enable NuGet Package Restore to download them.  For more information, see http://go.microsoft.com/fwlink/?LinkID=322105. The missing file is {0}.</ErrorText>
     </PropertyGroup>
     <Error Condition="!Exists('$(SolutionDir)\.nuget\NuGet.targets')" Text="$([System.String]::Format('$(ErrorText)', '$(SolutionDir)\.nuget\NuGet.targets'))" />
   </Target>
-</Project>
\ No newline at end of file
+</Project>

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/dd07dc3e/lang/cs/Org.Apache.REEF.Examples.HelloREEF/Org.Apache.REEF.Examples.HelloREEF.csproj
----------------------------------------------------------------------
diff --git a/lang/cs/Org.Apache.REEF.Examples.HelloREEF/Org.Apache.REEF.Examples.HelloREEF.csproj b/lang/cs/Org.Apache.REEF.Examples.HelloREEF/Org.Apache.REEF.Examples.HelloREEF.csproj
index aee23e2..825170f 100644
--- a/lang/cs/Org.Apache.REEF.Examples.HelloREEF/Org.Apache.REEF.Examples.HelloREEF.csproj
+++ b/lang/cs/Org.Apache.REEF.Examples.HelloREEF/Org.Apache.REEF.Examples.HelloREEF.csproj
@@ -69,10 +69,11 @@
   </ItemGroup>
   <Import Project="$(MSBuildToolsPath)\Microsoft.CSharp.targets" />
   <Import Project="$(SolutionDir)\.nuget\NuGet.targets" Condition="Exists('$(SolutionDir)\.nuget\NuGet.targets')" />
+  <Import Project="$(PackagesDir)\StyleCop.MSBuild.4.7.49.1\build\StyleCop.MSBuild.Targets" Condition="Exists('$(PackagesDir)\StyleCop.MSBuild.4.7.49.1\build\StyleCop.MSBuild.Targets')" />
   <Target Name="EnsureNuGetPackageBuildImports" BeforeTargets="PrepareForBuild">
     <PropertyGroup>
       <ErrorText>This project references NuGet package(s) that are missing on this computer. Enable NuGet Package Restore to download them.  For more information, see http://go.microsoft.com/fwlink/?LinkID=322105. The missing file is {0}.</ErrorText>
     </PropertyGroup>
     <Error Condition="!Exists('$(SolutionDir)\.nuget\NuGet.targets')" Text="$([System.String]::Format('$(ErrorText)', '$(SolutionDir)\.nuget\NuGet.targets'))" />
   </Target>
-</Project>
\ No newline at end of file
+</Project>

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/dd07dc3e/lang/cs/Org.Apache.REEF.Examples/Org.Apache.REEF.Examples.csproj
----------------------------------------------------------------------
diff --git a/lang/cs/Org.Apache.REEF.Examples/Org.Apache.REEF.Examples.csproj b/lang/cs/Org.Apache.REEF.Examples/Org.Apache.REEF.Examples.csproj
index 32d8fe3..17d36e3 100644
--- a/lang/cs/Org.Apache.REEF.Examples/Org.Apache.REEF.Examples.csproj
+++ b/lang/cs/Org.Apache.REEF.Examples/Org.Apache.REEF.Examples.csproj
@@ -100,6 +100,7 @@ under the License.
   </ItemGroup>
   <Import Project="$(MSBuildToolsPath)\Microsoft.CSharp.targets" />
   <Import Project="$(SolutionDir)\.nuget\NuGet.targets" Condition="Exists('$(SolutionDir)\.nuget\NuGet.targets')" />
+  <Import Project="$(PackagesDir)\StyleCop.MSBuild.4.7.49.1\build\StyleCop.MSBuild.Targets" Condition="Exists('$(PackagesDir)\StyleCop.MSBuild.4.7.49.1\build\StyleCop.MSBuild.Targets')" />
   <!-- To modify your build process, add your task inside one of the targets below and uncomment it. 
        Other similar extension points exist, see Microsoft.Common.targets.
   <Target Name="BeforeBuild">
@@ -107,4 +108,4 @@ under the License.
   <Target Name="AfterBuild">
   </Target>
   -->
-</Project>
\ No newline at end of file
+</Project>

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/dd07dc3e/lang/cs/Org.Apache.REEF.Examples/Tasks/StreamingTasks/StreamTask1.cs
----------------------------------------------------------------------
diff --git a/lang/cs/Org.Apache.REEF.Examples/Tasks/StreamingTasks/StreamTask1.cs b/lang/cs/Org.Apache.REEF.Examples/Tasks/StreamingTasks/StreamTask1.cs
index a594f24..ae25d21 100644
--- a/lang/cs/Org.Apache.REEF.Examples/Tasks/StreamingTasks/StreamTask1.cs
+++ b/lang/cs/Org.Apache.REEF.Examples/Tasks/StreamingTasks/StreamTask1.cs
@@ -55,8 +55,8 @@ namespace Org.Apache.REEF.Examples.Tasks.StreamingTasks
 
         public void SIFirstNode()
         {
-            //var a = new SIFirstNodeXAM();
-            //a.Process(1111, 2222, ipAddress);
+            // var a = new SIFirstNodeXAM();
+            // a.Process(1111, 2222, ipAddress);
         }
 
         [NamedParameter("Ip Address", "IP", "10.121.32.158")]

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/dd07dc3e/lang/cs/Org.Apache.REEF.Examples/Tasks/StreamingTasks/StreamTask2.cs
----------------------------------------------------------------------
diff --git a/lang/cs/Org.Apache.REEF.Examples/Tasks/StreamingTasks/StreamTask2.cs b/lang/cs/Org.Apache.REEF.Examples/Tasks/StreamingTasks/StreamTask2.cs
index db043d4..1284948 100644
--- a/lang/cs/Org.Apache.REEF.Examples/Tasks/StreamingTasks/StreamTask2.cs
+++ b/lang/cs/Org.Apache.REEF.Examples/Tasks/StreamingTasks/StreamTask2.cs
@@ -44,8 +44,8 @@ namespace Org.Apache.REEF.Examples.Tasks.StreamingTasks
 
         public void SISecondNode()
         {
-            //var a = new SISecondNodeXAM();
-            //a.Process(2222, 1111);
+            // var a = new SISecondNodeXAM();
+            // a.Process(2222, 1111);
         }
     }
 }

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/dd07dc3e/lang/cs/Org.Apache.REEF.IMRU.Examples/Org.Apache.REEF.IMRU.Examples.csproj
----------------------------------------------------------------------
diff --git a/lang/cs/Org.Apache.REEF.IMRU.Examples/Org.Apache.REEF.IMRU.Examples.csproj b/lang/cs/Org.Apache.REEF.IMRU.Examples/Org.Apache.REEF.IMRU.Examples.csproj
index 54fea9f..b4762b3 100644
--- a/lang/cs/Org.Apache.REEF.IMRU.Examples/Org.Apache.REEF.IMRU.Examples.csproj
+++ b/lang/cs/Org.Apache.REEF.IMRU.Examples/Org.Apache.REEF.IMRU.Examples.csproj
@@ -104,10 +104,11 @@ under the License.
   </ItemGroup>
   <Import Project="$(MSBuildToolsPath)\Microsoft.CSharp.targets" />
   <Import Project="$(SolutionDir)\.nuget\NuGet.targets" Condition="Exists('$(SolutionDir)\.nuget\NuGet.targets')" />
+  <Import Project="$(PackagesDir)\StyleCop.MSBuild.4.7.49.1\build\StyleCop.MSBuild.Targets" Condition="Exists('$(PackagesDir)\StyleCop.MSBuild.4.7.49.1\build\StyleCop.MSBuild.Targets')" />
   <Target Name="EnsureNuGetPackageBuildImports" BeforeTargets="PrepareForBuild">
     <PropertyGroup>
       <ErrorText>This project references NuGet package(s) that are missing on this computer. Enable NuGet Package Restore to download them.  For more information, see http://go.microsoft.com/fwlink/?LinkID=322105. The missing file is {0}.</ErrorText>
     </PropertyGroup>
     <Error Condition="!Exists('$(SolutionDir)\.nuget\NuGet.targets')" Text="$([System.String]::Format('$(ErrorText)', '$(SolutionDir)\.nuget\NuGet.targets'))" />
   </Target>
-</Project>
\ No newline at end of file
+</Project>

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/dd07dc3e/lang/cs/Org.Apache.REEF.IMRU.Examples/PipelinedBroadcastReduce/BroadcastReceiverReduceSenderMapFunction.cs
----------------------------------------------------------------------
diff --git a/lang/cs/Org.Apache.REEF.IMRU.Examples/PipelinedBroadcastReduce/BroadcastReceiverReduceSenderMapFunction.cs b/lang/cs/Org.Apache.REEF.IMRU.Examples/PipelinedBroadcastReduce/BroadcastReceiverReduceSenderMapFunction.cs
index 30b67b5..5d2c4d5 100644
--- a/lang/cs/Org.Apache.REEF.IMRU.Examples/PipelinedBroadcastReduce/BroadcastReceiverReduceSenderMapFunction.cs
+++ b/lang/cs/Org.Apache.REEF.IMRU.Examples/PipelinedBroadcastReduce/BroadcastReceiverReduceSenderMapFunction.cs
@@ -30,7 +30,7 @@ namespace Org.Apache.REEF.IMRU.Examples.PipelinedBroadcastReduce
     /// </summary>
     internal sealed class BroadcastReceiverReduceSenderMapFunction : IMapFunction<int[], int[]>
     {
-        private static readonly Logger Logger = Logger.GetLogger(typeof (BroadcastReceiverReduceSenderMapFunction));
+        private static readonly Logger Logger = Logger.GetLogger(typeof(BroadcastReceiverReduceSenderMapFunction));
 
         private int _iterations;
 

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/dd07dc3e/lang/cs/Org.Apache.REEF.IMRU.Examples/PipelinedBroadcastReduce/BroadcastSenderReduceReceiverUpdateFunction.cs
----------------------------------------------------------------------
diff --git a/lang/cs/Org.Apache.REEF.IMRU.Examples/PipelinedBroadcastReduce/BroadcastSenderReduceReceiverUpdateFunction.cs b/lang/cs/Org.Apache.REEF.IMRU.Examples/PipelinedBroadcastReduce/BroadcastSenderReduceReceiverUpdateFunction.cs
index 868a914..3efccd8 100644
--- a/lang/cs/Org.Apache.REEF.IMRU.Examples/PipelinedBroadcastReduce/BroadcastSenderReduceReceiverUpdateFunction.cs
+++ b/lang/cs/Org.Apache.REEF.IMRU.Examples/PipelinedBroadcastReduce/BroadcastSenderReduceReceiverUpdateFunction.cs
@@ -30,7 +30,7 @@ namespace Org.Apache.REEF.IMRU.Examples.PipelinedBroadcastReduce
     /// </summary>
     internal sealed class BroadcastSenderReduceReceiverUpdateFunction : IUpdateFunction<int[], int[], int[]>
     {
-        private static readonly Logger Logger = Logger.GetLogger(typeof (BroadcastSenderReduceReceiverUpdateFunction));
+        private static readonly Logger Logger = Logger.GetLogger(typeof(BroadcastSenderReduceReceiverUpdateFunction));
 
         private int _iterations;
         private readonly int _maxIters;
@@ -40,10 +40,9 @@ namespace Org.Apache.REEF.IMRU.Examples.PipelinedBroadcastReduce
 
         [Inject]
         private BroadcastSenderReduceReceiverUpdateFunction(
-            [Parameter(typeof (BroadcastReduceConfiguration.NumberOfIterations))] int maxIters,
-            [Parameter(typeof (BroadcastReduceConfiguration.Dimensions))] int dim,
-            [Parameter(typeof (BroadcastReduceConfiguration.NumWorkers))] int numWorkers
-            )
+            [Parameter(typeof(BroadcastReduceConfiguration.NumberOfIterations))] int maxIters,
+            [Parameter(typeof(BroadcastReduceConfiguration.Dimensions))] int dim,
+            [Parameter(typeof(BroadcastReduceConfiguration.NumWorkers))] int numWorkers)
         {
             _maxIters = maxIters;
             _iterations = 0;
@@ -61,7 +60,7 @@ namespace Org.Apache.REEF.IMRU.Examples.PipelinedBroadcastReduce
         {
             Logger.Log(Level.Info, string.Format("Received value {0}", input[0]));
 
-            if (input[0] != (_iterations + 1)*_workers)
+            if (input[0] != (_iterations + 1) * _workers)
             {
                 Exceptions.Throw(new Exception("Expected input to update functon not same as actual input"), Logger);
             }