You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@reef.apache.org by ju...@apache.org on 2015/02/13 18:57:26 UTC

[6/6] incubator-reef git commit: [REEF-157] Automated Refactorings

[REEF-157] Automated Refactorings

  This PR contains lots of automated changes:

    * Removed unused references
    * Cleaned up unused `using` statements
    * Made all fields possible `readonly`
    * Keep REEF.ALL as it was

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

Author:    Markus Weimer <we...@apache.org>

This closes #79


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

Branch: refs/heads/master
Commit: 1d6563e5309dfd99e23db418215801e5a74c754b
Parents: 05a00e1
Author: Markus Weimer <we...@apache.org>
Authored: Thu Feb 12 16:05:41 2015 -0800
Committer: Julia Wang <jw...@yahoo.com>
Committed: Fri Feb 13 09:47:23 2015 -0800

----------------------------------------------------------------------
 .../Org.Apache.REEF.All.csproj                  | 33 ++++++--------
 .../Properties/AssemblyInfo.cs                  |  1 -
 .../Org.Apache.REEF.Client/CLRBridgeClient.cs   | 12 ++---
 .../Org.Apache.REEF.Client.csproj               |  7 +--
 .../Properties/AssemblyInfo.cs                  |  1 -
 .../Api/AbstractFailure.cs                      |  2 +-
 lang/cs/Org.Apache.REEF.Common/Api/IFailure.cs  |  2 +-
 .../Avro/AvroDriverInfo.cs                      |  7 +--
 .../Avro/AvroHttpRequest.cs                     |  5 +-
 .../Avro/AvroHttpSerializer.cs                  |  2 +-
 .../Avro/AvroJsonSerializer.cs                  |  3 +-
 .../Avro/AvroReefServiceInfo.cs                 |  5 +-
 .../Catalog/Capabilities/CPU.cs                 |  2 +-
 .../Catalog/Capabilities/RAM.cs                 |  2 +-
 .../Catalog/NodeDescriptorImpl.cs               |  6 +--
 .../Catalog/ResourceCatalogImpl.cs              |  8 ++--
 .../ClientJobStatusHandler.cs                   | 12 ++---
 .../DefaultLocalHttpDriverConnection.cs         |  2 +-
 .../DefaultYarnClusterHttpDriverConnection.cs   |  2 +-
 .../DefaultYarnOneBoxHttpDriverConnection.cs    |  2 +-
 .../Evaluator/DriverInformation.cs              | 12 ++---
 .../EvaluatorHeartBeatSanityChecker.cs          |  6 +--
 .../Exceptions/EvaluatorException.cs            |  2 +-
 .../Exceptions/JobException.cs                  |  2 +-
 lang/cs/Org.Apache.REEF.Common/FailedRuntime.cs |  4 +-
 .../Org.Apache.REEF.Common.csproj               |  6 +--
 .../Properties/AssemblyInfo.cs                  |  1 -
 .../Evaluator/Context/ContextConfiguration.cs   |  2 +-
 .../Evaluator/Context/ContextLifeCycle.cs       |  2 +-
 .../Runtime/Evaluator/Context/ContextManager.cs |  2 +-
 .../Runtime/Evaluator/Context/ContextRuntime.cs |  2 +-
 .../Runtime/Evaluator/EvaluatorRuntime.cs       |  2 +-
 .../Runtime/Evaluator/EvaluatorSettings.cs      | 16 +++----
 .../Runtime/Evaluator/HeartBeatManager.cs       |  2 +-
 .../Runtime/Evaluator/Task/DriverMessageImpl.cs |  2 +-
 .../Runtime/Evaluator/Task/TaskStatus.cs        |  4 +-
 .../Evaluator/Utils/EvaluatorConfigurations.cs  |  4 +-
 .../Runtime/MachineStatus.cs                    |  8 ++--
 .../Bridge/BridgeLogger.cs                      |  3 +-
 .../Bridge/ClrHandlerHelper.cs                  | 14 +++---
 .../Bridge/ClrSystemHandler.cs                  |  2 +-
 .../Bridge/ClrSystemHandlerWrapper.cs           |  8 ++--
 .../Bridge/DriverBridge.cs                      | 48 ++++++++++----------
 .../Bridge/DriverBridgeConfiguration.cs         | 13 +++---
 .../Bridge/DriverBridgeConfigurationOptions.cs  |  9 ++--
 .../Bridge/Events/ClosedContext.cs              |  4 +-
 .../Bridge/Events/FailedContext.cs              |  6 +--
 .../Bridge/Events/RunningTask.cs                |  4 +-
 .../Bridge/Events/TaskMessage.cs                |  2 +-
 .../Bridge/HttpServerHandler.cs                 | 13 +++---
 .../Bridge/IHttpHandler.cs                      |  2 -
 .../Context/ContextConfiguration.cs             |  6 +--
 .../Context/ContextConfigurationOptions.cs      |  7 ++-
 .../Context/EvaluatorContext.cs                 |  6 +--
 .../Context/IActiveContext.cs                   |  2 +-
 .../Defaults/DefaultClientCloseHandler.cs       |  4 +-
 .../DefaultClientCloseWithMessageHandler.cs     |  4 +-
 .../Defaults/DefaultClientMessageHandler.cs     |  4 +-
 .../Defaults/DefaultContextActiveHandler.cs     |  6 +--
 .../Defaults/DefaultContextClosureHandler.cs    |  5 +-
 .../Defaults/DefaultContextFailureHandler.cs    |  2 +-
 .../Defaults/DefaultContextMessageHandler.cs    |  4 +-
 .../Defaults/DefaultCustomTraceListener.cs      |  2 +-
 .../DefaultDriverRestartContextActiveHandler.cs |  6 +--
 .../Defaults/DefaultDriverRestartHandler.cs     |  5 +-
 .../DefaultDriverRestartTaskRunningHandler.cs   |  4 +-
 .../DefaultEvaluatorAllocationHandler.cs        |  7 ++-
 .../DefaultEvaluatorCompletionHandler.cs        |  4 +-
 .../Defaults/DefaultEvaluatorFailureHandler.cs  |  6 +--
 .../DefaultEvaluatorRequestorHandler.cs         |  5 +-
 .../Defaults/DefaultHttpHandler.cs              |  2 +-
 .../Defaults/DefaultTaskCompletionHandler.cs    |  8 ++--
 .../Defaults/DefaultTaskFailureHandler.cs       |  5 +-
 .../Defaults/DefaultTaskMessageHandler.cs       |  5 +-
 .../Defaults/DefaultTaskRunningHandler.cs       |  4 +-
 .../Defaults/DefaultTaskSuspensionHandler.cs    |  7 ++-
 .../DriverConfigGenerator.cs                    |  2 +-
 .../DriverConfigurationSettings.cs              |  1 -
 lang/cs/Org.Apache.REEF.Driver/DriverManager.cs | 32 ++++++-------
 .../DriverRuntimeConfiguration.cs               |  3 --
 .../Evaluator/EvaluatorDescriptorImpl.cs        | 10 ++--
 .../Evaluator/EvaluatorRequestBuilder.cs        |  5 +-
 .../Evaluator/IAllocatedEvaluator.cs            |  3 +-
 .../Evaluator/IEvaluatorRequest .cs             |  4 +-
 .../Evaluator/IEvaluatorRequestor.cs            |  2 -
 .../Evaluator/IFailedEvaluator.cs               |  5 +-
 .../Org.Apache.REEF.Driver/EvaluatorManager.cs  | 33 +++++++-------
 lang/cs/Org.Apache.REEF.Driver/FailedJob.cs     |  2 +-
 .../Org.Apache.REEF.Driver.csproj               | 13 +-----
 .../Properties/AssemblyInfo.cs                  |  1 -
 .../Org.Apache.REEF.Driver/Task/IRunningTask.cs |  2 +-
 .../Task/RunningTaskImpl.cs                     | 11 ++---
 lang/cs/Org.Apache.REEF.Evaluator/Evaluator.cs  | 25 +++++-----
 .../Org.Apache.REEF.Evaluator.csproj            |  7 +--
 .../Properties/AssemblyInfo.cs                  |  1 -
 .../AnotherHelloAllocatedEvaluatorHandler.cs    |  2 +-
 .../Handlers/HelloActiveContextHandler.cs       |  9 ++--
 .../Handlers/HelloAllocatedEvaluatorHandler.cs  | 16 +++----
 .../Handlers/HelloCompletedEvaluatorHandler.cs  |  7 +--
 .../HelloDriverRestartActiveContextHandler.cs   |  4 +-
 .../HelloDriverRestartRunningTaskHandler.cs     |  2 +-
 .../Handlers/HelloEvaluatorRequestorHandler.cs  |  4 +-
 .../Handlers/HelloFailedEvaluatorHandler.cs     |  5 +-
 .../Handlers/HelloFailedTaskHandler.cs          |  6 +--
 .../HelloCLRBridge/Handlers/HelloHttpHandler.cs |  2 +-
 .../Handlers/HelloRestartHandler.cs             |  3 +-
 .../Handlers/HelloRunningTaskHandler.cs         |  2 +-
 .../Handlers/HelloSimpleEventHandlers.cs        | 12 ++---
 .../Handlers/HelloStartHandler.cs               |  2 +-
 .../HelloCLRBridge/HelloTraceListener.cs        |  4 +-
 .../KMeans/KMeansDriverHandlers.cs              | 14 +++---
 .../MachineLearning/KMeans/KMeansMasterTask.cs  | 12 ++---
 .../MachineLearning/KMeans/KMeansSlaveTask.cs   | 16 +++----
 .../MachineLearning/KMeans/LegacyKMeansTask.cs  |  6 +--
 .../Org.Apache.REEF.Examples.csproj             |  7 +--
 .../Properties/AssemblyInfo.cs                  |  1 -
 .../RetainedEvalEvaluatorRequestorHandler.cs    |  1 -
 .../Tasks/HelloTask/HelloService.cs             |  2 +-
 .../Tasks/HelloTask/HelloTask.cs                |  4 +-
 .../Tasks/StreamingTasks/StreamTask1.cs         |  2 +-
 .../Group/Codec/GcmMessageProto.cs              |  6 ---
 .../Codec/GroupCommunicationMessageCodec.cs     |  7 ---
 .../Group/Config/MpiConfigurationOptions.cs     |  4 --
 .../Group/Driver/ICommunicationGroupDriver.cs   |  3 +-
 .../Driver/Impl/CommunicationGroupDriver.cs     | 24 +++++-----
 .../Group/Driver/Impl/MpiDriver.cs              | 14 +++---
 .../Group/Driver/Impl/TaskStarter.cs            | 14 +++---
 .../Group/Operators/IBroadcastReceiver.cs       |  6 ---
 .../Group/Operators/IBroadcastSender.cs         |  6 ---
 .../Group/Operators/IMpiOperator.cs             |  6 ---
 .../Group/Operators/IOperatorSpec.cs            |  2 -
 .../Group/Operators/IReduceFunction.cs          |  4 --
 .../Group/Operators/IReduceReceiver.cs          |  6 ---
 .../Group/Operators/IReduceSender.cs            |  6 ---
 .../Group/Operators/IScatterReceiver.cs         |  4 --
 .../Group/Operators/IScatterSender.cs           |  4 --
 .../Group/Operators/Impl/BroadcastReceiver.cs   |  7 ++-
 .../Group/Operators/Impl/BroadcastSender.cs     |  9 ++--
 .../Group/Operators/Impl/ReduceFunction.cs      |  4 +-
 .../Group/Operators/Impl/ReduceReceiver.cs      |  7 ++-
 .../Group/Operators/Impl/ReduceSender.cs        |  9 ++--
 .../Group/Operators/Impl/ScatterOperatorSpec.cs |  5 --
 .../Group/Operators/Impl/ScatterReceiver.cs     |  8 +---
 .../Group/Operators/Impl/ScatterSender.cs       |  8 +---
 .../Group/Operators/Impl/Sender.cs              |  6 +--
 .../Group/Task/ICommunicationGroupClient.cs     |  5 --
 .../Task/ICommunicationGroupNetworkObserver.cs  |  7 +--
 .../Group/Task/IMpiClient.cs                    |  7 +--
 .../Group/Task/IMpiNetworkObserver.cs           |  8 +---
 .../Group/Task/Impl/CommunicationGroupClient.cs | 23 +++++-----
 .../Impl/CommunicationGroupNetworkObserver.cs   |  7 ++-
 .../Group/Task/Impl/MpiClient.cs                | 13 +++---
 .../Group/Task/Impl/MpiNetworkObserver.cs       | 13 +++---
 .../Group/Task/Impl/NodeStruct.cs               |  3 +-
 .../Group/Task/Impl/OperatorTopology.cs         | 39 ++++++++--------
 .../Group/Topology/FlatTopology.cs              | 21 ++++-----
 .../Group/Topology/ITopology.cs                 |  5 --
 .../Group/Topology/TaskNode.cs                  |  8 +---
 .../Naming/Codec/NamingLookupRequestCodec.cs    |  2 +-
 .../Naming/Codec/NamingLookupResponseCodec.cs   |  6 +--
 .../Naming/Codec/NamingRegisterRequestCodec.cs  |  2 +-
 .../Naming/Codec/NamingRegisterResponseCodec.cs |  2 +-
 .../Codec/NamingUnregisterRequestCodec.cs       |  2 +-
 .../Naming/INameServer.cs                       |  1 -
 .../Naming/NameClient.cs                        | 18 ++++----
 .../Naming/NameLookupClient.cs                  |  6 +--
 .../Naming/NameRegisterClient.cs                |  4 +-
 .../Naming/NameServer.cs                        | 18 ++++----
 .../Observers/NamingGetAllRequestObserver.cs    |  2 +-
 .../Observers/NamingLookupRequestObserver.cs    |  4 +-
 .../Observers/NamingRegisterRequestObserver.cs  |  2 +-
 .../NamingUnregisterRequestObserver.cs          |  2 +-
 .../NetworkService/Codec/NsMessageCodec.cs      |  9 ++--
 .../NetworkService/Codec/NsMessageProto.cs      |  5 --
 .../NetworkService/INetworkService.cs           |  1 -
 .../NetworkService/NetworkService.cs            | 14 +++---
 .../NetworkServiceConfiguration.cs              |  6 ---
 .../NetworkService/NetworkServiceOptions.cs     |  2 -
 .../NetworkService/NsConnection.cs              | 14 +++---
 .../Org.Apache.REEF.Network.csproj              |  9 +---
 .../Properties/AssemblyInfo.cs                  |  1 -
 .../Org.Apache.REEF.Network/Utilities/Utils.cs  |  8 ++--
 .../AnonymousType.cs                            |  2 +-
 .../Org.Apache.REEF.Tang.Examples/CheckChild.cs |  8 +---
 .../DocumentedLocalNamedParameter.cs            |  7 +--
 .../Org.Apache.REEF.Tang.Examples/FileNames.cs  |  6 ---
 .../ForksInjectorInConstructor.cs               | 16 ++-----
 .../NamedParameterConstructors.cs               |  9 ++--
 .../Org.Apache.REEF.Tang.Examples.csproj        | 11 +----
 .../Properties/AssemblyInfo.cs                  |  1 -
 .../ShortNameFooAB.cs                           |  9 ++--
 .../SimpleConstructors.cs                       |  5 +-
 .../TestClasses.cs                              |  8 +---
 lang/cs/Org.Apache.REEF.Tang.Examples/Timer.cs  |  5 +-
 .../TweetExample.cs                             | 11 +++--
 .../ClassHierarchy/TestAnonymousType.cs         |  5 +-
 .../ClassHierarchy/TestClassHierarchy.cs        |  9 ++--
 .../TestClassHierarchyRoundTrip.cs              |  3 +-
 .../ClassHierarchy/TestGeneric.cs               |  5 +-
 .../ClassHierarchy/TestMultipleInterface.cs     |  3 +-
 .../ClassHierarchy/TestParameterParser.cs       | 16 +++----
 .../ClassHierarchy/TestSerilization.cs          | 17 ++++---
 .../Configuration/TestAvroConfiguration.cs      |  7 ++-
 .../TestAvroSerializerRoundTrip.cs              |  4 +-
 .../Configuration/TestConfiguration.cs          | 31 ++++++-------
 .../TestCsConfigurationBuilderExtension.cs      |  7 ++-
 .../Format/TestConfigurationModule.cs           |  5 +-
 .../Format/TestConfigurationModuleForList.cs    |  5 +-
 .../Format/TestTaskConfiguration.cs             |  9 ++--
 .../Injection/TestAmbigousConstructors.cs       |  6 +--
 .../Injection/TestForkInjection.cs              |  5 +-
 .../Injection/TestInjection.cs                  | 11 ++---
 .../Injection/TestInjectionFuture.cs            | 15 +++---
 .../Injection/TestListInjection.cs              |  4 +-
 .../Injection/TestMissingParameters.cs          |  6 +--
 .../Injection/TestMissingParamtersInNested.cs   |  6 +--
 .../Injection/TestMultipleConstructors.cs       |  5 +-
 .../Injection/TestNamedParameter.cs             |  6 +--
 .../Injection/TestSetInjection.cs               | 17 ++++---
 .../Org.Apache.REEF.Tang.Tests.csproj           | 14 +-----
 .../Properties/AssemblyInfo.cs                  |  1 -
 .../ScenarioTest/HttpServer.cs                  |  2 +-
 .../ScenarioTest/TestDefaultConstructor.cs      |  3 +-
 .../ScenarioTest/TestHttpService.cs             |  5 +-
 .../ScenarioTest/TestRuntimeClock.cs            |  9 ++--
 .../ScenarioTest/TestTrackingURIProvider.cs     |  6 +--
 .../ScenarioTest/TrackingURIProvider.cs         |  2 +-
 .../SmokeTest/CyclicDependencyClassTwo.cs       |  1 -
 .../SmokeTest/ListOfBaseTypes.cs                |  4 --
 .../SmokeTest/ObjectTreeTest.cs                 |  3 +-
 .../SmokeTest/RoundTripTest.cs                  |  3 +-
 .../SmokeTest/SetOfBaseTypes.cs                 |  1 -
 .../SmokeTest/TestConfigurationModuleBuilder.cs |  2 -
 .../Tang/TestDefaultImpementaion.cs             |  5 +-
 .../Tang/TestExternalConstructors.cs            |  7 ++-
 .../Tang/TestLegacyConstructors.cs              |  5 +-
 .../Org.Apache.REEF.Tang.Tests/Tang/TestTang.cs | 18 ++++----
 .../Utilities/TestUtilities.cs                  |  9 ++--
 .../ClassHierarchyBuilder.cs                    |  7 ++-
 .../Org.Apache.REEF.Tang.Tools.csproj           | 19 +-------
 .../Properties/AssemblyInfo.cs                  |  1 -
 .../Annotations/DefaultImplementation.cs        |  9 ++--
 .../Annotations/NamedParameter.cs               |  5 +-
 .../Annotations/Parameter.cs                    |  6 ++-
 .../cs/Org.Apache.REEF.Tang/Annotations/Unit.cs |  6 ++-
 .../Exceptions/BindException.cs                 |  5 +-
 .../Exceptions/ClassHierarchyException.cs       |  5 +-
 .../Exceptions/IllegalStateException.cs         |  5 +-
 .../Exceptions/InjectionException.cs            |  5 +-
 .../Exceptions/NameResolutionException.cs       |  5 +-
 .../Exceptions/ParseException.cs                |  5 +-
 .../Formats/AvroConfigurationSerializer.cs      |  9 ++--
 .../Formats/ConfigurationFile.cs                | 16 +++----
 .../Formats/ConfigurationModule.cs              |  5 +-
 .../Formats/ConfigurationModuleBuilder.cs       |  5 +-
 .../Formats/IConfigurationSerializer.cs         |  1 -
 lang/cs/Org.Apache.REEF.Tang/Formats/IImpl.cs   |  6 ---
 lang/cs/Org.Apache.REEF.Tang/Formats/IParam.cs  |  6 ---
 .../Formats/OptionalImpl.cs                     |  6 ---
 .../Formats/OptionalParameter.cs                |  6 ---
 .../cs/Org.Apache.REEF.Tang/Formats/Provides.cs |  6 ---
 .../Formats/RequiredImpl.cs                     |  6 ---
 .../Formats/RequiredParameter.cs                |  6 ---
 .../ClassHierarchy/AbstractNode.cs              | 13 +++---
 .../ClassHierarchy/ClassHierarchyImpl.cs        | 17 +++----
 .../ClassHierarchy/ClassNodeImpl.cs             | 10 ++--
 .../ClassHierarchy/ConstructorArgImpl.cs        |  5 +-
 .../ClassHierarchy/ConstructorDefImpl.cs        |  9 ++--
 .../ClassHierarchy/NamedParameterNodeImpl.cs    |  5 +-
 .../ClassHierarchy/NodeFactory.cs               | 15 +++---
 .../ClassHierarchy/PackageNodeImpl.cs           |  5 +-
 .../ClassHierarchy/ParameterParser.cs           | 11 +++--
 .../Configuration/ConfigurationBuilderImpl.cs   | 17 ++++---
 .../Configuration/ConfigurationImpl.cs          |  5 +-
 .../Configuration/CsConfigurationBuilderImpl.cs | 14 +++---
 .../Configuration/CsConfigurationImpl.cs        |  8 +---
 .../InjectionPlan/Constructor.cs                | 20 ++++----
 .../Implementations/InjectionPlan/CsInstance.cs | 13 ++----
 .../InjectionPlan/InjectionFuture.cs            | 11 ++---
 .../InjectionPlan/InjectionFuturePlan.cs        |  9 ++--
 .../InjectionPlan/InjectionPlan.cs              |  9 ++--
 .../InjectionPlan/InjectorImpl.cs               | 22 ++++-----
 .../InjectionPlan/SetInjectionPlan.cs           |  5 +-
 .../Implementations/InjectionPlan/Subplan.cs    | 15 +++---
 .../Implementations/Tang/TangFactory.cs         |  5 +-
 .../Implementations/Tang/TangImpl.cs            | 15 +++---
 .../Org.Apache.REEF.Tang/Interface/IAspect.cs   |  8 ++--
 .../Interface/IClassHierarchy.cs                |  5 +-
 .../Interface/IConfiguration.cs                 |  8 ++--
 .../Interface/IConfigurationBuilder.cs          |  7 +--
 .../Interface/ICsClassHierarchy.cs              |  5 +-
 .../Interface/ICsConfigurationBuilder.cs        |  5 +-
 .../Org.Apache.REEF.Tang/Interface/IInjector.cs |  8 ++--
 lang/cs/Org.Apache.REEF.Tang/Interface/ITang.cs |  5 +-
 .../Org.Apache.REEF.Tang.csproj                 |  6 +--
 .../Properties/AssemblyInfo.cs                  |  1 -
 .../Protobuf/ProtocolBufferClassHierarchy.cs    | 14 +++---
 .../Protobuf/ProtocolBufferInjectionPlan.cs     | 11 ++---
 .../cs/Org.Apache.REEF.Tang/Types/IClassNode.cs |  5 +-
 .../Types/IConstructorDef.cs                    |  5 +-
 lang/cs/Org.Apache.REEF.Tang/Types/INode.cs     |  5 +-
 .../Org.Apache.REEF.Tang/Types/ITraversable.cs  |  5 +-
 .../Util/AbstractMonotonicMultiMap.cs           |  2 +-
 .../Org.Apache.REEF.Tang/Util/AssemblyLoader.cs |  7 +--
 .../Org.Apache.REEF.Tang/Util/MonotonicSet.cs   |  7 +--
 .../Util/MonotonicTreeMap.cs                    |  9 ++--
 .../Util/ReflectionUtilities.cs                 | 19 ++++----
 .../Org.Apache.REEF.Tang/Util/SetValuedKey.cs   |  5 +-
 .../Evaluator/EvaluatorTests.cs                 | 12 ++---
 .../Functional/ML/KMeans/TestKMeans.cs          |  2 +-
 .../BroadcastReduceDriver.cs                    | 10 ++--
 .../MPI/BroadcastReduceTest/MasterTask.cs       | 14 +++---
 .../MPI/BroadcastReduceTest/SlaveTask.cs        | 12 ++---
 .../MPI/ScatterReduceTest/MasterTask.cs         | 10 ++--
 .../ScatterReduceTest/ScatterReduceDriver.cs    |  8 ++--
 .../MPI/ScatterReduceTest/SlaveTask.cs          | 10 ++--
 .../Functional/Messaging/MessageTask.cs         |  2 +-
 .../Functional/ReefFunctionalTest.cs            | 10 ++--
 .../Network/NetworkServiceTests.cs              |  2 +-
 .../Org.Apache.REEF.Tests.csproj                | 46 +------------------
 .../Properties/AssemblyInfo.cs                  |  1 -
 lang/cs/Org.Apache.REEF.Utilities/AvroUtils.cs  |  5 --
 .../Diagnostics/DiagnosticsMessages.cs          |  6 ---
 .../Diagnostics/Exceptions.cs                   |  1 -
 .../Org.Apache.REEF.Utilities/Logging/Logger.cs |  4 +-
 .../Org.Apache.REEF.Utilities/NetUtilities.cs   |  4 +-
 .../Org.Apache.Reef.Utilities.csproj            | 10 +---
 .../Properties/AssemblyInfo.cs                  |  1 -
 lang/cs/Org.Apache.REEF.Wake.Tests/ClockTest.cs |  4 +-
 .../Org.Apache.REEF.Wake.Tests.csproj           | 11 +----
 .../Properties/AssemblyInfo.cs                  |  1 -
 lang/cs/Org.Apache.REEF.Wake/IIdentifier.cs     |  6 ---
 .../Org.Apache.REEF.Wake/IIdentifierFactory.cs  |  5 --
 .../cs/Org.Apache.REEF.Wake/IObserverFactory.cs |  6 ---
 .../Impl/LoggingEventHandler.cs                 |  4 +-
 .../Impl/MissingStartHandlerHandler.cs          |  1 -
 .../Impl/PubSubEventHandler.cs                  |  4 +-
 lang/cs/Org.Apache.REEF.Wake/Impl/SyncStage.cs  |  2 -
 .../Impl/ThreadPoolStage.cs                     |  2 -
 lang/cs/Org.Apache.REEF.Wake/Impl/TimerStage.cs |  2 -
 .../Org.Apache.REEF.Wake.csproj                 | 10 +---
 .../Properties/AssemblyInfo.cs                  |  1 -
 .../Org.Apache.REEF.Wake/RX/AbstractObserver.cs |  2 +-
 .../RX/IStaticObservable.cs                     |  5 --
 .../RX/Impl/PubSubSubject.cs                    | 13 ++----
 .../Org.Apache.REEF.Wake/RX/Impl/RxSyncStage.cs |  2 +-
 .../RX/Impl/RxThreadPoolStage.cs                |  2 +-
 .../RX/Impl/RxTimerStage.cs                     |  1 -
 .../RX/Impl/SimpleSubject.cs                    |  2 +-
 .../Remote/ICodecFactory.cs                     |  5 --
 lang/cs/Org.Apache.REEF.Wake/Remote/ILink.cs    |  5 --
 .../Org.Apache.REEF.Wake/Remote/IRemoteEvent.cs |  4 --
 .../Remote/Impl/ByteCodecFactory.cs             |  5 --
 .../Org.Apache.REEF.Wake/Remote/Impl/Channel.cs |  5 +-
 .../Remote/Impl/DefaultRemoteManager.cs         | 21 +++------
 .../Remote/Impl/IPEndpointComparer.cs           |  4 --
 .../Remote/Impl/IntCodec.cs                     |  2 +-
 .../cs/Org.Apache.REEF.Wake/Remote/Impl/Link.cs | 11 ++---
 .../Remote/Impl/MultiCodec.cs                   |  5 --
 .../Remote/Impl/MultiDecoder.cs                 |  5 +-
 .../Remote/Impl/MultiEncoder.cs                 |  6 +--
 .../Remote/Impl/ObserverContainer.cs            | 11 +----
 .../Remote/Impl/RemoteEventDecoder.cs           |  2 +-
 .../Remote/Impl/RemoteEventEndpoint.cs          |  8 +---
 .../Remote/Impl/SocketRemoteIdentifier.cs       |  6 +--
 .../Remote/Impl/StringCodec.cs                  |  4 --
 .../Remote/Impl/StringIdentifier.cs             |  6 ---
 .../Remote/Impl/StringIdentifierFactory.cs      |  5 --
 .../Remote/Impl/TransportClient.cs              |  6 +--
 .../Remote/Impl/TransportEvent.cs               |  8 ----
 .../Remote/Impl/TransportServer.cs              | 12 ++---
 .../Remote/RemoteConfiguration.cs               |  2 +-
 .../cs/Org.Apache.REEF.Wake/Time/Event/Alarm.cs |  2 +-
 lang/cs/Org.Apache.REEF.Wake/Time/IClock.cs     |  1 -
 .../Time/Runtime/Event/ClientAlarm.cs           |  4 --
 .../Time/Runtime/Event/RuntimeAlarm.cs          |  4 --
 .../Org.Apache.REEF.Wake/Time/Runtime/ITimer.cs |  5 --
 .../Time/Runtime/LogicalTimer.cs                |  6 ---
 .../Time/Runtime/RealTimer.cs                   |  6 ---
 .../Time/Runtime/RuntimeClock.cs                | 12 ++---
 lang/cs/Org.Apache.REEF.Wake/Util/Disposable.cs |  8 +---
 .../Util/FixedThreadPoolTaskService.cs          |  7 +--
 lang/cs/Org.Apache.REEF.Wake/Util/IStartable.cs |  6 ---
 .../Org.Apache.REEF.Wake/Util/NetworkUtils.cs   |  5 +-
 .../Util/SerializationHelper.cs                 |  4 +-
 .../Org.Apache.REEF.Wake/Util/TaskExtensions.cs |  4 --
 lang/cs/Org.Apache.REEF.Wake/Util/TimeHelper.cs |  1 -
 387 files changed, 1024 insertions(+), 1659 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/1d6563e5/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 d909543..b270016 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
