You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@reef.apache.org by ma...@apache.org on 2016/03/03 20:28:30 UTC

reef git commit: [REEF-842] Act on obsoletes in .Net typos

Repository: reef
Updated Branches:
  refs/heads/master 00ac1d06a -> e7debb1e8


[REEF-842] Act on obsoletes in .Net typos

This change removes several fields and classes marked for
deprecation after release 0.14.

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

Pull Request:
  Closes #868


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

Branch: refs/heads/master
Commit: e7debb1e80d3a74bb0dc03fe9f49ea34a7e06e0f
Parents: 00ac1d0
Author: Dongjoon Hyun <do...@apache.org>
Authored: Tue Mar 1 14:55:15 2016 -0800
Committer: Mariia Mykhailova <ma...@apache.org>
Committed: Thu Mar 3 11:26:34 2016 -0800

----------------------------------------------------------------------
 lang/cs/Org.Apache.REEF.Driver/Constants.cs     |  26 ---
 .../DriverSubmissionSettings.cs                 | 191 -------------------
 .../Org.Apache.REEF.Driver.csproj               |   1 -
 .../Group/Operators/IOperatorSpec.cs            |   4 -
 .../Operators/Impl/BroadcastOperatorSpec.cs     |  11 --
 .../Group/Operators/Impl/ReduceOperatorSpec.cs  |  11 --
 .../Group/Operators/Impl/ScatterOperatorSpec.cs |  11 --
 .../Util/ReflectionUtilities.cs                 |   7 -
 .../Utility/TestDriverConfigGenerator.cs        |  16 +-
 .../Org.Apache.REEF.Utilities/ByteUtilities.cs  |   7 -
 .../Org.Apache.REEF.Utilities/Logging/Logger.cs |   7 -
 11 files changed, 8 insertions(+), 284 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/reef/blob/e7debb1e/lang/cs/Org.Apache.REEF.Driver/Constants.cs
