You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@thrift.apache.org by je...@apache.org on 2019/04/27 22:32:16 UTC

[thrift] branch master updated: THRIFT-4853 TServerFramedTransport is now obsolete and can be removed Client: netstd Patch: Jens Geyer

This is an automated email from the ASF dual-hosted git repository.

jensg pushed a commit to branch master
in repository https://gitbox.apache.org/repos/asf/thrift.git


The following commit(s) were added to refs/heads/master by this push:
     new 8f327f2  THRIFT-4853 TServerFramedTransport is now obsolete and can be removed Client: netstd Patch: Jens Geyer
8f327f2 is described below

commit 8f327f24eeb6ca4c2cdb99a8c5e5a1ce93b29bf6
Author: Jens Geyer <je...@apache.org>
AuthorDate: Sat Apr 27 11:20:17 2019 +0200

    THRIFT-4853 TServerFramedTransport is now obsolete and can be removed
    Client: netstd
    Patch: Jens Geyer
    
    This closes #1789
---
 .../Transport/Server/TServerFramedTransport.cs     | 150 ---------------------
 1 file changed, 150 deletions(-)

diff --git a/lib/netstd/Thrift/Transport/Server/TServerFramedTransport.cs b/lib/netstd/Thrift/Transport/Server/TServerFramedTransport.cs
deleted file mode 100644
index b3b3802..0000000
--- a/lib/netstd/Thrift/Transport/Server/TServerFramedTransport.cs
+++ /dev/null
@@ -1,150 +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.Net;
-using System.Net.Sockets;
-using System.Threading;
-using System.Threading.Tasks;
-using Thrift.Transport.Client;
-
-namespace Thrift.Transport.Server
-{
-    // ReSharper disable once InconsistentNaming
-    public class TServerFramedTransport : TServerTransport
-    {
-        private readonly int _clientTimeout;
-        private readonly int _port;
-        private TcpListener _server;
-
-        public TServerFramedTransport(TcpListener listener)
-            : this(listener, 0)
-        {
-        }
-
-        public TServerFramedTransport(TcpListener listener, int clientTimeout)
-        {
-            _server = listener;
-            _clientTimeout = clientTimeout;
-        }
-
-        public TServerFramedTransport(int port)
-            : this(port, 0)
-        {
-        }
-
-        public TServerFramedTransport(int port, int clientTimeout)
-        {
-            _port = port;
-            _clientTimeout = clientTimeout;
-            try
-            {
-                // Make server socket
-                _server = new TcpListener(IPAddress.Any, _port);
-                _server.Server.NoDelay = true;
-            }
-            catch (Exception)
-            {
-                _server = null;
-                throw new TTransportException("Could not create ServerSocket on port " + port + ".");
-            }
-        }
-
-        public override void Listen()
-        {
-            // Make sure not to block on accept
-            if (_server != null)
-            {
-                try
-                {
-                    _server.Start();
-                }
-                catch (SocketException sx)
-                {
-                    throw new TTransportException("Could not accept on listening socket: " + sx.Message);
-                }
-            }
-        }
-
-        public override bool IsClientPending()
-        {
-            return _server.Pending();
-        }
-
-        protected override async Task<TTransport> AcceptImplementationAsync(CancellationToken cancellationToken)
-        {
-            if (cancellationToken.IsCancellationRequested)
-            {
-                return await Task.FromCanceled<TTransport>(cancellationToken);
-            }
-
-            if (_server == null)
-            {
-                throw new TTransportException(TTransportException.ExceptionType.NotOpen, "No underlying server socket.");
-            }
-
-            try
-            {
-                TFramedTransport tSocketTransport = null;
-                var tcpClient = await _server.AcceptTcpClientAsync();
-
-                try
-                {
-                    tSocketTransport = new TFramedTransport(new TSocketTransport(tcpClient)
-                    {
-                        Timeout = _clientTimeout
-                    });
-
-                    return tSocketTransport;
-                }
-                catch (Exception)
-                {
-                    if (tSocketTransport != null)
-                    {
-                        tSocketTransport.Dispose();
-                    }
-                    else //  Otherwise, clean it up ourselves.
-                    {
-                        ((IDisposable) tcpClient).Dispose();
-                    }
-
-                    throw;
-                }
-            }
-            catch (Exception ex)
-            {
-                throw new TTransportException(ex.ToString());
-            }
-        }
-
-        public override void Close()
-        {
-            if (_server != null)
-            {
-                try
-                {
-                    _server.Stop();
-                }
-                catch (Exception ex)
-                {
-                    throw new TTransportException("WARNING: Could not close server socket: " + ex);
-                }
-                _server = null;
-            }
-        }
-    }
-}
\ No newline at end of file