@@ -34,44 +34,39 @@ under the License.
   <ItemGroup>
     <Reference Include="System" />
     <Reference Include="System.Core" />
-    <Reference Include="System.Xml.Linq" />
-    <Reference Include="System.Data.DataSetExtensions" />
-    <Reference Include="Microsoft.CSharp" />
-    <Reference Include="System.Data" />
-    <Reference Include="System.Xml" />
   </ItemGroup>
   <ItemGroup>
     <Compile Include="Properties\AssemblyInfo.cs" />
   </ItemGroup>
   <ItemGroup>
-    <ProjectReference Include="$(SolutionDir)\Org.Apache.REEF.Common\Org.Apache.REEF.Common.csproj">
+    <ProjectReference Include="..\Org.Apache.REEF.Common\Org.Apache.REEF.Common.csproj">
       <Project>{545a0582-4105-44ce-b99c-b1379514a630}</Project>
       <Name>Org.Apache.REEF.Common</Name>
     </ProjectReference>
-    <ProjectReference Include="$(SolutionDir)\Org.Apache.REEF.Driver\Org.Apache.REEF.Driver.csproj">
+    <ProjectReference Include="..\Org.Apache.REEF.Driver\Org.Apache.REEF.Driver.csproj">
       <Project>{a6baa2a7-f52f-4329-884e-1bcf711d6805}</Project>
       <Name>Org.Apache.REEF.Driver</Name>
     </ProjectReference>