----------------------------------------------------------------------
diff --git a/lang/cs/Org.Apache.REEF.Driver/Constants.cs b/lang/cs/Org.Apache.REEF.Driver/Constants.cs
index 1725f3b..cadb904 100644
--- a/lang/cs/Org.Apache.REEF.Driver/Constants.cs
+++ b/lang/cs/Org.Apache.REEF.Driver/Constants.cs
@@ -19,34 +19,14 @@ using System;
 
 namespace Org.Apache.REEF.Driver
 {
-    // TODO[REEF-842] Act on the obsoletes
     public static class Constants
     {
         /// <summary>
         /// Null handler that is not used on Java side.
         /// </summary>
-        [Obsolete("Deprecated in 0.14. Will be removed in 0.15.")]
         public const ulong NullHandler = 0;
 
         /// <summary>
-        /// The class hierarchy file from .NET.
-        /// </summary>
-        [Obsolete("Deprecated in 0.14. Will be removed in 0.15.")]
-        public const string ClassHierarachyBin = "clrClassHierarchy.bin";
-
-        /// <summary>
-        /// The class hierarchy file from .NET.
-        /// </summary>
-        [Obsolete("Deprecated in 0.14. Will be removed in 0.15.")]
-        public const string ClassHierarchyBin = "clrClassHierarchy.bin";
-
-        /// <summary>
-        /// The file containing user supplied libraries.
-        /// </summary>
-        [Obsolete("Deprecated in 0.14. Will be removed in 0.15.")]
-        public const string GlobalUserSuppliedJavaLibraries = "userSuppliedGlobalLibraries.txt";
-
-        /// <summary>
         /// The default memory granularity for evaluators.
         /// </summary>
         public const int DefaultMemoryGranularity = 1024;
@@ -56,12 +36,6 @@ namespace Org.Apache.REEF.Driver
         /// </summary>
         public const string DriverAppDirectory = "ReefDriverAppDlls";
         
-        /// <summary>
-        /// The bridge JAR name.
-        /// </summary>
-        [Obsolete("Deprecated in 0.14. Will be removed in 0.15.")]
-        public const string JavaBridgeJarFileName = "reef-bridge-java-0.15.0-SNAPSHOT-shaded.jar";
-
         public const string BridgeLaunchClass = "org.apache.reef.javabridge.generic.Launch";
 
         /// <summary>

http://git-wip-us.apache.org/repos/asf/reef/blob/e7debb1e/lang/cs/Org.Apache.REEF.Driver/DriverSubmissionSettings.cs
----------------------------------------------------------------------
diff --git a/lang/cs/Org.Apache.REEF.Driver/DriverSubmissionSettings.cs b/lang/cs/Org.Apache.REEF.Driver/DriverSubmissionSettings.cs
deleted file mode 100644
index 87aa475..0000000
--- a/lang/cs/Org.Apache.REEF.Driver/DriverSubmissionSettings.cs
+++ /dev/null
@@ -1,191 +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 Org.Apache.REEF.Utilities.Logging;
-
-namespace Org.Apache.REEF.Driver
-{
-    // TODO: merge with EvaluatorConfigurations class
-    // TODO[REEF-842] Act on the obsoletes
-    [Obsolete("Deprecated in 0.14. Please use DriverConfigurationSettings instead.")]
-    public class DriverSubmissionSettings
-    {
-        // default to "ReefDevClrBridge"
-        private string _driverIdentifier;
-
-        // default to _defaultSubmissionDirectory is not provided
-        private string _submissionDirectory;
-
-        // deault to 512MB if no value is provided
-        private int _driverMemory = 0;
-
-        // default value, client wait till driver exit
-        private int _clientWaitTime = -1;
-
-        // default to submit to driver with driver config
-        private bool _submit = true;
-
-        // default to always update jar before submission
-        private bool _updateJar = true;
-
-        // default to run on local
-        private bool _runOnYarn;
-
-        // default to set to info logging
-        private JavaLoggingSetting _javaLogLevel = JavaLoggingSetting.INFO;
-
-        /// <summary>
-        /// Whether to update jar file with needed dlls before submission
-        /// User can choose to reduce startup time by skipping the update, if jar file already contains all necessary dll
-        /// Note this settig is .NET only, it does not propagate to java side.
-        /// </summary>
-        public bool UpdateJarBeforeSubmission 
-        {
-            get { return _updateJar; }
-            set { _updateJar = value; }
-        }
-
-        /// <summary>
-        /// Determine the vebosity of Java driver's log.
-        /// Note this parameter is used when launching java process only, it does not propagate to java side.
-        /// </summary>
-        public JavaLoggingSetting JavaLogLevel
-        {
-            get { return _javaLogLevel; }
-            set { _javaLogLevel = value; }
-        }
-
-        /// <summary>
-        /// Memory allocated for driver, default to 512 MB
-        /// </summary>
-        public int DriverMemory
-        {
-            get
-            {
-                return _driverMemory;
-            }
-
-            set
-            {
-                if (value < 0)
-                {
-                    throw new ArgumentException("driver memory cannot be negatvie value.");
-                }
-                _driverMemory = value;
-            }
-        }
-
-        /// <summary>
-        /// Driver Identifier, default to "ReefDevClrBridge" 
-        /// </summary>
-        public string DriverIdentifier
-        {
-            get
-            {
-                return _driverIdentifier;
-            }
-
-            set
-            {
-                _driverIdentifier = value;
-            }
-        }
-
-        /// <summary>
-        /// Whether to submit driver with config after driver configuration is construted, default to True
-        /// </summary>
-        public bool Submit
-        {
-            get
-            {
-                return _submit;
-            }
-
-            set
-            {
-                _submit = value;
-            }
-        }
-
-        /// <summary>
-        /// How long client would wait for Driver, default to wait till  driver is done
-        /// </summary>
-        public int ClientWaitTime
-        {
-            get
-            {
-                return _clientWaitTime;
-            }
-
-            set
-            {
-                _clientWaitTime = value;
-            }
-        }
-
-        /// <summary>
-        /// Driver job submission directory in (H)DFS where jar file shall be uploaded, default to a tmp directory with GUID name
-        /// If set by CLR user, the user must guarantee the uniquness of the directory across multiple jobs
-        /// </summary>
-        public string SubmissionDirectory
-        {
-            get
-            {
-                return _submissionDirectory;
-            }
-
-            set
-            {
-                _submissionDirectory = value;
-            }
-        }
-
-        /// <summary>
-        /// Whether to Run on YARN runtime, default to false
-        /// </summary>
-        public bool RunOnYarn
-        {
-            get
-            {
-                return _runOnYarn;
-            }
-
-            set
-            {
-                _runOnYarn = value;
-            }
-        }
-
-        [Obsolete("Deprecated in 0.14, please use ToCommandLineArguments instead.")]
-        public string ToComamndLineArguments()
-        {
-            return ToCommandLineArguments();
-        }
-
-        public string ToCommandLineArguments()
-        {
-            return
-                (RunOnYarn ? " -local false" : string.Empty) +
-                (!Submit ? " -submit false" : string.Empty) +
-                (DriverMemory > 0 ? " -driver_memory " + DriverMemory : string.Empty) +
-                (!string.IsNullOrWhiteSpace(DriverIdentifier) ? " -drive_id " + DriverIdentifier : string.Empty) +
-                (ClientWaitTime > 0 ? " -wait_time " + ClientWaitTime : string.Empty) +
-                (!string.IsNullOrWhiteSpace(SubmissionDirectory) ? " -submission_directory " + SubmissionDirectory : string.Empty);
-        }
-    }
-}

http://git-wip-us.apache.org/repos/asf/reef/blob/e7debb1e/lang/cs/Org.Apache.REEF.Driver/Org.Apache.REEF.Driver.csproj
----------------------------------------------------------------------
diff --git a/lang/cs/Org.Apache.REEF.Driver/Org.Apache.REEF.Driver.csproj b/lang/cs/Org.Apache.REEF.Driver/Org.Apache.REEF.Driver.csproj
index 796bfb9..3deef72 100644
--- a/lang/cs/Org.Apache.REEF.Driver/Org.Apache.REEF.Driver.csproj
+++ b/lang/cs/Org.Apache.REEF.Driver/Org.Apache.REEF.Driver.csproj
@@ -125,7 +125,6 @@ under the License.
     <Compile Include="DriverConfigGenerator.cs" />
     <Compile Include="DriverConfiguration.cs" />
     <Compile Include="DriverConfigurationSettings.cs" />
-    <Compile Include="DriverSubmissionSettings.cs" />
     <Compile Include="Evaluator\EvaluatorDescriptorImpl.cs" />
     <Compile Include="Evaluator\EvaluatorException.cs" />
     <Compile Include="Evaluator\EvaluatorRequest.cs" />

http://git-wip-us.apache.org/repos/asf/reef/blob/e7debb1e/lang/cs/Org.Apache.REEF.Network/Group/Operators/IOperatorSpec.cs
----------------------------------------------------------------------
diff --git a/lang/cs/Org.Apache.REEF.Network/Group/Operators/IOperatorSpec.cs b/lang/cs/Org.Apache.REEF.Network/Group/Operators/IOperatorSpec.cs
index b53359c..d706fe3 100644
--- a/lang/cs/Org.Apache.REEF.Network/Group/Operators/IOperatorSpec.cs
+++ b/lang/cs/Org.Apache.REEF.Network/Group/Operators/IOperatorSpec.cs
@@ -23,12 +23,8 @@ namespace Org.Apache.REEF.Network.Group.Operators
     /// <summary>
     /// The specification used to define Broadcast Operators.
     /// </summary>
-    //// TODO[REEF-842] Act on the obsoletes
     public interface IOperatorSpec
     {
-        [Obsolete("Deprecated in 0.14, please use Configuration instead.")]
-        IConfiguration Configiration { get; }
-
         IConfiguration Configuration { get; }
     }
 }

http://git-wip-us.apache.org/repos/asf/reef/blob/e7debb1e/lang/cs/Org.Apache.REEF.Network/Group/Operators/Impl/BroadcastOperatorSpec.cs
----------------------------------------------------------------------
diff --git a/lang/cs/Org.Apache.REEF.Network/Group/Operators/Impl/BroadcastOperatorSpec.cs b/lang/cs/Org.Apache.REEF.Network/Group/Operators/Impl/BroadcastOperatorSpec.cs
index 1d45d7f..f8b60fa 100644
--- a/lang/cs/Org.Apache.REEF.Network/Group/Operators/Impl/BroadcastOperatorSpec.cs
+++ b/lang/cs/Org.Apache.REEF.Network/Group/Operators/Impl/BroadcastOperatorSpec.cs
@@ -25,7 +25,6 @@ namespace Org.Apache.REEF.Network.Group.Operators.Impl
     /// <summary>
     /// The specification used to define Broadcast Operators.
     /// </summary>
-    /// TODO[REEF-842] Act on the obsoletes
     [Private]
     public sealed class BroadcastOperatorSpec : IOperatorSpec
     {
@@ -48,16 +47,6 @@ namespace Org.Apache.REEF.Network.Group.Operators.Impl
         /// <summary>
         /// Returns the Configuration for Codec, ReduceFunction and DataConverter
         /// </summary>
-        [Obsolete("Deprecated in 0.14, please use Configuration instead.")]
-        public IConfiguration Configiration
-        {
-            get { return Configuration; }
-            private set { Configuration = value; }
-        }
-
-        /// <summary>
-        /// Returns the Configuration for Codec, ReduceFunction and DataConverter
-        /// </summary>
         public IConfiguration Configuration { get; private set; }
     }
 }

