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

[12/19] incubator-reef git commit: [REEF-136] Harmonize namespaces and folder names in Org.Apache.REEF projects

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/7edb8570/lang/cs/Org.Apache.REEF.Common/events/IContextStop.cs
----------------------------------------------------------------------
diff --git a/lang/cs/Org.Apache.REEF.Common/events/IContextStop.cs b/lang/cs/Org.Apache.REEF.Common/events/IContextStop.cs
deleted file mode 100644
index bdc5a73..0000000
--- a/lang/cs/Org.Apache.REEF.Common/events/IContextStop.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.Common.Events
-{
-    public interface IContextStop
-    {
-        string Id { get; set; }
-    }
-}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/7edb8570/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
deleted file mode 100644
index 33248ae..0000000
--- a/lang/cs/Org.Apache.REEF.Common/exceptions/EvaluatorException.cs
+++ /dev/null
@@ -1,75 +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.Task;
-using Org.Apache.REEF.Utilities;
-using System;
-
-namespace Org.Apache.REEF.Common.Exceptions
-{
-    public class EvaluatorException : System.Exception, IIdentifiable
-    {
-        private readonly string _evaluatorId;
-
-        public EvaluatorException(string evaluatorId)
-        {
-            _evaluatorId = evaluatorId;
-            RunningTask = null;
-        }
-
-        public EvaluatorException(string evaluatorId, string message, System.Exception cause)
-            : base(message, cause)
-        {
-            _evaluatorId = evaluatorId;
-            RunningTask = null;
-        }
-
-        public EvaluatorException(string evaluatorId, string message)
-            : this(evaluatorId, message, (IRunningTask)null)
-        {
-        }
-
-        public EvaluatorException(string evaluatorId, string message, IRunningTask runningTask)
-            : base(message)
-        {
-            _evaluatorId = evaluatorId;
-            RunningTask = runningTask;
-        }
-
-        public EvaluatorException(string evaluatorId, System.Exception cause)
-            : this(evaluatorId, cause, null)
-        {
-        }
-
-        public EvaluatorException(string evaluatorId, Exception cause, IRunningTask runningTask)
-            : base(string.Empty, cause)
-        {
-            _evaluatorId = evaluatorId;
-            RunningTask = runningTask;
-        }
-
-        public IRunningTask RunningTask { get; set; }
-
-        public string Id
-        {
-            get { return _evaluatorId; }
-            set { }
-        }
-    }
-}

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/7edb8570/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
deleted file mode 100644
index 0cceecc..0000000
--- a/lang/cs/Org.Apache.REEF.Common/exceptions/JobException.cs
+++ /dev/null
@@ -1,58 +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.Utilities;
-using System;
-
-namespace Org.Apache.REEF.Common
-{
-    public class JobException : Exception, IIdentifiable
-    {
-        private string _jobId;
-
-        public JobException(string jobId)
-        {
-            _jobId = jobId;
-        }
-
-        public JobException(string jobId, string message, Exception cause) 
-            : base(message, cause)
-        {
-            _jobId = jobId;
-        }
-
-        public JobException(string jobId, string message)
-            : base(message)
-        {
-            _jobId = jobId;
-        }
-
-        public JobException(string jobId, Exception cause)
-            : base(string.Empty, cause)
-        {
-            _jobId = jobId;
-        }
-
-        public string Id
-        {
-            get { return _jobId; }
-            set { }
-        }
-    }
-}

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/7edb8570/lang/cs/Org.Apache.REEF.Common/io/INameClient.cs
----------------------------------------------------------------------
diff --git a/lang/cs/Org.Apache.REEF.Common/io/INameClient.cs b/lang/cs/Org.Apache.REEF.Common/io/INameClient.cs
deleted file mode 100644
index 941d023..0000000
--- a/lang/cs/Org.Apache.REEF.Common/io/INameClient.cs
+++ /dev/null
@@ -1,71 +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;
-using System.Collections.Generic;
-using System.Net;
-
-namespace Org.Apache.REEF.Common.io
-{
-    /// <summary>
-    /// Client for the Reef name service. 
-    /// Used to register, unregister, and lookup IP Addresses of known hosts.
-    /// </summary>
-    public interface INameClient : IDisposable
-    {
-        /// <summary>
-        /// Registers the identifier with the NameService.  
-        /// Overwrites the previous mapping if the identifier has already 
-        /// been registered.
-        /// </summary>
-        /// <param name="id">The key used to map the remote endpoint</param>
-        /// <param name="endpoint">The endpoint to map</param>
-        void Register(string id, IPEndPoint endpoint);
-
-        /// <summary>
-        /// Unregisters the remote identifier with the NameService
-        /// </summary>
-        /// <param name="id">The identifier to unregister</param>
-        void Unregister(string id);
-
-        /// <summary>
-        /// Looks up the IPEndpoint for the registered identifier.
-        /// </summary>
-        /// <param name="id">The identifier to look up</param>
-        /// <returns>The mapped IPEndpoint for the identifier, or null if
-        /// the identifier has not been registered with the NameService</returns>
-        IPEndPoint Lookup(string id);
-
-        /// <summary>
-        /// Looks up the IPEndpoint for each of the registered identifiers in the list.
-        /// </summary>
-        /// <param name="ids">The list of identifiers to look up</param>
-        /// <returns>The list of NameAssignments representing a pair of identifer
-        /// and mapped IPEndpoint for that identifier.  If any of the requested identifiers
-        /// are not registered with the NameService, their corresponding NameAssignment
-        /// IPEndpoint value will be null.</returns>
-        List<NameAssignment> Lookup(List<string> ids);
-
-        /// <summary>
-        /// Restart the name client in case of failure.
-        /// </summary>
-        /// <param name="serverEndpoint">The new server endpoint to connect to</param>
-        void Restart(IPEndPoint serverEndpoint);
-    }
-}

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/7edb8570/lang/cs/Org.Apache.REEF.Common/io/NameAssignment.cs
----------------------------------------------------------------------
diff --git a/lang/cs/Org.Apache.REEF.Common/io/NameAssignment.cs b/lang/cs/Org.Apache.REEF.Common/io/NameAssignment.cs
deleted file mode 100644
index 8751244..0000000
--- a/lang/cs/Org.Apache.REEF.Common/io/NameAssignment.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.Net;
-using System.Net.Sockets;
-
-namespace Org.Apache.REEF.Common.io
-{
-    /// <summary>
-    /// Tuple containing the string identifier and IPEndpoint.
-    /// Used by NameServer and NameClient
-    /// </summary>
-    public class NameAssignment
-    {
-        public NameAssignment(string id, IPEndPoint endpoint)
-        {
-            Identifier = id;
-            Endpoint = endpoint;
-        }
-
-        public NameAssignment(string id, string address, int port)
-        {
-            Identifier = id;
-            IPAddress ipAddress;
-            if (!IPAddress.TryParse(address, out ipAddress))
-            {
-                IPHostEntry hostEntry = Dns.GetHostEntry(address);
-                foreach (var ip in hostEntry.AddressList)
-                {
-                    if (ip.AddressFamily == AddressFamily.InterNetwork)
-                    {
-                        ipAddress = ip;
-                        break;
-                    }
-                }
-            }
-            Endpoint = new IPEndPoint(ipAddress, port);
-        }
-
-        public string Identifier { get; set; }
-
-        public IPEndPoint Endpoint { get; set; }
-    }
-}

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/7edb8570/lang/cs/Org.Apache.REEF.Common/io/NamingConfiguration.cs
----------------------------------------------------------------------
diff --git a/lang/cs/Org.Apache.REEF.Common/io/NamingConfiguration.cs b/lang/cs/Org.Apache.REEF.Common/io/NamingConfiguration.cs
deleted file mode 100644
index 9a73267..0000000
--- a/lang/cs/Org.Apache.REEF.Common/io/NamingConfiguration.cs
+++ /dev/null
@@ -1,45 +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.Diagnostics.CodeAnalysis;
-using Org.Apache.REEF.Tang.Formats;
-using Org.Apache.REEF.Tang.Util;
-
-namespace Org.Apache.REEF.Common.io
-{
-    public class NamingConfiguration : ConfigurationModuleBuilder
-    {
-        [SuppressMessage("Microsoft.Security", "CA2104:Do not declare read only mutable reference types", Justification = "not applicable")]
-        public static readonly RequiredParameter<string> NameServerAddress = new RequiredParameter<string>();
-
-        [SuppressMessage("Microsoft.Security", "CA2104:Do not declare read only mutable reference types", Justification = "not applicable")]
-        public static readonly RequiredParameter<int> NameServerPort = new RequiredParameter<int>();
-
-        public static ConfigurationModule ConfigurationModule
-        {
-            get
-            {
-                return new NamingConfiguration()
-                    .BindNamedParameter(GenericType<NamingConfigurationOptions.NameServerAddress>.Class, NameServerAddress)
-                    .BindNamedParameter(GenericType<NamingConfigurationOptions.NameServerPort>.Class, NameServerPort)
-                    .Build();
-            }
-        }
-    }
-}

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/7edb8570/lang/cs/Org.Apache.REEF.Common/io/NamingConfigurationOptions.cs
----------------------------------------------------------------------
diff --git a/lang/cs/Org.Apache.REEF.Common/io/NamingConfigurationOptions.cs b/lang/cs/Org.Apache.REEF.Common/io/NamingConfigurationOptions.cs
deleted file mode 100644
index e1096cd..0000000
--- a/lang/cs/Org.Apache.REEF.Common/io/NamingConfigurationOptions.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.Tang.Annotations;
-
-namespace Org.Apache.REEF.Common.io
-{
-    public class NamingConfigurationOptions
-    {
-        [NamedParameter("IP address of NameServer")]
-        public class NameServerAddress : Name<string>
-        {
-        }
-
-        [NamedParameter("Port of NameServer")]
-        public class NameServerPort : Name<int>
-        {
-        }
-    }
-}

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/7edb8570/lang/cs/Org.Apache.REEF.Common/protobuf/cs/ClientRuntime.pb.cs
----------------------------------------------------------------------
diff --git a/lang/cs/Org.Apache.REEF.Common/protobuf/cs/ClientRuntime.pb.cs b/lang/cs/Org.Apache.REEF.Common/protobuf/cs/ClientRuntime.pb.cs
deleted file mode 100644
index 970dcc3..0000000
--- a/lang/cs/Org.Apache.REEF.Common/protobuf/cs/ClientRuntime.pb.cs
+++ /dev/null
@@ -1,147 +0,0 @@
-//------------------------------------------------------------------------------
-// <auto-generated>
-//     This code was generated by a tool.
-//
-//     Changes to this file may cause incorrect behavior and will be lost if
-//     the code is regenerated.
-// </auto-generated>
-//------------------------------------------------------------------------------
-
-// Generated from: client_runtime.proto
-// Note: requires additional types generated from: reef_service_protos.proto
-
-using Org.Apache.REEF.Common.ProtoBuf.ReefServiceProto;
-
-namespace Org.Apache.REEF.Common.ProtoBuf.ClienRuntimeProto{
-  [global::System.Serializable, global::ProtoBuf.ProtoContract(Name=@"JobSubmissionProto")]
-  public partial class JobSubmissionProto : global::ProtoBuf.IExtensible
-  {
-    public JobSubmissionProto() {}
-    
-    private string _identifier;
-    [global::ProtoBuf.ProtoMember(1, IsRequired = true, Name=@"identifier", DataFormat = global::ProtoBuf.DataFormat.Default)]
-    public string identifier
-    {
-      get { return _identifier; }
-      set { _identifier = value; }
-    }
-    private string _remote_id;
-    [global::ProtoBuf.ProtoMember(2, IsRequired = true, Name=@"remote_id", DataFormat = global::ProtoBuf.DataFormat.Default)]
-    public string remote_id
-    {
-      get { return _remote_id; }
-      set { _remote_id = value; }
-    }
-    private string _configuration;
-    [global::ProtoBuf.ProtoMember(5, IsRequired = true, Name=@"configuration", DataFormat = global::ProtoBuf.DataFormat.Default)]
-    public string configuration
-    {
-      get { return _configuration; }
-      set { _configuration = value; }
-    }
-    private string _user_name;
-    [global::ProtoBuf.ProtoMember(6, IsRequired = true, Name=@"user_name", DataFormat = global::ProtoBuf.DataFormat.Default)]
-    public string user_name
-    {
-      get { return _user_name; }
-      set { _user_name = value; }
-    }
-    private SIZE _driver_size = SIZE.SMALL;
-    [global::ProtoBuf.ProtoMember(7, IsRequired = false, Name=@"driver_size", DataFormat = global::ProtoBuf.DataFormat.TwosComplement)]
-    [global::System.ComponentModel.DefaultValue(SIZE.SMALL)]
-    public SIZE driver_size
-    {
-      get { return _driver_size; }
-      set { _driver_size = value; }
-    }
-    private int _driver_memory = default(int);
-    [global::ProtoBuf.ProtoMember(8, IsRequired = false, Name=@"driver_memory", DataFormat = global::ProtoBuf.DataFormat.TwosComplement)]
-    [global::System.ComponentModel.DefaultValue(default(int))]
-    public int driver_memory
-    {
-      get { return _driver_memory; }
-      set { _driver_memory = value; }
-    }
-    private int _priority = default(int);
-    [global::ProtoBuf.ProtoMember(9, IsRequired = false, Name=@"priority", DataFormat = global::ProtoBuf.DataFormat.TwosComplement)]
-    [global::System.ComponentModel.DefaultValue(default(int))]
-    public int priority
-    {
-      get { return _priority; }
-      set { _priority = value; }
-    }
-    private string _queue = "";
-    [global::ProtoBuf.ProtoMember(10, IsRequired = false, Name=@"queue", DataFormat = global::ProtoBuf.DataFormat.Default)]
-    [global::System.ComponentModel.DefaultValue("")]
-    public string queue
-    {
-      get { return _queue; }
-      set { _queue = value; }
-    }
-    private readonly global::System.Collections.Generic.List<FileResourceProto> _global_file = new global::System.Collections.Generic.List<FileResourceProto>();
-    [global::ProtoBuf.ProtoMember(11, Name=@"global_file", DataFormat = global::ProtoBuf.DataFormat.Default)]
-    public global::System.Collections.Generic.List<FileResourceProto> global_file
-    {
-      get { return _global_file; }
-    }
-  
-    private readonly global::System.Collections.Generic.List<FileResourceProto> _local_File = new global::System.Collections.Generic.List<FileResourceProto>();
-    [global::ProtoBuf.ProtoMember(12, Name=@"local_File", DataFormat = global::ProtoBuf.DataFormat.Default)]
-    public global::System.Collections.Generic.List<FileResourceProto> local_File
-    {
-      get { return _local_File; }
-    }
-  
-    private global::ProtoBuf.IExtension extensionObject;
-    global::ProtoBuf.IExtension global::ProtoBuf.IExtensible.GetExtensionObject(bool createIfMissing)
-      { return global::ProtoBuf.Extensible.GetExtensionObject(ref extensionObject, createIfMissing); }
-  }
-  
-  [global::System.Serializable, global::ProtoBuf.ProtoContract(Name=@"JobControlProto")]
-  public partial class JobControlProto : global::ProtoBuf.IExtensible
-  {
-    public JobControlProto() {}
-    
-    private string _identifier;
-    [global::ProtoBuf.ProtoMember(1, IsRequired = true, Name=@"identifier", DataFormat = global::ProtoBuf.DataFormat.Default)]
-    public string identifier
-    {
-      get { return _identifier; }
-      set { _identifier = value; }
-    }
-    private Signal _signal = Signal.SIG_TERMINATE;
-    [global::ProtoBuf.ProtoMember(2, IsRequired = false, Name=@"signal", DataFormat = global::ProtoBuf.DataFormat.TwosComplement)]
-    [global::System.ComponentModel.DefaultValue(Signal.SIG_TERMINATE)]
-    public Signal signal
-    {
-      get { return _signal; }
-      set { _signal = value; }
-    }
-    private byte[] _message = null;
-    [global::ProtoBuf.ProtoMember(3, IsRequired = false, Name=@"message", DataFormat = global::ProtoBuf.DataFormat.Default)]
-    [global::System.ComponentModel.DefaultValue(null)]
-    public byte[] message
-    {
-      get { return _message; }
-      set { _message = value; }
-    }
-    private global::ProtoBuf.IExtension extensionObject;
-    global::ProtoBuf.IExtension global::ProtoBuf.IExtensible.GetExtensionObject(bool createIfMissing)
-      { return global::ProtoBuf.Extensible.GetExtensionObject(ref extensionObject, createIfMissing); }
-  }
-  
-    [global::ProtoBuf.ProtoContract(Name=@"Signal")]
-    public enum Signal
-    {
-            
-      [global::ProtoBuf.ProtoEnum(Name=@"SIG_TERMINATE", Value=1)]
-      SIG_TERMINATE = 1,
-            
-      [global::ProtoBuf.ProtoEnum(Name=@"SIG_SUSPEND", Value=2)]
-      SIG_SUSPEND = 2,
-            
-      [global::ProtoBuf.ProtoEnum(Name=@"SIG_RESUME", Value=3)]
-      SIG_RESUME = 3
-    }
-  
-}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/7edb8570/lang/cs/Org.Apache.REEF.Common/protobuf/cs/DriverRuntime.pb.cs
----------------------------------------------------------------------
diff --git a/lang/cs/Org.Apache.REEF.Common/protobuf/cs/DriverRuntime.pb.cs b/lang/cs/Org.Apache.REEF.Common/protobuf/cs/DriverRuntime.pb.cs
deleted file mode 100644
index 6a12cf1..0000000
--- a/lang/cs/Org.Apache.REEF.Common/protobuf/cs/DriverRuntime.pb.cs
+++ /dev/null
@@ -1,339 +0,0 @@
-//------------------------------------------------------------------------------
-// <auto-generated>
-//     This code was generated by a tool.
-//
-//     Changes to this file may cause incorrect behavior and will be lost if
-//     the code is regenerated.
-// </auto-generated>
-//------------------------------------------------------------------------------
-
-// Generated from: driver_runtime.proto
-// Note: requires additional types generated from: reef_service_protos.proto
-
-using Org.Apache.REEF.Common.ProtoBuf.ReefServiceProto;
-
-namespace Org.Apache.REEF.Common.ProtoBuf.DriverRuntimeProto
-{
-  [global::System.Serializable, global::ProtoBuf.ProtoContract(Name=@"DriverProcessRegistrationProto")]
-  public partial class DriverProcessRegistrationProto : global::ProtoBuf.IExtensible
-  {
-    public DriverProcessRegistrationProto() {}
-    
-    private string _remote_identifier;
-    [global::ProtoBuf.ProtoMember(1, IsRequired = true, Name=@"remote_identifier", DataFormat = global::ProtoBuf.DataFormat.Default)]
-    public string remote_identifier
-    {
-      get { return _remote_identifier; }
-      set { _remote_identifier = value; }
-    }
-    private global::ProtoBuf.IExtension extensionObject;
-    global::ProtoBuf.IExtension global::ProtoBuf.IExtensible.GetExtensionObject(bool createIfMissing)
-      { return global::ProtoBuf.Extensible.GetExtensionObject(ref extensionObject, createIfMissing); }
-  }
-  
-  [global::System.Serializable, global::ProtoBuf.ProtoContract(Name=@"NodeDescriptorProto")]
-  public partial class NodeDescriptorProto : global::ProtoBuf.IExtensible
-  {
-    public NodeDescriptorProto() {}
-    
-    private string _identifier;
-    [global::ProtoBuf.ProtoMember(1, IsRequired = true, Name=@"identifier", DataFormat = global::ProtoBuf.DataFormat.Default)]
-    public string identifier
-    {
-      get { return _identifier; }
-      set { _identifier = value; }
-    }
-    private string _host_name;
-    [global::ProtoBuf.ProtoMember(2, IsRequired = true, Name=@"host_name", DataFormat = global::ProtoBuf.DataFormat.Default)]
-    public string host_name
-    {
-      get { return _host_name; }
-      set { _host_name = value; }
-    }
-    private int _port;
-    [global::ProtoBuf.ProtoMember(3, IsRequired = true, Name=@"port", DataFormat = global::ProtoBuf.DataFormat.TwosComplement)]
-    public int port
-    {
-      get { return _port; }
-      set { _port = value; }
-    }
-    private int _memory_size;
-    [global::ProtoBuf.ProtoMember(4, IsRequired = true, Name=@"memory_size", DataFormat = global::ProtoBuf.DataFormat.TwosComplement)]
-    public int memory_size
-    {
-      get { return _memory_size; }
-      set { _memory_size = value; }
-    }
-    private string _rack_name = "";
-    [global::ProtoBuf.ProtoMember(5, IsRequired = false, Name=@"rack_name", DataFormat = global::ProtoBuf.DataFormat.Default)]
-    [global::System.ComponentModel.DefaultValue("")]
-    public string rack_name
-    {
-      get { return _rack_name; }
-      set { _rack_name = value; }
-    }
-    private global::ProtoBuf.IExtension extensionObject;
-    global::ProtoBuf.IExtension global::ProtoBuf.IExtensible.GetExtensionObject(bool createIfMissing)
-      { return global::ProtoBuf.Extensible.GetExtensionObject(ref extensionObject, createIfMissing); }
-  }
-  
-  [global::System.Serializable, global::ProtoBuf.ProtoContract(Name=@"ResourceAllocationProto")]
-  public partial class ResourceAllocationProto : global::ProtoBuf.IExtensible
-  {
-    public ResourceAllocationProto() {}
-    
-    private string _identifier;
-    [global::ProtoBuf.ProtoMember(1, IsRequired = true, Name=@"identifier", DataFormat = global::ProtoBuf.DataFormat.Default)]
-    public string identifier
-    {
-      get { return _identifier; }
-      set { _identifier = value; }
-    }
-    private int _resource_memory;
-    [global::ProtoBuf.ProtoMember(2, IsRequired = true, Name=@"resource_memory", DataFormat = global::ProtoBuf.DataFormat.TwosComplement)]
-    public int resource_memory
-    {
-      get { return _resource_memory; }
-      set { _resource_memory = value; }
-    }
-    private string _node_id;
-    [global::ProtoBuf.ProtoMember(3, IsRequired = true, Name=@"node_id", DataFormat = global::ProtoBuf.DataFormat.Default)]
-    public string node_id
-    {
-      get { return _node_id; }
-      set { _node_id = value; }
-    }
-    private int _virtual_cores = default(int);
-    [global::ProtoBuf.ProtoMember(4, IsRequired = false, Name=@"virtual_cores", DataFormat = global::ProtoBuf.DataFormat.TwosComplement)]
-    [global::System.ComponentModel.DefaultValue(default(int))]
-    public int virtual_cores
-    {
-      get { return _virtual_cores; }
-      set { _virtual_cores = value; }
-    }
-    private global::ProtoBuf.IExtension extensionObject;
-    global::ProtoBuf.IExtension global::ProtoBuf.IExtensible.GetExtensionObject(bool createIfMissing)
-      { return global::ProtoBuf.Extensible.GetExtensionObject(ref extensionObject, createIfMissing); }
-  }
-  
-  [global::System.Serializable, global::ProtoBuf.ProtoContract(Name=@"ResourceStatusProto")]
-  public partial class ResourceStatusProto : global::ProtoBuf.IExtensible
-  {
-    public ResourceStatusProto() {}
-    
-    private string _identifier;
-    [global::ProtoBuf.ProtoMember(1, IsRequired = true, Name=@"identifier", DataFormat = global::ProtoBuf.DataFormat.Default)]
-    public string identifier
-    {
-      get { return _identifier; }
-      set { _identifier = value; }
-    }
-    private State _state;
-    [global::ProtoBuf.ProtoMember(2, IsRequired = true, Name=@"state", DataFormat = global::ProtoBuf.DataFormat.TwosComplement)]
-    public State state
-    {
-      get { return _state; }
-      set { _state = value; }
-    }
-    private string _diagnostics = "";
-    [global::ProtoBuf.ProtoMember(3, IsRequired = false, Name=@"diagnostics", DataFormat = global::ProtoBuf.DataFormat.Default)]
-    [global::System.ComponentModel.DefaultValue("")]
-    public string diagnostics
-    {
-      get { return _diagnostics; }
-      set { _diagnostics = value; }
-    }
-    private int _exit_code = default(int);
-    [global::ProtoBuf.ProtoMember(4, IsRequired = false, Name=@"exit_code", DataFormat = global::ProtoBuf.DataFormat.TwosComplement)]
-    [global::System.ComponentModel.DefaultValue(default(int))]
-    public int exit_code
-    {
-      get { return _exit_code; }
-      set { _exit_code = value; }
-    }
-    private bool _is_from_previous_driver = default(bool);
-    [global::ProtoBuf.ProtoMember(5, IsRequired = false, Name=@"is_from_previous_driver", DataFormat = global::ProtoBuf.DataFormat.Default)]
-    [global::System.ComponentModel.DefaultValue(default(bool))]
-    public bool is_from_previous_driver
-    {
-      get { return _is_from_previous_driver; }
-      set { _is_from_previous_driver = value; }
-    }
-    private global::ProtoBuf.IExtension extensionObject;
-    global::ProtoBuf.IExtension global::ProtoBuf.IExtensible.GetExtensionObject(bool createIfMissing)
-      { return global::ProtoBuf.Extensible.GetExtensionObject(ref extensionObject, createIfMissing); }
-  }
-  
-  [global::System.Serializable, global::ProtoBuf.ProtoContract(Name=@"RuntimeStatusProto")]
-  public partial class RuntimeStatusProto : global::ProtoBuf.IExtensible
-  {
-    public RuntimeStatusProto() {}
-    
-    private string _name;
-    [global::ProtoBuf.ProtoMember(1, IsRequired = true, Name=@"name", DataFormat = global::ProtoBuf.DataFormat.Default)]
-    public string name
-    {
-      get { return _name; }
-      set { _name = value; }
-    }
-    private State _state;
-    [global::ProtoBuf.ProtoMember(2, IsRequired = true, Name=@"state", DataFormat = global::ProtoBuf.DataFormat.TwosComplement)]
-    public State state
-    {
-      get { return _state; }
-      set { _state = value; }
-    }
-    private RuntimeErrorProto _error = null;
-    [global::ProtoBuf.ProtoMember(3, IsRequired = false, Name=@"error", DataFormat = global::ProtoBuf.DataFormat.Default)]
-    [global::System.ComponentModel.DefaultValue(null)]
-    public RuntimeErrorProto error
-    {
-      get { return _error; }
-      set { _error = value; }
-    }
-    private int _outstanding_container_requests = default(int);
-    [global::ProtoBuf.ProtoMember(5, IsRequired = false, Name=@"outstanding_container_requests", DataFormat = global::ProtoBuf.DataFormat.TwosComplement)]
-    [global::System.ComponentModel.DefaultValue(default(int))]
-    public int outstanding_container_requests
-    {
-      get { return _outstanding_container_requests; }
-      set { _outstanding_container_requests = value; }
-    }
-    private readonly global::System.Collections.Generic.List<string> _container_allocation = new global::System.Collections.Generic.List<string>();
-    [global::ProtoBuf.ProtoMember(6, Name=@"container_allocation", DataFormat = global::ProtoBuf.DataFormat.Default)]
-    public global::System.Collections.Generic.List<string> container_allocation
-    {
-      get { return _container_allocation; }
-    }
-  
-    private global::ProtoBuf.IExtension extensionObject;
-    global::ProtoBuf.IExtension global::ProtoBuf.IExtensible.GetExtensionObject(bool createIfMissing)
-      { return global::ProtoBuf.Extensible.GetExtensionObject(ref extensionObject, createIfMissing); }
-  }
-  
-  [global::System.Serializable, global::ProtoBuf.ProtoContract(Name=@"ResourceRequestProto")]
-  public partial class ResourceRequestProto : global::ProtoBuf.IExtensible
-  {
-    public ResourceRequestProto() {}
-    
-    private int _memory_size = default(int);
-    [global::ProtoBuf.ProtoMember(2, IsRequired = false, Name=@"memory_size", DataFormat = global::ProtoBuf.DataFormat.TwosComplement)]
-    [global::System.ComponentModel.DefaultValue(default(int))]
-    public int memory_size
-    {
-      get { return _memory_size; }
-      set { _memory_size = value; }
-    }
-    private int _priority = default(int);
-    [global::ProtoBuf.ProtoMember(3, IsRequired = false, Name=@"priority", DataFormat = global::ProtoBuf.DataFormat.TwosComplement)]
-    [global::System.ComponentModel.DefaultValue(default(int))]
-    public int priority
-    {
-      get { return _priority; }
-      set { _priority = value; }
-    }
-    private int _virtual_cores = default(int);
-    [global::ProtoBuf.ProtoMember(4, IsRequired = false, Name=@"virtual_cores", DataFormat = global::ProtoBuf.DataFormat.TwosComplement)]
-    [global::System.ComponentModel.DefaultValue(default(int))]
-    public int virtual_cores
-    {
-      get { return _virtual_cores; }
-      set { _virtual_cores = value; }
-    }
-    private int _resource_count;
-    [global::ProtoBuf.ProtoMember(5, IsRequired = true, Name=@"resource_count", DataFormat = global::ProtoBuf.DataFormat.TwosComplement)]
-    public int resource_count
-    {
-      get { return _resource_count; }
-      set { _resource_count = value; }
-    }
-    private readonly global::System.Collections.Generic.List<string> _node_name = new global::System.Collections.Generic.List<string>();
-    [global::ProtoBuf.ProtoMember(6, Name=@"node_name", DataFormat = global::ProtoBuf.DataFormat.Default)]
-    public global::System.Collections.Generic.List<string> node_name
-    {
-      get { return _node_name; }
-    }
-  
-    private readonly global::System.Collections.Generic.List<string> _rack_name = new global::System.Collections.Generic.List<string>();
-    [global::ProtoBuf.ProtoMember(7, Name=@"rack_name", DataFormat = global::ProtoBuf.DataFormat.Default)]
-    public global::System.Collections.Generic.List<string> rack_name
-    {
-      get { return _rack_name; }
-    }
-  
-    private bool _relax_locality = default(bool);
-    [global::ProtoBuf.ProtoMember(10, IsRequired = false, Name=@"relax_locality", DataFormat = global::ProtoBuf.DataFormat.Default)]
-    [global::System.ComponentModel.DefaultValue(default(bool))]
-    public bool relax_locality
-    {
-      get { return _relax_locality; }
-      set { _relax_locality = value; }
-    }
-    private global::ProtoBuf.IExtension extensionObject;
-    global::ProtoBuf.IExtension global::ProtoBuf.IExtensible.GetExtensionObject(bool createIfMissing)
-      { return global::ProtoBuf.Extensible.GetExtensionObject(ref extensionObject, createIfMissing); }
-  }
-  
-  [global::System.Serializable, global::ProtoBuf.ProtoContract(Name=@"ResourceReleaseProto")]
-  public partial class ResourceReleaseProto : global::ProtoBuf.IExtensible
-  {
-    public ResourceReleaseProto() {}
-    
-    private string _identifier;
-    [global::ProtoBuf.ProtoMember(1, IsRequired = true, Name=@"identifier", DataFormat = global::ProtoBuf.DataFormat.Default)]
-    public string identifier
-    {
-      get { return _identifier; }
-      set { _identifier = value; }
-    }
-    private global::ProtoBuf.IExtension extensionObject;
-    global::ProtoBuf.IExtension global::ProtoBuf.IExtensible.GetExtensionObject(bool createIfMissing)
-      { return global::ProtoBuf.Extensible.GetExtensionObject(ref extensionObject, createIfMissing); }
-  }
-  
-  [global::System.Serializable, global::ProtoBuf.ProtoContract(Name=@"ResourceLaunchProto")]
-  public partial class ResourceLaunchProto : global::ProtoBuf.IExtensible
-  {
-    public ResourceLaunchProto() {}
-    
-    private string _identifier;
-    [global::ProtoBuf.ProtoMember(1, IsRequired = true, Name=@"identifier", DataFormat = global::ProtoBuf.DataFormat.Default)]
-    public string identifier
-    {
-      get { return _identifier; }
-      set { _identifier = value; }
-    }
-    private string _remote_id;
-    [global::ProtoBuf.ProtoMember(2, IsRequired = true, Name=@"remote_id", DataFormat = global::ProtoBuf.DataFormat.Default)]
-    public string remote_id
-    {
-      get { return _remote_id; }
-      set { _remote_id = value; }
-    }
-    private string _evaluator_conf;
-    [global::ProtoBuf.ProtoMember(3, IsRequired = true, Name=@"evaluator_conf", DataFormat = global::ProtoBuf.DataFormat.Default)]
-    public string evaluator_conf
-    {
-      get { return _evaluator_conf; }
-      set { _evaluator_conf = value; }
-    }
-    private ProcessType _type;
-    [global::ProtoBuf.ProtoMember(4, IsRequired = true, Name=@"type", DataFormat = global::ProtoBuf.DataFormat.TwosComplement)]
-    public ProcessType type
-    {
-      get { return _type; }
-      set { _type = value; }
-    }
-    private readonly global::System.Collections.Generic.List<FileResourceProto> _file = new global::System.Collections.Generic.List<FileResourceProto>();
-    [global::ProtoBuf.ProtoMember(10, Name=@"file", DataFormat = global::ProtoBuf.DataFormat.Default)]
-    public global::System.Collections.Generic.List<FileResourceProto> file
-    {
-      get { return _file; }
-    }
-  
-    private global::ProtoBuf.IExtension extensionObject;
-    global::ProtoBuf.IExtension global::ProtoBuf.IExtensible.GetExtensionObject(bool createIfMissing)
-      { return global::ProtoBuf.Extensible.GetExtensionObject(ref extensionObject, createIfMissing); }
-  }
-  
-}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/7edb8570/lang/cs/Org.Apache.REEF.Common/protobuf/cs/EvaluatorRunTime.pb.cs
----------------------------------------------------------------------
diff --git a/lang/cs/Org.Apache.REEF.Common/protobuf/cs/EvaluatorRunTime.pb.cs b/lang/cs/Org.Apache.REEF.Common/protobuf/cs/EvaluatorRunTime.pb.cs
deleted file mode 100644
index 2e7ae9d..0000000
--- a/lang/cs/Org.Apache.REEF.Common/protobuf/cs/EvaluatorRunTime.pb.cs
+++ /dev/null
@@ -1,305 +0,0 @@
-//------------------------------------------------------------------------------
-// <auto-generated>
-//     This code was generated by a tool.
-//
-//     Changes to this file may cause incorrect behavior and will be lost if
-//     the code is regenerated.
-// </auto-generated>
-//------------------------------------------------------------------------------
-
-using Org.Apache.REEF.Common.ProtoBuf.ReefServiceProto;
-// Generated from: evaluator_runtime.proto
-// Note: requires additional types generated from: reef_service_protos.proto
-namespace Org.Apache.REEF.Common.ProtoBuf.EvaluatorRunTimeProto
-{
-  [global::System.Serializable, global::ProtoBuf.ProtoContract(Name=@"StopEvaluatorProto")]
-  public partial class StopEvaluatorProto : global::ProtoBuf.IExtensible
-  {
-    public StopEvaluatorProto() {}
-    
-    private global::ProtoBuf.IExtension extensionObject;
-    global::ProtoBuf.IExtension global::ProtoBuf.IExtensible.GetExtensionObject(bool createIfMissing)
-      { return global::ProtoBuf.Extensible.GetExtensionObject(ref extensionObject, createIfMissing); }
-  }
-  
-  [global::System.Serializable, global::ProtoBuf.ProtoContract(Name=@"KillEvaluatorProto")]
-  public partial class KillEvaluatorProto : global::ProtoBuf.IExtensible
-  {
-    public KillEvaluatorProto() {}
-    
-    private global::ProtoBuf.IExtension extensionObject;
-    global::ProtoBuf.IExtension global::ProtoBuf.IExtensible.GetExtensionObject(bool createIfMissing)
-      { return global::ProtoBuf.Extensible.GetExtensionObject(ref extensionObject, createIfMissing); }
-  }
-  
-  [global::System.Serializable, global::ProtoBuf.ProtoContract(Name=@"StartTaskProto")]
-  public partial class StartTaskProto : global::ProtoBuf.IExtensible
-  {
-    public StartTaskProto() {}
-    
-    private string _context_id;
-    [global::ProtoBuf.ProtoMember(1, IsRequired = true, Name=@"context_id", DataFormat = global::ProtoBuf.DataFormat.Default)]
-    public string context_id
-    {
-      get { return _context_id; }
-      set { _context_id = value; }
-    }
-    private string _configuration;
-    [global::ProtoBuf.ProtoMember(2, IsRequired = true, Name=@"configuration", DataFormat = global::ProtoBuf.DataFormat.Default)]
-    public string configuration
-    {
-      get { return _configuration; }
-      set { _configuration = value; }
-    }
-    private global::ProtoBuf.IExtension extensionObject;
-    global::ProtoBuf.IExtension global::ProtoBuf.IExtensible.GetExtensionObject(bool createIfMissing)
-      { return global::ProtoBuf.Extensible.GetExtensionObject(ref extensionObject, createIfMissing); }
-  }
-  
-  [global::System.Serializable, global::ProtoBuf.ProtoContract(Name=@"AddContextProto")]
-  public partial class AddContextProto : global::ProtoBuf.IExtensible
-  {
-    public AddContextProto() {}
-    
-    private string _parent_context_id;
-    [global::ProtoBuf.ProtoMember(1, IsRequired = true, Name=@"parent_context_id", DataFormat = global::ProtoBuf.DataFormat.Default)]
-    public string parent_context_id
-    {
-      get { return _parent_context_id; }
-      set { _parent_context_id = value; }
-    }
-    private string _context_configuration;
-    [global::ProtoBuf.ProtoMember(2, IsRequired = true, Name=@"context_configuration", DataFormat = global::ProtoBuf.DataFormat.Default)]
-    public string context_configuration
-    {
-      get { return _context_configuration; }
-      set { _context_configuration = value; }
-    }
-    private string _service_configuration = "";
-    [global::ProtoBuf.ProtoMember(3, IsRequired = false, Name=@"service_configuration", DataFormat = global::ProtoBuf.DataFormat.Default)]
-    [global::System.ComponentModel.DefaultValue("")]
-    public string service_configuration
-    {
-      get { return _service_configuration; }
-      set { _service_configuration = value; }
-    }
-    private global::ProtoBuf.IExtension extensionObject;
-    global::ProtoBuf.IExtension global::ProtoBuf.IExtensible.GetExtensionObject(bool createIfMissing)
-      { return global::ProtoBuf.Extensible.GetExtensionObject(ref extensionObject, createIfMissing); }
-  }
-  
-  [global::System.Serializable, global::ProtoBuf.ProtoContract(Name=@"RemoveContextProto")]
-  public partial class RemoveContextProto : global::ProtoBuf.IExtensible
-  {
-    public RemoveContextProto() {}
-    
-    private string _context_id;
-    [global::ProtoBuf.ProtoMember(1, IsRequired = true, Name=@"context_id", DataFormat = global::ProtoBuf.DataFormat.Default)]
-    public string context_id
-    {
-      get { return _context_id; }
-      set { _context_id = value; }
-    }
-    private global::ProtoBuf.IExtension extensionObject;
-    global::ProtoBuf.IExtension global::ProtoBuf.IExtensible.GetExtensionObject(bool createIfMissing)
-      { return global::ProtoBuf.Extensible.GetExtensionObject(ref extensionObject, createIfMissing); }
-  }
-  
-  [global::System.Serializable, global::ProtoBuf.ProtoContract(Name=@"StopTaskProto")]
-  public partial class StopTaskProto : global::ProtoBuf.IExtensible
-  {
-    public StopTaskProto() {}
-    
-    private global::ProtoBuf.IExtension extensionObject;
-    global::ProtoBuf.IExtension global::ProtoBuf.IExtensible.GetExtensionObject(bool createIfMissing)
-      { return global::ProtoBuf.Extensible.GetExtensionObject(ref extensionObject, createIfMissing); }
-  }
-  
-  [global::System.Serializable, global::ProtoBuf.ProtoContract(Name=@"SuspendTaskProto")]
-  public partial class SuspendTaskProto : global::ProtoBuf.IExtensible
-  {
-    public SuspendTaskProto() {}
-    
-    private global::ProtoBuf.IExtension extensionObject;
-    global::ProtoBuf.IExtension global::ProtoBuf.IExtensible.GetExtensionObject(bool createIfMissing)
-      { return global::ProtoBuf.Extensible.GetExtensionObject(ref extensionObject, createIfMissing); }
-  }
-  
-  [global::System.Serializable, global::ProtoBuf.ProtoContract(Name=@"ContextMessageProto")]
-  public partial class ContextMessageProto : global::ProtoBuf.IExtensible
-  {
-    public ContextMessageProto() {}
-    
-    private string _context_id;
-    [global::ProtoBuf.ProtoMember(1, IsRequired = true, Name=@"context_id", DataFormat = global::ProtoBuf.DataFormat.Default)]
-    public string context_id
-    {
-      get { return _context_id; }
-      set { _context_id = value; }
-    }
-    private byte[] _message;
-    [global::ProtoBuf.ProtoMember(2, IsRequired = true, Name=@"message", DataFormat = global::ProtoBuf.DataFormat.Default)]
-    public byte[] message
-    {
-      get { return _message; }
-      set { _message = value; }
-    }
-    private global::ProtoBuf.IExtension extensionObject;
-    global::ProtoBuf.IExtension global::ProtoBuf.IExtensible.GetExtensionObject(bool createIfMissing)
-      { return global::ProtoBuf.Extensible.GetExtensionObject(ref extensionObject, createIfMissing); }
-  }
-  
-  [global::System.Serializable, global::ProtoBuf.ProtoContract(Name=@"ContextControlProto")]
-  public partial class ContextControlProto : global::ProtoBuf.IExtensible
-  {
-    public ContextControlProto() {}
-    
-    private byte[] _task_message = null;
-    [global::ProtoBuf.ProtoMember(1, IsRequired = false, Name=@"task_message", DataFormat = global::ProtoBuf.DataFormat.Default)]
-    [global::System.ComponentModel.DefaultValue(null)]
-    public byte[] task_message
-    {
-      get { return _task_message; }
-      set { _task_message = value; }
-    }
-    private ContextMessageProto _context_message = null;
-    [global::ProtoBuf.ProtoMember(2, IsRequired = false, Name=@"context_message", DataFormat = global::ProtoBuf.DataFormat.Default)]
-    [global::System.ComponentModel.DefaultValue(null)]
-    public ContextMessageProto context_message
-    {
-      get { return _context_message; }
-      set { _context_message = value; }
-    }
-    private AddContextProto _add_context = null;
-    [global::ProtoBuf.ProtoMember(5, IsRequired = false, Name=@"add_context", DataFormat = global::ProtoBuf.DataFormat.Default)]
-    [global::System.ComponentModel.DefaultValue(null)]
-    public AddContextProto add_context
-    {
-      get { return _add_context; }
-      set { _add_context = value; }
-    }
-    private RemoveContextProto _remove_context = null;
-    [global::ProtoBuf.ProtoMember(6, IsRequired = false, Name=@"remove_context", DataFormat = global::ProtoBuf.DataFormat.Default)]
-    [global::System.ComponentModel.DefaultValue(null)]
-    public RemoveContextProto remove_context
-    {
-      get { return _remove_context; }
-      set { _remove_context = value; }
-    }
-    private StartTaskProto _start_task = null;
-    [global::ProtoBuf.ProtoMember(7, IsRequired = false, Name=@"start_task", DataFormat = global::ProtoBuf.DataFormat.Default)]
-    [global::System.ComponentModel.DefaultValue(null)]
-    public StartTaskProto start_task
-    {
-      get { return _start_task; }
-      set { _start_task = value; }
-    }
-    private StopTaskProto _stop_task = null;
-    [global::ProtoBuf.ProtoMember(8, IsRequired = false, Name=@"stop_task", DataFormat = global::ProtoBuf.DataFormat.Default)]
-    [global::System.ComponentModel.DefaultValue(null)]
-    public StopTaskProto stop_task
-    {
-      get { return _stop_task; }
-      set { _stop_task = value; }
-    }
-    private SuspendTaskProto _suspend_task = null;
-    [global::ProtoBuf.ProtoMember(9, IsRequired = false, Name=@"suspend_task", DataFormat = global::ProtoBuf.DataFormat.Default)]
-    [global::System.ComponentModel.DefaultValue(null)]
-    public SuspendTaskProto suspend_task
-    {
-      get { return _suspend_task; }
-      set { _suspend_task = value; }
-    }
-    private global::ProtoBuf.IExtension extensionObject;
-    global::ProtoBuf.IExtension global::ProtoBuf.IExtensible.GetExtensionObject(bool createIfMissing)
-      { return global::ProtoBuf.Extensible.GetExtensionObject(ref extensionObject, createIfMissing); }
-  }
-  
-  [global::System.Serializable, global::ProtoBuf.ProtoContract(Name=@"EvaluatorHeartbeatProto")]
-  public partial class EvaluatorHeartbeatProto : global::ProtoBuf.IExtensible
-  {
-    public EvaluatorHeartbeatProto() {}
-    
-    private long _timestamp;
-    [global::ProtoBuf.ProtoMember(1, IsRequired = true, Name=@"timestamp", DataFormat = global::ProtoBuf.DataFormat.TwosComplement)]
-    public long timestamp
-    {
-      get { return _timestamp; }
-      set { _timestamp = value; }
-    }
-    private EvaluatorStatusProto _evaluator_status;
-    [global::ProtoBuf.ProtoMember(2, IsRequired = true, Name=@"evaluator_status", DataFormat = global::ProtoBuf.DataFormat.Default)]
-    public EvaluatorStatusProto evaluator_status
-    {
-      get { return _evaluator_status; }
-      set { _evaluator_status = value; }
-    }
-    private readonly global::System.Collections.Generic.List<ContextStatusProto> _context_status = new global::System.Collections.Generic.List<ContextStatusProto>();
-    [global::ProtoBuf.ProtoMember(3, Name=@"context_status", DataFormat = global::ProtoBuf.DataFormat.Default)]
-    public global::System.Collections.Generic.List<ContextStatusProto> context_status
-    {
-      get { return _context_status; }
-    }
-  
-    private TaskStatusProto _task_status = null;
-    [global::ProtoBuf.ProtoMember(4, IsRequired = false, Name=@"task_status", DataFormat = global::ProtoBuf.DataFormat.Default)]
-    [global::System.ComponentModel.DefaultValue(null)]
-    public TaskStatusProto task_status
-    {
-      get { return _task_status; }
-      set { _task_status = value; }
-    }
-    private global::ProtoBuf.IExtension extensionObject;
-    global::ProtoBuf.IExtension global::ProtoBuf.IExtensible.GetExtensionObject(bool createIfMissing)
-      { return global::ProtoBuf.Extensible.GetExtensionObject(ref extensionObject, createIfMissing); }
-
-    private bool _recovery;
-    [global::ProtoBuf.ProtoMember(5, IsRequired = false, Name = @"recovery", DataFormat = global::ProtoBuf.DataFormat.Default)]
-    public bool recovery
-    {
-        get { return _recovery; }
-        set { _recovery = value; }
-    }
-  }
-  
-  [global::System.Serializable, global::ProtoBuf.ProtoContract(Name=@"EvaluatorControlProto")]
-  public partial class EvaluatorControlProto : global::ProtoBuf.IExtensible
-  {
-    public EvaluatorControlProto() {}
-    
-    private long _timestamp;
-    [global::ProtoBuf.ProtoMember(1, IsRequired = true, Name=@"timestamp", DataFormat = global::ProtoBuf.DataFormat.TwosComplement)]
-    public long timestamp
-    {
-      get { return _timestamp; }
-      set { _timestamp = value; }
-    }
-    private string _identifier;
-    [global::ProtoBuf.ProtoMember(2, IsRequired = true, Name=@"identifier", DataFormat = global::ProtoBuf.DataFormat.Default)]
-    public string identifier
-    {
-      get { return _identifier; }
-      set { _identifier = value; }
-    }
-    private ContextControlProto _context_control = null;
-    [global::ProtoBuf.ProtoMember(3, IsRequired = false, Name=@"context_control", DataFormat = global::ProtoBuf.DataFormat.Default)]
-    [global::System.ComponentModel.DefaultValue(null)]
-    public ContextControlProto context_control
-    {
-      get { return _context_control; }
-      set { _context_control = value; }
-    }
-    private KillEvaluatorProto _kill_evaluator = null;
-    [global::ProtoBuf.ProtoMember(4, IsRequired = false, Name=@"kill_evaluator", DataFormat = global::ProtoBuf.DataFormat.Default)]
-    [global::System.ComponentModel.DefaultValue(null)]
-    public KillEvaluatorProto kill_evaluator
-    {
-      get { return _kill_evaluator; }
-      set { _kill_evaluator = value; }
-    }
-    private global::ProtoBuf.IExtension extensionObject;
-    global::ProtoBuf.IExtension global::ProtoBuf.IExtensible.GetExtensionObject(bool createIfMissing)
-      { return global::ProtoBuf.Extensible.GetExtensionObject(ref extensionObject, createIfMissing); }
-  }
-  
-}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/7edb8570/lang/cs/Org.Apache.REEF.Common/protobuf/cs/ReefProtocol.pb.cs
----------------------------------------------------------------------
diff --git a/lang/cs/Org.Apache.REEF.Common/protobuf/cs/ReefProtocol.pb.cs b/lang/cs/Org.Apache.REEF.Common/protobuf/cs/ReefProtocol.pb.cs
deleted file mode 100644
index 1ade6de..0000000
--- a/lang/cs/Org.Apache.REEF.Common/protobuf/cs/ReefProtocol.pb.cs
+++ /dev/null
@@ -1,78 +0,0 @@
-//------------------------------------------------------------------------------
-// <auto-generated>
-//     This code was generated by a tool.
-//
-//     Changes to this file may cause incorrect behavior and will be lost if
-//     the code is regenerated.
-// </auto-generated>
-//------------------------------------------------------------------------------
-
-// Generated from: reef_protocol.proto
-// Note: requires additional types generated from: client_runtime.proto
-// Note: requires additional types generated from: evaluator_runtime.proto
-// Note: requires additional types generated from: reef_service_protos.proto
-using Org.Apache.REEF.Common.ProtoBuf.ClienRuntimeProto;
-using Org.Apache.REEF.Common.ProtoBuf.EvaluatorRunTimeProto;
-using Org.Apache.REEF.Common.ProtoBuf.ReefServiceProto;
-
-namespace Org.Apache.REEF.Common.ProtoBuf.ReefProtocol
-{
-  [global::System.Serializable, global::ProtoBuf.ProtoContract(Name=@"REEFMessage")]
-  public partial class REEFMessage : global::ProtoBuf.IExtensible
-  {
-    public REEFMessage() {}
-    
-    private JobSubmissionProto _jobSubmission = null;
-    [global::ProtoBuf.ProtoMember(1, IsRequired = false, Name=@"jobSubmission", DataFormat = global::ProtoBuf.DataFormat.Default)]
-    [global::System.ComponentModel.DefaultValue(null)]
-    public JobSubmissionProto jobSubmission
-    {
-      get { return _jobSubmission; }
-      set { _jobSubmission = value; }
-    }
-    private JobControlProto _jobControl = null;
-    [global::ProtoBuf.ProtoMember(2, IsRequired = false, Name=@"jobControl", DataFormat = global::ProtoBuf.DataFormat.Default)]
-    [global::System.ComponentModel.DefaultValue(null)]
-    public JobControlProto jobControl
-    {
-      get { return _jobControl; }
-      set { _jobControl = value; }
-    }
-    private RuntimeErrorProto _runtimeError = null;
-    [global::ProtoBuf.ProtoMember(3, IsRequired = false, Name=@"runtimeError", DataFormat = global::ProtoBuf.DataFormat.Default)]
-    [global::System.ComponentModel.DefaultValue(null)]
-    public RuntimeErrorProto runtimeError
-    {
-      get { return _runtimeError; }
-      set { _runtimeError = value; }
-    }
-    private JobStatusProto _jobStatus = null;
-    [global::ProtoBuf.ProtoMember(4, IsRequired = false, Name=@"jobStatus", DataFormat = global::ProtoBuf.DataFormat.Default)]
-    [global::System.ComponentModel.DefaultValue(null)]
-    public JobStatusProto jobStatus
-    {
-      get { return _jobStatus; }
-      set { _jobStatus = value; }
-    }
-    private EvaluatorControlProto _evaluatorControl = null;
-    [global::ProtoBuf.ProtoMember(5, IsRequired = false, Name=@"evaluatorControl", DataFormat = global::ProtoBuf.DataFormat.Default)]
-    [global::System.ComponentModel.DefaultValue(null)]
-    public EvaluatorControlProto evaluatorControl
-    {
-      get { return _evaluatorControl; }
-      set { _evaluatorControl = value; }
-    }
-    private EvaluatorHeartbeatProto _evaluatorHeartBeat = null;
-    [global::ProtoBuf.ProtoMember(6, IsRequired = false, Name=@"evaluatorHeartBeat", DataFormat = global::ProtoBuf.DataFormat.Default)]
-    [global::System.ComponentModel.DefaultValue(null)]
-    public EvaluatorHeartbeatProto evaluatorHeartBeat
-    {
-      get { return _evaluatorHeartBeat; }
-      set { _evaluatorHeartBeat = value; }
-    }
-    private global::ProtoBuf.IExtension extensionObject;
-    global::ProtoBuf.IExtension global::ProtoBuf.IExtensible.GetExtensionObject(bool createIfMissing)
-      { return global::ProtoBuf.Extensible.GetExtensionObject(ref extensionObject, createIfMissing); }
-  }
-  
-}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/7edb8570/lang/cs/Org.Apache.REEF.Common/protobuf/cs/ReefService.pb.cs
----------------------------------------------------------------------
diff --git a/lang/cs/Org.Apache.REEF.Common/protobuf/cs/ReefService.pb.cs b/lang/cs/Org.Apache.REEF.Common/protobuf/cs/ReefService.pb.cs
deleted file mode 100644
index 383467e..0000000
--- a/lang/cs/Org.Apache.REEF.Common/protobuf/cs/ReefService.pb.cs
+++ /dev/null
@@ -1,393 +0,0 @@
-//------------------------------------------------------------------------------
-// <auto-generated>
-//     This code was generated by a tool.
-//
-//     Changes to this file may cause incorrect behavior and will be lost if
-//     the code is regenerated.
-// </auto-generated>
-//------------------------------------------------------------------------------
-
-// Generated from: reef_service_protos.proto
-namespace Org.Apache.REEF.Common.ProtoBuf.ReefServiceProto
-
-{
-  [global::System.Serializable, global::ProtoBuf.ProtoContract(Name=@"FileResourceProto")]
-  public partial class FileResourceProto : global::ProtoBuf.IExtensible
-  {
-    public FileResourceProto() {}
-    
-    private FileType _type;
-    [global::ProtoBuf.ProtoMember(1, IsRequired = true, Name=@"type", DataFormat = global::ProtoBuf.DataFormat.TwosComplement)]
-    public FileType type
-    {
-      get { return _type; }
-      set { _type = value; }
-    }
-    private string _name;
-    [global::ProtoBuf.ProtoMember(2, IsRequired = true, Name=@"name", DataFormat = global::ProtoBuf.DataFormat.Default)]
-    public string name
-    {
-      get { return _name; }
-      set { _name = value; }
-    }
-    private string _path;
-    [global::ProtoBuf.ProtoMember(3, IsRequired = true, Name=@"path", DataFormat = global::ProtoBuf.DataFormat.Default)]
-    public string path
-    {
-      get { return _path; }
-      set { _path = value; }
-    }
-    private global::ProtoBuf.IExtension extensionObject;
-    global::ProtoBuf.IExtension global::ProtoBuf.IExtensible.GetExtensionObject(bool createIfMissing)
-      { return global::ProtoBuf.Extensible.GetExtensionObject(ref extensionObject, createIfMissing); }
-  }
-  
-  [global::System.Serializable, global::ProtoBuf.ProtoContract(Name=@"RuntimeErrorProto")]
-  public partial class RuntimeErrorProto : global::ProtoBuf.IExtensible
-  {
-    public RuntimeErrorProto() {}
-    
-    private string _name;
-    [global::ProtoBuf.ProtoMember(1, IsRequired = true, Name=@"name", DataFormat = global::ProtoBuf.DataFormat.Default)]
-    public string name
-    {
-      get { return _name; }
-      set { _name = value; }
-    }
-    private string _message;
-    [global::ProtoBuf.ProtoMember(2, IsRequired = true, Name=@"message", DataFormat = global::ProtoBuf.DataFormat.Default)]
-    public string message
-    {
-      get { return _message; }
-      set { _message = value; }
-    }
-    private byte[] _exception = null;
-    [global::ProtoBuf.ProtoMember(3, IsRequired = false, Name=@"exception", DataFormat = global::ProtoBuf.DataFormat.Default)]
-    [global::System.ComponentModel.DefaultValue(null)]
-    public byte[] exception
-    {
-      get { return _exception; }
-      set { _exception = value; }
-    }
-    private string _identifier = "";
-    [global::ProtoBuf.ProtoMember(5, IsRequired = false, Name=@"identifier", DataFormat = global::ProtoBuf.DataFormat.Default)]
-    [global::System.ComponentModel.DefaultValue("")]
-    public string identifier
-    {
-      get { return _identifier; }
-      set { _identifier = value; }
-    }
-    private global::ProtoBuf.IExtension extensionObject;
-    global::ProtoBuf.IExtension global::ProtoBuf.IExtensible.GetExtensionObject(bool createIfMissing)
-      { return global::ProtoBuf.Extensible.GetExtensionObject(ref extensionObject, createIfMissing); }
-  }
-  
-  [global::System.Serializable, global::ProtoBuf.ProtoContract(Name=@"JobStatusProto")]
-  public partial class JobStatusProto : global::ProtoBuf.IExtensible
-  {
-    public JobStatusProto() {}
-    
-    private string _identifier;
-    [global::ProtoBuf.ProtoMember(1, IsRequired = true, Name=@"identifier", DataFormat = global::ProtoBuf.DataFormat.Default)]
-    public string identifier
-    {
-      get { return _identifier; }
-      set { _identifier = value; }
-    }
-    private State _state;
-    [global::ProtoBuf.ProtoMember(2, IsRequired = true, Name=@"state", DataFormat = global::ProtoBuf.DataFormat.TwosComplement)]
-    public State state
-    {
-      get { return _state; }
-      set { _state = value; }
-    }
-    private byte[] _message = null;
-    [global::ProtoBuf.ProtoMember(3, IsRequired = false, Name=@"message", DataFormat = global::ProtoBuf.DataFormat.Default)]
-    [global::System.ComponentModel.DefaultValue(null)]
-    public byte[] message
-    {
-      get { return _message; }
-      set { _message = value; }
-    }
-    private byte[] _exception = null;
-    [global::ProtoBuf.ProtoMember(4, IsRequired = false, Name=@"exception", DataFormat = global::ProtoBuf.DataFormat.Default)]
-    [global::System.ComponentModel.DefaultValue(null)]
-    public byte[] exception
-    {
-      get { return _exception; }
-      set { _exception = value; }
-    }
-    private global::ProtoBuf.IExtension extensionObject;
-    global::ProtoBuf.IExtension global::ProtoBuf.IExtensible.GetExtensionObject(bool createIfMissing)
-      { return global::ProtoBuf.Extensible.GetExtensionObject(ref extensionObject, createIfMissing); }
-  }
-  
-  [global::System.Serializable, global::ProtoBuf.ProtoContract(Name=@"ContextStatusProto")]
-  public partial class ContextStatusProto : global::ProtoBuf.IExtensible
-  {
-    public ContextStatusProto() {}
-    
-    private ContextStatusProto.State _context_state;
-    [global::ProtoBuf.ProtoMember(1, IsRequired = true, Name=@"context_state", DataFormat = global::ProtoBuf.DataFormat.TwosComplement)]
-    public ContextStatusProto.State context_state
-    {
-      get { return _context_state; }
-      set { _context_state = value; }
-    }
-    private string _context_id;
-    [global::ProtoBuf.ProtoMember(2, IsRequired = true, Name=@"context_id", DataFormat = global::ProtoBuf.DataFormat.Default)]
-    public string context_id
-    {
-      get { return _context_id; }
-      set { _context_id = value; }
-    }
-    private string _parent_id = "";
-    [global::ProtoBuf.ProtoMember(3, IsRequired = false, Name=@"parent_id", DataFormat = global::ProtoBuf.DataFormat.Default)]
-    [global::System.ComponentModel.DefaultValue("")]
-    public string parent_id
-    {
-      get { return _parent_id; }
-      set { _parent_id = value; }
-    }
-    private byte[] _error = null;
-    [global::ProtoBuf.ProtoMember(5, IsRequired = false, Name=@"error", DataFormat = global::ProtoBuf.DataFormat.Default)]
-    [global::System.ComponentModel.DefaultValue(null)]
-    public byte[] error
-    {
-      get { return _error; }
-      set { _error = value; }
-    }
-    private bool _recovery = false;
-    [global::ProtoBuf.ProtoMember(6, IsRequired = false, Name = @"recovery", DataFormat = global::ProtoBuf.DataFormat.Default)]
-    [global::System.ComponentModel.DefaultValue(false)]
-    public bool recovery
-    {
-        get { return _recovery; }
-        set { _recovery = value; }
-    }
-    private readonly global::System.Collections.Generic.List<ContextStatusProto.ContextMessageProto> _context_message = new global::System.Collections.Generic.List<ContextStatusProto.ContextMessageProto>();
-    [global::ProtoBuf.ProtoMember(7, Name=@"context_message", DataFormat = global::ProtoBuf.DataFormat.Default)]
-    public global::System.Collections.Generic.List<ContextStatusProto.ContextMessageProto> context_message
-    {
-      get { return _context_message; }
-    }
-  
-  [global::System.Serializable, global::ProtoBuf.ProtoContract(Name=@"ContextMessageProto")]
-  public partial class ContextMessageProto : global::ProtoBuf.IExtensible
-  {
-    public ContextMessageProto() {}
-    
-    private string _source_id;
-    [global::ProtoBuf.ProtoMember(1, IsRequired = true, Name=@"source_id", DataFormat = global::ProtoBuf.DataFormat.Default)]
-    public string source_id
-    {
-      get { return _source_id; }
-      set { _source_id = value; }
-    }
-    private byte[] _message;
-    [global::ProtoBuf.ProtoMember(2, IsRequired = true, Name=@"message", DataFormat = global::ProtoBuf.DataFormat.Default)]
-    public byte[] message
-    {
-      get { return _message; }
-      set { _message = value; }
-    }
-    private global::ProtoBuf.IExtension extensionObject;
-    global::ProtoBuf.IExtension global::ProtoBuf.IExtensible.GetExtensionObject(bool createIfMissing)
-      { return global::ProtoBuf.Extensible.GetExtensionObject(ref extensionObject, createIfMissing); }
-  }
-  
-    [global::ProtoBuf.ProtoContract(Name=@"State")]
-    public enum State
-    {
-            
-      [global::ProtoBuf.ProtoEnum(Name=@"READY", Value=0)]
-      READY = 0,
-            
-      [global::ProtoBuf.ProtoEnum(Name=@"DONE", Value=1)]
-      DONE = 1,
-            
-      [global::ProtoBuf.ProtoEnum(Name=@"FAIL", Value=2)]
-      FAIL = 2
-    }
-  
-    private global::ProtoBuf.IExtension extensionObject;
-    global::ProtoBuf.IExtension global::ProtoBuf.IExtensible.GetExtensionObject(bool createIfMissing)
-      { return global::ProtoBuf.Extensible.GetExtensionObject(ref extensionObject, createIfMissing); }
-  }
-  
-  [global::System.Serializable, global::ProtoBuf.ProtoContract(Name=@"TaskStatusProto")]
-  public partial class TaskStatusProto : global::ProtoBuf.IExtensible
-  {
-    public TaskStatusProto() {}
-    
-    private string _task_id;
-    [global::ProtoBuf.ProtoMember(1, IsRequired = true, Name=@"task_id", DataFormat = global::ProtoBuf.DataFormat.Default)]
-    public string task_id
-    {
-      get { return _task_id; }
-      set { _task_id = value; }
-    }
-    private string _context_id;
-    [global::ProtoBuf.ProtoMember(2, IsRequired = true, Name=@"context_id", DataFormat = global::ProtoBuf.DataFormat.Default)]
-    public string context_id
-    {
-      get { return _context_id; }
-      set { _context_id = value; }
-    }
-    private State _state;
-    [global::ProtoBuf.ProtoMember(3, IsRequired = true, Name=@"state", DataFormat = global::ProtoBuf.DataFormat.TwosComplement)]
-    public State state
-    {
-      get { return _state; }
-      set { _state = value; }
-    }
-    private byte[] _result = null;
-    [global::ProtoBuf.ProtoMember(4, IsRequired = false, Name=@"result", DataFormat = global::ProtoBuf.DataFormat.Default)]
-    [global::System.ComponentModel.DefaultValue(null)]
-    public byte[] result
-    {
-      get { return _result; }
-      set { _result = value; }
-    }
-    private bool _recovery = false;
-    [global::ProtoBuf.ProtoMember(5, IsRequired = false, Name = @"recovery", DataFormat = global::ProtoBuf.DataFormat.Default)]
-    [global::System.ComponentModel.DefaultValue(false)]
-    public bool recovery
-    {
-        get { return _recovery; }
-        set { _recovery = value; }
-    }
-    private readonly global::System.Collections.Generic.List<TaskStatusProto.TaskMessageProto> _task_message = new global::System.Collections.Generic.List<TaskStatusProto.TaskMessageProto>();
-    [global::ProtoBuf.ProtoMember(6, Name=@"task_message", DataFormat = global::ProtoBuf.DataFormat.Default)]
-    public global::System.Collections.Generic.List<TaskStatusProto.TaskMessageProto> task_message
-    {
-      get { return _task_message; }
-    }
-  
-  [global::System.Serializable, global::ProtoBuf.ProtoContract(Name=@"TaskMessageProto")]
-  public partial class TaskMessageProto : global::ProtoBuf.IExtensible
-  {
-    public TaskMessageProto() {}
-    
-    private string _source_id;
-    [global::ProtoBuf.ProtoMember(1, IsRequired = true, Name=@"source_id", DataFormat = global::ProtoBuf.DataFormat.Default)]
-    public string source_id
-    {
-      get { return _source_id; }
-      set { _source_id = value; }
-    }
-    private byte[] _message;
-    [global::ProtoBuf.ProtoMember(2, IsRequired = true, Name=@"message", DataFormat = global::ProtoBuf.DataFormat.Default)]
-    public byte[] message
-    {
-      get { return _message; }
-      set { _message = value; }
-    }
-    private global::ProtoBuf.IExtension extensionObject;
-    global::ProtoBuf.IExtension global::ProtoBuf.IExtensible.GetExtensionObject(bool createIfMissing)
-      { return global::ProtoBuf.Extensible.GetExtensionObject(ref extensionObject, createIfMissing); }
-  }
-  
-    private global::ProtoBuf.IExtension extensionObject;
-    global::ProtoBuf.IExtension global::ProtoBuf.IExtensible.GetExtensionObject(bool createIfMissing)
-      { return global::ProtoBuf.Extensible.GetExtensionObject(ref extensionObject, createIfMissing); }
-  }
-  
-  [global::System.Serializable, global::ProtoBuf.ProtoContract(Name=@"EvaluatorStatusProto")]
-  public partial class EvaluatorStatusProto : global::ProtoBuf.IExtensible
-  {
-    public EvaluatorStatusProto() {}
-    
-    private string _evaluator_id;
-    [global::ProtoBuf.ProtoMember(1, IsRequired = true, Name=@"evaluator_id", DataFormat = global::ProtoBuf.DataFormat.Default)]
-    public string evaluator_id
-    {
-      get { return _evaluator_id; }
-      set { _evaluator_id = value; }
-    }
-    private State _state;
-    [global::ProtoBuf.ProtoMember(2, IsRequired = true, Name=@"state", DataFormat = global::ProtoBuf.DataFormat.TwosComplement)]
-    public State state
-    {
-      get { return _state; }
-      set { _state = value; }
-    }
-    private byte[] _error = null;
-    [global::ProtoBuf.ProtoMember(3, IsRequired = false, Name=@"error", DataFormat = global::ProtoBuf.DataFormat.Default)]
-    [global::System.ComponentModel.DefaultValue(null)]
-    public byte[] error
-    {
-      get { return _error; }
-      set { _error = value; }
-    }
-    private global::ProtoBuf.IExtension extensionObject;
-    global::ProtoBuf.IExtension global::ProtoBuf.IExtensible.GetExtensionObject(bool createIfMissing)
-      { return global::ProtoBuf.Extensible.GetExtensionObject(ref extensionObject, createIfMissing); }
-  }
-  
-    [global::ProtoBuf.ProtoContract(Name=@"State")]
-    public enum State
-    {
-            
-      [global::ProtoBuf.ProtoEnum(Name=@"INIT", Value=0)]
-      INIT = 0,
-            
-      [global::ProtoBuf.ProtoEnum(Name=@"RUNNING", Value=1)]
-      RUNNING = 1,
-            
-      [global::ProtoBuf.ProtoEnum(Name=@"DONE", Value=2)]
-      DONE = 2,
-            
-      [global::ProtoBuf.ProtoEnum(Name=@"SUSPEND", Value=3)]
-      SUSPEND = 3,
-            
-      [global::ProtoBuf.ProtoEnum(Name=@"FAILED", Value=4)]
-      FAILED = 4,
-            
-      [global::ProtoBuf.ProtoEnum(Name=@"KILLED", Value=5)]
-      KILLED = 5
-    }
-  
-    [global::ProtoBuf.ProtoContract(Name=@"FileType")]
-    public enum FileType
-    {
-            
-      [global::ProtoBuf.ProtoEnum(Name=@"PLAIN", Value=0)]
-      PLAIN = 0,
-            
-      [global::ProtoBuf.ProtoEnum(Name=@"LIB", Value=1)]
-      LIB = 1,
-            
-      [global::ProtoBuf.ProtoEnum(Name=@"ARCHIVE", Value=2)]
-      ARCHIVE = 2
-    }
-  
-    [global::ProtoBuf.ProtoContract(Name=@"SIZE")]
-    public enum SIZE
-    {
-            
-      [global::ProtoBuf.ProtoEnum(Name=@"SMALL", Value=0)]
-      SMALL = 0,
-            
-      [global::ProtoBuf.ProtoEnum(Name=@"MEDIUM", Value=1)]
-      MEDIUM = 1,
-            
-      [global::ProtoBuf.ProtoEnum(Name=@"LARGE", Value=2)]
-      LARGE = 2,
-            
-      [global::ProtoBuf.ProtoEnum(Name=@"XLARGE", Value=3)]
-      XLARGE = 3
-    }
-  
-    [global::ProtoBuf.ProtoContract(Name=@"ProcessType")]
-    public enum ProcessType
-    {
-            
-      [global::ProtoBuf.ProtoEnum(Name=@"JVM", Value=0)]
-      JVM = 0,
-            
-      [global::ProtoBuf.ProtoEnum(Name=@"CLR", Value=1)]
-      CLR = 1
-    }
-  
-}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/7edb8570/lang/cs/Org.Apache.REEF.Common/protobuf/cs/Serializer.cs
----------------------------------------------------------------------
diff --git a/lang/cs/Org.Apache.REEF.Common/protobuf/cs/Serializer.cs b/lang/cs/Org.Apache.REEF.Common/protobuf/cs/Serializer.cs
deleted file mode 100644
index 6bd90e8..0000000
--- a/lang/cs/Org.Apache.REEF.Common/protobuf/cs/Serializer.cs
+++ /dev/null
@@ -1,130 +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.ProtoBuf.EvaluatorRunTimeProto;
-using Org.Apache.REEF.Common.ProtoBuf.ReefServiceProto;
-using Org.Apache.REEF.Utilities;
-
-using ProtoBuf;
-using System;
-using System.Diagnostics.CodeAnalysis;
-using System.Globalization;
-using System.IO;
-using System.Text;
-
-[module: SuppressMessage("StyleCop.CSharp.MaintainabilityRules", "SA1403:FileMayOnlyContainASingleNamespace", Justification = "Serializers for all protobuf types")]
-[module: SuppressMessage("StyleCop.CSharp.MaintainabilityRules", "SA1402:FileMayOnlyContainASingleClass", Justification = "Serializers for all protobuf types")]
-
-namespace Org.Apache.REEF.Common.ProtoBuf.ReefProtocol
-{
-    /// <summary>
-    /// Add serializer/deserializer to REEFMessage
-    /// </summary>
-    public partial class REEFMessage
-    {
-        public REEFMessage(EvaluatorHeartbeatProto evaluatorHeartbeatProto)
-        {
-            _evaluatorHeartBeat = evaluatorHeartbeatProto;
-        }
-
-        public static REEFMessage Deserialize(byte[] bytes)
-        {
-            REEFMessage pbuf = null;
-            using (var s = new MemoryStream(bytes))
-            {
-                pbuf = Serializer.Deserialize<REEFMessage>(s);
-            }
-            return pbuf;
-        }
-
-        public byte[] Serialize()
-        {
-            byte[] b = null;
-            using (var s = new MemoryStream())
-            {
-                Serializer.Serialize<REEFMessage>(s, this);
-                b = new byte[s.Position];
-                var fullBuffer = s.GetBuffer();
-                Array.Copy(fullBuffer, b, b.Length);
-            }
-            return b;
-        }
-    }
-}
-
-namespace Org.Apache.REEF.Common.ProtoBuf.EvaluatorRunTimeProto
-{
-    /// <summary>
-    /// Add serializer/deserializer to EvaluatorHeartbeatProto
-    /// </summary>
-    public partial class EvaluatorHeartbeatProto
-    {
-        public static EvaluatorHeartbeatProto Deserialize(byte[] bytes)
-        {
-            EvaluatorHeartbeatProto pbuf = null;
-            using (var s = new MemoryStream(bytes))
-            {
-                pbuf = Serializer.Deserialize<EvaluatorHeartbeatProto>(s);
-            }
-            return pbuf;
-        }
-
-        public byte[] Serialize()
-        {
-            byte[] b = null;
-            using (var s = new MemoryStream())
-            {
-                Serializer.Serialize<EvaluatorHeartbeatProto>(s, this);
-                b = new byte[s.Position];
-                var fullBuffer = s.GetBuffer();
-                Array.Copy(fullBuffer, b, b.Length);
-            }
-            return b;
-        }
-
-        public override string ToString()
-        {
-            string contextStatus = string.Empty;
-            string taskStatusMessage = string.Empty;
-            foreach (ContextStatusProto contextStatusProto in context_status)
-            {
-                contextStatus += string.Format(CultureInfo.InvariantCulture, "evaluator {0} has context {1} in state {2} with recovery flag {3}",
-                                               evaluator_status.evaluator_id,
-                                               contextStatusProto.context_id,
-                                               contextStatusProto.context_state,
-                                               contextStatusProto.recovery);
-            }
-            if (task_status != null && task_status.task_message != null && task_status.task_message.Count > 0)
-            {
-                foreach (TaskStatusProto.TaskMessageProto taskMessageProto in task_status.task_message)
-                {
-                    taskStatusMessage += ByteUtilities.ByteArrarysToString(taskMessageProto.message);
-                }
-            }
-            return string.Format(CultureInfo.InvariantCulture, "EvaluatorHeartbeatProto: task_id=[{0}], task_status=[{1}], task_message=[{2}], evaluator_status=[{3}], context_status=[{4}], timestamp=[{5}], recoveryFlag =[{6}]",
-                task_status == null ? string.Empty : task_status.task_id,
-                task_status == null ? string.Empty : task_status.state.ToString(),
-                taskStatusMessage,
-                evaluator_status.state.ToString(),
-                contextStatus,
-                timestamp,
-                recovery);
-        }
-    }
-}

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/7edb8570/lang/cs/Org.Apache.REEF.Common/protobuf/cs/codec/EvaluatorHeartbeatProtoCodec.cs
----------------------------------------------------------------------
diff --git a/lang/cs/Org.Apache.REEF.Common/protobuf/cs/codec/EvaluatorHeartbeatProtoCodec.cs b/lang/cs/Org.Apache.REEF.Common/protobuf/cs/codec/EvaluatorHeartbeatProtoCodec.cs
deleted file mode 100644
index 0f997a4..0000000
--- a/lang/cs/Org.Apache.REEF.Common/protobuf/cs/codec/EvaluatorHeartbeatProtoCodec.cs
+++ /dev/null
@@ -1,41 +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.ProtoBuf.EvaluatorRunTimeProto;
-using Org.Apache.REEF.Wake.Remote;
-
-namespace Org.Apache.REEF.Common.ProtoBuf.ReefProtocol
-{
-    public class EvaluatorHeartbeatProtoCodec : ICodec<EvaluatorHeartbeatProto>
-    {
-        public byte[] Encode(EvaluatorHeartbeatProto obj)
-        {
-            EvaluatorHeartbeatProto pbuf = new EvaluatorHeartbeatProto();
-
-            pbuf.evaluator_status = obj.evaluator_status;
-            return pbuf.Serialize();
-        }
-
-        public EvaluatorHeartbeatProto Decode(byte[] data)
-        {
-            EvaluatorHeartbeatProto pbuf = EvaluatorHeartbeatProto.Deserialize(data);
-            return pbuf;
-        }
-    }
-}

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/7edb8570/lang/cs/Org.Apache.REEF.Common/protobuf/cs/codec/REEFMessageCodec.cs
----------------------------------------------------------------------
diff --git a/lang/cs/Org.Apache.REEF.Common/protobuf/cs/codec/REEFMessageCodec.cs b/lang/cs/Org.Apache.REEF.Common/protobuf/cs/codec/REEFMessageCodec.cs
deleted file mode 100644
index 41109e3..0000000
--- a/lang/cs/Org.Apache.REEF.Common/protobuf/cs/codec/REEFMessageCodec.cs
+++ /dev/null
@@ -1,37 +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.Wake.Remote;
-
-namespace Org.Apache.REEF.Common.ProtoBuf.ReefProtocol
-{
-    public class REEFMessageCodec : ICodec<REEFMessage>
-    {
-        public byte[] Encode(REEFMessage obj)
-        {
-            return obj.Serialize();
-        }
-
-        public REEFMessage Decode(byte[] data)
-        {
-            REEFMessage pbuf = REEFMessage.Deserialize(data);
-            return pbuf;
-        }
-    }
-}

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/7edb8570/lang/cs/Org.Apache.REEF.Common/protobuf/proto/client_runtime.proto
----------------------------------------------------------------------
diff --git a/lang/cs/Org.Apache.REEF.Common/protobuf/proto/client_runtime.proto b/lang/cs/Org.Apache.REEF.Common/protobuf/proto/client_runtime.proto
deleted file mode 100644
index 3d1f927..0000000
--- a/lang/cs/Org.Apache.REEF.Common/protobuf/proto/client_runtime.proto
+++ /dev/null
@@ -1,56 +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.
- */
-option java_package = "org.apache.reef.proto";
-option java_outer_classname = "ClientRuntimeProtocol";
-option java_generic_services = true;
-option java_generate_equals_and_hash = true;
-
-import "reef_service_protos.proto";
-
-// Messages from REEF Client -> Driver Runtime
-
-message JobSubmissionProto {
-	required string identifier     = 1; // the job identifier
-	required string remote_id      = 2; // the remote identifier
-	required string configuration  = 5; // the runtime configuration
-	required string user_name      = 6; // the user name
-
-  optional SIZE   driver_size    = 7;
-  optional int32  driver_memory  = 8;
-  optional int32  priority       = 9;
-  optional string queue          = 10;
-
-	repeated FileResourceProto global_file = 11; // files that should be placed on the driver and all subsequent evaluators
-	repeated FileResourceProto local_File  = 12; // files that should be placed on the driver only
-
-}
-
-enum Signal {
-	SIG_TERMINATE = 1;
-	SIG_SUSPEND   = 2;
-	SIG_RESUME    = 3;
-}
-
-message JobControlProto {
-	required string identifier = 1;
-	optional Signal signal     = 2;
-	optional bytes message     = 3;
-}
-
-