-    <ProjectReference Include="$(SolutionDir)\Org.Apache.REEF.Evaluator\Org.Apache.REEF.Evaluator.csproj">
+    <ProjectReference Include="..\Org.Apache.REEF.Evaluator\Org.Apache.REEF.Evaluator.csproj">
       <Project>{1b983182-9c30-464c-948d-f87eb93a8240}</Project>
       <Name>Org.Apache.REEF.Evaluator</Name>
     </ProjectReference>
-    <ProjectReference Include="$(SolutionDir)\Org.Apache.REEF.Tang\Org.Apache.REEF.Tang.csproj">
-      <Project>{97dbb573-3994-417a-9f69-ffa25f00d2a6}</Project>
-      <Name>Org.Apache.REEF.Tang</Name>
-    </ProjectReference>
-    <ProjectReference Include="$(SolutionDir)\Org.Apache.REEF.Wake\Org.Apache.REEF.Wake.csproj">
-      <Project>{cdfb3464-4041-42b1-9271-83af24cd5008}</Project>
-      <Name>Org.Apache.REEF.Wake</Name>
-    </ProjectReference>
-    <ProjectReference Include="$(SolutionDir)\Org.Apache.REEF.Network\Org.Apache.REEF.Network.csproj">
+    <ProjectReference Include="..\Org.Apache.REEF.Network\Org.Apache.REEF.Network.csproj">
       <Project>{883ce800-6a6a-4e0a-b7fe-c054f4f2c1dc}</Project>
       <Name>Org.Apache.REEF.Network</Name>
     </ProjectReference>
-    <ProjectReference Include="$(SolutionDir)\Org.Apache.REEF.Utilities\Org.Apache.REEF.Utilities.csproj">
+    <ProjectReference Include="..\Org.Apache.REEF.Tang\Org.Apache.REEF.Tang.csproj">
+      <Project>{97dbb573-3994-417a-9f69-ffa25f00d2a6}</Project>
+      <Name>Org.Apache.REEF.Tang</Name>
+    </ProjectReference>
+    <ProjectReference Include="..\Org.Apache.REEF.Utilities\Org.Apache.REEF.Utilities.csproj">
       <Project>{79e7f89a-1dfb-45e1-8d43-d71a954aeb98}</Project>
       <Name>Org.Apache.REEF.Utilities</Name>
     </ProjectReference>
+    <ProjectReference Include="..\Org.Apache.REEF.Wake\Org.Apache.REEF.Wake.csproj">
+      <Project>{cdfb3464-4041-42b1-9271-83af24cd5008}</Project>
+      <Name>Org.Apache.REEF.Wake</Name>
+    </ProjectReference>
   </ItemGroup>
   <Import Project="$(MSBuildToolsPath)\Microsoft.CSharp.targets" />
   <!-- To modify your build process, add your task inside one of the targets below and uncomment it. 
@@ -81,4 +76,4 @@ under the License.
   <Target Name="AfterBuild">
   </Target>
   -->
-</Project>
+</Project>
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/1d6563e5/lang/cs/Org.Apache.REEF.All/Properties/AssemblyInfo.cs
----------------------------------------------------------------------
diff --git a/lang/cs/Org.Apache.REEF.All/Properties/AssemblyInfo.cs b/lang/cs/Org.Apache.REEF.All/Properties/AssemblyInfo.cs
index 66bfd68..d6a4872 100644
--- a/lang/cs/Org.Apache.REEF.All/Properties/AssemblyInfo.cs
+++ b/lang/cs/Org.Apache.REEF.All/Properties/AssemblyInfo.cs
@@ -18,7 +18,6 @@
  */
 
 using System.Reflection;
-using System.Runtime.CompilerServices;
 using System.Runtime.InteropServices;
 
 // General Information about an assembly is controlled through the following 

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/1d6563e5/lang/cs/Org.Apache.REEF.Client/CLRBridgeClient.cs
----------------------------------------------------------------------
diff --git a/lang/cs/Org.Apache.REEF.Client/CLRBridgeClient.cs b/lang/cs/Org.Apache.REEF.Client/CLRBridgeClient.cs
index 84e5b68..79cc647 100644
--- a/lang/cs/Org.Apache.REEF.Client/CLRBridgeClient.cs
+++ b/lang/cs/Org.Apache.REEF.Client/CLRBridgeClient.cs
@@ -17,19 +17,19 @@
  * under the License.
  */
 
+using System;
+using System.Collections.Generic;
+using System.IO;
 using Org.Apache.REEF.Common.Evaluator;
 using Org.Apache.REEF.Driver;
 using Org.Apache.REEF.Driver.Bridge;
 using Org.Apache.REEF.Driver.Defaults;
 using Org.Apache.REEF.Examples.HelloCLRBridge.Handlers;
+using Org.Apache.REEF.Examples.Tasks.HelloTask;
 using Org.Apache.REEF.Network.Naming;
-using Org.Apache.REEF.Utilities.Logging;
 using Org.Apache.REEF.Tang.Interface;
 using Org.Apache.REEF.Tang.Util;