http://git-wip-us.apache.org/repos/asf/reef/blob/e7debb1e/lang/cs/Org.Apache.REEF.Network/Group/Operators/Impl/ReduceOperatorSpec.cs
----------------------------------------------------------------------
diff --git a/lang/cs/Org.Apache.REEF.Network/Group/Operators/Impl/ReduceOperatorSpec.cs b/lang/cs/Org.Apache.REEF.Network/Group/Operators/Impl/ReduceOperatorSpec.cs
index b3fc820..40a5a42 100644
--- a/lang/cs/Org.Apache.REEF.Network/Group/Operators/Impl/ReduceOperatorSpec.cs
+++ b/lang/cs/Org.Apache.REEF.Network/Group/Operators/Impl/ReduceOperatorSpec.cs
@@ -25,7 +25,6 @@ namespace Org.Apache.REEF.Network.Group.Operators.Impl
     /// <summary>
     /// The specification used to define Reduce Group Communication Operators.
     /// </summary>
-    /// TODO[REEF-842] Act on the obsoletes
     [Private]
     public sealed class ReduceOperatorSpec : IOperatorSpec
     {
@@ -51,16 +50,6 @@ namespace Org.Apache.REEF.Network.Group.Operators.Impl
         /// <summary>
         /// Returns the Configuration for Codec, ReduceFunction and DataConverter
         /// </summary>
-        [Obsolete("Deprecated in 0.14, please use Configuration instead.")]
-        public IConfiguration Configiration 
-        {
-            get { return Configuration; }
-            private set { Configuration = value; }
-        }
-
-        /// <summary>
-        /// Returns the Configuration for Codec, ReduceFunction and DataConverter
-        /// </summary>
         public IConfiguration Configuration { get; private set; }
     }
 }