http://git-wip-us.apache.org/repos/asf/incubator-reef/blob/7edb8570/lang/cs/Org.Apache.REEF.Common/protobuf/proto/driver_runtime.proto
----------------------------------------------------------------------
diff --git a/lang/cs/Org.Apache.REEF.Common/protobuf/proto/driver_runtime.proto b/lang/cs/Org.Apache.REEF.Common/protobuf/proto/driver_runtime.proto
deleted file mode 100644
index 2b21ac7..0000000
--- a/lang/cs/Org.Apache.REEF.Common/protobuf/proto/driver_runtime.proto
+++ /dev/null
@@ -1,90 +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.
- */
-option java_package = "org.apache.reef.proto";
-option java_outer_classname = "DriverRuntimeProtocol";
-option java_generic_services = true;
-option java_generate_equals_and_hash = true;
-
-
-import "reef_service_protos.proto";
-
-// Messages from Driver Runtime -> Driver Process
-
-message DriverProcessRegistrationProto {
-	required string remote_identifier = 1;
-}
-
-
-message NodeDescriptorProto {
-	required string identifier = 1;
-	required string host_name  = 2; // e.g., IP address
-	required int32 port        = 3; // e.g., IP port
-	required int32 memory_size = 4;
-	optional string rack_name  = 5; // e.g., /default-rack
-}
-
-message ResourceAllocationProto {
-	required string identifier     = 1; // e.g., the container id, or the thread id
-	required int32 resource_memory = 2; // megabytes
-	required string node_id        = 3;
-}
-
-message ResourceStatusProto {
-	required string identifier   = 1;
-	required State  state        = 2;
-	optional string diagnostics  = 3;
-	optional int32  exit_code    = 4;
-	optional bool is_from_previous_driver = 5;
-}
-
-message RuntimeStatusProto {
-   required string name  = 1;   // e.g., local, yarn21
-   required State  state = 2;
-   optional RuntimeErrorProto error = 3; // runtime (e.g., YARN) error
-
-   optional int32 outstanding_container_requests = 5;
-   repeated string container_allocation = 6;
-}
-
-//////////////////////////////////////////////////////
-// Messages from Driver Process -> Driver Runtime
-
-message ResourceRequestProto {
-	// optional SIZE resource_size   = 1; // Removed in REEF 0.3 in favor of memory_size.
-    optional int32 memory_size = 2; // Memory size of the evaluator in MB
-    optional int32 priority       = 3;
-
-    required int32 resource_count = 5;
-	repeated string node_name     = 6; // a list of specific nodes
-	repeated string rack_name     = 7; // a list of specific racks
-
-    optional bool relax_locality = 10;
-}
-
-message ResourceReleaseProto {
-	required string identifier = 1;
-}
-
-message ResourceLaunchProto {
-	required string identifier      = 1;
-	required string remote_id       = 2;
-	required string evaluator_conf  = 3;
-    required ProcessType type       = 4;
-	repeated FileResourceProto file = 10;
-}