-using System;
-using System.Collections.Generic;
-using System.IO;
-using Org.Apache.REEF.Examples.Tasks.HelloTask;
+using Org.Apache.REEF.Utilities.Logging;
 
 namespace Org.Apache.REEF.Client
 {
@@ -44,7 +44,7 @@ namespace Org.Apache.REEF.Client
         private static string _reefJar = null;
         private static string _className = Constants.BridgeLaunchClass;
         private static string _runCommand = DefaultRunCommand;
-        private static string _submitControlForAllocatedEvaluator = "submitContextAndTask"; // submitContext, submitContextAndTask, submitContextAndServiceAndTask
+        private static readonly string _submitControlForAllocatedEvaluator = "submitContextAndTask"; // submitContext, submitContextAndTask, submitContextAndServiceAndTask
 
         public static HashSet<string> AppDll
         {

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/1d6563e5/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 06efcec..9eac07f 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
@@ -37,11 +37,6 @@ under the License.
   <ItemGroup>
     <Reference Include="System" />
     <Reference Include="System.Core" />
-    <Reference Include="System.Xml.Linq" />
-    <Reference Include="System.Data.DataSetExtensions" />
-    <Reference Include="Microsoft.CSharp" />
-    <Reference Include="System.Data" />
-    <Reference Include="System.Xml" />
   </ItemGroup>
   <ItemGroup>
     <Compile Include="CLRBridgeClient.cs" />
@@ -88,4 +83,4 @@ under the License.
   <Target Name="AfterBuild">
   </Target>
   -->
-</Project>
+</Project>
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/1d6563e5/lang/cs/Org.Apache.REEF.Client/Properties/AssemblyInfo.cs
----------------------------------------------------------------------
diff --git a/lang/cs/Org.Apache.REEF.Client/Properties/AssemblyInfo.cs b/lang/cs/Org.Apache.REEF.Client/Properties/AssemblyInfo.cs
index ca5e1fb..3d1221c 100644
--- a/lang/cs/Org.Apache.REEF.Client/Properties/AssemblyInfo.cs
+++ b/lang/cs/Org.Apache.REEF.Client/Properties/AssemblyInfo.cs
@@ -18,7 +18,6 @@
  */
 
 using System.Reflection;
-using System.Runtime.CompilerServices;
 using System.Runtime.InteropServices;
 
 // General Information about an assembly is controlled through the following 

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/1d6563e5/lang/cs/Org.Apache.REEF.Common/Api/AbstractFailure.cs
----------------------------------------------------------------------
diff --git a/lang/cs/Org.Apache.REEF.Common/Api/AbstractFailure.cs b/lang/cs/Org.Apache.REEF.Common/Api/AbstractFailure.cs
index 50fd6b7..aa95829 100644
--- a/lang/cs/Org.Apache.REEF.Common/Api/AbstractFailure.cs
+++ b/lang/cs/Org.Apache.REEF.Common/Api/AbstractFailure.cs
@@ -17,9 +17,9 @@
  * under the License.
  */
 
-using Org.Apache.REEF.Utilities;
 using System;
 using System.Globalization;
+using Org.Apache.REEF.Utilities;
 using Org.Apache.REEF.Utilities.Logging;
 
 namespace Org.Apache.REEF.Common.Api

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/1d6563e5/lang/cs/Org.Apache.REEF.Common/Api/IFailure.cs
----------------------------------------------------------------------
diff --git a/lang/cs/Org.Apache.REEF.Common/Api/IFailure.cs b/lang/cs/Org.Apache.REEF.Common/Api/IFailure.cs
index 454bdf4..94b8b66 100644
--- a/lang/cs/Org.Apache.REEF.Common/Api/IFailure.cs
+++ b/lang/cs/Org.Apache.REEF.Common/Api/IFailure.cs
@@ -17,8 +17,8 @@
  * under the License.
  */
 
-using Org.Apache.REEF.Utilities;
 using System;
+using Org.Apache.REEF.Utilities;
 
 namespace Org.Apache.REEF.Common.Api
 {

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/1d6563e5/lang/cs/Org.Apache.REEF.Common/Avro/AvroDriverInfo.cs
----------------------------------------------------------------------
diff --git a/lang/cs/Org.Apache.REEF.Common/Avro/AvroDriverInfo.cs b/lang/cs/Org.Apache.REEF.Common/Avro/AvroDriverInfo.cs
index 2f0ae95..5eafc10 100644
--- a/lang/cs/Org.Apache.REEF.Common/Avro/AvroDriverInfo.cs
+++ b/lang/cs/Org.Apache.REEF.Common/Avro/AvroDriverInfo.cs
@@ -1,9 +1,10 @@
 //<auto-generated />
+
+using System.Collections.Generic;
+using System.Runtime.Serialization;
+
 namespace Org.Apache.REEF.Common.Avro
 {
-    using System.Collections.Generic;
-    using System.Runtime.Serialization;
-
     /// <summary>
     /// Used to serialize and deserialize Avro record org.apache.reef.webserver.AvroDriverInfo.
     /// </summary>

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/1d6563e5/lang/cs/Org.Apache.REEF.Common/Avro/AvroHttpRequest.cs
----------------------------------------------------------------------
diff --git a/lang/cs/Org.Apache.REEF.Common/Avro/AvroHttpRequest.cs b/lang/cs/Org.Apache.REEF.Common/Avro/AvroHttpRequest.cs
index 3767c2b..29b9ef7 100644
--- a/lang/cs/Org.Apache.REEF.Common/Avro/AvroHttpRequest.cs
+++ b/lang/cs/Org.Apache.REEF.Common/Avro/AvroHttpRequest.cs
@@ -1,8 +1,9 @@
 //<auto-generated />
+
+using System.Runtime.Serialization;
+
 namespace Org.Apache.REEF.Common.Avro
 {
-    using System.Runtime.Serialization;
-
     /// <summary>
     /// Used to serialize and deserialize Avro record org.apache.reef.webserver.AvroHttpRequest.
     /// </summary>

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/1d6563e5/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 2d1fb53..5a57a5b 100644
--- a/lang/cs/Org.Apache.REEF.Common/Avro/AvroHttpSerializer.cs
+++ b/lang/cs/Org.Apache.REEF.Common/Avro/AvroHttpSerializer.cs
@@ -17,8 +17,8 @@
  * under the License.
  */
 
-using Microsoft.Hadoop.Avro;
 using System.IO;
+using Microsoft.Hadoop.Avro;
 
 namespace Org.Apache.REEF.Common.Avro
 {

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/1d6563e5/lang/cs/Org.Apache.REEF.Common/Avro/AvroJsonSerializer.cs
----------------------------------------------------------------------
diff --git a/lang/cs/Org.Apache.REEF.Common/Avro/AvroJsonSerializer.cs b/lang/cs/Org.Apache.REEF.Common/Avro/AvroJsonSerializer.cs
index a3c0007..8954fe9 100644
--- a/lang/cs/Org.Apache.REEF.Common/Avro/AvroJsonSerializer.cs
+++ b/lang/cs/Org.Apache.REEF.Common/Avro/AvroJsonSerializer.cs
@@ -17,9 +17,8 @@
  * under the License.
  */
 
-using Org.Apache.REEF.Utilities;
-
 using Newtonsoft.Json;
+using Org.Apache.REEF.Utilities;
 
 namespace Org.Apache.REEF.Common.Avro
 {

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/1d6563e5/lang/cs/Org.Apache.REEF.Common/Avro/AvroReefServiceInfo.cs
----------------------------------------------------------------------
diff --git a/lang/cs/Org.Apache.REEF.Common/Avro/AvroReefServiceInfo.cs b/lang/cs/Org.Apache.REEF.Common/Avro/AvroReefServiceInfo.cs
index 9b65c62..d7da473 100644
--- a/lang/cs/Org.Apache.REEF.Common/Avro/AvroReefServiceInfo.cs
+++ b/lang/cs/Org.Apache.REEF.Common/Avro/AvroReefServiceInfo.cs
@@ -1,8 +1,9 @@
 //<auto-generated />
+
+using System.Runtime.Serialization;
+
 namespace Org.Apache.REEF.Common.Avro
 {
-    using System.Runtime.Serialization;
-
     /// <summary>
     /// Used to serialize and deserialize Avro record org.apache.reef.webserver.AvroReefServiceInfo.
     /// </summary>

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/1d6563e5/lang/cs/Org.Apache.REEF.Common/Catalog/Capabilities/CPU.cs
----------------------------------------------------------------------
diff --git a/lang/cs/Org.Apache.REEF.Common/Catalog/Capabilities/CPU.cs b/lang/cs/Org.Apache.REEF.Common/Catalog/Capabilities/CPU.cs
index 4a26a3c..9f64a05 100644
--- a/lang/cs/Org.Apache.REEF.Common/Catalog/Capabilities/CPU.cs
+++ b/lang/cs/Org.Apache.REEF.Common/Catalog/Capabilities/CPU.cs
@@ -27,7 +27,7 @@ namespace Org.Apache.REEF.Common.Catalog.Capabilities
     {
         private static readonly Logger LOGGER = Logger.GetLogger(typeof(CPU));
 
-        private int _cores;
+        private readonly int _cores;
 
         public CPU(int cores)
         {

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/1d6563e5/lang/cs/Org.Apache.REEF.Common/Catalog/Capabilities/RAM.cs
----------------------------------------------------------------------
diff --git a/lang/cs/Org.Apache.REEF.Common/Catalog/Capabilities/RAM.cs b/lang/cs/Org.Apache.REEF.Common/Catalog/Capabilities/RAM.cs
index 94358e3..1183072 100644
--- a/lang/cs/Org.Apache.REEF.Common/Catalog/Capabilities/RAM.cs
+++ b/lang/cs/Org.Apache.REEF.Common/Catalog/Capabilities/RAM.cs
@@ -23,7 +23,7 @@ namespace Org.Apache.REEF.Common.Catalog.Capabilities
 {
     public class RAM : ICapability
     {
-        private int _megaBytes;
+        private readonly int _megaBytes;
 
         public RAM(int megaBytes)
         {

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/1d6563e5/lang/cs/Org.Apache.REEF.Common/Catalog/NodeDescriptorImpl.cs
----------------------------------------------------------------------
diff --git a/lang/cs/Org.Apache.REEF.Common/Catalog/NodeDescriptorImpl.cs b/lang/cs/Org.Apache.REEF.Common/Catalog/NodeDescriptorImpl.cs
index 0e2cb90..a04d2b4 100644
--- a/lang/cs/Org.Apache.REEF.Common/Catalog/NodeDescriptorImpl.cs
+++ b/lang/cs/Org.Apache.REEF.Common/Catalog/NodeDescriptorImpl.cs
@@ -25,15 +25,15 @@ namespace Org.Apache.REEF.Common.Catalog
 {
     public class NodeDescriptorImpl : INodeDescriptor
     {
-        private RackDescriptorImpl _rack;
+        private readonly RackDescriptorImpl _rack;
 
-        private string _id;
+        private readonly string _id;
 
         private IPEndPoint _address;
 
         private RAM _ram;
 
-        private IList<ICapability> _capabilities;
+        private readonly IList<ICapability> _capabilities;
 
         public NodeDescriptorImpl()
         {

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/1d6563e5/lang/cs/Org.Apache.REEF.Common/Catalog/ResourceCatalogImpl.cs
----------------------------------------------------------------------
diff --git a/lang/cs/Org.Apache.REEF.Common/Catalog/ResourceCatalogImpl.cs b/lang/cs/Org.Apache.REEF.Common/Catalog/ResourceCatalogImpl.cs
index 22947ca..6989c3c 100644
--- a/lang/cs/Org.Apache.REEF.Common/Catalog/ResourceCatalogImpl.cs
+++ b/lang/cs/Org.Apache.REEF.Common/Catalog/ResourceCatalogImpl.cs
@@ -17,7 +17,6 @@
  * under the License.
  */
 
-using Org.Apache.REEF.Utilities.Logging;
 using System;
 using System.Collections.Generic;
 using System.Globalization;
@@ -25,6 +24,7 @@ using System.Net;
 using System.Text;
 using Org.Apache.REEF.Common.Catalog.Capabilities;
 using Org.Apache.REEF.Common.Protobuf.ReefProtocol;
+using Org.Apache.REEF.Utilities.Logging;
 
 namespace Org.Apache.REEF.Common.Catalog
 {
@@ -32,11 +32,11 @@ namespace Org.Apache.REEF.Common.Catalog
     {
         private static readonly Logger LOGGER = Logger.GetLogger(typeof(ResourceCatalogImpl));
         
-        private static string defaultRackName = "default-rack";
+        private static readonly string defaultRackName = "default-rack";
 
-        private Dictionary<string, RackDescriptorImpl> _racks = new Dictionary<string, RackDescriptorImpl>();
+        private readonly Dictionary<string, RackDescriptorImpl> _racks = new Dictionary<string, RackDescriptorImpl>();
  
-        private Dictionary<string, NodeDescriptorImpl> _nodes = new Dictionary<string, NodeDescriptorImpl>();
+        private readonly Dictionary<string, NodeDescriptorImpl> _nodes = new Dictionary<string, NodeDescriptorImpl>();
 
         public string Name { get; set; }
 

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/1d6563e5/lang/cs/Org.Apache.REEF.Common/ClientJobStatusHandler.cs
----------------------------------------------------------------------
diff --git a/lang/cs/Org.Apache.REEF.Common/ClientJobStatusHandler.cs b/lang/cs/Org.Apache.REEF.Common/ClientJobStatusHandler.cs
index 158161c..2dea0d0 100644
--- a/lang/cs/Org.Apache.REEF.Common/ClientJobStatusHandler.cs
+++ b/lang/cs/Org.Apache.REEF.Common/ClientJobStatusHandler.cs
@@ -17,12 +17,12 @@
  * under the License.
  */
 
+using System;
+using Org.Apache.REEF.Common.Protobuf.ReefProtocol;
 using Org.Apache.REEF.Utilities;
 using Org.Apache.REEF.Utilities.Logging;
 using Org.Apache.REEF.Wake.Remote;
 using Org.Apache.REEF.Wake.Time;
-using System;
-using Org.Apache.REEF.Common.Protobuf.ReefProtocol;
 using Org.Apache.REEF.Wake.Time.Event;
 
 namespace Org.Apache.REEF.Common
@@ -31,13 +31,13 @@ namespace Org.Apache.REEF.Common
     {
         private static readonly Logger LOGGER = Logger.GetLogger(typeof(ClientJobStatusHandler));
 
-        private IClock _clock;
+        private readonly IClock _clock;
 
-        private string _jobId;
+        private readonly string _jobId;
 
-        private IObserver<JobStatusProto> _jobStatusHandler;
+        private readonly IObserver<JobStatusProto> _jobStatusHandler;
 
-        private IDisposable _jobControlChannel;
+        private readonly IDisposable _jobControlChannel;
 
         State _state = State.INIT;
 

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/1d6563e5/lang/cs/Org.Apache.REEF.Common/Evaluator/DefaultLocalHttpDriverConnection.cs
----------------------------------------------------------------------
diff --git a/lang/cs/Org.Apache.REEF.Common/Evaluator/DefaultLocalHttpDriverConnection.cs b/lang/cs/Org.Apache.REEF.Common/Evaluator/DefaultLocalHttpDriverConnection.cs
index 26049e6..d3aa79f 100644
--- a/lang/cs/Org.Apache.REEF.Common/Evaluator/DefaultLocalHttpDriverConnection.cs
+++ b/lang/cs/Org.Apache.REEF.Common/Evaluator/DefaultLocalHttpDriverConnection.cs
@@ -17,8 +17,8 @@
  * under the License.
  */
 
-using Org.Apache.REEF.Tang.Annotations;
 using System;
+using Org.Apache.REEF.Tang.Annotations;
 
 namespace Org.Apache.REEF.Common.Evaluator
 {

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/1d6563e5/lang/cs/Org.Apache.REEF.Common/Evaluator/DefaultYarnClusterHttpDriverConnection.cs
----------------------------------------------------------------------
diff --git a/lang/cs/Org.Apache.REEF.Common/Evaluator/DefaultYarnClusterHttpDriverConnection.cs b/lang/cs/Org.Apache.REEF.Common/Evaluator/DefaultYarnClusterHttpDriverConnection.cs
index e0076e7..f60a852 100644
--- a/lang/cs/Org.Apache.REEF.Common/Evaluator/DefaultYarnClusterHttpDriverConnection.cs
+++ b/lang/cs/Org.Apache.REEF.Common/Evaluator/DefaultYarnClusterHttpDriverConnection.cs
@@ -17,8 +17,8 @@
  * under the License.
  */
 
-using Org.Apache.REEF.Tang.Annotations;
 using System;
+using Org.Apache.REEF.Tang.Annotations;
 
 namespace Org.Apache.REEF.Common.Evaluator
 {

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/1d6563e5/lang/cs/Org.Apache.REEF.Common/Evaluator/DefaultYarnOneBoxHttpDriverConnection.cs
----------------------------------------------------------------------
diff --git a/lang/cs/Org.Apache.REEF.Common/Evaluator/DefaultYarnOneBoxHttpDriverConnection.cs b/lang/cs/Org.Apache.REEF.Common/Evaluator/DefaultYarnOneBoxHttpDriverConnection.cs
index 9a4974c..66381ca 100644
--- a/lang/cs/Org.Apache.REEF.Common/Evaluator/DefaultYarnOneBoxHttpDriverConnection.cs
+++ b/lang/cs/Org.Apache.REEF.Common/Evaluator/DefaultYarnOneBoxHttpDriverConnection.cs
@@ -17,9 +17,9 @@
  * under the License.
  */
 
-using Org.Apache.REEF.Tang.Annotations;
 using System;
 using System.Globalization;
+using Org.Apache.REEF.Tang.Annotations;
 
 namespace Org.Apache.REEF.Common.Evaluator
 {

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/1d6563e5/lang/cs/Org.Apache.REEF.Common/Evaluator/DriverInformation.cs
----------------------------------------------------------------------
diff --git a/lang/cs/Org.Apache.REEF.Common/Evaluator/DriverInformation.cs b/lang/cs/Org.Apache.REEF.Common/Evaluator/DriverInformation.cs
index 055784e..2a22ada 100644
--- a/lang/cs/Org.Apache.REEF.Common/Evaluator/DriverInformation.cs
+++ b/lang/cs/Org.Apache.REEF.Common/Evaluator/DriverInformation.cs
@@ -17,8 +17,6 @@
  * under the License.
  */
 
-using Org.Apache.REEF.Common.Avro;
-using Org.Apache.REEF.Utilities.Logging;
 using System;
 using System.Collections.Generic;
 using System.Globalization;
@@ -26,6 +24,8 @@ using System.IO;
 using System.Linq;
 using System.Net;
 using System.Text;
+using Org.Apache.REEF.Common.Avro;
+using Org.Apache.REEF.Utilities.Logging;
 
 namespace Org.Apache.REEF.Common.Evaluator
 {
@@ -33,13 +33,13 @@ namespace Org.Apache.REEF.Common.Evaluator
     {
         private static readonly Logger LOGGER = Logger.GetLogger(typeof(DriverInformation));
         
-        private string _rid;
+        private readonly string _rid;
 
-        private string _startTime;
+        private readonly string _startTime;
 
-        private string _nameServerId;
+        private readonly string _nameServerId;
 
-        private IList<AvroReefServiceInfo> _services;
+        private readonly IList<AvroReefServiceInfo> _services;
 
         public DriverInformation(string rid, string startTime, IList<AvroReefServiceInfo> services)
         {

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/1d6563e5/lang/cs/Org.Apache.REEF.Common/EvaluatorHeartBeatSanityChecker.cs
----------------------------------------------------------------------
diff --git a/lang/cs/Org.Apache.REEF.Common/EvaluatorHeartBeatSanityChecker.cs b/lang/cs/Org.Apache.REEF.Common/EvaluatorHeartBeatSanityChecker.cs
index 845e50c..8653959 100644
--- a/lang/cs/Org.Apache.REEF.Common/EvaluatorHeartBeatSanityChecker.cs
+++ b/lang/cs/Org.Apache.REEF.Common/EvaluatorHeartBeatSanityChecker.cs
@@ -17,18 +17,18 @@
  * under the License.
  */
 
-using Org.Apache.REEF.Utilities.Logging;
 using System;
 using System.Collections.Generic;
 using System.Globalization;
+using Org.Apache.REEF.Utilities.Logging;
 
 namespace Org.Apache.REEF.Common
 {
     public class EvaluatorHeartBeatSanityChecker
     {
         private static readonly Logger LOGGER = Logger.GetLogger(typeof(EvaluatorHeartBeatSanityChecker));
-        
-        Dictionary<string, long> _timeStamps = new Dictionary<string, long>();
+
+        readonly Dictionary<string, long> _timeStamps = new Dictionary<string, long>();
 
         public void check(string id, long timeStamp)
         {

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/1d6563e5/lang/cs/Org.Apache.REEF.Common/Exceptions/EvaluatorException.cs
----------------------------------------------------------------------
diff --git a/lang/cs/Org.Apache.REEF.Common/Exceptions/EvaluatorException.cs b/lang/cs/Org.Apache.REEF.Common/Exceptions/EvaluatorException.cs
index d1bb558..9cb207a 100644
--- a/lang/cs/Org.Apache.REEF.Common/Exceptions/EvaluatorException.cs
+++ b/lang/cs/Org.Apache.REEF.Common/Exceptions/EvaluatorException.cs
@@ -17,9 +17,9 @@
  * under the License.
  */
 
-using Org.Apache.REEF.Utilities;
 using System;
 using Org.Apache.REEF.Common.Tasks;
+using Org.Apache.REEF.Utilities;
 
 namespace Org.Apache.REEF.Common.Exceptions
 {

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/1d6563e5/lang/cs/Org.Apache.REEF.Common/Exceptions/JobException.cs
----------------------------------------------------------------------
diff --git a/lang/cs/Org.Apache.REEF.Common/Exceptions/JobException.cs b/lang/cs/Org.Apache.REEF.Common/Exceptions/JobException.cs
index e379b92..643cd76 100644
--- a/lang/cs/Org.Apache.REEF.Common/Exceptions/JobException.cs
+++ b/lang/cs/Org.Apache.REEF.Common/Exceptions/JobException.cs
@@ -24,7 +24,7 @@ namespace Org.Apache.REEF.Common.Exceptions
 {
     public class JobException : Exception, IIdentifiable
     {
-        private string _jobId;
+        private readonly string _jobId;
 
         public JobException(string jobId)
         {

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/1d6563e5/lang/cs/Org.Apache.REEF.Common/FailedRuntime.cs
----------------------------------------------------------------------
diff --git a/lang/cs/Org.Apache.REEF.Common/FailedRuntime.cs b/lang/cs/Org.Apache.REEF.Common/FailedRuntime.cs
index 2ac6781..0bc5203 100644
--- a/lang/cs/Org.Apache.REEF.Common/FailedRuntime.cs
+++ b/lang/cs/Org.Apache.REEF.Common/FailedRuntime.cs
@@ -17,10 +17,10 @@
  * under the License.
  */
 
-using Org.Apache.REEF.Common.Api;
-using Org.Apache.REEF.Utilities;
 using System;
+using Org.Apache.REEF.Common.Api;
 using Org.Apache.REEF.Common.Protobuf.ReefProtocol;
+using Org.Apache.REEF.Utilities;
 
 namespace Org.Apache.REEF.Common
 {

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/1d6563e5/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 9d3bbe8..b531904 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
@@ -50,10 +50,6 @@ under the License.
     <Reference Include="System" />
     <Reference Include="System.Core" />
     <Reference Include="System.Runtime.Serialization" />
-    <Reference Include="System.Xml.Linq" />
-    <Reference Include="System.Data.DataSetExtensions" />
-    <Reference Include="Microsoft.CSharp" />
-    <Reference Include="System.Data" />
     <Reference Include="System.Xml" />
   </ItemGroup>
   <ItemGroup>
@@ -189,4 +185,4 @@ under the License.
   <Target Name="AfterBuild">
   </Target>
   -->
-</Project>
+</Project>
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/1d6563e5/lang/cs/Org.Apache.REEF.Common/Properties/AssemblyInfo.cs
----------------------------------------------------------------------
diff --git a/lang/cs/Org.Apache.REEF.Common/Properties/AssemblyInfo.cs b/lang/cs/Org.Apache.REEF.Common/Properties/AssemblyInfo.cs
index 2e74594..cc01377 100644
--- a/lang/cs/Org.Apache.REEF.Common/Properties/AssemblyInfo.cs
+++ b/lang/cs/Org.Apache.REEF.Common/Properties/AssemblyInfo.cs
@@ -18,7 +18,6 @@
  */
 
 using System.Reflection;
-using System.Runtime.CompilerServices;
 using System.Runtime.InteropServices;
 
 // General Information about an assembly is controlled through the following 

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/1d6563e5/lang/cs/Org.Apache.REEF.Common/Runtime/Evaluator/Context/ContextConfiguration.cs
----------------------------------------------------------------------
diff --git a/lang/cs/Org.Apache.REEF.Common/Runtime/Evaluator/Context/ContextConfiguration.cs b/lang/cs/Org.Apache.REEF.Common/Runtime/Evaluator/Context/ContextConfiguration.cs
index 7191924..20c4d44 100644
--- a/lang/cs/Org.Apache.REEF.Common/Runtime/Evaluator/Context/ContextConfiguration.cs
+++ b/lang/cs/Org.Apache.REEF.Common/Runtime/Evaluator/Context/ContextConfiguration.cs
@@ -32,7 +32,7 @@ namespace Org.Apache.REEF.Common.Runtime.Evaluator.Context
     {
         private static readonly Logger LOGGER = Logger.GetLogger(typeof(ContextConfiguration));
         
-        private Dictionary<string, string> _settings;
+        private readonly Dictionary<string, string> _settings;
 
         public ContextConfiguration(string configString)
         {

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/1d6563e5/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 a6e6b4a..25ae343 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
@@ -33,7 +33,7 @@ namespace Org.Apache.REEF.Common.Runtime.Evaluator.Context
 
         private HashSet<IObserver<IContextStop>> _contextStopHandlers;
 
-        private HashSet<IContextMessageSource> _contextMessageSources;
+        private readonly HashSet<IContextMessageSource> _contextMessageSources;
 
         // @Inject
         public ContextLifeCycle(

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/1d6563e5/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 9231575..97f2ad2 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
@@ -39,7 +39,7 @@ namespace Org.Apache.REEF.Common.Runtime.Evaluator.Context
 
         private readonly HeartBeatManager _heartBeatManager;
 
-        private RootContextLauncher _rootContextLauncher;
+        private readonly RootContextLauncher _rootContextLauncher;
 
         public ContextManager(HeartBeatManager heartBeatManager, Optional<ServiceConfiguration> rootServiceConfig, Optional<TaskConfiguration> rootTaskConfig)
         {

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/1d6563e5/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 6a5f7cb..b27061c 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
@@ -44,7 +44,7 @@ namespace Org.Apache.REEF.Common.Runtime.Evaluator.Context
         private Optional<ContextRuntime> _childContext = Optional<ContextRuntime>.Empty();
 
         // The parent context, if any.
-        private Optional<ContextRuntime> _parentContext = Optional<ContextRuntime>.Empty();
+        private readonly Optional<ContextRuntime> _parentContext = Optional<ContextRuntime>.Empty();
 
         // The currently running task, if any.
         private Optional<TaskRuntime> _task = Optional<TaskRuntime>.Empty();

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/1d6563e5/lang/cs/Org.Apache.REEF.Common/Runtime/Evaluator/EvaluatorRuntime.cs
----------------------------------------------------------------------
diff --git a/lang/cs/Org.Apache.REEF.Common/Runtime/Evaluator/EvaluatorRuntime.cs b/lang/cs/Org.Apache.REEF.Common/Runtime/Evaluator/EvaluatorRuntime.cs
index 3af0aba..51f3bd2 100644
--- a/lang/cs/Org.Apache.REEF.Common/Runtime/Evaluator/EvaluatorRuntime.cs
+++ b/lang/cs/Org.Apache.REEF.Common/Runtime/Evaluator/EvaluatorRuntime.cs
@@ -46,7 +46,7 @@ namespace Org.Apache.REEF.Common.Runtime.Evaluator
 
         private State _state = State.INIT;
 
-        private IDisposable _evaluatorControlChannel; 
+        private readonly IDisposable _evaluatorControlChannel; 
 
         [Inject]
         public EvaluatorRuntime(

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/1d6563e5/lang/cs/Org.Apache.REEF.Common/Runtime/Evaluator/EvaluatorSettings.cs
----------------------------------------------------------------------
diff --git a/lang/cs/Org.Apache.REEF.Common/Runtime/Evaluator/EvaluatorSettings.cs b/lang/cs/Org.Apache.REEF.Common/Runtime/Evaluator/EvaluatorSettings.cs
index a9b436b..afc520f 100644
--- a/lang/cs/Org.Apache.REEF.Common/Runtime/Evaluator/EvaluatorSettings.cs
+++ b/lang/cs/Org.Apache.REEF.Common/Runtime/Evaluator/EvaluatorSettings.cs
@@ -31,21 +31,21 @@ namespace Org.Apache.REEF.Common.Runtime.Evaluator
     // TODO: merge with EvaluatorConfigurations class
     public class EvaluatorSettings
     {
-        private string _applicationId;
+        private readonly string _applicationId;
 
-        private string _evaluatorId;
+        private readonly string _evaluatorId;
 
-        private int _heartBeatPeriodInMs;
+        private readonly int _heartBeatPeriodInMs;
 
-        private int _maxHeartbeatRetries;
+        private readonly int _maxHeartbeatRetries;
 
-        private ContextConfiguration _rootContextConfig;
+        private readonly ContextConfiguration _rootContextConfig;
 
-        private IClock _clock;
+        private readonly IClock _clock;
 
-        private IRemoteManager<REEFMessage> _remoteManager;
+        private readonly IRemoteManager<REEFMessage> _remoteManager;
 
-        private IInjector _injector;
+        private readonly IInjector _injector;
 
         private EvaluatorOperationState _operationState;
 

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/1d6563e5/lang/cs/Org.Apache.REEF.Common/Runtime/Evaluator/HeartBeatManager.cs
----------------------------------------------------------------------
diff --git a/lang/cs/Org.Apache.REEF.Common/Runtime/Evaluator/HeartBeatManager.cs b/lang/cs/Org.Apache.REEF.Common/Runtime/Evaluator/HeartBeatManager.cs
index 6a6e287..698dcfc 100644
--- a/lang/cs/Org.Apache.REEF.Common/Runtime/Evaluator/HeartBeatManager.cs
+++ b/lang/cs/Org.Apache.REEF.Common/Runtime/Evaluator/HeartBeatManager.cs
@@ -65,7 +65,7 @@ namespace Org.Apache.REEF.Common.Runtime.Evaluator
         // the queue can only contains the following:
         // 1. all failed heartbeats (regular and event-based) before entering RECOVERY state
         // 2. event-based heartbeats generated in RECOVERY state (since there will be no attempt to send regular heartbeat)
-        private Queue<EvaluatorHeartbeatProto> _queuedHeartbeats = new Queue<EvaluatorHeartbeatProto>();
+        private readonly Queue<EvaluatorHeartbeatProto> _queuedHeartbeats = new Queue<EvaluatorHeartbeatProto>();
 
         public HeartBeatManager(EvaluatorSettings settings, IRemoteIdentifier remoteId)
         {

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/1d6563e5/lang/cs/Org.Apache.REEF.Common/Runtime/Evaluator/Task/DriverMessageImpl.cs
----------------------------------------------------------------------
diff --git a/lang/cs/Org.Apache.REEF.Common/Runtime/Evaluator/Task/DriverMessageImpl.cs b/lang/cs/Org.Apache.REEF.Common/Runtime/Evaluator/Task/DriverMessageImpl.cs
index 548e13a..d01d52a 100644
--- a/lang/cs/Org.Apache.REEF.Common/Runtime/Evaluator/Task/DriverMessageImpl.cs
+++ b/lang/cs/Org.Apache.REEF.Common/Runtime/Evaluator/Task/DriverMessageImpl.cs
@@ -24,7 +24,7 @@ namespace Org.Apache.REEF.Common.Runtime.Evaluator.Task
 {
     public class DriverMessageImpl : IDriverMessage
     {
-        private Optional<byte[]> _value;
+        private readonly Optional<byte[]> _value;
  
         public DriverMessageImpl()
         {

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/1d6563e5/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 d62ef39..bdf9af8 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
@@ -34,8 +34,8 @@ namespace Org.Apache.REEF.Common.Runtime.Evaluator.Task
         private readonly HeartBeatManager _heartBeatManager;
         private readonly Optional<ISet<ITaskMessageSource>> _evaluatorMessageSources;
 
-        private string _taskId;
-        private string _contextId;
+        private readonly string _taskId;
+        private readonly string _contextId;
         private Optional<Exception> _lastException = Optional<Exception>.Empty();
         private Optional<byte[]> _result = Optional<byte[]>.Empty();
         private TaskState _state;

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/1d6563e5/lang/cs/Org.Apache.REEF.Common/Runtime/Evaluator/Utils/EvaluatorConfigurations.cs
----------------------------------------------------------------------
diff --git a/lang/cs/Org.Apache.REEF.Common/Runtime/Evaluator/Utils/EvaluatorConfigurations.cs b/lang/cs/Org.Apache.REEF.Common/Runtime/Evaluator/Utils/EvaluatorConfigurations.cs
index 66f726d..016aa78 100644
--- a/lang/cs/Org.Apache.REEF.Common/Runtime/Evaluator/Utils/EvaluatorConfigurations.cs
+++ b/lang/cs/Org.Apache.REEF.Common/Runtime/Evaluator/Utils/EvaluatorConfigurations.cs
@@ -30,9 +30,9 @@ namespace Org.Apache.REEF.Common.Runtime.Evaluator.Utils
     {
         private static readonly Logger LOGGER = Logger.GetLogger(typeof(EvaluatorConfigurations));
 
-        private AvroConfiguration _avroConfiguration;
+        private readonly AvroConfiguration _avroConfiguration;
 
-        private string _configFile;
+        private readonly string _configFile;
 
         private string _applicationId;
 

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/1d6563e5/lang/cs/Org.Apache.REEF.Common/Runtime/MachineStatus.cs
----------------------------------------------------------------------
diff --git a/lang/cs/Org.Apache.REEF.Common/Runtime/MachineStatus.cs b/lang/cs/Org.Apache.REEF.Common/Runtime/MachineStatus.cs
index 54aca4c..c687372 100644
--- a/lang/cs/Org.Apache.REEF.Common/Runtime/MachineStatus.cs
+++ b/lang/cs/Org.Apache.REEF.Common/Runtime/MachineStatus.cs
@@ -26,13 +26,13 @@ namespace Org.Apache.REEF.Common.Runtime
 {
     public class MachineStatus
     {
-        private static PerformanceCounter _cpuCounter;
+        private static readonly PerformanceCounter _cpuCounter;
 
-        private static PerformanceCounter _ramCounter;
+        private static readonly PerformanceCounter _ramCounter;
 
-        private static PerformanceCounter _processCpuCounter;
+        private static readonly PerformanceCounter _processCpuCounter;
 
-        private static Process _process;
+        private static readonly Process _process;
 
         private static bool _checkStatus;
 

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/1d6563e5/lang/cs/Org.Apache.REEF.Driver/Bridge/BridgeLogger.cs
----------------------------------------------------------------------
diff --git a/lang/cs/Org.Apache.REEF.Driver/Bridge/BridgeLogger.cs b/lang/cs/Org.Apache.REEF.Driver/Bridge/BridgeLogger.cs
index 3e2dada..bdbb80a 100644
--- a/lang/cs/Org.Apache.REEF.Driver/Bridge/BridgeLogger.cs
+++ b/lang/cs/Org.Apache.REEF.Driver/Bridge/BridgeLogger.cs
@@ -18,7 +18,6 @@
  */
 
 using System;
-
 using Org.Apache.REEF.Utilities.Logging;
 
 namespace Org.Apache.REEF.Driver.Bridge
@@ -30,7 +29,7 @@ namespace Org.Apache.REEF.Driver.Bridge
     /// </summary>
     public class BridgeLogger
     {
-        private Logger _logger;
+        private readonly Logger _logger;
 
         public BridgeLogger(string name)
         {

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/1d6563e5/lang/cs/Org.Apache.REEF.Driver/Bridge/ClrHandlerHelper.cs
----------------------------------------------------------------------
diff --git a/lang/cs/Org.Apache.REEF.Driver/Bridge/ClrHandlerHelper.cs b/lang/cs/Org.Apache.REEF.Driver/Bridge/ClrHandlerHelper.cs
index 8d9020c..575519c 100644
--- a/lang/cs/Org.Apache.REEF.Driver/Bridge/ClrHandlerHelper.cs
+++ b/lang/cs/Org.Apache.REEF.Driver/Bridge/ClrHandlerHelper.cs
@@ -17,21 +17,19 @@
  * under the License.
  */
 
-using Org.Apache.REEF.Utilities.Diagnostics;
-using Org.Apache.REEF.Utilities.Logging;
-using Org.Apache.REEF.Tang.Exceptions;
-using Org.Apache.REEF.Tang.Formats;
-using Org.Apache.REEF.Tang.Implementations;
-using Org.Apache.REEF.Tang.Interface;
-using Org.Apache.REEF.Tang.Protobuf;
 using System;
-using System.Collections;
 using System.Collections.Generic;
 using System.Globalization;
 using System.IO;
 using System.Linq;
 using System.Runtime.InteropServices;
+using Org.Apache.REEF.Tang.Exceptions;
+using Org.Apache.REEF.Tang.Formats;
 using Org.Apache.REEF.Tang.Implementations.Tang;
+using Org.Apache.REEF.Tang.Interface;
+using Org.Apache.REEF.Tang.Protobuf;
+using Org.Apache.REEF.Utilities.Diagnostics;
+using Org.Apache.REEF.Utilities.Logging;
 
 namespace Org.Apache.REEF.Driver.Bridge
 {

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/1d6563e5/lang/cs/Org.Apache.REEF.Driver/Bridge/ClrSystemHandler.cs
----------------------------------------------------------------------
diff --git a/lang/cs/Org.Apache.REEF.Driver/Bridge/ClrSystemHandler.cs b/lang/cs/Org.Apache.REEF.Driver/Bridge/ClrSystemHandler.cs
index 15b957d..10e93c6 100644
--- a/lang/cs/Org.Apache.REEF.Driver/Bridge/ClrSystemHandler.cs
+++ b/lang/cs/Org.Apache.REEF.Driver/Bridge/ClrSystemHandler.cs
@@ -24,7 +24,7 @@ namespace Org.Apache.REEF.Driver.Bridge
 {
     public class ClrSystemHandler<T> : IObserver<T>, IObservable<T>
     {
-        List<IObserver<T>> userHandlers = new List<IObserver<T>>();
+        readonly List<IObserver<T>> userHandlers = new List<IObserver<T>>();
 
         public void OnNext(T value)
         {

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/1d6563e5/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 531ebbf..80d22f5 100644
--- a/lang/cs/Org.Apache.REEF.Driver/Bridge/ClrSystemHandlerWrapper.cs
+++ b/lang/cs/Org.Apache.REEF.Driver/Bridge/ClrSystemHandlerWrapper.cs
@@ -27,13 +27,11 @@ using Org.Apache.REEF.Driver.Bridge.Events;
 using Org.Apache.REEF.Driver.Context;
 using Org.Apache.REEF.Driver.Evaluator;
 using Org.Apache.REEF.Driver.Task;
-using Org.Apache.REEF.Utilities.Diagnostics;
-using Org.Apache.REEF.Utilities.Logging;
 using Org.Apache.REEF.Tang.Formats;
-using Org.Apache.REEF.Tang.Implementations;
-using Org.Apache.REEF.Tang.Interface;
-using Org.Apache.REEF.Wake.Time;
 using Org.Apache.REEF.Tang.Implementations.Tang;
+using Org.Apache.REEF.Tang.Interface;
+using Org.Apache.REEF.Utilities.Diagnostics;
+using Org.Apache.REEF.Utilities.Logging;
 using Org.Apache.REEF.Wake.Time.Event;
 using ContextMessage = Org.Apache.REEF.Driver.Bridge.Events.ContextMessage;
 

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/1d6563e5/lang/cs/Org.Apache.REEF.Driver/Bridge/DriverBridge.cs
----------------------------------------------------------------------
diff --git a/lang/cs/Org.Apache.REEF.Driver/Bridge/DriverBridge.cs b/lang/cs/Org.Apache.REEF.Driver/Bridge/DriverBridge.cs
index 1ecda50..281af0d 100644
--- a/lang/cs/Org.Apache.REEF.Driver/Bridge/DriverBridge.cs
+++ b/lang/cs/Org.Apache.REEF.Driver/Bridge/DriverBridge.cs
@@ -17,19 +17,17 @@
  * under the License.
  */
 
-using Org.Apache.REEF.Common.Context;
-using Org.Apache.REEF.Driver.Context;
-using Org.Apache.REEF.Driver.Evaluator;
-using Org.Apache.REEF.Driver.Task;
-using Org.Apache.REEF.Utilities.Logging;
-using Org.Apache.REEF.Tang.Annotations;
 using System;
 using System.Collections.Generic;
 using System.Diagnostics;
 using System.Globalization;
 using System.Linq;
-
-using Org.Apache.REEF.Wake.Time;
+using Org.Apache.REEF.Common.Context;
+using Org.Apache.REEF.Driver.Context;
+using Org.Apache.REEF.Driver.Evaluator;
+using Org.Apache.REEF.Driver.Task;
+using Org.Apache.REEF.Tang.Annotations;
+using Org.Apache.REEF.Utilities.Logging;
 using Org.Apache.REEF.Wake.Time.Event;
 
 namespace Org.Apache.REEF.Driver.Bridge
@@ -72,39 +70,39 @@ namespace Org.Apache.REEF.Driver.Bridge
 
         private static ClrSystemHandler<StartTime> _driverRestartSubscriber;
 
-        private IObserver<StartTime> _driverRestartHandler; 
+        private readonly IObserver<StartTime> _driverRestartHandler; 
 
-        private ISet<IObserver<IEvaluatorRequestor>> _evaluatorRequestHandlers;
+        private readonly ISet<IObserver<IEvaluatorRequestor>> _evaluatorRequestHandlers;
 
-        private ISet<IObserver<IAllocatedEvaluator>> _allocatedEvaluatorHandlers;
+        private readonly ISet<IObserver<IAllocatedEvaluator>> _allocatedEvaluatorHandlers;
 
-        private ISet<IObserver<IActiveContext>> _activeContextHandlers;
+        private readonly ISet<IObserver<IActiveContext>> _activeContextHandlers;
 
-        private ISet<IObserver<IActiveContext>> _driverRestartActiveContextHandlers;
+        private readonly ISet<IObserver<IActiveContext>> _driverRestartActiveContextHandlers;
 
-        private ISet<IObserver<ITaskMessage>> _taskMessageHandlers;
+        private readonly ISet<IObserver<ITaskMessage>> _taskMessageHandlers;
 
-        private ISet<IObserver<IFailedTask>> _failedTaskHandlers;
+        private readonly ISet<IObserver<IFailedTask>> _failedTaskHandlers;
 
-        private ISet<IObserver<ISuspendedTask>> _suspendedTaskHandlers;
+        private readonly ISet<IObserver<ISuspendedTask>> _suspendedTaskHandlers;
 
-        private ISet<IObserver<IRunningTask>> _runningTaskHandlers;
+        private readonly ISet<IObserver<IRunningTask>> _runningTaskHandlers;
 
-        private ISet<IObserver<IRunningTask>> _driverRestartRunningTaskHandlers;
+        private readonly ISet<IObserver<IRunningTask>> _driverRestartRunningTaskHandlers;
 
-        private ISet<IObserver<IFailedEvaluator>> _failedEvaluatorHandlers;
+        private readonly ISet<IObserver<IFailedEvaluator>> _failedEvaluatorHandlers;
 
-        private ISet<IObserver<ICompletedEvaluator>> _completedEvaluatorHandlers;
+        private readonly ISet<IObserver<ICompletedEvaluator>> _completedEvaluatorHandlers;
 
-        private ISet<IObserver<IClosedContext>> _closedContextHandlers;
+        private readonly ISet<IObserver<IClosedContext>> _closedContextHandlers;
 
-        private ISet<IObserver<IFailedContext>> _failedContextHandlers;
+        private readonly ISet<IObserver<IFailedContext>> _failedContextHandlers;
 
-        private ISet<IObserver<IContextMessage>> _contextMessageHandlers;
+        private readonly ISet<IObserver<IContextMessage>> _contextMessageHandlers;
 
-        private ISet<IObserver<ICompletedTask>> _completedTaskHandlers;
+        private readonly ISet<IObserver<ICompletedTask>> _completedTaskHandlers;
 
-        private HttpServerHandler _httpServerHandler;
+        private readonly HttpServerHandler _httpServerHandler;
 
         [Inject]
         public DriverBridge(

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/1d6563e5/lang/cs/Org.Apache.REEF.Driver/Bridge/DriverBridgeConfiguration.cs
----------------------------------------------------------------------
diff --git a/lang/cs/Org.Apache.REEF.Driver/Bridge/DriverBridgeConfiguration.cs b/lang/cs/Org.Apache.REEF.Driver/Bridge/DriverBridgeConfiguration.cs
index 7b7b280..d1f53ae 100644
--- a/lang/cs/Org.Apache.REEF.Driver/Bridge/DriverBridgeConfiguration.cs
+++ b/lang/cs/Org.Apache.REEF.Driver/Bridge/DriverBridgeConfiguration.cs
@@ -17,21 +17,20 @@
  * under the License.
  */
 
+using System;
+using System.Collections.Generic;
+using System.Diagnostics;
+using System.Diagnostics.CodeAnalysis;
+using System.Globalization;
 using Org.Apache.REEF.Common.Context;
 using Org.Apache.REEF.Common.Evaluator;
 using Org.Apache.REEF.Driver.Context;
 using Org.Apache.REEF.Driver.Evaluator;
 using Org.Apache.REEF.Driver.Task;
-using Org.Apache.REEF.Utilities.Logging;
 using Org.Apache.REEF.Tang.Annotations;
 using Org.Apache.REEF.Tang.Formats;
 using Org.Apache.REEF.Tang.Util;
-using Org.Apache.REEF.Wake.Time;
-using System;
-using System.Collections.Generic;
-using System.Diagnostics;
-using System.Diagnostics.CodeAnalysis;
-using System.Globalization;
+using Org.Apache.REEF.Utilities.Logging;
 using Org.Apache.REEF.Wake.Time.Event;
 
 [module: SuppressMessage("StyleCop.CSharp.MaintainabilityRules", "SA1401:FieldsMustBePrivate", Justification = "static field, typical usage in configurations")]

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/1d6563e5/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 9bc2402..14aed94 100644
--- a/lang/cs/Org.Apache.REEF.Driver/Bridge/DriverBridgeConfigurationOptions.cs
+++ b/lang/cs/Org.Apache.REEF.Driver/Bridge/DriverBridgeConfigurationOptions.cs
@@ -17,17 +17,16 @@
  * under the License.
  */
 
+using System;
+using System.Collections.Generic;
+using System.Diagnostics;
+using System.Diagnostics.CodeAnalysis;
 using Org.Apache.REEF.Common.Context;
 using Org.Apache.REEF.Driver.Context;
 using Org.Apache.REEF.Driver.Defaults;
 using Org.Apache.REEF.Driver.Evaluator;
 using Org.Apache.REEF.Driver.Task;
 using Org.Apache.REEF.Tang.Annotations;
-using Org.Apache.REEF.Wake.Time;
-using System;
-using System.Collections.Generic;
-using System.Diagnostics;
-using System.Diagnostics.CodeAnalysis;
 using Org.Apache.REEF.Wake.Time.Event;
 
 [module: SuppressMessage("StyleCop.CSharp.MaintainabilityRules", "SA1402:FileMayOnlyContainASingleClass", Justification = "allow name parameter class to be embedded")]

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/1d6563e5/lang/cs/Org.Apache.REEF.Driver/Bridge/Events/ClosedContext.cs
----------------------------------------------------------------------
diff --git a/lang/cs/Org.Apache.REEF.Driver/Bridge/Events/ClosedContext.cs b/lang/cs/Org.Apache.REEF.Driver/Bridge/Events/ClosedContext.cs
index 693d520..61ff926 100644
--- a/lang/cs/Org.Apache.REEF.Driver/Bridge/Events/ClosedContext.cs
+++ b/lang/cs/Org.Apache.REEF.Driver/Bridge/Events/ClosedContext.cs
@@ -28,9 +28,9 @@ namespace Org.Apache.REEF.Driver.Bridge.Events
 {
     public class ClosedContext : IClosedContext
     {
-        private string _id;
+        private readonly string _id;
 
-        private string _evaluatorId;
+        private readonly string _evaluatorId;
 
         public ClosedContext(IClosedContextClr2Java clr2java)
         {

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/1d6563e5/lang/cs/Org.Apache.REEF.Driver/Bridge/Events/FailedContext.cs
----------------------------------------------------------------------
diff --git a/lang/cs/Org.Apache.REEF.Driver/Bridge/Events/FailedContext.cs b/lang/cs/Org.Apache.REEF.Driver/Bridge/Events/FailedContext.cs
index eb982c6..f3bd4ba 100644
--- a/lang/cs/Org.Apache.REEF.Driver/Bridge/Events/FailedContext.cs
+++ b/lang/cs/Org.Apache.REEF.Driver/Bridge/Events/FailedContext.cs
@@ -26,11 +26,11 @@ namespace Org.Apache.REEF.Driver.Bridge.Events
 {
     public class FailedContext : IFailedContext
     {
-        private string _id;
+        private readonly string _id;
 
-        private string _evaluatorId;
+        private readonly string _evaluatorId;
 
-        private string _parentId;
+        private readonly string _parentId;
 
         public FailedContext(IFailedContextClr2Java clr2Java)
         {

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/1d6563e5/lang/cs/Org.Apache.REEF.Driver/Bridge/Events/RunningTask.cs
----------------------------------------------------------------------
diff --git a/lang/cs/Org.Apache.REEF.Driver/Bridge/Events/RunningTask.cs b/lang/cs/Org.Apache.REEF.Driver/Bridge/Events/RunningTask.cs
index a38f6d5..12e59d1 100644
--- a/lang/cs/Org.Apache.REEF.Driver/Bridge/Events/RunningTask.cs
+++ b/lang/cs/Org.Apache.REEF.Driver/Bridge/Events/RunningTask.cs
@@ -27,8 +27,8 @@ namespace Org.Apache.REEF.Driver.Bridge.Events
     public class RunningTask : IRunningTask
     {
         private static readonly Logger LOGGER = Logger.GetLogger(typeof(RunningTask));
-        private IRunningTaskClr2Java _runningTaskClr2Java;
-        private IActiveContextClr2Java _activeContextClr2Java;
+        private readonly IRunningTaskClr2Java _runningTaskClr2Java;
+        private readonly IActiveContextClr2Java _activeContextClr2Java;
 
         public RunningTask(IRunningTaskClr2Java runningTaskClr2Java)
         {

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/1d6563e5/lang/cs/Org.Apache.REEF.Driver/Bridge/Events/TaskMessage.cs
----------------------------------------------------------------------
diff --git a/lang/cs/Org.Apache.REEF.Driver/Bridge/Events/TaskMessage.cs b/lang/cs/Org.Apache.REEF.Driver/Bridge/Events/TaskMessage.cs
index b905a92..b2f8caa 100644
--- a/lang/cs/Org.Apache.REEF.Driver/Bridge/Events/TaskMessage.cs
+++ b/lang/cs/Org.Apache.REEF.Driver/Bridge/Events/TaskMessage.cs
@@ -30,7 +30,7 @@ namespace Org.Apache.REEF.Driver.Bridge.Events
     [DataContract]
     internal class TaskMessage : ITaskMessage
     {
-        private ITaskMessageClr2Java _taskMessageClr2Java;
+        private readonly ITaskMessageClr2Java _taskMessageClr2Java;
         private byte[] _message;
         private string _instanceId;
 

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/1d6563e5/lang/cs/Org.Apache.REEF.Driver/Bridge/HttpServerHandler.cs
----------------------------------------------------------------------
diff --git a/lang/cs/Org.Apache.REEF.Driver/Bridge/HttpServerHandler.cs b/lang/cs/Org.Apache.REEF.Driver/Bridge/HttpServerHandler.cs
index 8dba521..7d56f82 100644
--- a/lang/cs/Org.Apache.REEF.Driver/Bridge/HttpServerHandler.cs
+++ b/lang/cs/Org.Apache.REEF.Driver/Bridge/HttpServerHandler.cs
@@ -17,16 +17,15 @@
  * under the License.
  */
 
-using Org.Apache.REEF.Common.Avro;
-using Org.Apache.REEF.Utilities;
-using Org.Apache.REEF.Utilities.Diagnostics;
-using Org.Apache.REEF.Utilities.Logging;
 using System;
 using System.Collections.Generic;
 using System.Globalization;
 using System.Linq;
-using System.Net;
+using Org.Apache.REEF.Common.Avro;
 using Org.Apache.REEF.Tang.Annotations;
+using Org.Apache.REEF.Utilities;
+using Org.Apache.REEF.Utilities.Diagnostics;
+using Org.Apache.REEF.Utilities.Logging;
 
 namespace Org.Apache.REEF.Driver.Bridge
 {
@@ -39,9 +38,9 @@ namespace Org.Apache.REEF.Driver.Bridge
 
         private static readonly string SPEC = "SPEC";
 
-        private IDictionary<string, IHttpHandler> eventHandlers = new Dictionary<string, IHttpHandler>();
+        private readonly IDictionary<string, IHttpHandler> eventHandlers = new Dictionary<string, IHttpHandler>();
 
-        private HttpServerPort httpServerPort;
+        private readonly HttpServerPort httpServerPort;
 
         /// <summary>
         /// Initializes a new instance of the <see cref="HttpServerHandler" /> class.

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/1d6563e5/lang/cs/Org.Apache.REEF.Driver/Bridge/IHttpHandler.cs
----------------------------------------------------------------------
diff --git a/lang/cs/Org.Apache.REEF.Driver/Bridge/IHttpHandler.cs b/lang/cs/Org.Apache.REEF.Driver/Bridge/IHttpHandler.cs
index 409c974..4778603 100644
--- a/lang/cs/Org.Apache.REEF.Driver/Bridge/IHttpHandler.cs
+++ b/lang/cs/Org.Apache.REEF.Driver/Bridge/IHttpHandler.cs
@@ -17,8 +17,6 @@
  * under the License.
  */
 
-using Org.Apache.REEF.Driver.Bridge;
-
 namespace Org.Apache.REEF.Driver.Bridge
 {
     public interface IHttpHandler

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/1d6563e5/lang/cs/Org.Apache.REEF.Driver/Context/ContextConfiguration.cs
----------------------------------------------------------------------
diff --git a/lang/cs/Org.Apache.REEF.Driver/Context/ContextConfiguration.cs b/lang/cs/Org.Apache.REEF.Driver/Context/ContextConfiguration.cs
index 1bcea1b..8c6a0d5 100644
--- a/lang/cs/Org.Apache.REEF.Driver/Context/ContextConfiguration.cs
+++ b/lang/cs/Org.Apache.REEF.Driver/Context/ContextConfiguration.cs
@@ -17,14 +17,14 @@
  * under the License.
  */
 
+using System;
+using System.Diagnostics.CodeAnalysis;
 using Org.Apache.REEF.Common.Context;
 using Org.Apache.REEF.Common.Events;
 using Org.Apache.REEF.Common.Tasks;
+using Org.Apache.REEF.Common.Tasks.Events;
 using Org.Apache.REEF.Tang.Formats;
 using Org.Apache.REEF.Tang.Util;
-using System;
-using System.Diagnostics.CodeAnalysis;
-using Org.Apache.REEF.Common.Tasks.Events;
 
 [module: SuppressMessage("StyleCop.CSharp.MaintainabilityRules", "SA1401:FieldsMustBePrivate", Justification = "static field, typical usage in configurations")]
 

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/1d6563e5/lang/cs/Org.Apache.REEF.Driver/Context/ContextConfigurationOptions.cs
----------------------------------------------------------------------
diff --git a/lang/cs/Org.Apache.REEF.Driver/Context/ContextConfigurationOptions.cs b/lang/cs/Org.Apache.REEF.Driver/Context/ContextConfigurationOptions.cs
index 48eba08..ffe06fb 100644
--- a/lang/cs/Org.Apache.REEF.Driver/Context/ContextConfigurationOptions.cs
+++ b/lang/cs/Org.Apache.REEF.Driver/Context/ContextConfigurationOptions.cs
@@ -17,14 +17,13 @@
  * under the License.
  */
 
+using System;
+using System.Collections.Generic;
 using Org.Apache.REEF.Common.Context;
 using Org.Apache.REEF.Common.Events;
-using Org.Apache.REEF.Driver.Defaults;
+using Org.Apache.REEF.Driver.Context.Defaults;
 using Org.Apache.REEF.Tang.Annotations;
 using Org.Apache.REEF.Tang.Formats;
-using System;
-using System.Collections.Generic;
-using Org.Apache.REEF.Driver.Context.Defaults;
 
 namespace Org.Apache.REEF.Driver.Context
 {

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/1d6563e5/lang/cs/Org.Apache.REEF.Driver/Context/EvaluatorContext.cs
----------------------------------------------------------------------
diff --git a/lang/cs/Org.Apache.REEF.Driver/Context/EvaluatorContext.cs b/lang/cs/Org.Apache.REEF.Driver/Context/EvaluatorContext.cs
index 4538112..b16021c 100644
--- a/lang/cs/Org.Apache.REEF.Driver/Context/EvaluatorContext.cs
+++ b/lang/cs/Org.Apache.REEF.Driver/Context/EvaluatorContext.cs
@@ -33,11 +33,11 @@ namespace Org.Apache.REEF.Driver.Context
     {
         private static readonly Logger LOGGER = Logger.GetLogger(typeof(EvaluatorContext));
         
-        private string _identifier;
+        private readonly string _identifier;
 
-        private Optional<string> _parentId;
+        private readonly Optional<string> _parentId;
 
-        private EvaluatorManager _evaluatorManager;
+        private readonly EvaluatorManager _evaluatorManager;
 
         private bool _disposed = false;
 

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/1d6563e5/lang/cs/Org.Apache.REEF.Driver/Context/IActiveContext.cs
----------------------------------------------------------------------
diff --git a/lang/cs/Org.Apache.REEF.Driver/Context/IActiveContext.cs b/lang/cs/Org.Apache.REEF.Driver/Context/IActiveContext.cs
index 87ae9d2..53ade72 100644
--- a/lang/cs/Org.Apache.REEF.Driver/Context/IActiveContext.cs
+++ b/lang/cs/Org.Apache.REEF.Driver/Context/IActiveContext.cs
@@ -17,8 +17,8 @@
  * under the License.
  */
 
-using Org.Apache.REEF.Common;
 using System;
+using Org.Apache.REEF.Common;
 
 namespace Org.Apache.REEF.Driver.Context
 {

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/1d6563e5/lang/cs/Org.Apache.REEF.Driver/Defaults/DefaultClientCloseHandler.cs
----------------------------------------------------------------------
diff --git a/lang/cs/Org.Apache.REEF.Driver/Defaults/DefaultClientCloseHandler.cs b/lang/cs/Org.Apache.REEF.Driver/Defaults/DefaultClientCloseHandler.cs
index a47a2b1..5c593f9 100644
--- a/lang/cs/Org.Apache.REEF.Driver/Defaults/DefaultClientCloseHandler.cs
+++ b/lang/cs/Org.Apache.REEF.Driver/Defaults/DefaultClientCloseHandler.cs
@@ -17,9 +17,9 @@
  * under the License.
  */
 
-using Org.Apache.REEF.Utilities.Logging;
-using Org.Apache.REEF.Tang.Annotations;
 using System;
+using Org.Apache.REEF.Tang.Annotations;
+using Org.Apache.REEF.Utilities.Logging;
 
 namespace Org.Apache.REEF.Driver.Defaults
 {

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/1d6563e5/lang/cs/Org.Apache.REEF.Driver/Defaults/DefaultClientCloseWithMessageHandler.cs
----------------------------------------------------------------------
diff --git a/lang/cs/Org.Apache.REEF.Driver/Defaults/DefaultClientCloseWithMessageHandler.cs b/lang/cs/Org.Apache.REEF.Driver/Defaults/DefaultClientCloseWithMessageHandler.cs
index 0dbb6f0..ddf0a3a 100644
--- a/lang/cs/Org.Apache.REEF.Driver/Defaults/DefaultClientCloseWithMessageHandler.cs
+++ b/lang/cs/Org.Apache.REEF.Driver/Defaults/DefaultClientCloseWithMessageHandler.cs
@@ -17,11 +17,11 @@
  * under the License.
  */
 
+using System;
+using Org.Apache.REEF.Tang.Annotations;
 using Org.Apache.REEF.Utilities;
 using Org.Apache.REEF.Utilities.Diagnostics;
 using Org.Apache.REEF.Utilities.Logging;
-using Org.Apache.REEF.Tang.Annotations;
-using System;
 
 namespace Org.Apache.REEF.Driver.Defaults
 {

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/1d6563e5/lang/cs/Org.Apache.REEF.Driver/Defaults/DefaultClientMessageHandler.cs
----------------------------------------------------------------------
diff --git a/lang/cs/Org.Apache.REEF.Driver/Defaults/DefaultClientMessageHandler.cs b/lang/cs/Org.Apache.REEF.Driver/Defaults/DefaultClientMessageHandler.cs
index ca5ac0e..da9ef89 100644
--- a/lang/cs/Org.Apache.REEF.Driver/Defaults/DefaultClientMessageHandler.cs
+++ b/lang/cs/Org.Apache.REEF.Driver/Defaults/DefaultClientMessageHandler.cs
@@ -17,10 +17,10 @@
  * under the License.
  */
 
+using System;
+using Org.Apache.REEF.Tang.Annotations;
 using Org.Apache.REEF.Utilities;
 using Org.Apache.REEF.Utilities.Logging;
-using Org.Apache.REEF.Tang.Annotations;
-using System;
 
 namespace Org.Apache.REEF.Driver.Defaults
 {

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/1d6563e5/lang/cs/Org.Apache.REEF.Driver/Defaults/DefaultContextActiveHandler.cs
----------------------------------------------------------------------
diff --git a/lang/cs/Org.Apache.REEF.Driver/Defaults/DefaultContextActiveHandler.cs b/lang/cs/Org.Apache.REEF.Driver/Defaults/DefaultContextActiveHandler.cs
index 7bb27ad..61c3f1b 100644
--- a/lang/cs/Org.Apache.REEF.Driver/Defaults/DefaultContextActiveHandler.cs
+++ b/lang/cs/Org.Apache.REEF.Driver/Defaults/DefaultContextActiveHandler.cs
@@ -17,11 +17,11 @@
  * under the License.
  */
 
-using Org.Apache.REEF.Driver.Context;
-using Org.Apache.REEF.Utilities.Logging;
-using Org.Apache.REEF.Tang.Annotations;
 using System;
 using System.Globalization;
+using Org.Apache.REEF.Driver.Context;
+using Org.Apache.REEF.Tang.Annotations;
+using Org.Apache.REEF.Utilities.Logging;
 
 namespace Org.Apache.REEF.Driver.Defaults
 {

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/1d6563e5/lang/cs/Org.Apache.REEF.Driver/Defaults/DefaultContextClosureHandler.cs
----------------------------------------------------------------------
diff --git a/lang/cs/Org.Apache.REEF.Driver/Defaults/DefaultContextClosureHandler.cs b/lang/cs/Org.Apache.REEF.Driver/Defaults/DefaultContextClosureHandler.cs
index aa957c7..8d929e5 100644
--- a/lang/cs/Org.Apache.REEF.Driver/Defaults/DefaultContextClosureHandler.cs
+++ b/lang/cs/Org.Apache.REEF.Driver/Defaults/DefaultContextClosureHandler.cs
@@ -17,11 +17,10 @@
  * under the License.
  */
 
-using Org.Apache.REEF.Common.Context;
+using System;
 using Org.Apache.REEF.Driver.Context;
-using Org.Apache.REEF.Utilities.Logging;
 using Org.Apache.REEF.Tang.Annotations;
-using System;
+using Org.Apache.REEF.Utilities.Logging;
 
 namespace Org.Apache.REEF.Driver.Defaults
 {

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/1d6563e5/lang/cs/Org.Apache.REEF.Driver/Defaults/DefaultContextFailureHandler.cs
----------------------------------------------------------------------
diff --git a/lang/cs/Org.Apache.REEF.Driver/Defaults/DefaultContextFailureHandler.cs b/lang/cs/Org.Apache.REEF.Driver/Defaults/DefaultContextFailureHandler.cs
index d8014c6..22c5f86 100644
--- a/lang/cs/Org.Apache.REEF.Driver/Defaults/DefaultContextFailureHandler.cs
+++ b/lang/cs/Org.Apache.REEF.Driver/Defaults/DefaultContextFailureHandler.cs
@@ -17,9 +17,9 @@
  * under the License.
  */
 
+using System;
 using Org.Apache.REEF.Driver.Context;
 using Org.Apache.REEF.Tang.Annotations;
-using System;
 
 namespace Org.Apache.REEF.Driver.Defaults
 {