Python port of ShadowsocksR
You can not select more than 25 topics Topics must start with a letter or number, can include dashes ('-') and can be up to 35 characters long.

705 lines
28 KiB

10 years ago
#!/usr/bin/python
# -*- coding: utf-8 -*-
# Copyright (c) 2014 clowwindy
#
# Permission is hereby granted, free of charge, to any person obtaining a copy
# of this software and associated documentation files (the "Software"), to deal
# in the Software without restriction, including without limitation the rights
# to use, copy, modify, merge, publish, distribute, sublicense, and/or sell
# copies of the Software, and to permit persons to whom the Software is
# furnished to do so, subject to the following conditions:
#
# The above copyright notice and this permission notice shall be included in
# all copies or substantial portions of the Software.
#
# THE SOFTWARE IS PROVIDED "AS IS", WITHOUT WARRANTY OF ANY KIND, EXPRESS OR
# IMPLIED, INCLUDING BUT NOT LIMITED TO THE WARRANTIES OF MERCHANTABILITY,
# FITNESS FOR A PARTICULAR PURPOSE AND NONINFRINGEMENT. IN NO EVENT SHALL THE
# AUTHORS OR COPYRIGHT HOLDERS BE LIABLE FOR ANY CLAIM, DAMAGES OR OTHER
# LIABILITY, WHETHER IN AN ACTION OF CONTRACT, TORT OR OTHERWISE, ARISING FROM,
# OUT OF OR IN CONNECTION WITH THE SOFTWARE OR THE USE OR OTHER DEALINGS IN THE
# SOFTWARE.
from __future__ import absolute_import, division, print_function, \
with_statement
10 years ago
import time
import socket
10 years ago
import errno
import struct
10 years ago
import logging
10 years ago
import traceback
10 years ago
import random
from shadowsocks import encrypt, eventloop, utils, common
from shadowsocks.common import parse_header
10 years ago
10 years ago
# we clear at most TIMEOUTS_CLEAN_SIZE timeouts each time
TIMEOUTS_CLEAN_SIZE = 512
10 years ago
# we check timeouts every TIMEOUT_PRECISION seconds
TIMEOUT_PRECISION = 4
MSG_FASTOPEN = 0x20000000
10 years ago
# SOCKS CMD defination
10 years ago
CMD_CONNECT = 1
10 years ago
CMD_BIND = 2
CMD_UDP_ASSOCIATE = 3
10 years ago
10 years ago
# TCP Relay can be either sslocal or ssserver
# for sslocal it is called is_local=True
# for each opening port, we have a TCP Relay
# for each connection, we have a TCP Relay Handler to handle the connection
# for each handler, we have 2 sockets:
# local: connected to the client
# remote: connected to remote server
# for each handler, we have 2 streams:
# upstream: from client to server direction
# read local and write to remote
# downstream: from server to client direction
# read remote and write to local
# for each handler, it could be at one of several stages:
10 years ago
# local:
10 years ago
# stage 0 SOCKS hello received from local, send hello to local
# stage 1 addr received from local, query DNS for remote
10 years ago
# stage 2 UDP assoc
10 years ago
# stage 3 DNS resolved, connect to remote
# stage 4 still connecting, more data from local received
# stage 5 remote connected, piping local and remote
10 years ago
# remote:
10 years ago
# stage 0 just jump to stage 1
# stage 1 addr received from local, query DNS for remote
# stage 3 DNS resolved, connect to remote
# stage 4 still connecting, more data from local received
# stage 5 remote connected, piping local and remote
10 years ago
10 years ago
STAGE_INIT = 0
10 years ago
STAGE_ADDR = 1
10 years ago
STAGE_UDP_ASSOC = 2
STAGE_DNS = 3
10 years ago
STAGE_CONNECTING = 4
10 years ago
STAGE_STREAM = 5
STAGE_DESTROYED = -1
10 years ago
# stream direction
STREAM_UP = 0
STREAM_DOWN = 1
10 years ago
# stream wait status, indicating it's waiting for reading, etc
10 years ago
WAIT_STATUS_INIT = 0
WAIT_STATUS_READING = 1
WAIT_STATUS_WRITING = 2
WAIT_STATUS_READWRITING = WAIT_STATUS_READING | WAIT_STATUS_WRITING
10 years ago
10 years ago
BUF_SIZE = 32 * 1024
10 years ago
class TCPRelayHandler(object):
def __init__(self, server, fd_to_handlers, loop, local_sock, config,
dns_resolver, is_local):
self._server = server
10 years ago
self._fd_to_handlers = fd_to_handlers
self._loop = loop
10 years ago
self._local_sock = local_sock
self._remote_sock = None
10 years ago
self._config = config
self._dns_resolver = dns_resolver
10 years ago
self._is_local = is_local
10 years ago
self._stage = STAGE_INIT
10 years ago
self._encryptor = encrypt.Encryptor(config['password'],
config['method'])
self._fastopen_connected = False
10 years ago
self._data_to_write_to_local = []
self._data_to_write_to_remote = []
10 years ago
self._upstream_status = WAIT_STATUS_READING
self._downstream_status = WAIT_STATUS_INIT
self._remote_address = None
10 years ago
if is_local:
self._chosen_server = self._get_a_server()
10 years ago
fd_to_handlers[local_sock.fileno()] = self
local_sock.setblocking(False)
10 years ago
local_sock.setsockopt(socket.SOL_TCP, socket.TCP_NODELAY, 1)
10 years ago
loop.add(local_sock, eventloop.POLL_IN | eventloop.POLL_ERR)
self.last_activity = 0
10 years ago
self._update_activity()
def __hash__(self):
# default __hash__ is id / 16
# we want to eliminate collisions
return id(self)
@property
def remote_address(self):
return self._remote_address
10 years ago
def _get_a_server(self):
server = self._config['server']
server_port = self._config['server_port']
if type(server_port) == list:
server_port = random.choice(server_port)
logging.debug('chosen server: %s:%d', server, server_port)
# TODO support multiple server IP
return server, server_port
10 years ago
def _update_activity(self):
10 years ago
# tell the TCP Relay we have activities recently
# else it will think we are inactive and timed out
self._server.update_activity(self)
10 years ago
10 years ago
def _update_stream(self, stream, status):
10 years ago
# update a stream to a new waiting status
# check if status is changed
# only update if dirty
10 years ago
dirty = False
if stream == STREAM_DOWN:
if self._downstream_status != status:
self._downstream_status = status
dirty = True
elif stream == STREAM_UP:
if self._upstream_status != status:
self._upstream_status = status
dirty = True
if dirty:
if self._local_sock:
event = eventloop.POLL_ERR
10 years ago
if self._downstream_status & WAIT_STATUS_WRITING:
10 years ago
event |= eventloop.POLL_OUT
10 years ago
if self._upstream_status & WAIT_STATUS_READING:
10 years ago
event |= eventloop.POLL_IN
self._loop.modify(self._local_sock, event)
if self._remote_sock:
event = eventloop.POLL_ERR
10 years ago
if self._downstream_status & WAIT_STATUS_READING:
10 years ago
event |= eventloop.POLL_IN
10 years ago
if self._upstream_status & WAIT_STATUS_WRITING:
10 years ago
event |= eventloop.POLL_OUT
self._loop.modify(self._remote_sock, event)
10 years ago
10 years ago
def _write_to_sock(self, data, sock):
10 years ago
# write data to sock
# if only some of the data are written, put remaining in the buffer
# and update the stream to wait for writing
10 years ago
if not data or not sock:
return False
10 years ago
uncomplete = False
try:
l = len(data)
s = sock.send(data)
if s < l:
data = data[s:]
uncomplete = True
except (OSError, IOError) as e:
error_no = eventloop.errno_from_exception(e)
if error_no in (errno.EAGAIN, errno.EINPROGRESS,
errno.EWOULDBLOCK):
10 years ago
uncomplete = True
else:
logging.error(e)
10 years ago
if self._config['verbose']:
traceback.print_exc()
10 years ago
self.destroy()
return False
10 years ago
if uncomplete:
if sock == self._local_sock:
self._data_to_write_to_local.append(data)
10 years ago
self._update_stream(STREAM_DOWN, WAIT_STATUS_WRITING)
10 years ago
elif sock == self._remote_sock:
self._data_to_write_to_remote.append(data)
10 years ago
self._update_stream(STREAM_UP, WAIT_STATUS_WRITING)
10 years ago
else:
logging.error('write_all_to_sock:unknown socket')
10 years ago
else:
if sock == self._local_sock:
10 years ago
self._update_stream(STREAM_DOWN, WAIT_STATUS_READING)
10 years ago
elif sock == self._remote_sock:
10 years ago
self._update_stream(STREAM_UP, WAIT_STATUS_READING)
10 years ago
else:
logging.error('write_all_to_sock:unknown socket')
return True
10 years ago
10 years ago
def _handle_stage_connecting(self, data):
10 years ago
if self._is_local:
data = self._encryptor.encrypt(data)
self._data_to_write_to_remote.append(data)
if self._is_local and not self._fastopen_connected and \
10 years ago
self._config['fast_open']:
10 years ago
# for sslocal and fastopen, we basically wait for data and use
# sendto to connect
10 years ago
try:
10 years ago
# only connect once
self._fastopen_connected = True
10 years ago
remote_sock = \
self._create_remote_socket(self._chosen_server[0],
self._chosen_server[1])
10 years ago
self._loop.add(remote_sock, eventloop.POLL_ERR)
data = b''.join(self._data_to_write_to_local)
10 years ago
l = len(data)
10 years ago
s = remote_sock.sendto(data, MSG_FASTOPEN, self._chosen_server)
10 years ago
if s < l:
data = data[s:]
self._data_to_write_to_local = [data]
self._update_stream(STREAM_UP, WAIT_STATUS_READWRITING)
else:
self._data_to_write_to_local = []
self._update_stream(STREAM_UP, WAIT_STATUS_READING)
self._stage = STAGE_STREAM
except (OSError, IOError) as e:
if eventloop.errno_from_exception(e) == errno.EINPROGRESS:
self._update_stream(STREAM_UP, WAIT_STATUS_READWRITING)
elif eventloop.errno_from_exception(e) == errno.ENOTCONN:
logging.error('fast open not supported on this OS')
self._config['fast_open'] = False
self.destroy()
else:
logging.error(e)
10 years ago
if self._config['verbose']:
traceback.print_exc()
10 years ago
self.destroy()
10 years ago
def _handle_stage_addr(self, data):
10 years ago
try:
if self._is_local:
cmd = common.ord(data[1])
10 years ago
if cmd == CMD_UDP_ASSOCIATE:
logging.debug('UDP associate')
if self._local_sock.family == socket.AF_INET6:
header = b'\x05\x00\x00\x04'
10 years ago
else:
header = b'\x05\x00\x00\x01'
10 years ago
addr, port = self._local_sock.getsockname()[:2]
10 years ago
addr_to_send = socket.inet_pton(self._local_sock.family,
addr)
port_to_send = struct.pack('>H', port)
self._write_to_sock(header + addr_to_send + port_to_send,
self._local_sock)
self._stage = STAGE_UDP_ASSOC
# just wait for the client to disconnect
return
elif cmd == CMD_CONNECT:
# just trim VER CMD RSV
data = data[3:]
else:
logging.error('unknown command %d', cmd)
self.destroy()
return
header_result = parse_header(data)
if header_result is None:
raise Exception('can not parse header')
addrtype, remote_addr, remote_port, header_length = header_result
logging.info('connecting %s:%d' % (common.to_str(remote_addr),
remote_port))
10 years ago
self._remote_address = (remote_addr, remote_port)
# pause reading
self._update_stream(STREAM_UP, WAIT_STATUS_WRITING)
self._stage = STAGE_DNS
10 years ago
if self._is_local:
# forward address to remote
10 years ago
self._write_to_sock((b'\x05\x00\x00\x01'
b'\x00\x00\x00\x00\x10\x10'),
10 years ago
self._local_sock)
data_to_send = self._encryptor.encrypt(data)
self._data_to_write_to_remote.append(data_to_send)
# notice here may go into _handle_dns_resolved directly
10 years ago
self._dns_resolver.resolve(self._chosen_server[0],
self._handle_dns_resolved)
10 years ago
else:
if len(data) > header_length:
self._data_to_write_to_remote.append(data[header_length:])
# notice here may go into _handle_dns_resolved directly
self._dns_resolver.resolve(remote_addr,
self._handle_dns_resolved)
10 years ago
except Exception as e:
logging.error(e)
10 years ago
if self._config['verbose']:
traceback.print_exc()
10 years ago
# TODO use logging when debug completed
self.destroy()
10 years ago
def _create_remote_socket(self, ip, port):
addrs = socket.getaddrinfo(ip, port, 0, socket.SOCK_STREAM,
socket.SOL_TCP)
if len(addrs) == 0:
raise Exception("getaddrinfo failed for %s:%d" % (ip, port))
af, socktype, proto, canonname, sa = addrs[0]
remote_sock = socket.socket(af, socktype, proto)
self._remote_sock = remote_sock
self._fd_to_handlers[remote_sock.fileno()] = self
remote_sock.setblocking(False)
remote_sock.setsockopt(socket.SOL_TCP, socket.TCP_NODELAY, 1)
return remote_sock
def _handle_dns_resolved(self, result, error):
if error:
logging.error(error)
self.destroy()
return
if result:
ip = result[1]
if ip:
try:
10 years ago
self._stage = STAGE_CONNECTING
10 years ago
remote_addr = ip
if self._is_local:
10 years ago
remote_port = self._chosen_server[1]
else:
remote_port = self._remote_address[1]
if self._is_local and self._config['fast_open']:
10 years ago
# for fastopen:
# wait for more data to arrive and send them in one SYN
10 years ago
self._stage = STAGE_CONNECTING
# we don't have to wait for remote since it's not
# created
self._update_stream(STREAM_UP, WAIT_STATUS_READING)
# TODO when there is already data in this packet
else:
10 years ago
# else do connect
10 years ago
remote_sock = self._create_remote_socket(remote_addr,
remote_port)
try:
10 years ago
remote_sock.connect((remote_addr, remote_port))
except (OSError, IOError) as e:
if eventloop.errno_from_exception(e) == \
errno.EINPROGRESS:
pass
self._loop.add(remote_sock,
eventloop.POLL_ERR | eventloop.POLL_OUT)
10 years ago
self._stage = STAGE_CONNECTING
self._update_stream(STREAM_UP, WAIT_STATUS_READWRITING)
self._update_stream(STREAM_DOWN, WAIT_STATUS_READING)
return
except (OSError, IOError) as e:
logging.error(e)
10 years ago
if self._config['verbose']:
traceback.print_exc()
self.destroy()
10 years ago
def _on_local_read(self):
10 years ago
# handle all local read events and dispatch them to methods for
# each stage
10 years ago
self._update_activity()
10 years ago
if not self._local_sock:
return
is_local = self._is_local
10 years ago
data = None
try:
data = self._local_sock.recv(BUF_SIZE)
except (OSError, IOError) as e:
if eventloop.errno_from_exception(e) in \
(errno.ETIMEDOUT, errno.EAGAIN, errno.EWOULDBLOCK):
10 years ago
return
if not data:
self.destroy()
return
10 years ago
if not is_local:
data = self._encryptor.decrypt(data)
10 years ago
if not data:
return
10 years ago
if self._stage == STAGE_STREAM:
10 years ago
if self._is_local:
data = self._encryptor.encrypt(data)
10 years ago
self._write_to_sock(data, self._remote_sock)
10 years ago
return
10 years ago
elif is_local and self._stage == STAGE_INIT:
10 years ago
# TODO check auth method
self._write_to_sock(b'\x05\00', self._local_sock)
10 years ago
self._stage = STAGE_ADDR
10 years ago
return
10 years ago
elif self._stage == STAGE_CONNECTING:
self._handle_stage_connecting(data)
elif (is_local and self._stage == STAGE_ADDR) or \
10 years ago
(not is_local and self._stage == STAGE_INIT):
10 years ago
self._handle_stage_addr(data)
10 years ago
10 years ago
def _on_remote_read(self):
10 years ago
# handle all remote read events
10 years ago
self._update_activity()
10 years ago
data = None
try:
data = self._remote_sock.recv(BUF_SIZE)
except (OSError, IOError) as e:
if eventloop.errno_from_exception(e) in \
(errno.ETIMEDOUT, errno.EAGAIN, errno.EWOULDBLOCK):
10 years ago
return
if not data:
self.destroy()
return
10 years ago
if self._is_local:
data = self._encryptor.decrypt(data)
10 years ago
else:
data = self._encryptor.encrypt(data)
10 years ago
try:
10 years ago
self._write_to_sock(data, self._local_sock)
10 years ago
except Exception as e:
logging.error(e)
10 years ago
if self._config['verbose']:
traceback.print_exc()
10 years ago
# TODO use logging when debug completed
self.destroy()
10 years ago
def _on_local_write(self):
10 years ago
# handle local writable event
10 years ago
if self._data_to_write_to_local:
data = b''.join(self._data_to_write_to_local)
10 years ago
self._data_to_write_to_local = []
10 years ago
self._write_to_sock(data, self._local_sock)
10 years ago
else:
10 years ago
self._update_stream(STREAM_DOWN, WAIT_STATUS_READING)
10 years ago
10 years ago
def _on_remote_write(self):
10 years ago
# handle remote writable event
10 years ago
self._stage = STAGE_STREAM
10 years ago
if self._data_to_write_to_remote:
data = b''.join(self._data_to_write_to_remote)
10 years ago
self._data_to_write_to_remote = []
10 years ago
self._write_to_sock(data, self._remote_sock)
10 years ago
else:
10 years ago
self._update_stream(STREAM_UP, WAIT_STATUS_READING)
10 years ago
10 years ago
def _on_local_error(self):
10 years ago
logging.debug('got local error')
10 years ago
if self._local_sock:
logging.error(eventloop.get_sock_error(self._local_sock))
10 years ago
self.destroy()
10 years ago
def _on_remote_error(self):
10 years ago
logging.debug('got remote error')
10 years ago
if self._remote_sock:
logging.error(eventloop.get_sock_error(self._remote_sock))
10 years ago
self.destroy()
def handle_event(self, sock, event):
10 years ago
# handle all events in this handler and dispatch them to methods
if self._stage == STAGE_DESTROYED:
10 years ago
logging.debug('ignore handle_event: destroyed')
return
10 years ago
# order is important
10 years ago
if sock == self._remote_sock:
if event & eventloop.POLL_ERR:
self._on_remote_error()
10 years ago
if self._stage == STAGE_DESTROYED:
return
10 years ago
if event & (eventloop.POLL_IN | eventloop.POLL_HUP):
10 years ago
self._on_remote_read()
10 years ago
if self._stage == STAGE_DESTROYED:
return
10 years ago
if event & eventloop.POLL_OUT:
10 years ago
self._on_remote_write()
10 years ago
elif sock == self._local_sock:
if event & eventloop.POLL_ERR:
self._on_local_error()
10 years ago
if self._stage == STAGE_DESTROYED:
return
10 years ago
if event & (eventloop.POLL_IN | eventloop.POLL_HUP):
10 years ago
self._on_local_read()
10 years ago
if self._stage == STAGE_DESTROYED:
return
10 years ago
if event & eventloop.POLL_OUT:
10 years ago
self._on_local_write()
10 years ago
else:
logging.warn('unknown socket')
def destroy(self):
10 years ago
# destroy the handler and release any resources
# promises:
# 1. destroy won't make another destroy() call inside
# 2. destroy releases resources so it prevents future call to destroy
# 3. destroy won't raise any exceptions
# if any of the promises are broken, it indicates a bug have been
# introduced! mostly likely memory leaks, etc
if self._stage == STAGE_DESTROYED:
10 years ago
# this couldn't happen
10 years ago
logging.debug('already destroyed')
return
self._stage = STAGE_DESTROYED
if self._remote_address:
logging.debug('destroy: %s:%d' %
self._remote_address)
else:
logging.debug('destroy')
10 years ago
if self._remote_sock:
10 years ago
logging.debug('destroying remote')
10 years ago
self._loop.remove(self._remote_sock)
del self._fd_to_handlers[self._remote_sock.fileno()]
10 years ago
self._remote_sock.close()
10 years ago
self._remote_sock = None
if self._local_sock:
10 years ago
logging.debug('destroying local')
10 years ago
self._loop.remove(self._local_sock)
del self._fd_to_handlers[self._local_sock.fileno()]
10 years ago
self._local_sock.close()
10 years ago
self._local_sock = None
self._dns_resolver.remove_callback(self._handle_dns_resolved)
self._server.remove_handler(self)
10 years ago
class TCPRelay(object):
10 years ago
def __init__(self, config, dns_resolver, is_local):
10 years ago
self._config = config
self._is_local = is_local
10 years ago
self._dns_resolver = dns_resolver
10 years ago
self._closed = False
10 years ago
self._eventloop = None
10 years ago
self._fd_to_handlers = {}
10 years ago
self._last_time = time.time()
10 years ago
self._timeout = config['timeout']
self._timeouts = [] # a list for all the handlers
10 years ago
# we trim the timeouts once a while
self._timeout_offset = 0 # last checked position for timeout
self._handler_to_timeouts = {} # key: handler value: index in timeouts
10 years ago
if is_local:
listen_addr = config['local_address']
listen_port = config['local_port']
else:
listen_addr = config['server']
listen_port = config['server_port']
self._listen_port = listen_port
10 years ago
addrs = socket.getaddrinfo(listen_addr, listen_port, 0,
10 years ago
socket.SOCK_STREAM, socket.SOL_TCP)
if len(addrs) == 0:
raise Exception("can't get addrinfo for %s:%d" %
10 years ago
(listen_addr, listen_port))
10 years ago
af, socktype, proto, canonname, sa = addrs[0]
server_socket = socket.socket(af, socktype, proto)
server_socket.setsockopt(socket.SOL_SOCKET, socket.SO_REUSEADDR, 1)
10 years ago
server_socket.bind(sa)
10 years ago
server_socket.setblocking(False)
if config['fast_open']:
try:
server_socket.setsockopt(socket.SOL_TCP, 23, 5)
except socket.error:
logging.error('warning: fast open is not available')
self._config['fast_open'] = False
server_socket.listen(1024)
10 years ago
self._server_socket = server_socket
10 years ago
def add_to_loop(self, loop):
10 years ago
if self._eventloop:
raise Exception('already add to loop')
10 years ago
if self._closed:
raise Exception('already closed')
self._eventloop = loop
loop.add_handler(self._handle_events)
self._eventloop.add(self._server_socket,
10 years ago
eventloop.POLL_IN | eventloop.POLL_ERR)
10 years ago
def remove_handler(self, handler):
index = self._handler_to_timeouts.get(hash(handler), -1)
if index >= 0:
# delete is O(n), so we just set it to None
self._timeouts[index] = None
del self._handler_to_timeouts[hash(handler)]
def update_activity(self, handler):
10 years ago
# set handler to active
now = int(time.time())
if now - handler.last_activity < TIMEOUT_PRECISION:
# thus we can lower timeout modification frequency
return
handler.last_activity = now
index = self._handler_to_timeouts.get(hash(handler), -1)
if index >= 0:
# delete is O(n), so we just set it to None
self._timeouts[index] = None
length = len(self._timeouts)
self._timeouts.append(handler)
self._handler_to_timeouts[hash(handler)] = length
def _sweep_timeout(self):
10 years ago
# tornado's timeout memory management is more flexible than we need
10 years ago
# we just need a sorted last_activity queue and it's faster than heapq
# in fact we can do O(1) insertion/remove so we invent our own
if self._timeouts:
logging.log(utils.VERBOSE_LEVEL, 'sweeping timeouts')
now = time.time()
length = len(self._timeouts)
pos = self._timeout_offset
while pos < length:
handler = self._timeouts[pos]
if handler:
if now - handler.last_activity < self._timeout:
break
else:
if handler.remote_address:
logging.warn('timed out: %s:%d' %
handler.remote_address)
else:
logging.warn('timed out')
handler.destroy()
self._timeouts[pos] = None # free memory
pos += 1
else:
pos += 1
if pos > TIMEOUTS_CLEAN_SIZE and pos > length >> 1:
# clean up the timeout queue when it gets larger than half
# of the queue
self._timeouts = self._timeouts[pos:]
for key in self._handler_to_timeouts:
self._handler_to_timeouts[key] -= pos
pos = 0
self._timeout_offset = pos
10 years ago
def _handle_events(self, events):
10 years ago
# handle events and dispatch to handlers
10 years ago
for sock, fd, event in events:
if sock:
logging.log(utils.VERBOSE_LEVEL, 'fd %d %s', fd,
eventloop.EVENT_NAMES.get(event, event))
10 years ago
if sock == self._server_socket:
if event & eventloop.POLL_ERR:
# TODO
raise Exception('server_socket error')
try:
10 years ago
logging.debug('accept')
10 years ago
conn = self._server_socket.accept()
10 years ago
TCPRelayHandler(self, self._fd_to_handlers,
self._eventloop, conn[0], self._config,
self._dns_resolver, self._is_local)
10 years ago
except (OSError, IOError) as e:
error_no = eventloop.errno_from_exception(e)
if error_no in (errno.EAGAIN, errno.EINPROGRESS,
errno.EWOULDBLOCK):
10 years ago
continue
else:
logging.error(e)
10 years ago
if self._config['verbose']:
traceback.print_exc()
10 years ago
else:
10 years ago
if sock:
10 years ago
handler = self._fd_to_handlers.get(fd, None)
if handler:
handler.handle_event(sock, event)
10 years ago
else:
10 years ago
logging.warn('poll removed fd')
now = time.time()
if now - self._last_time > TIMEOUT_PRECISION:
self._sweep_timeout()
self._last_time = now
if self._closed:
if self._server_socket:
self._eventloop.remove(self._server_socket)
self._server_socket.close()
self._server_socket = None
logging.info('closed listen port %d', self._listen_port)
if not self._fd_to_handlers:
self._eventloop.remove_handler(self._handle_events)
def close(self, next_tick=False):
10 years ago
self._closed = True
if not next_tick:
self._server_socket.close()