http://git-wip-us.apache.org/repos/asf/reef/blob/e7debb1e/lang/cs/Org.Apache.REEF.Network/Group/Operators/Impl/ScatterOperatorSpec.cs
----------------------------------------------------------------------
diff --git a/lang/cs/Org.Apache.REEF.Network/Group/Operators/Impl/ScatterOperatorSpec.cs b/lang/cs/Org.Apache.REEF.Network/Group/Operators/Impl/ScatterOperatorSpec.cs
index 526d0e6..02730ea 100644
--- a/lang/cs/Org.Apache.REEF.Network/Group/Operators/Impl/ScatterOperatorSpec.cs
+++ b/lang/cs/Org.Apache.REEF.Network/Group/Operators/Impl/ScatterOperatorSpec.cs
@@ -25,7 +25,6 @@ namespace Org.Apache.REEF.Network.Group.Operators.Impl
     /// <summary>
     /// The specification used to define Scatter Group Communication Operators.
     /// </summary>
-    /// TODO[REEF-842] Act on the obsoletes
     [Private]
     public sealed class ScatterOperatorSpec : IOperatorSpec
     {
@@ -49,16 +48,6 @@ namespace Org.Apache.REEF.Network.Group.Operators.Impl
         /// <summary>
         /// Returns the Configuration for Codec, ReduceFunction and DataConverter
         /// </summary>
-        [Obsolete("Deprecated in 0.14, please use Configuration instead.")]
-        public IConfiguration Configiration
-        {
-            get { return Configuration; }
-            private set { Configuration = value; }
-        }
-
-        /// <summary>
-        /// Returns the Configuration for Codec, ReduceFunction and DataConverter
-        /// </summary>
         public IConfiguration Configuration { get; private set; }
     }
 }

