You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@reef.apache.org by we...@apache.org on 2015/02/05 22:05:39 UTC

[18/51] [partial] incubator-reef git commit: [REEF-131] Towards the new .Net project structure This is to change .Net project structure for Tang, Wake, REEF utilities, Common and Driver:

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/c1b5200f/lang/cs/Source/REEF/reef-common/ReefDriver/bridge/DriverBridge.cs
----------------------------------------------------------------------
diff --git a/lang/cs/Source/REEF/reef-common/ReefDriver/bridge/DriverBridge.cs b/lang/cs/Source/REEF/reef-common/ReefDriver/bridge/DriverBridge.cs
deleted file mode 100644
index 05f33b3..0000000
--- a/lang/cs/Source/REEF/reef-common/ReefDriver/bridge/DriverBridge.cs
+++ /dev/null
@@ -1,321 +0,0 @@
-/**
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- *   http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied.  See the License for the
- * specific language governing permissions and limitations
- * under the License.
- */
-
-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;
-
-namespace Org.Apache.Reef.Driver.Bridge
-{
-    public class DriverBridge
-    {
-        private static Logger _logger;
-        
-        private static ClrSystemHandler<IAllocatedEvaluator> _allocatedEvaluatorSubscriber;
-
-        private static ClrSystemHandler<IEvaluatorRequestor> _evaluatorRequestorSubscriber;
-
-        private static ClrSystemHandler<ITaskMessage> _taskMessageSubscriber;
-
-        private static ClrSystemHandler<IActiveContext> _activeContextSubscriber;
-
-        private static ClrSystemHandler<IActiveContext> _driverRestartActiveContextSubscriber;
-
-        private static ClrSystemHandler<IFailedTask> _failedTaskSubscriber;
-
-        private static ClrSystemHandler<IRunningTask> _runningTaskSubscriber;
-
-        private static ClrSystemHandler<IRunningTask> _driverRestartRunningTaskSubscriber;
-
-        private static ClrSystemHandler<ISuspendedTask> _suspendedTaskSubscriber;
-
-        private static ClrSystemHandler<IFailedEvaluator> _failedEvaluatorSubscriber;
-
-        private static ClrSystemHandler<ICompletedEvaluator> _completedEvaluatorSubscriber;
-
-        private static ClrSystemHandler<IHttpMessage> _httpServerEventSubscriber;
-
-        private static ClrSystemHandler<ICompletedTask> _completedTaskSubscriber;
-
-        private static ClrSystemHandler<IClosedContext> _closedContextSubscriber;
-
-        private static ClrSystemHandler<IFailedContext> _failedContextSubscriber;
-
-        private static ClrSystemHandler<IContextMessage> _contextMessageSubscriber;
-
-        private static ClrSystemHandler<StartTime> _driverRestartSubscriber;
-
-        private IObserver<StartTime> _driverRestartHandler; 
-
-        private ISet<IObserver<IEvaluatorRequestor>> _evaluatorRequestHandlers;
-
-        private ISet<IObserver<IAllocatedEvaluator>> _allocatedEvaluatorHandlers;
-
-        private ISet<IObserver<IActiveContext>> _activeContextHandlers;
-
-        private ISet<IObserver<IActiveContext>> _driverRestartActiveContextHandlers;
-
-        private ISet<IObserver<ITaskMessage>> _taskMessageHandlers;
-
-        private ISet<IObserver<IFailedTask>> _failedTaskHandlers;
-
-        private ISet<IObserver<ISuspendedTask>> _suspendedTaskHandlers;
-
-        private ISet<IObserver<IRunningTask>> _runningTaskHandlers;
-
-        private ISet<IObserver<IRunningTask>> _driverRestartRunningTaskHandlers;
-
-        private ISet<IObserver<IFailedEvaluator>> _failedEvaluatorHandlers;
-
-        private ISet<IObserver<ICompletedEvaluator>> _completedEvaluatorHandlers;
-
-        private ISet<IObserver<IClosedContext>> _closedContextHandlers;
-
-        private ISet<IObserver<IFailedContext>> _failedContextHandlers;
-
-        private ISet<IObserver<IContextMessage>> _contextMessageHandlers;
-
-        private ISet<IObserver<ICompletedTask>> _completedTaskHandlers;
-
-        private HttpServerHandler _httpServerHandler;
-
-        [Inject]
-        public DriverBridge(
-            [Parameter(Value = typeof(DriverBridgeConfigurationOptions.DriverRestartHandler))] IObserver<StartTime> driverRestartHandler,
-            [Parameter(Value = typeof(DriverBridgeConfigurationOptions.EvaluatorRequestHandlers))] ISet<IObserver<IEvaluatorRequestor>> evaluatorRequestHandlers,
-            [Parameter(Value = typeof(DriverBridgeConfigurationOptions.AllocatedEvaluatorHandlers))] ISet<IObserver<IAllocatedEvaluator>> allocatedEvaluatorHandlers,
-            [Parameter(Value = typeof(DriverBridgeConfigurationOptions.ActiveContextHandlers))] ISet<IObserver<IActiveContext>> activeContextHandlers,
-            [Parameter(Value = typeof(DriverBridgeConfigurationOptions.TaskMessageHandlers))] ISet<IObserver<ITaskMessage>> taskMessageHandlers,
-            [Parameter(Value = typeof(DriverBridgeConfigurationOptions.FailedTaskHandlers))] ISet<IObserver<IFailedTask>> failedTaskHandlers,
-            [Parameter(Value = typeof(DriverBridgeConfigurationOptions.FailedEvaluatorHandlers))] ISet<IObserver<IFailedEvaluator>> failedEvaluatorHandlers,
-            [Parameter(Value = typeof(DriverBridgeConfigurationOptions.CompletedEvaluatorHandlers))] ISet<IObserver<ICompletedEvaluator>> completedEvaluatorHandlers,
-            [Parameter(Value = typeof(DriverBridgeConfigurationOptions.RunningTaskHandlers))] ISet<IObserver<IRunningTask>> runningTaskHandlers,
-            [Parameter(Value = typeof(DriverBridgeConfigurationOptions.CompletedTaskHandlers))] ISet<IObserver<ICompletedTask>> completedTaskHandlers,
-            [Parameter(Value = typeof(DriverBridgeConfigurationOptions.SuspendedTaskHandlers))] ISet<IObserver<ISuspendedTask>> suspendedTaskHandlers,
-            [Parameter(Value = typeof(DriverBridgeConfigurationOptions.ClosedContextHandlers))] ISet<IObserver<IClosedContext>> closedContextHandlers,
-            [Parameter(Value = typeof(DriverBridgeConfigurationOptions.FailedContextHandlers))] ISet<IObserver<IFailedContext>> failedContextHandlers,
-            [Parameter(Value = typeof(DriverBridgeConfigurationOptions.ContextMessageHandlers))] ISet<IObserver<IContextMessage>> contextMessageHandlers,
-            [Parameter(Value = typeof(DriverBridgeConfigurationOptions.DriverRestartActiveContextHandlers))] ISet<IObserver<IActiveContext>> driverRestartActiveContextHandlers,
-            [Parameter(Value = typeof(DriverBridgeConfigurationOptions.DriverRestartRunningTaskHandlers))] ISet<IObserver<IRunningTask>> driverRestartRunningTaskHandlers,
-            [Parameter(Value = typeof(DriverBridgeConfigurationOptions.TraceListenersSet))] ISet<TraceListener> traceListeners,
-            [Parameter(Value = typeof(DriverBridgeConfigurationOptions.TraceLevel))] string traceLevel,
-            HttpServerHandler httpServerHandler)
-        {
-            foreach (TraceListener listener in traceListeners)
-            {
-                Logger.AddTraceListner(listener);
-            }
-            _logger = Logger.GetLogger(typeof(DriverBridge));
-            _logger.Log(Level.Info, "Constructing DriverBridge");
-
-            Level level;
-            if (!Enum.TryParse(traceLevel.ToString(CultureInfo.InvariantCulture), out level))
-            {
-                _logger.Log(Level.Warning, string.Format(CultureInfo.InvariantCulture, "Invalid trace level {0} provided, will by default use verbose level", traceLevel));
-            }
-            else
-            {
-                Logger.SetCustomLevel(level);
-            }
-            
-            _evaluatorRequestHandlers = evaluatorRequestHandlers;
-            _allocatedEvaluatorHandlers = allocatedEvaluatorHandlers;
-            _activeContextHandlers = activeContextHandlers;
-            _taskMessageHandlers = taskMessageHandlers;
-            _failedEvaluatorHandlers = failedEvaluatorHandlers;
-            _failedTaskHandlers = failedTaskHandlers;
-            _completedTaskHandlers = completedTaskHandlers;
-            _runningTaskHandlers = runningTaskHandlers;
-            _suspendedTaskHandlers = suspendedTaskHandlers;
-            _completedEvaluatorHandlers = completedEvaluatorHandlers;
-            _closedContextHandlers = closedContextHandlers;
-            _failedContextHandlers = failedContextHandlers;
-            _contextMessageHandlers = contextMessageHandlers;
-            _driverRestartHandler = driverRestartHandler;
-            _driverRestartActiveContextHandlers = driverRestartActiveContextHandlers;
-            _driverRestartRunningTaskHandlers = driverRestartRunningTaskHandlers;
-            _httpServerHandler = httpServerHandler;
-
-            _evaluatorRequestorSubscriber = new ClrSystemHandler<IEvaluatorRequestor>();
-            _allocatedEvaluatorSubscriber = new ClrSystemHandler<IAllocatedEvaluator>();
-            _completedEvaluatorSubscriber = new ClrSystemHandler<ICompletedEvaluator>();
-            _taskMessageSubscriber = new ClrSystemHandler<ITaskMessage>();
-            _activeContextSubscriber = new ClrSystemHandler<IActiveContext>();
-            _failedTaskSubscriber = new ClrSystemHandler<IFailedTask>();
-            _failedEvaluatorSubscriber = new ClrSystemHandler<IFailedEvaluator>();
-            _httpServerEventSubscriber = new ClrSystemHandler<IHttpMessage>();
-            _completedTaskSubscriber = new ClrSystemHandler<ICompletedTask>();
-            _runningTaskSubscriber = new ClrSystemHandler<IRunningTask>();
-            _suspendedTaskSubscriber = new ClrSystemHandler<ISuspendedTask>();
-            _closedContextSubscriber = new ClrSystemHandler<IClosedContext>();
-            _failedContextSubscriber = new ClrSystemHandler<IFailedContext>();
-            _contextMessageSubscriber = new ClrSystemHandler<IContextMessage>();
-            _driverRestartSubscriber = new ClrSystemHandler<StartTime>();
-            _driverRestartActiveContextSubscriber = new ClrSystemHandler<IActiveContext>();
-            _driverRestartRunningTaskSubscriber = new ClrSystemHandler<IRunningTask>();
-        }
-
-        public ulong[] Subscribe()
-        {
-            ulong[] handlers = Enumerable.Repeat(Constants.NullHandler, Constants.HandlersNumber).ToArray();
-
-            // subscribe to StartTime event for driver restart         
-            _driverRestartSubscriber.Subscribe(_driverRestartHandler);
-            _logger.Log(Level.Info, "subscribed to Driver restart handler: " + _driverRestartHandler);
-            handlers[Constants.Handlers[Constants.DriverRestartHandler]] = ClrHandlerHelper.CreateHandler(_driverRestartSubscriber);
-
-            // subscribe to Evaluator Requestor          
-            foreach (var handler in _evaluatorRequestHandlers)
-            {
-                _evaluatorRequestorSubscriber.Subscribe(handler);
-                _logger.Log(Level.Info, "subscribed to IEvaluatorRequestor handler: " + handler);
-            }
-            handlers[Constants.Handlers[Constants.EvaluatorRequestorHandler]] = ClrHandlerHelper.CreateHandler(_evaluatorRequestorSubscriber);
-
-            // subscribe to Allocated Evaluator
-            foreach (var handler in _allocatedEvaluatorHandlers)
-            {
-                _allocatedEvaluatorSubscriber.Subscribe(handler);
-                _logger.Log(Level.Info, "subscribed to IAllocatedEvaluator handler: " + handler);
-            }
-            handlers[Constants.Handlers[Constants.AllocatedEvaluatorHandler]] = ClrHandlerHelper.CreateHandler(_allocatedEvaluatorSubscriber);
-
-            // subscribe to TaskMessage
-            foreach (var handler in _taskMessageHandlers)
-            {
-                _taskMessageSubscriber.Subscribe(handler);
-                _logger.Log(Level.Info, "subscribed to ITaskMessage handler: " + handler);
-            }
-            handlers[Constants.Handlers[Constants.TaskMessageHandler]] = ClrHandlerHelper.CreateHandler(_taskMessageSubscriber);
-
-            // subscribe to Active Context
-            foreach (var handler in _activeContextHandlers)
-            {
-                _activeContextSubscriber.Subscribe(handler);
-                _logger.Log(Level.Info, "subscribed to IActiveContext handler: " + handler);
-            }
-            handlers[Constants.Handlers[Constants.ActiveContextHandler]] = ClrHandlerHelper.CreateHandler(_activeContextSubscriber);
-
-            // subscribe to Failed Task
-            foreach (var handler in _failedTaskHandlers)
-            {
-                _failedTaskSubscriber.Subscribe(handler);
-                _logger.Log(Level.Info, "subscribed to IFailedTask handler: " + handler);
-            }
-            handlers[Constants.Handlers[Constants.FailedTaskHandler]] = ClrHandlerHelper.CreateHandler(_failedTaskSubscriber);
-
-            // subscribe to Running Task
-            foreach (var handler in _runningTaskHandlers)
-            {
-                _runningTaskSubscriber.Subscribe(handler);
-                _logger.Log(Level.Info, "subscribed to IRunningask handler: " + handler);
-            }
-            handlers[Constants.Handlers[Constants.RunningTaskHandler]] = ClrHandlerHelper.CreateHandler(_runningTaskSubscriber);
-
-            // subscribe to Completed Task
-            foreach (var handler in _completedTaskHandlers)
-            {
-                _completedTaskSubscriber.Subscribe(handler);
-                _logger.Log(Level.Info, "subscribed to ICompletedTask handler: " + handler);
-            }
-            handlers[Constants.Handlers[Constants.CompletedTaskHandler]] = ClrHandlerHelper.CreateHandler(_completedTaskSubscriber);
-
-            // subscribe to Suspended Task
-            foreach (var handler in _suspendedTaskHandlers)
-            {
-                _suspendedTaskSubscriber.Subscribe(handler);
-                _logger.Log(Level.Info, "subscribed to ISuspendedTask handler: " + handler);
-            }
-            handlers[Constants.Handlers[Constants.SuspendedTaskHandler]] = ClrHandlerHelper.CreateHandler(_suspendedTaskSubscriber);
-
-            // subscribe to Failed Evaluator
-            foreach (var handler in _failedEvaluatorHandlers)
-            {
-                _failedEvaluatorSubscriber.Subscribe(handler);
-                _logger.Log(Level.Info, "subscribed to IFailedEvaluator handler: " + handler);
-            }
-            handlers[Constants.Handlers[Constants.FailedEvaluatorHandler]] = ClrHandlerHelper.CreateHandler(_failedEvaluatorSubscriber);
-
-            // subscribe to Completed Evaluator
-            foreach (var handler in _completedEvaluatorHandlers)
-            {
-                _completedEvaluatorSubscriber.Subscribe(handler);
-                _logger.Log(Level.Info, "subscribed to ICompletedEvaluator handler: " + handler);
-            }
-            handlers[Constants.Handlers[Constants.CompletedEvaluatorHandler]] = ClrHandlerHelper.CreateHandler(_completedEvaluatorSubscriber);
-
-            // subscribe to Closed Context
-            foreach (var handler in _closedContextHandlers)
-            {
-                _closedContextSubscriber.Subscribe(handler);
-                _logger.Log(Level.Info, "subscribed to IClosedContext handler: " + handler);
-            }
-            handlers[Constants.Handlers[Constants.ClosedContextHandler]] = ClrHandlerHelper.CreateHandler(_closedContextSubscriber);
-
-            // subscribe to Failed Context
-            foreach (var handler in _failedContextHandlers)
-            {
-                _failedContextSubscriber.Subscribe(handler);
-                _logger.Log(Level.Info, "subscribed to IFailedContext handler: " + handler);
-            }
-            handlers[Constants.Handlers[Constants.FailedContextHandler]] = ClrHandlerHelper.CreateHandler(_failedContextSubscriber);
-
-            // subscribe to Context Message
-            foreach (var handler in _contextMessageHandlers)
-            {
-                _contextMessageSubscriber.Subscribe(handler);
-                _logger.Log(Level.Info, "subscribed to IContextMesage handler: " + handler);
-            }
-            handlers[Constants.Handlers[Constants.ContextMessageHandler]] = ClrHandlerHelper.CreateHandler(_contextMessageSubscriber);
-
-            // subscribe to Active Context received during driver restart
-            foreach (var handler in _driverRestartActiveContextHandlers)
-            {
-                _driverRestartActiveContextSubscriber.Subscribe(handler);
-                _logger.Log(Level.Info, "subscribed to handler for IActiveContext received during driver restart: " + handler);
-            }
-            handlers[Constants.Handlers[Constants.DriverRestartActiveContextHandler]] = ClrHandlerHelper.CreateHandler(_driverRestartActiveContextSubscriber);
-
-            // subscribe to Running Task received during driver restart
-            foreach (var handler in _driverRestartRunningTaskHandlers)
-            {
-                _driverRestartRunningTaskSubscriber.Subscribe(handler);
-                _logger.Log(Level.Info, "subscribed to handler for IRunningTask received during driver restart: " + handler);
-            }
-            handlers[Constants.Handlers[Constants.DriverRestartRunningTaskHandler]] = ClrHandlerHelper.CreateHandler(_driverRestartRunningTaskSubscriber);
-
-            // subscribe to Http message
-            _httpServerEventSubscriber.Subscribe(_httpServerHandler);
-            _logger.Log(Level.Info, "subscribed to IHttpMessage handler  :" + _httpServerHandler);
-            handlers[Constants.Handlers[Constants.HttpServerHandler]] = ClrHandlerHelper.CreateHandler(_httpServerEventSubscriber);
-
-            return handlers;
-        }
-    }
-}

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/c1b5200f/lang/cs/Source/REEF/reef-common/ReefDriver/bridge/DriverBridgeConfiguration.cs
----------------------------------------------------------------------
diff --git a/lang/cs/Source/REEF/reef-common/ReefDriver/bridge/DriverBridgeConfiguration.cs b/lang/cs/Source/REEF/reef-common/ReefDriver/bridge/DriverBridgeConfiguration.cs
deleted file mode 100644
index cf74529..0000000
--- a/lang/cs/Source/REEF/reef-common/ReefDriver/bridge/DriverBridgeConfiguration.cs
+++ /dev/null
@@ -1,273 +0,0 @@
-/**
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- *   http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied.  See the License for the
- * specific language governing permissions and limitations
- * under the License.
- */
-
-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;
-
-[module: SuppressMessage("StyleCop.CSharp.MaintainabilityRules", "SA1401:FieldsMustBePrivate", Justification = "static field, typical usage in configurations")]
-
-namespace Org.Apache.Reef.Driver.Bridge
-{
-    public class DriverBridgeConfiguration : ConfigurationModuleBuilder
-    {
-        /// <summary>
-        ///  The event handler invoked right after the driver boots up. 
-        /// </summary>
-        [SuppressMessage("Microsoft.Security", "CA2104:Do not declare read only mutable reference types", Justification = "not applicable")]
-        public static readonly RequiredImpl<IStartHandler> OnDriverStarted = new RequiredImpl<IStartHandler>();
-
-        /// <summary>
-        ///  The event handler invoked when driver restarts
-        /// </summary>
-        [SuppressMessage("Microsoft.Security", "CA2104:Do not declare read only mutable reference types", Justification = "not applicable")]
-        public static readonly OptionalImpl<IObserver<StartTime>> OnDriverRestarted = new OptionalImpl<IObserver<StartTime>>();
-
-        /// <summary>
-        /// The event handler for requesting evaluator
-        /// </summary>
-        [SuppressMessage("Microsoft.Security", "CA2104:Do not declare read only mutable reference types", Justification = "not applicable")]
-        public static readonly OptionalImpl<IObserver<IEvaluatorRequestor>> OnEvaluatorRequested = new OptionalImpl<IObserver<IEvaluatorRequestor>>();
-
-        /// <summary>
-        /// Event handler for allocated evaluators. Defaults to returning the evaluator if not bound.
-        /// </summary>
-        [SuppressMessage("Microsoft.Security", "CA2104:Do not declare read only mutable reference types", Justification = "not applicable")]
-        public static readonly OptionalImpl<IObserver<IAllocatedEvaluator>> OnEvaluatorAllocated = new OptionalImpl<IObserver<IAllocatedEvaluator>>();
-
-        /// <summary>
-        /// Event handler for completed evaluators. Defaults to logging if not bound.
-        /// </summary>
-        [SuppressMessage("Microsoft.Security", "CA2104:Do not declare read only mutable reference types", Justification = "not applicable")]
-        public static readonly OptionalImpl<IObserver<ICompletedEvaluator>> OnEvaluatorCompleted = new OptionalImpl<IObserver<ICompletedEvaluator>>();
-
-        /// <summary>
-        /// Event handler for failed evaluators. Defaults to job failure if not bound.
-        /// </summary>
-        [SuppressMessage("Microsoft.Security", "CA2104:Do not declare read only mutable reference types", Justification = "not applicable")]
-        public static readonly OptionalImpl<IObserver<IFailedEvaluator>> OnEvaluatorFailed = new OptionalImpl<IObserver<IFailedEvaluator>>();
-
-        /// <summary>
-        /// Event handler for failed evaluators. Defaults to job failure if not bound.
-        /// </summary>
-        [SuppressMessage("Microsoft.Security", "CA2104:Do not declare read only mutable reference types", Justification = "not applicable")]
-        public static readonly OptionalImpl<IHttpHandler> OnHttpEvent = new OptionalImpl<IHttpHandler>();
-
-        /// <summary>
-        /// Event handler for task messages. Defaults to logging if not bound.
-        /// </summary>
-        [SuppressMessage("Microsoft.Security", "CA2104:Do not declare read only mutable reference types", Justification = "not applicable")]
-        public static readonly OptionalImpl<IObserver<ITaskMessage>> OnTaskMessage = new OptionalImpl<IObserver<ITaskMessage>>();
-
-        /// <summary>
-        /// Event handler for completed tasks. Defaults to closing the context the task ran on if not bound.
-        /// </summary>
-        [SuppressMessage("Microsoft.Security", "CA2104:Do not declare read only mutable reference types", Justification = "not applicable")]        
-        public static readonly OptionalImpl<IObserver<ICompletedTask>> OnTaskCompleted = new OptionalImpl<IObserver<ICompletedTask>>();
-
-        /// <summary>
-        /// Event handler for failed tasks. Defaults to job failure if not bound.
-        /// </summary>
-        [SuppressMessage("Microsoft.Security", "CA2104:Do not declare read only mutable reference types", Justification = "not applicable")]
-        public static readonly OptionalImpl<IObserver<IFailedTask>> OnTaskFailed = new OptionalImpl<IObserver<IFailedTask>>();
-
-        ///// <summary>
-        ///// Event handler for running tasks. Defaults to logging if not bound.
-        ///// </summary>
-        [SuppressMessage("Microsoft.Security", "CA2104:Do not declare read only mutable reference types", Justification = "not applicable")]
-        public static readonly OptionalImpl<IObserver<IRunningTask>> OnTaskRunning = new OptionalImpl<IObserver<IRunningTask>>();
-
-        ///// <summary>
-        ///// Event handler for running task received during driver restart. Defaults to logging if not bound.
-        ///// </summary>
-        [SuppressMessage("Microsoft.Security", "CA2104:Do not declare read only mutable reference types", Justification = "not applicable")]
-        public static readonly OptionalImpl<IObserver<IRunningTask>> OnDriverRestartTaskRunning = new OptionalImpl<IObserver<IRunningTask>>();
-
-        /// <summary>
-        /// Event handler for suspended tasks. Defaults to job failure if not bound. Rationale: many jobs don't support
-        /// task suspension. Hence, this parameter should be optional. The only sane default is to crash the job, then.
-        /// </summary>
-        [SuppressMessage("Microsoft.Security", "CA2104:Do not declare read only mutable reference types", Justification = "not applicable")]
-        public static readonly OptionalImpl<IObserver<ISuspendedTask>> OnTaskSuspended = new OptionalImpl<IObserver<ISuspendedTask>>();
-
-        /// <summary>
-        /// Event handler for active context. Defaults to closing the context if not bound.
-        /// </summary>
-        [SuppressMessage("Microsoft.Security", "CA2104:Do not declare read only mutable reference types", Justification = "not applicable")]
-        public static readonly OptionalImpl<IObserver<IActiveContext>> OnContextActive = new OptionalImpl<IObserver<IActiveContext>>();
-
-        /// <summary>
-        /// Event handler for active context received during driver restart. Defaults to closing the context if not bound.
-        /// </summary>
-        [SuppressMessage("Microsoft.Security", "CA2104:Do not declare read only mutable reference types", Justification = "not applicable")]
-        public static readonly OptionalImpl<IObserver<IActiveContext>> OnDirverRestartContextActive = new OptionalImpl<IObserver<IActiveContext>>();
-
-        /// <summary>
-        /// Event handler for closed context. Defaults to logging if not bound.
-        /// </summary>
-        [SuppressMessage("Microsoft.Security", "CA2104:Do not declare read only mutable reference types", Justification = "not applicable")]
-        public static readonly OptionalImpl<IObserver<IClosedContext>> OnContextClosed = new OptionalImpl<IObserver<IClosedContext>>();
-
-        /// <summary>
-        ///  Event handler for closed context. Defaults to job failure if not bound.
-        /// </summary>
-        [SuppressMessage("Microsoft.Security", "CA2104:Do not declare read only mutable reference types", Justification = "not applicable")]
-        public static readonly OptionalImpl<IObserver<IFailedContext>> OnContextFailed = new OptionalImpl<IObserver<IFailedContext>>();
-
-        /// <summary>
-        ///  Event handler for context messages. Defaults to logging if not bound.
-        /// </summary>
-        [SuppressMessage("Microsoft.Security", "CA2104:Do not declare read only mutable reference types", Justification = "not applicable")]
-        public static readonly OptionalImpl<IObserver<IContextMessage>> OnContextMessage = new OptionalImpl<IObserver<IContextMessage>>();
-
-        /// <summary>
-        /// Additional set of string arguments that can be pssed to handlers through client
-        /// </summary>
-        [SuppressMessage("Microsoft.Security", "CA2104:Do not declare read only mutable reference types", Justification = "not applicable")]
-        public static readonly OptionalParameter<string> CommandLineArguments = new OptionalParameter<string>();
-
-        /// <summary>
-        /// The trace level of the TraceListner
-        /// </summary>
-        [SuppressMessage("Microsoft.Security", "CA2104:Do not declare read only mutable reference types", Justification = "not applicable")]
-        public static readonly OptionalParameter<string> CustomTraceLevel = new OptionalParameter<string>();
-
-        /// <summary>
-        /// Additional set of trace listners provided by client
-        /// </summary>
-        [SuppressMessage("Microsoft.Security", "CA2104:Do not declare read only mutable reference types", Justification = "not applicable")]
-        public static readonly OptionalParameter<TraceListener> CustomTraceListeners = new OptionalParameter<TraceListener>();
-
-        /// <summary>
-        ///  The implemenation for (attempting to) re-establish connection to driver
-        /// </summary>
-        [SuppressMessage("Microsoft.Security", "CA2104:Do not declare read only mutable reference types", Justification = "not applicable")]
-        public static readonly OptionalImpl<IDriverConnection> OnDriverReconnect = new OptionalImpl<IDriverConnection>();
-
-        // This is currently not needed in Bridge/Driver model
-        ///// <summary>
-        ///// The event handler invoked right before the driver shuts down. Defaults to ignore.
-        ///// </summary>
-        //public static readonly OptionalImpl<IObserver<StopTime>> OnDriverStop = new OptionalImpl<IObserver<StopTime>>();
-
-        // Client handlers only needed when client interactions are expeceted. Not enabled for now.
-        ///// <summary>
-        ///// Event handler for client messages. Defaults to logging if not bound.
-        ///// </summary>
-        //public static readonly OptionalImpl<IObserver<byte[]>> OnClientMessage = new OptionalImpl<IObserver<byte[]>>();
-
-        // Client handlers only needed when client interactions are expeceted. Not enabled for now.
-        ///// <summary>
-        ///// Event handler for close messages sent by the client. Defaults to job failure if not bound.
-        ///// Note: in java the type is void, but IObserver does not take void as a type
-        ///// </summary>
-        //public static readonly OptionalImpl<IObserver<byte[]>> OnClientClosed = new OptionalImpl<IObserver<byte[]>>();
-
-        // Client handlers only needed when client interactions are expeceted. Not enabled for now.
-        ///// <summary>
-        ///// Event handler for close messages sent by the client. Defaults to job failure if not bound.
-        ///// </summary>
-        //public static readonly OptionalImpl<IObserver<byte[]>> OnClientClosedMessage = new OptionalImpl<IObserver<byte[]>>();
-
-        public static ConfigurationModule ConfigurationModule
-        {
-            get
-            {
-                return new DriverBridgeConfiguration()
-                .BindImplementation(GenericType<IStartHandler>.Class, OnDriverStarted)
-                .BindNamedParameter(GenericType<DriverBridgeConfigurationOptions.DriverRestartHandler>.Class, OnDriverRestarted)
-                .BindImplementation(GenericType<IDriverConnection>.Class, OnDriverReconnect)
-                .BindSetEntry(GenericType<DriverBridgeConfigurationOptions.EvaluatorRequestHandlers>.Class, OnEvaluatorRequested)
-                .BindSetEntry(GenericType<DriverBridgeConfigurationOptions.AllocatedEvaluatorHandlers>.Class, OnEvaluatorAllocated)
-                .BindSetEntry(GenericType<DriverBridgeConfigurationOptions.ActiveContextHandlers>.Class, OnContextActive)
-                .BindSetEntry(GenericType<DriverBridgeConfigurationOptions.TaskMessageHandlers>.Class, OnTaskMessage)
-                .BindSetEntry(GenericType<DriverBridgeConfigurationOptions.FailedTaskHandlers>.Class, OnTaskFailed)
-                .BindSetEntry(GenericType<DriverBridgeConfigurationOptions.RunningTaskHandlers>.Class, OnTaskRunning)
-                .BindSetEntry(GenericType<DriverBridgeConfigurationOptions.SuspendedTaskHandlers>.Class, OnTaskSuspended)
-                .BindSetEntry(GenericType<DriverBridgeConfigurationOptions.FailedEvaluatorHandlers>.Class, OnEvaluatorFailed)
-                .BindSetEntry(GenericType<DriverBridgeConfigurationOptions.CompletedEvaluatorHandlers>.Class, OnEvaluatorCompleted)
-                .BindSetEntry(GenericType<DriverBridgeConfigurationOptions.CompletedTaskHandlers>.Class, OnTaskCompleted)
-                .BindSetEntry(GenericType<DriverBridgeConfigurationOptions.ClosedContextHandlers>.Class, OnContextClosed)
-                .BindSetEntry(GenericType<DriverBridgeConfigurationOptions.FailedContextHandlers>.Class, OnContextFailed)
-                .BindSetEntry(GenericType<DriverBridgeConfigurationOptions.ContextMessageHandlers>.Class, OnContextMessage)
-                .BindSetEntry(GenericType<DriverBridgeConfigurationOptions.ArgumentSets>.Class, CommandLineArguments)
-                .BindSetEntry(GenericType<DriverBridgeConfigurationOptions.HttpEventHandlers>.Class, OnHttpEvent)
-                .BindSetEntry(GenericType<DriverBridgeConfigurationOptions.TraceListenersSet>.Class, CustomTraceListeners)
-                .BindSetEntry(GenericType<DriverBridgeConfigurationOptions.DriverRestartActiveContextHandlers>.Class, OnDirverRestartContextActive)
-                .BindSetEntry(GenericType<DriverBridgeConfigurationOptions.DriverRestartRunningTaskHandlers>.Class, OnDriverRestartTaskRunning)
-                .BindNamedParameter(GenericType<DriverBridgeConfigurationOptions.TraceLevel>.Class, CustomTraceLevel)
-                .Build();
-            }
-        }
-    }
-
-    public class CommandLineArguments
-    {
-        [Inject]
-        public CommandLineArguments([Parameter(typeof(DriverBridgeConfigurationOptions.ArgumentSets))] ISet<string> arguments)
-        {
-            Arguments = arguments;
-        }
-
-        public ISet<string> Arguments { get; set; }
-    }
-
-    public class CustomTraceListeners
-    {
-        [Inject]
-        public CustomTraceListeners([Parameter(typeof(DriverBridgeConfigurationOptions.TraceListenersSet))] ISet<TraceListener> listeners)
-        {
-            Listeners = listeners;
-        }
-
-        public ISet<TraceListener> Listeners { get; set; }
-    }
-
-    public class CustomTraceLevel
-    {
-        [Inject]
-        public CustomTraceLevel([Parameter(typeof(DriverBridgeConfigurationOptions.TraceLevel))] string traceLevel)
-        {
-            Level level = Level.Verbose;
-            if (Enum.TryParse(traceLevel.ToString(CultureInfo.InvariantCulture), out level))
-            {
-                Logger.SetCustomLevel(level);
-            }
-            else
-            {
-                Console.WriteLine("Cannot parse trace level" + traceLevel);
-            }
-            TraceLevel = level;
-        }
-
-        public Level TraceLevel { get; set; }
-    }
-}

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/c1b5200f/lang/cs/Source/REEF/reef-common/ReefDriver/bridge/DriverBridgeConfigurationOptions.cs
----------------------------------------------------------------------
diff --git a/lang/cs/Source/REEF/reef-common/ReefDriver/bridge/DriverBridgeConfigurationOptions.cs b/lang/cs/Source/REEF/reef-common/ReefDriver/bridge/DriverBridgeConfigurationOptions.cs
deleted file mode 100644
index 73b1475..0000000
--- a/lang/cs/Source/REEF/reef-common/ReefDriver/bridge/DriverBridgeConfigurationOptions.cs
+++ /dev/null
@@ -1,154 +0,0 @@
-/**
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- *   http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied.  See the License for the
- * specific language governing permissions and limitations
- * under the License.
- */
-
-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;
-
-[module: SuppressMessage("StyleCop.CSharp.MaintainabilityRules", "SA1402:FileMayOnlyContainASingleClass", Justification = "allow name parameter class to be embedded")]
-
-namespace Org.Apache.Reef.Driver.Bridge
-{
-    /// <summary>
-    /// Hosts all named parameters for Drivers, including bridge handlers.
-    /// </summary>
-    public class DriverBridgeConfigurationOptions
-    {
-        // Level.Verbose (since enum is not suppoted for TANG, we use a string here)
-        private const string _verboseLevel = "Verbose";
-
-        [NamedParameter(documentation: "Called when driver is restarted, after CLR bridge is set up.", defaultClasses: new[] { typeof(DefaultDriverRestartHandler) })]
-        public class DriverRestartHandler : Name<IObserver<StartTime>>
-        {
-        }
-
-        [NamedParameter(documentation: "Called when evaluator is requested.", defaultClasses: new[] { typeof(DefaultEvaluatorRequestorHandler) })] 
-        public class EvaluatorRequestHandlers : Name<ISet<IObserver<IEvaluatorRequestor>>>
-        {
-        }
-
-        [NamedParameter(documentation: "Called when an exception occurs on a running evaluator.", defaultClasses: new[] { typeof(DefaultEvaluatorFailureHandler) })]
-        public class FailedEvaluatorHandlers : Name<ISet<IObserver<IFailedEvaluator>>>
-        {
-        }
-
-        [NamedParameter(documentation: "Called when an evaluator completes.", defaultClasses: new[] { typeof(DefaultEvaluatorCompletionHandler) })]
-        public class CompletedEvaluatorHandlers : Name<ISet<IObserver<ICompletedEvaluator>>>
-        {
-        }
-
-        [NamedParameter(documentation: "Called when an allocated evaluator is given to the client.", defaultClasses: new[] { typeof(DefaultEvaluatorAllocationHandler) })]
-        public class AllocatedEvaluatorHandlers : Name<ISet<IObserver<IAllocatedEvaluator>>>
-        {
-        }
-
-        [NamedParameter(documentation: "Running task handler.", defaultClasses: new[] { typeof(DefaultTaskRunningHandler) })]
-        public class RunningTaskHandlers : Name<ISet<IObserver<IRunningTask>>>
-        {
-        }
-
-        [NamedParameter(documentation: "Running task during driver restart handler.", defaultClasses: new[] { typeof(DefaultDriverRestartTaskRunningHandler) })]
-        public class DriverRestartRunningTaskHandlers : Name<ISet<IObserver<IRunningTask>>>
-        {
-        }
-
-        [NamedParameter(documentation: "Task exception handler.", defaultClasses: new[] { typeof(DefaultTaskFailureHandler) })]
-        public class FailedTaskHandlers : Name<ISet<IObserver<IFailedTask>>>
-        {
-        }
-
-        [NamedParameter(documentation: "Task message handler.", defaultClasses: new[] { typeof(DefaultTaskMessageHandler) })]
-        public class TaskMessageHandlers : Name<ISet<IObserver<ITaskMessage>>>
-        {
-        }
-
-        [NamedParameter(documentation: "Http Event Handlers.", defaultClasses: new[] { typeof(DefaultHttpHandler) })]
-        public class HttpEventHandlers : Name<ISet<IHttpHandler>>
-        {
-        }
-
-        [NamedParameter(documentation: "Completed task handler.", defaultClasses: new[] { typeof(DefaultTaskCompletionHandler) })]
-        public class CompletedTaskHandlers : Name<ISet<IObserver<ICompletedTask>>>
-        {
-        }
-
-        [NamedParameter(documentation: "Suspended task handler.", defaultClasses: new[] { typeof(DefaultTaskSuspensionHandler) })]
-        public class SuspendedTaskHandlers : Name<ISet<IObserver<ISuspendedTask>>>
-        {
-        }
-
-        [NamedParameter(documentation: "Handler for IActiveContext.", defaultClasses: new[] { typeof(DefaultContextActiveHandler) })]
-        public class ActiveContextHandlers : Name<ISet<IObserver<IActiveContext>>>
-        {
-        }
-
-        [NamedParameter(documentation: "Handler for IActiveContext received during driver restart.", defaultClasses: new[] { typeof(DefaultDriverRestartContextActiveHandler) })]
-        public class DriverRestartActiveContextHandlers : Name<ISet<IObserver<IActiveContext>>>
-        {
-        }
-
-        [NamedParameter(documentation: "Handler for ClosedContext.", defaultClasses: new[] { typeof(DefaultContextClosureHandler) })]
-        public class ClosedContextHandlers : Name<ISet<IObserver<IClosedContext>>>
-        {
-        }
-
-        [NamedParameter(documentation: "Handler for FailedContext.", defaultClasses: new[] { typeof(DefaultContextFailureHandler) })]
-        public class FailedContextHandlers : Name<ISet<IObserver<IFailedContext>>>
-        {
-        }
-
-        [NamedParameter(documentation: "Handler for ContextMessage.", defaultClasses: new[] { typeof(DefaultContextMessageHandler) })]
-        public class ContextMessageHandlers : Name<ISet<IObserver<IContextMessage>>>
-        {
-        }
-
-        [NamedParameter("Command Line Arguments supplied by client", "CommandLineArguments", null)]
-        public class ArgumentSets : Name<ISet<string>>
-        {
-        }
-
-        [NamedParameter("Additional trace listners supplied by client", "TraceListeners", null, defaultClasses: new[] { typeof(DefaultCustomTraceListener) })]
-        public class TraceListenersSet : Name<ISet<TraceListener>>
-        {
-        }
-
-        [NamedParameter("Custom Trace Level", "TraceLevel", defaultValue: _verboseLevel)]
-        public class TraceLevel : Name<string>
-        {
-        }
-
-        //[NamedParameter(documentation: "Job message handler.", defaultClasses: new[] { typeof(DefaultClientMessageHandler) })]
-        //public class ClientMessageHandlers : Name<ISet<IObserver<byte[]>>>
-        //{
-        //}
-
-        //[NamedParameter(documentation: "Client close handler.", defaultClasses: new[] { typeof(DefaultClientCloseHandler) })]
-        //public class ClientCloseHandlers : Name<ISet<IObserver<byte[]>>>
-        //{
-        //}
-    }
-}

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/c1b5200f/lang/cs/Source/REEF/reef-common/ReefDriver/bridge/HttpMessage.cs
----------------------------------------------------------------------
diff --git a/lang/cs/Source/REEF/reef-common/ReefDriver/bridge/HttpMessage.cs b/lang/cs/Source/REEF/reef-common/ReefDriver/bridge/HttpMessage.cs
deleted file mode 100644
index bf10b5f..0000000
--- a/lang/cs/Source/REEF/reef-common/ReefDriver/bridge/HttpMessage.cs
+++ /dev/null
@@ -1,60 +0,0 @@
-/**
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- *   http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied.  See the License for the
- * specific language governing permissions and limitations
- * under the License.
- */
-
-using System.Runtime.Serialization;
-
-namespace Org.Apache.Reef.Driver.Bridge
-{
-    [DataContract]
-    public class HttpMessage : IHttpMessage
-    {
-        public HttpMessage(IHttpServerBridgeClr2Java httpServerBridgeClr2Java)
-        {
-            HttpServerBridgeClr2Java = httpServerBridgeClr2Java;
-        }
-
-        [DataMember]
-        private IHttpServerBridgeClr2Java HttpServerBridgeClr2Java { get; set; }
-
-        public string GetRequestString()
-        {
-            return HttpServerBridgeClr2Java.GetQueryString();
-        }
-
-        public void SetQueryResult(string responseString)
-        {
-            HttpServerBridgeClr2Java.SetQueryResult(responseString);
-        }
-
-        public byte[] GetQueryReuestData()
-        {
-            return HttpServerBridgeClr2Java.GetQueryRequestData();            
-        }
-
-        public void SetQueryResponseData(byte[] responseData)
-        {
-            HttpServerBridgeClr2Java.SetQueryResponseData(responseData);
-        }
-
-        public void SetUriSpecification(string uriSpecification)
-        {
-            HttpServerBridgeClr2Java.SetUriSpecification(uriSpecification);
-        }
-    }
-}

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/c1b5200f/lang/cs/Source/REEF/reef-common/ReefDriver/bridge/HttpServerHandler.cs
----------------------------------------------------------------------
diff --git a/lang/cs/Source/REEF/reef-common/ReefDriver/bridge/HttpServerHandler.cs b/lang/cs/Source/REEF/reef-common/ReefDriver/bridge/HttpServerHandler.cs
deleted file mode 100644
index 0609fb6..0000000
--- a/lang/cs/Source/REEF/reef-common/ReefDriver/bridge/HttpServerHandler.cs
+++ /dev/null
@@ -1,165 +0,0 @@
-/**
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- *   http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied.  See the License for the
- * specific language governing permissions and limitations
- * under the License.
- */
-
-using Org.Apache.Reef.Common.Avro;
-using Org.Apache.Reef.Driver.bridge;
-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.Tang.Annotations;
-
-namespace Org.Apache.Reef.Driver.Bridge
-{
-    /// <summary>
-    ///  HttpServerHandler, the handler for all CLR http events
-    /// </summary>
-    public class HttpServerHandler : IObserver<IHttpMessage>
-    {
-        private static readonly Logger LOGGER = Logger.GetLogger(typeof(HttpServerHandler));
-
-        private static readonly string SPEC = "SPEC";
-
-        private IDictionary<string, IHttpHandler> eventHandlers = new Dictionary<string, IHttpHandler>();
-
-        private HttpServerPort httpServerPort;
-
-        /// <summary>
-        /// Initializes a new instance of the <see cref="HttpServerHandler" /> class.
-        /// </summary>
-        /// <param name="httpEventHandlers">The HTTP event handlers.</param>
-        /// <param name="httpServerPort">The HTTP server port.</param>
-        [Inject]
-        public HttpServerHandler([Parameter(Value = typeof(DriverBridgeConfigurationOptions.HttpEventHandlers))] ISet<IHttpHandler> httpEventHandlers,
-                                 HttpServerPort httpServerPort)
-        {
-            LOGGER.Log(Level.Info, "Constructing HttpServerHandler");       
-            foreach (var h in httpEventHandlers)
-            {
-                string spec = h.GetSpecification();
-                if (spec.Contains(":"))
-                {
-                    Exceptions.Throw(new ArgumentException("spec cannot contain :"), "The http spec given is " + spec, LOGGER);
-                }
-                LOGGER.Log(Level.Info, "HttpHandler spec:" + spec);   
-                eventHandlers.Add(spec.ToLower(CultureInfo.CurrentCulture), h);
-            }
-            this.httpServerPort = httpServerPort;
-        }
-
-        /// <summary>
-        /// Called when receving an http request from Java side
-        /// </summary>
-        /// <param name="httpMessage">The HTTP message.</param>
-        public void OnNext(IHttpMessage httpMessage)
-        {
-            LOGGER.Log(Level.Info, "HttpHandler OnNext is called");
-            string requestString = httpMessage.GetRequestString();
-
-            if (requestString != null && requestString.Equals(SPEC))
-            {
-                LOGGER.Log(Level.Info, "HttpHandler OnNext, requestString:" + requestString);
-                LOGGER.Log(Level.Info, "HttpHandler OnNext, port number:" + httpServerPort.PortNumber);
-
-                httpMessage.SetUriSpecification(GetAllSpecifications());
-            }
-            else
-            {
-                LOGGER.Log(Level.Info, "HttpHandler OnNext, handling http request.");
-                byte[] byteData = httpMessage.GetQueryReuestData();                    
-                AvroHttpRequest avroHttpRequest = AvroHttpSerializer.FromBytes(byteData);
-                LOGGER.Log(Level.Info, "HttpHandler OnNext, requestData:" + avroHttpRequest);
-
-                string spec = GetSpecification(avroHttpRequest.PathInfo);
-                if (spec != null)
-                {
-                    LOGGER.Log(Level.Info, "HttpHandler OnNext, target:" + spec);
-                    ReefHttpRequest request = ToHttpRequest(avroHttpRequest);
-                    ReefHttpResponse response = new ReefHttpResponse();
-
-                    IHttpHandler handler;
-                    eventHandlers.TryGetValue(spec.ToLower(CultureInfo.CurrentCulture), out handler);
-
-                    byte[] responseData;
-                    if (handler != null)
-                    {
-                        LOGGER.Log(Level.Info, "HttpHandler OnNext, get eventHandler:" + handler.GetSpecification());
-                        handler.OnHttpRequest(request, response);
-                        responseData = response.OutputStream;
-                    }
-                    else
-                    {
-                        responseData =
-                            ByteUtilities.StringToByteArrays(string.Format(CultureInfo.CurrentCulture,
-                                                                           "No event handler found at CLR side for {0}.",
-                                                                           spec));
-                    }
-                    httpMessage.SetQueryResponseData(responseData);
-                }
-            }
-        }
-
-        public void OnCompleted()
-        {
-            throw new NotImplementedException();
-        }
-
-        public void OnError(Exception error)
-        {
-            throw new NotImplementedException();
-        }
-
-        private string GetAllSpecifications()
-        {
-            return string.Join(":", eventHandlers.Keys.ToArray());
-        }
-
-        private string GetSpecification(string requestUri)
-        {
-            if (requestUri != null)
-            {
-                string[] parts = requestUri.Split('/');
-
-                if (parts.Length > 1)
-                {
-                    return parts[1];
-                }
-            }
-            return null;            
-        }
-
-        private ReefHttpRequest ToHttpRequest(AvroHttpRequest avroRequest)
-        {
-            ReefHttpRequest httpRequest = new ReefHttpRequest();
-            httpRequest.PathInfo = avroRequest.PathInfo;
-            httpRequest.InputStream = avroRequest.InputStream;
-            httpRequest.Url = avroRequest.RequestUrl;
-            httpRequest.Querystring = avroRequest.QueryString;
-
-            HttpMethod m;
-            HttpMethod.TryParse(avroRequest.HttpMethod, true, out m);
-            httpRequest.Method = m;
-            return httpRequest;
-        }    
-    }
-}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/c1b5200f/lang/cs/Source/REEF/reef-common/ReefDriver/bridge/HttpServerPort.cs
----------------------------------------------------------------------
diff --git a/lang/cs/Source/REEF/reef-common/ReefDriver/bridge/HttpServerPort.cs b/lang/cs/Source/REEF/reef-common/ReefDriver/bridge/HttpServerPort.cs
deleted file mode 100644
index af001e2..0000000
--- a/lang/cs/Source/REEF/reef-common/ReefDriver/bridge/HttpServerPort.cs
+++ /dev/null
@@ -1,33 +0,0 @@
-/**
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- *   http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied.  See the License for the
- * specific language governing permissions and limitations
- * under the License.
- */
-
-using Org.Apache.Reef.Tang.Annotations;
-
-namespace Org.Apache.Reef.Driver.bridge
-{
-    public class HttpServerPort
-    {
-        [Inject]
-        public HttpServerPort()
-        {            
-        }
-
-        public int PortNumber { get; set; }
-    }
-}

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/c1b5200f/lang/cs/Source/REEF/reef-common/ReefDriver/bridge/IHttpHandler.cs
----------------------------------------------------------------------
diff --git a/lang/cs/Source/REEF/reef-common/ReefDriver/bridge/IHttpHandler.cs b/lang/cs/Source/REEF/reef-common/ReefDriver/bridge/IHttpHandler.cs
deleted file mode 100644
index 4bd5895..0000000
--- a/lang/cs/Source/REEF/reef-common/ReefDriver/bridge/IHttpHandler.cs
+++ /dev/null
@@ -1,39 +0,0 @@
-/**
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- *   http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied.  See the License for the
- * specific language governing permissions and limitations
- * under the License.
- */
-
-using Org.Apache.Reef.Driver.Bridge;
-
-namespace Org.Apache.Reef.Driver.Bridge
-{
-    public interface IHttpHandler
-    {
-        /// <summary>
-        /// Define the specification of the handler. ":" is not allowed in the specification.
-        /// </summary>
-        /// <returns>string specification</returns>
-        string GetSpecification();
-
-        /// <summary>
-        /// Called when Http request is sent
-        /// </summary>
-        /// <param name="requet">The requet.</param>
-        /// <param name="resonse">The resonse.</param>
-        void OnHttpRequest(ReefHttpRequest requet, ReefHttpResponse resonse);  
-    }
-}

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/c1b5200f/lang/cs/Source/REEF/reef-common/ReefDriver/bridge/IHttpMessage.cs
----------------------------------------------------------------------
diff --git a/lang/cs/Source/REEF/reef-common/ReefDriver/bridge/IHttpMessage.cs b/lang/cs/Source/REEF/reef-common/ReefDriver/bridge/IHttpMessage.cs
deleted file mode 100644
index 59e66a6..0000000
--- a/lang/cs/Source/REEF/reef-common/ReefDriver/bridge/IHttpMessage.cs
+++ /dev/null
@@ -1,33 +0,0 @@
-/**
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- *   http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied.  See the License for the
- * specific language governing permissions and limitations
- * under the License.
- */
-namespace Org.Apache.Reef.Driver.Bridge
-{
-    public interface IHttpMessage
-    {
-        string GetRequestString();
-        
-        void SetQueryResult(string responseString);
-
-        byte[] GetQueryReuestData();
-
-        void SetQueryResponseData(byte[] responseData);
-        
-        void SetUriSpecification(string uriSpecification);
-    }
-}

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/c1b5200f/lang/cs/Source/REEF/reef-common/ReefDriver/bridge/ReefHttpRequest.cs
----------------------------------------------------------------------
diff --git a/lang/cs/Source/REEF/reef-common/ReefDriver/bridge/ReefHttpRequest.cs b/lang/cs/Source/REEF/reef-common/ReefDriver/bridge/ReefHttpRequest.cs
deleted file mode 100644
index ccc9571..0000000
--- a/lang/cs/Source/REEF/reef-common/ReefDriver/bridge/ReefHttpRequest.cs
+++ /dev/null
@@ -1,49 +0,0 @@
-/**
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- *   http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied.  See the License for the
- * specific language governing permissions and limitations
- * under the License.
- */
-
-using System.Globalization;
-
-namespace Org.Apache.Reef.Driver.Bridge
-{
-    public enum HttpMethod
-    {
-        Post,
-        Put,
-        Get,
-        Delete
-    }
-
-    public class ReefHttpRequest
-    {
-        public HttpMethod Method { get; set; }
-
-        public string Url { get; set; }
-
-        public string Querystring { get; set; }
-
-        public byte[] InputStream { get; set; }
-
-        public string PathInfo { get; set; }
-
-        public string Tostring()
-        {
-            return string.Format(CultureInfo.InvariantCulture, "Url: {0}, query string {1}", Url, Querystring);
-        }
-    }
-}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/c1b5200f/lang/cs/Source/REEF/reef-common/ReefDriver/bridge/ReefHttpResponse.cs
----------------------------------------------------------------------
diff --git a/lang/cs/Source/REEF/reef-common/ReefDriver/bridge/ReefHttpResponse.cs b/lang/cs/Source/REEF/reef-common/ReefDriver/bridge/ReefHttpResponse.cs
deleted file mode 100644
index 4eb3e6f..0000000
--- a/lang/cs/Source/REEF/reef-common/ReefDriver/bridge/ReefHttpResponse.cs
+++ /dev/null
@@ -1,30 +0,0 @@
-/**
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- *   http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied.  See the License for the
- * specific language governing permissions and limitations
- * under the License.
- */
-
-using System.Net;
-
-namespace Org.Apache.Reef.Driver.Bridge
-{
-    public class ReefHttpResponse
-    {
-        public byte[] OutputStream { get; set; }
-
-        public HttpStatusCode Status { get; set; }
-    }
-}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/c1b5200f/lang/cs/Source/REEF/reef-common/ReefDriver/bridge/clr2java/IActiveContextClr2Java.cs
----------------------------------------------------------------------
diff --git a/lang/cs/Source/REEF/reef-common/ReefDriver/bridge/clr2java/IActiveContextClr2Java.cs b/lang/cs/Source/REEF/reef-common/ReefDriver/bridge/clr2java/IActiveContextClr2Java.cs
deleted file mode 100644
index a61d639..0000000
--- a/lang/cs/Source/REEF/reef-common/ReefDriver/bridge/clr2java/IActiveContextClr2Java.cs
+++ /dev/null
@@ -1,36 +0,0 @@
-/**
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- *   http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied.  See the License for the
- * specific language governing permissions and limitations
- * under the License.
- */
-
-using Org.Apache.Reef.Driver.Evaluator;
-
-namespace Org.Apache.Reef.Driver.Bridge
-{
-    public interface IActiveContextClr2Java : IClr2Java
-    {
-        void SubmitTask(string taskConfigStr);
-        
-        void Close();
-
-        string GetId();
-
-        string GetEvaluatorId();
-
-        IEvaluatorDescriptor GetEvaluatorDescriptor();
-    }
-}

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/c1b5200f/lang/cs/Source/REEF/reef-common/ReefDriver/bridge/clr2java/IAllocatedEvaluaotrClr2Java.cs
----------------------------------------------------------------------
diff --git a/lang/cs/Source/REEF/reef-common/ReefDriver/bridge/clr2java/IAllocatedEvaluaotrClr2Java.cs b/lang/cs/Source/REEF/reef-common/ReefDriver/bridge/clr2java/IAllocatedEvaluaotrClr2Java.cs
deleted file mode 100644
index 01f14e1..0000000
--- a/lang/cs/Source/REEF/reef-common/ReefDriver/bridge/clr2java/IAllocatedEvaluaotrClr2Java.cs
+++ /dev/null
@@ -1,42 +0,0 @@
-/**
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- *   http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied.  See the License for the
- * specific language governing permissions and limitations
- * under the License.
- */
-
-using Org.Apache.Reef.Driver.Evaluator;
-
-namespace Org.Apache.Reef.Driver.Bridge
-{
-    public interface IAllocatedEvaluaotrClr2Java : IClr2Java
-    {
-        void SubmitContextAndTask(string contextConfigStr, string taskConfigStr);
-
-        void SubmitContext(string contextConfigStr);
-
-        void SubmitContextAndService(string contextConfigStr, string serviceConfigStr);
-
-        void SubmitContextAndServiceAndTask(string contextConfigStr, string serviceConfigStr, string taskConfigStr);
-
-        void Close();
-
-        string GetId();
-
-        string GetNameServerInfo();
-
-        IEvaluatorDescriptor GetEvaluatorDescriptor();
-    }
-}

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/c1b5200f/lang/cs/Source/REEF/reef-common/ReefDriver/bridge/clr2java/IClosedContextClr2Java.cs
----------------------------------------------------------------------
diff --git a/lang/cs/Source/REEF/reef-common/ReefDriver/bridge/clr2java/IClosedContextClr2Java.cs b/lang/cs/Source/REEF/reef-common/ReefDriver/bridge/clr2java/IClosedContextClr2Java.cs
deleted file mode 100644
index ed45211..0000000
--- a/lang/cs/Source/REEF/reef-common/ReefDriver/bridge/clr2java/IClosedContextClr2Java.cs
+++ /dev/null
@@ -1,34 +0,0 @@
-/**
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- *   http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied.  See the License for the
- * specific language governing permissions and limitations
- * under the License.
- */
-
-using Org.Apache.Reef.Driver.Evaluator;
-
-namespace Org.Apache.Reef.Driver.Bridge
-{
-    public interface IClosedContextClr2Java : IClr2Java
-    {        
-        string GetId();
-
-        string GetEvaluatorId();
-
-        IEvaluatorDescriptor GetEvaluatorDescriptor();
-
-        IActiveContextClr2Java GetParentContext();
-    }
-}

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/c1b5200f/lang/cs/Source/REEF/reef-common/ReefDriver/bridge/clr2java/IClr2Java.cs
----------------------------------------------------------------------
diff --git a/lang/cs/Source/REEF/reef-common/ReefDriver/bridge/clr2java/IClr2Java.cs b/lang/cs/Source/REEF/reef-common/ReefDriver/bridge/clr2java/IClr2Java.cs
deleted file mode 100644
index 3f6c5c5..0000000
--- a/lang/cs/Source/REEF/reef-common/ReefDriver/bridge/clr2java/IClr2Java.cs
+++ /dev/null
@@ -1,26 +0,0 @@
-/**
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- *   http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied.  See the License for the
- * specific language governing permissions and limitations
- * under the License.
- */
-
-namespace Org.Apache.Reef.Driver.Bridge
-{
-    public interface IClr2Java
-    {
-        void OnError(string message);
-    }
-}

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/c1b5200f/lang/cs/Source/REEF/reef-common/ReefDriver/bridge/clr2java/ICompletedEvaluatorClr2Java.cs
----------------------------------------------------------------------
diff --git a/lang/cs/Source/REEF/reef-common/ReefDriver/bridge/clr2java/ICompletedEvaluatorClr2Java.cs b/lang/cs/Source/REEF/reef-common/ReefDriver/bridge/clr2java/ICompletedEvaluatorClr2Java.cs
deleted file mode 100644
index 3a27723..0000000
--- a/lang/cs/Source/REEF/reef-common/ReefDriver/bridge/clr2java/ICompletedEvaluatorClr2Java.cs
+++ /dev/null
@@ -1,30 +0,0 @@
-/**
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- *   http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied.  See the License for the
- * specific language governing permissions and limitations
- * under the License.
- */
-
-namespace Org.Apache.Reef.Driver.Bridge
-{
-    public interface ICompletedEvaluatorClr2Java : IClr2Java
-    {
-        /// <summary>
-        /// evaluator id
-        /// </summary>
-        /// <returns>id of the completed evaluator</returns>
-        string GetId();
-    }
-}

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/c1b5200f/lang/cs/Source/REEF/reef-common/ReefDriver/bridge/clr2java/ICompletedTaskClr2Java.cs
----------------------------------------------------------------------
diff --git a/lang/cs/Source/REEF/reef-common/ReefDriver/bridge/clr2java/ICompletedTaskClr2Java.cs b/lang/cs/Source/REEF/reef-common/ReefDriver/bridge/clr2java/ICompletedTaskClr2Java.cs
deleted file mode 100644
index a69789b..0000000
--- a/lang/cs/Source/REEF/reef-common/ReefDriver/bridge/clr2java/ICompletedTaskClr2Java.cs
+++ /dev/null
@@ -1,28 +0,0 @@
-/**
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- *   http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied.  See the License for the
- * specific language governing permissions and limitations
- * under the License.
- */
-
-namespace Org.Apache.Reef.Driver.Bridge
-{
-    public interface ICompletedTaskClr2Java : IClr2Java
-    {
-        IActiveContextClr2Java GetActiveContext();
-        
-        string GetId();
-    }
-}

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/c1b5200f/lang/cs/Source/REEF/reef-common/ReefDriver/bridge/clr2java/IContextMessageClr2Java.cs
----------------------------------------------------------------------
diff --git a/lang/cs/Source/REEF/reef-common/ReefDriver/bridge/clr2java/IContextMessageClr2Java.cs b/lang/cs/Source/REEF/reef-common/ReefDriver/bridge/clr2java/IContextMessageClr2Java.cs
deleted file mode 100644
index f50dca3..0000000
--- a/lang/cs/Source/REEF/reef-common/ReefDriver/bridge/clr2java/IContextMessageClr2Java.cs
+++ /dev/null
@@ -1,30 +0,0 @@
-/**
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- *   http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied.  See the License for the
- * specific language governing permissions and limitations
- * under the License.
- */
-
-namespace Org.Apache.Reef.Driver.Bridge
-{
-    public interface IContextMessageClr2Java : IClr2Java
-    {
-        byte[] Get();
-
-        string GetId();
-
-        string GetMessageSourceId();
-    }
-}

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/c1b5200f/lang/cs/Source/REEF/reef-common/ReefDriver/bridge/clr2java/IEvaluatorRequestorClr2Java.cs
----------------------------------------------------------------------
diff --git a/lang/cs/Source/REEF/reef-common/ReefDriver/bridge/clr2java/IEvaluatorRequestorClr2Java.cs b/lang/cs/Source/REEF/reef-common/ReefDriver/bridge/clr2java/IEvaluatorRequestorClr2Java.cs
deleted file mode 100644
index b1ee4d1..0000000
--- a/lang/cs/Source/REEF/reef-common/ReefDriver/bridge/clr2java/IEvaluatorRequestorClr2Java.cs
+++ /dev/null
@@ -1,28 +0,0 @@
-/**
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- *   http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied.  See the License for the
- * specific language governing permissions and limitations
- * under the License.
- */
-
-using Org.Apache.Reef.Driver.Evaluator;
-
-namespace Org.Apache.Reef.Driver.Bridge
-{
-    public interface IEvaluatorRequestorClr2Java : IClr2Java
-    {
-        void Submit(IEvaluatorRequest evaluatorRequest);
-    }
-}

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/c1b5200f/lang/cs/Source/REEF/reef-common/ReefDriver/bridge/clr2java/IFailedContextClr2Java.cs
----------------------------------------------------------------------
diff --git a/lang/cs/Source/REEF/reef-common/ReefDriver/bridge/clr2java/IFailedContextClr2Java.cs b/lang/cs/Source/REEF/reef-common/ReefDriver/bridge/clr2java/IFailedContextClr2Java.cs
deleted file mode 100644
index cd9a157..0000000
--- a/lang/cs/Source/REEF/reef-common/ReefDriver/bridge/clr2java/IFailedContextClr2Java.cs
+++ /dev/null
@@ -1,36 +0,0 @@
-/**
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- *   http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied.  See the License for the
- * specific language governing permissions and limitations
- * under the License.
- */
-
-using Org.Apache.Reef.Driver.Evaluator;
-
-namespace Org.Apache.Reef.Driver.Bridge
-{
-    public interface IFailedContextClr2Java : IClr2Java
-    {        
-        string GetId();
-
-        string GetEvaluatorId();
-
-        string GetParentId();
-
-        IEvaluatorDescriptor GetEvaluatorDescriptor();
-
-        IActiveContextClr2Java GetParentContext();
-    }
-}

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/c1b5200f/lang/cs/Source/REEF/reef-common/ReefDriver/bridge/clr2java/IFailedEvaluatorClr2Java.cs
----------------------------------------------------------------------
diff --git a/lang/cs/Source/REEF/reef-common/ReefDriver/bridge/clr2java/IFailedEvaluatorClr2Java.cs b/lang/cs/Source/REEF/reef-common/ReefDriver/bridge/clr2java/IFailedEvaluatorClr2Java.cs
deleted file mode 100644
index 33bb4a4..0000000
--- a/lang/cs/Source/REEF/reef-common/ReefDriver/bridge/clr2java/IFailedEvaluatorClr2Java.cs
+++ /dev/null
@@ -1,30 +0,0 @@
-/**
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- *   http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied.  See the License for the
- * specific language governing permissions and limitations
- * under the License.
- */
-
-using Org.Apache.Reef.Driver.Bridge;
-
-namespace Org.Apache.Reef.Driver
-{
-    public interface IFailedEvaluatorClr2Java
-    {
-        IEvaluatorRequestorClr2Java GetEvaluatorRequestor();
-
-        string GetId();
-    }
-}

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/c1b5200f/lang/cs/Source/REEF/reef-common/ReefDriver/bridge/clr2java/IFailedTaskClr2Java.cs
----------------------------------------------------------------------
diff --git a/lang/cs/Source/REEF/reef-common/ReefDriver/bridge/clr2java/IFailedTaskClr2Java.cs b/lang/cs/Source/REEF/reef-common/ReefDriver/bridge/clr2java/IFailedTaskClr2Java.cs
deleted file mode 100644
index 70dc34e..0000000
--- a/lang/cs/Source/REEF/reef-common/ReefDriver/bridge/clr2java/IFailedTaskClr2Java.cs
+++ /dev/null
@@ -1,28 +0,0 @@
-/**
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- *   http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied.  See the License for the
- * specific language governing permissions and limitations
- * under the License.
- */
-
-namespace Org.Apache.Reef.Driver.Bridge
-{
-    public interface IFailedTaskClr2Java : IClr2Java
-    {
-        IActiveContextClr2Java GetActiveContext();
-
-        string GetString();
-    }
-}

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/c1b5200f/lang/cs/Source/REEF/reef-common/ReefDriver/bridge/clr2java/IHttpServerBridgeClr2Java.cs
----------------------------------------------------------------------
diff --git a/lang/cs/Source/REEF/reef-common/ReefDriver/bridge/clr2java/IHttpServerBridgeClr2Java.cs b/lang/cs/Source/REEF/reef-common/ReefDriver/bridge/clr2java/IHttpServerBridgeClr2Java.cs
deleted file mode 100644
index c30e3b4..0000000
--- a/lang/cs/Source/REEF/reef-common/ReefDriver/bridge/clr2java/IHttpServerBridgeClr2Java.cs
+++ /dev/null
@@ -1,34 +0,0 @@
-/**
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- *   http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied.  See the License for the
- * specific language governing permissions and limitations
- * under the License.
- */
-
-namespace Org.Apache.Reef.Driver.Bridge
-{
-    public interface IHttpServerBridgeClr2Java : IClr2Java
-    {
-        string GetQueryString();
-
-        void SetQueryResult(string queryResult);
-
-        byte[] GetQueryRequestData();
-
-        void SetQueryResponseData(byte[] responseData);
-
-        void SetUriSpecification(string uriSpecification);
-    }
-}

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/c1b5200f/lang/cs/Source/REEF/reef-common/ReefDriver/bridge/clr2java/IRunningTaskClr2Java.cs
----------------------------------------------------------------------
diff --git a/lang/cs/Source/REEF/reef-common/ReefDriver/bridge/clr2java/IRunningTaskClr2Java.cs b/lang/cs/Source/REEF/reef-common/ReefDriver/bridge/clr2java/IRunningTaskClr2Java.cs
deleted file mode 100644
index eb95c31..0000000
--- a/lang/cs/Source/REEF/reef-common/ReefDriver/bridge/clr2java/IRunningTaskClr2Java.cs
+++ /dev/null
@@ -1,30 +0,0 @@
-/**
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- *   http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied.  See the License for the
- * specific language governing permissions and limitations
- * under the License.
- */
-
-namespace Org.Apache.Reef.Driver.Bridge
-{
-    public interface IRunningTaskClr2Java : IClr2Java
-    {
-        IActiveContextClr2Java GetActiveContext();
-
-        string GetId();
-
-        void Send(byte[] message);
-    }
-}

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/c1b5200f/lang/cs/Source/REEF/reef-common/ReefDriver/bridge/clr2java/ISuspendedTaskClr2Java.cs
----------------------------------------------------------------------
diff --git a/lang/cs/Source/REEF/reef-common/ReefDriver/bridge/clr2java/ISuspendedTaskClr2Java.cs b/lang/cs/Source/REEF/reef-common/ReefDriver/bridge/clr2java/ISuspendedTaskClr2Java.cs
deleted file mode 100644
index be04fd3..0000000
--- a/lang/cs/Source/REEF/reef-common/ReefDriver/bridge/clr2java/ISuspendedTaskClr2Java.cs
+++ /dev/null
@@ -1,42 +0,0 @@
-/**
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- *   http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied.  See the License for the
- * specific language governing permissions and limitations
- * under the License.
- */
-
-namespace Org.Apache.Reef.Driver.Bridge
-{
-    public interface ISuspendedTaskClr2Java : IClr2Java
-    {
-        /// <summary>
-        /// get active context the task is running in
-        /// </summary>
-        /// <returns>active context</returns>
-        IActiveContextClr2Java GetActiveContext();
-
-        /// <summary>
-        /// get suspsended task id
-        /// </summary>
-        /// <returns>suspsended task id</returns>
-        string GetId();
-
-        /// <summary>
-        /// get the message
-        /// </summary>
-        /// <returns>suspended task message</returns>
-        byte[] Get();
-    }
-}

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/c1b5200f/lang/cs/Source/REEF/reef-common/ReefDriver/bridge/clr2java/ITaskMessageClr2Java.cs
----------------------------------------------------------------------
diff --git a/lang/cs/Source/REEF/reef-common/ReefDriver/bridge/clr2java/ITaskMessageClr2Java.cs b/lang/cs/Source/REEF/reef-common/ReefDriver/bridge/clr2java/ITaskMessageClr2Java.cs
deleted file mode 100644
index c364587..0000000
--- a/lang/cs/Source/REEF/reef-common/ReefDriver/bridge/clr2java/ITaskMessageClr2Java.cs
+++ /dev/null
@@ -1,26 +0,0 @@
-/**
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- *   http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied.  See the License for the
- * specific language governing permissions and limitations
- * under the License.
- */
-
-namespace Org.Apache.Reef.Driver.Bridge
-{
-    public interface ITaskMessageClr2Java : IClr2Java
-    {
-        string GetId();
-    }
-}