http://git-wip-us.apache.org/repos/asf/reef/blob/e7debb1e/lang/cs/Org.Apache.REEF.Tang/Util/ReflectionUtilities.cs
----------------------------------------------------------------------
diff --git a/lang/cs/Org.Apache.REEF.Tang/Util/ReflectionUtilities.cs b/lang/cs/Org.Apache.REEF.Tang/Util/ReflectionUtilities.cs
index 8a65b1e..abdd093 100644
--- a/lang/cs/Org.Apache.REEF.Tang/Util/ReflectionUtilities.cs
+++ b/lang/cs/Org.Apache.REEF.Tang/Util/ReflectionUtilities.cs
@@ -27,7 +27,6 @@ using Org.Apache.REEF.Utilities.Logging;
 
 namespace Org.Apache.REEF.Tang.Util
 {
-    // TODO[REEF-842] Act on the obsoletes
     public static class ReflectionUtilities
     {
         private static readonly Logger LOGGER = Logger.GetLogger(typeof(ReflectionUtilities));
@@ -509,12 +508,6 @@ namespace Org.Apache.REEF.Tang.Util
         // Here is a more elaborate hack to test for anonymous type:
         // http://stackoverflow.com/questions/2483023/how-to-test-if-a-type-is-anonymous
         // compiler generated classes are always recreatable and need not additional references to check for.
-        [Obsolete("Deprecated in 0.14, please use IsAnonymousType instead.")]
-        public static bool IsAnnonymousType(Type type)
-        {
-            return IsAnonymousType(type);
-        }
-
         public static bool IsAnonymousType(Type type)
         {
             if (type != null)

http://git-wip-us.apache.org/repos/asf/reef/blob/e7debb1e/lang/cs/Org.Apache.REEF.Tests/Utility/TestDriverConfigGenerator.cs
----------------------------------------------------------------------
diff --git a/lang/cs/Org.Apache.REEF.Tests/Utility/TestDriverConfigGenerator.cs b/lang/cs/Org.Apache.REEF.Tests/Utility/TestDriverConfigGenerator.cs
index 7d55f41..9ce9d1a 100644
--- a/lang/cs/Org.Apache.REEF.Tests/Utility/TestDriverConfigGenerator.cs
+++ b/lang/cs/Org.Apache.REEF.Tests/Utility/TestDriverConfigGenerator.cs
@@ -40,7 +40,7 @@ namespace Org.Apache.REEF.Tests.Utility
         [Fact]
         public void TestGeneratingFullDriverConfigFile()
         {
-            DriverConfigurationSettings driverSubmissionSettings = new DriverConfigurationSettings()
+            DriverConfigurationSettings driverConfigurationSettings = new DriverConfigurationSettings()
             {
                 DriverMemory = 1024,
                 DriverIdentifier = "juliaDriverId",
@@ -51,13 +51,13 @@ namespace Org.Apache.REEF.Tests.Utility
                 JarFileFolder = ".\\"
             };
 
-            DriverConfigGenerator.DriverConfigurationBuilder(driverSubmissionSettings);
+            DriverConfigGenerator.DriverConfigurationBuilder(driverConfigurationSettings);
         }
 
         [Fact]
         public void TestGeneratingDriverConfigFileWithoutHttp()
         {
-            DriverConfigurationSettings driverSubmissionSettings = new DriverConfigurationSettings()
+            DriverConfigurationSettings driverConfigurationSettings = new DriverConfigurationSettings()
             {
                 DriverMemory = 1024,
                 DriverIdentifier = "juliaDriverId",
@@ -68,13 +68,13 @@ namespace Org.Apache.REEF.Tests.Utility
                 JarFileFolder = ".\\"
             };
 
-            DriverConfigGenerator.DriverConfigurationBuilder(driverSubmissionSettings);
+            DriverConfigGenerator.DriverConfigurationBuilder(driverConfigurationSettings);
         }
 
         [Fact]
         public void TestGeneratingDriverConfigFileWithoutNameServer()
         {
-            DriverConfigurationSettings driverSubmissionSettings = new DriverConfigurationSettings()
+            DriverConfigurationSettings driverConfigurationSettings = new DriverConfigurationSettings()
             {
                 DriverMemory = 1024,
                 DriverIdentifier = "juliaDriverId",
@@ -85,13 +85,13 @@ namespace Org.Apache.REEF.Tests.Utility
                 JarFileFolder = ".\\"
             };
 
-            DriverConfigGenerator.DriverConfigurationBuilder(driverSubmissionSettings);
+            DriverConfigGenerator.DriverConfigurationBuilder(driverConfigurationSettings);
         }
 
         [Fact]
         public void TestGeneratingDriverConfigFileDriverOnly()
         {
-            DriverConfigurationSettings driverSubmissionSettings = new DriverConfigurationSettings()
+            DriverConfigurationSettings driverConfigurationSettings = new DriverConfigurationSettings()
             {
                 DriverMemory = 1024,
                 DriverIdentifier = "juliaDriverId",
@@ -102,7 +102,7 @@ namespace Org.Apache.REEF.Tests.Utility
                 JarFileFolder = ".\\"
             };
 
-            DriverConfigGenerator.DriverConfigurationBuilder(driverSubmissionSettings);
+            DriverConfigGenerator.DriverConfigurationBuilder(driverConfigurationSettings);
         }
     }
 }

http://git-wip-us.apache.org/repos/asf/reef/blob/e7debb1e/lang/cs/Org.Apache.REEF.Utilities/ByteUtilities.cs
----------------------------------------------------------------------
diff --git a/lang/cs/Org.Apache.REEF.Utilities/ByteUtilities.cs b/lang/cs/Org.Apache.REEF.Utilities/ByteUtilities.cs
index 36bafb5..b69930b 100644
--- a/lang/cs/Org.Apache.REEF.Utilities/ByteUtilities.cs
+++ b/lang/cs/Org.Apache.REEF.Utilities/ByteUtilities.cs
@@ -20,7 +20,6 @@ using System.Text;
 
 namespace Org.Apache.REEF.Utilities
 {
-    // TODO[REEF-842] Act on the obsoletes
     public class ByteUtilities
     {
         public static byte[] StringToByteArrays(string s)
@@ -28,12 +27,6 @@ namespace Org.Apache.REEF.Utilities
             return Encoding.UTF8.GetBytes(s);
         }
 
-        [Obsolete("Deprecated in 0.14, please use ByteArraysToString instead.")]
-        public static string ByteArrarysToString(byte[] b)
-        {
-            return ByteArraysToString(b);
-        }
-
         public static string ByteArraysToString(byte[] b)
         {
             return Encoding.UTF8.GetString(b);

http://git-wip-us.apache.org/repos/asf/reef/blob/e7debb1e/lang/cs/Org.Apache.REEF.Utilities/Logging/Logger.cs
----------------------------------------------------------------------
diff --git a/lang/cs/Org.Apache.REEF.Utilities/Logging/Logger.cs b/lang/cs/Org.Apache.REEF.Utilities/Logging/Logger.cs
index a035508..14fa837 100644
--- a/lang/cs/Org.Apache.REEF.Utilities/Logging/Logger.cs
+++ b/lang/cs/Org.Apache.REEF.Utilities/Logging/Logger.cs
@@ -22,7 +22,6 @@ using System.Globalization;
 
 namespace Org.Apache.REEF.Utilities.Logging
 {
-    // TODO[REEF-842] Act on the obsoletes
     public sealed class Logger
     {
         private static readonly string[] LogLevel = new string[]
@@ -106,12 +105,6 @@ namespace Org.Apache.REEF.Utilities.Logging
             _customLevel = customLevel;
         }
 
-        [Obsolete("Deprecated in 0.14, please use AddTraceListener instead.")]
-        public static void AddTraceListner(TraceListener listener)
-        {
-            AddTraceListener(listener);
-        }
-
         public static void AddTraceListener(TraceListener listener)
         {
             TraceListeners.Add(listener);