diff --git a/msrplib/__init__.py b/msrplib/__init__.py index 35e57b2..4ab7eca 100644 --- a/msrplib/__init__.py +++ b/msrplib/__init__.py @@ -1,7 +1,7 @@ -# Copyright (C) 2008-2012 AG Projects. See LICENSE for details +# Copyright (C) 2008-2021 AG Projects. See LICENSE for details -__version__ = '0.21.0' +__version__ = '0.21.1' class MSRPError(Exception): pass diff --git a/msrplib/connect.py b/msrplib/connect.py index 9137a3d..f07e32d 100644 --- a/msrplib/connect.py +++ b/msrplib/connect.py @@ -1,527 +1,527 @@ -# Copyright (C) 2008-2012 AG Projects. See LICENSE for details +# Copyright (C) 2008-2021 AG Projects. See LICENSE for details """Establish MSRP connection. This module provides means to obtain a connected and bound MSRPTransport instance. It uniformly handles 3 different configurations you may find your client engaged in: 1. Calling endpoint, not using a relay (DirectConnector) 2. Answering endpoint, not using a relay (DirectAcceptor) 3. Endpoint using a relay (RelayConnection) The answering endpoint may skip using the relay if sure that it's accessible directly. The calling endpoint is unlikely to need the relay. Once you have an instance of the right class, the procedure to establish the connection is the same: full_local_path = connector.prepare() try: ... put full_local_path in SDP 'a:path' attribute ... get full_remote_path from remote's 'a:path: attribute ... (the order of the above steps is reversed if you're the ... answering party, but that does not affect connector's usage) msrptransport = connector.complete(full_remote_path) finally: connector.cleanup() To customize connection's parameters, create a new protocol.URI object and pass it to prepare() function, e.g. local_uri = protocol.URI(use_tls=False, port=5000) connector.prepare(local_uri) prepare() may update local_uri in place with the actual connection parameters used (e.g. if you specified port=0). 'port' attribute of local_uri is currently only respected by AcceptorDirect. Note that, acceptors and connectors are one-use only. MSRPServer, on the contrary, can be used multiple times. """ import random from twisted.internet.address import IPv4Address from twisted.names.srvconnect import SRVConnector from application.python import Null from application.system import host from eventlib.twistedutil.protocol import GreenClientCreator, SpawnFactory from eventlib import coros from eventlib.api import timeout, sleep from eventlib.green.socket import gethostbyname from gnutls.interfaces.twisted import TLSContext from gnutls.errors import CertificateError from msrplib import protocol, MSRPError from msrplib.transport import MSRPTransport, MSRPTransactionError, MSRPBadRequest, MSRPNoSuchSessionError from msrplib.digest import process_www_authenticate __all__ = ['MSRPRelaySettings', 'MSRPTimeout', 'MSRPConnectTimeout', 'MSRPRelayConnectTimeout', 'MSRPIncomingConnectTimeout', 'MSRPBindSessionTimeout', 'MSRPRelayAuthError', 'MSRPAuthTimeout', 'MSRPServer', 'DirectConnector', 'DirectAcceptor', 'RelayConnection'] class MSRPRelaySettings(protocol.ConnectInfo): use_tls = True def __init__(self, domain, username, password, host=None, port=None, use_tls=None, credentials=None): protocol.ConnectInfo.__init__(self, host, use_tls=use_tls, port=port, credentials=credentials) self.domain = domain self.username = username self.password = password def __str__(self): result = "MSRPRelay %s://%s" % (self.scheme, self.host or self.domain) if self.port: result += ':%s' % self.port return result def __repr__(self): params = [self.domain, self.username, self.password, self.host, self.port] if params[-1] is None: del params[-1] if params[-1] is None: del params[-1] return '%s(%s)' % (type(self).__name__, ', '.join(repr(x) for x in params)) @property def uri_domain(self): return protocol.URI(host=self.domain, port=self.port, use_tls=self.use_tls, session_id='') class TimeoutMixin(object): @classmethod def timeout(cls, *throw_args): if not throw_args: throw_args = (cls, ) return timeout(cls.seconds, *throw_args) class MSRPTimeout(MSRPError, TimeoutMixin): seconds = 30 class MSRPConnectTimeout(MSRPTimeout): pass class MSRPRelayConnectTimeout(MSRPTimeout): pass class MSRPIncomingConnectTimeout(MSRPTimeout): pass class MSRPBindSessionTimeout(MSRPTimeout): pass class MSRPRelayAuthError(MSRPTransactionError): pass class MSRPAuthTimeout(MSRPTransactionError, TimeoutMixin): code = 408 comment = 'No response to AUTH request' seconds = 30 class MSRPSRVConnector(SRVConnector): def pickServer(self): assert self.servers is not None assert self.orderedServers is not None if not self.servers and not self.orderedServers: # no SRV record, fall back.. return self.domain, 2855 return SRVConnector.pickServer(self) class ConnectBase(object): SRVConnectorClass = MSRPSRVConnector remote_uri = None remote_endpoint = None relay = None def __init__(self, logger=Null, use_sessmatch=False): self.logger = logger self.use_sessmatch = use_sessmatch self.local_uri = None def _connect(self, local_uri, remote_uri): self.logger.info('Connecting to %s', remote_uri) self.remote_uri = remote_uri creator = GreenClientCreator(gtransport_class=MSRPTransport, local_uri=local_uri, logger=self.logger, use_sessmatch=self.use_sessmatch) if remote_uri.host: if remote_uri.use_tls: msrp = creator.connectTLS(remote_uri.host, remote_uri.port or 2855, TLSContext(local_uri.credentials)) else: msrp = creator.connectTCP(remote_uri.host, remote_uri.port or 2855) else: if not remote_uri.domain: raise ValueError("remote_uri must have either 'host' or 'domain'") if remote_uri.use_tls: connectFuncName = 'connectTLS' connectFuncArgs = (TLSContext(local_uri.credentials),) else: connectFuncName = 'connectTCP' connectFuncArgs = () msrp = creator.connectSRV(remote_uri.scheme, remote_uri.domain, connectFuncName=connectFuncName, connectFuncArgs=connectFuncArgs, ConnectorClass=self.SRVConnectorClass) remote_address = msrp.getPeer() self.logger.info('Connected to %s:%s', remote_address.host, remote_address.port) self.remote_endpoint = "%s:%s:%s" % ('tls' if remote_uri.use_tls else 'tcp', remote_address.host, remote_address.port) return msrp def _listen(self, local_uri, factory): from twisted.internet import reactor if local_uri.use_tls: port = reactor.listenTLS(local_uri.port or 0, factory, TLSContext(local_uri.credentials), interface=local_uri.host) else: port = reactor.listenTCP(local_uri.port or 0, factory, interface=local_uri.host) local_address = port.getHost() local_uri.port = local_address.port self.logger.info('Listening for incoming %s connections on %s:%s', local_uri.scheme.upper(), local_address.host, local_address.port) return port def cleanup(self, wait=True): pass class DirectConnector(ConnectBase): def __init__(self, logger=Null, use_sessmatch=False): ConnectBase.__init__(self, logger, use_sessmatch) self.host_ip = host.default_ip def __repr__(self): return '<%s at %s local_uri=%s>' % (type(self).__name__, hex(id(self)), getattr(self, 'local_uri', '(none)')) def prepare(self, local_uri=None): local_uri = local_uri or protocol.URI(port=0) local_uri.port = local_uri.port or 2855 self.local_uri = local_uri return [local_uri] def getHost(self): return IPv4Address('TCP', self.host_ip, 0) def complete(self, full_remote_path): with MSRPConnectTimeout.timeout(): msrp = self._connect(self.local_uri, full_remote_path[0]) self.remote_uri = full_remote_path[0] # can't do the following, because local_uri was already used in the INVITE #msrp.local_uri.port = msrp.getHost().port try: with MSRPBindSessionTimeout.timeout(): msrp.bind(full_remote_path) except: msrp.loseConnection(wait=False) raise return msrp class DirectAcceptor(ConnectBase): def __init__(self, logger=Null, use_sessmatch=False): ConnectBase.__init__(self, logger, use_sessmatch) self.listening_port = None self.transport_event = None def __repr__(self): return '<%s at %s local_uri=%s listening_port=%s>' % (type(self).__name__, hex(id(self)), self.local_uri, self.listening_port) def prepare(self, local_uri=None): """Start listening for an incoming MSRP connection using port and use_tls from local_uri if provided. Return full local path, suitable to put in SDP a:path attribute. Note, that `local_uri' may be updated in place. """ local_uri = local_uri or protocol.URI(port=0) self.transport_event = coros.event() local_uri.host = gethostbyname(local_uri.host) factory = SpawnFactory(self.transport_event, MSRPTransport, local_uri, logger=self.logger, use_sessmatch=self.use_sessmatch) self.listening_port = self._listen(local_uri, factory) self.local_uri = local_uri return [local_uri] def getHost(self): return self.listening_port.getHost() def complete(self, full_remote_path): """Accept an incoming MSRP connection and bind it. Return MSRPTransport instance. """ try: with MSRPIncomingConnectTimeout.timeout(): try: msrp = self.transport_event.wait() except CertificateError as e: raise remote_address = msrp.getPeer() self.logger.info('Incoming %s connection from %s:%s', self.local_uri.scheme.upper(), remote_address.host, remote_address.port) self.remote_endpoint = "%s:$s:%s" % (self.local_uri.scheme.upper(), remote_address.host, remote_address.port) finally: self.cleanup() try: with MSRPBindSessionTimeout.timeout(): msrp.accept_binding(full_remote_path) self.remote_uri = full_remote_path[0] except: msrp.loseConnection(wait=False) raise return msrp def cleanup(self, wait=True): if self.listening_port is not None: self.listening_port.stopListening() self.listening_port = None self.transport_event = None self.local_uri = None def _deliver_chunk(msrp, chunk): msrp.write_chunk(chunk) with MSRPAuthTimeout.timeout(): response = msrp.read_chunk() if response.method is not None: raise MSRPBadRequest if response.transaction_id!=chunk.transaction_id: raise MSRPBadRequest return response class RelayConnection(ConnectBase): def __init__(self, relay, mode, logger=Null, use_sessmatch=False): if mode not in ('active', 'passive'): raise ValueError("RelayConnection mode should be one of 'active' or 'passive'") ConnectBase.__init__(self, logger, use_sessmatch) self.mode = mode self.relay = relay self.remote_uri = relay self.msrp = None def __repr__(self): return '<%s at %s relay=%r msrp=%s>' % (type(self).__name__, hex(id(self)), self.relay, self.msrp) def _relay_connect(self): try: msrp = self._connect(self.local_uri, self.relay) except Exception: self.logger.info('Could not connect to relay %s', self.relay) raise local_address = msrp.getHost() remote_address = msrp.getPeer() try: self.local_uri.port = local_address.port msrpdata = protocol.MSRPData(method="AUTH", transaction_id='%x' % random.getrandbits(64)) msrpdata.add_header(protocol.ToPathHeader([self.relay.uri_domain])) msrpdata.add_header(protocol.FromPathHeader([self.local_uri])) response = _deliver_chunk(msrp, msrpdata) if response.code == 401: www_authenticate = response.headers["WWW-Authenticate"] auth, rsp_auth = process_www_authenticate(self.relay.username, self.relay.password, "AUTH", str(self.relay.uri_domain), **www_authenticate.decoded) msrpdata.transaction_id = '%x' % random.getrandbits(64) msrpdata.add_header(protocol.AuthorizationHeader(auth)) response = _deliver_chunk(msrp, msrpdata) if response.code != 200: raise MSRPRelayAuthError(comment=response.comment, code=response.code) msrp.set_local_path(list(response.headers["Use-Path"].decoded)) self.logger.info('Reserved session at relay %s:%s', remote_address.host, remote_address.port) self.remote_endpoint = "%s:%s:%s" % (self.local_uri.scheme, remote_address.host, remote_address.port) except: self.logger.info('Could not reserve session at relay %s:%s', remote_address.host, remote_address.port) msrp.loseConnection(wait=False) raise return msrp def _relay_connect_timeout(self): with MSRPRelayConnectTimeout.timeout(): return self._relay_connect() def prepare(self, local_uri=None): self.local_uri = local_uri or protocol.URI(port=0) self.msrp = self._relay_connect_timeout() return self.msrp.full_local_path def getHost(self): return self.msrp.getHost() def cleanup(self, wait=True): if self.msrp is not None: self.msrp.loseConnection(wait=wait) self.msrp = None def complete(self, full_remote_path): try: with MSRPBindSessionTimeout.timeout(): if self.mode == 'active': self.msrp.bind(full_remote_path) else: self.msrp.accept_binding(full_remote_path) return self.msrp except: self.msrp.loseConnection(wait=False) raise finally: self.msrp = None class Notifier(coros.event): def wait(self): if self.ready(): self.reset() return coros.event.wait(self) def send(self, value=None, exc=None): if self.ready(): self.reset() return coros.event.send(self, value, exc=exc) class MSRPServer(ConnectBase): """Manage listening sockets. Bind incoming requests. MSRPServer solves the problem with AcceptorDirect: concurrent using of 2 or more AcceptorDirect instances on the same non-zero port is not possible. If you initialize() those instances, one after another, one will listen on the socket and another will get BindError. MSRPServer avoids the problem by sharing the listening socket between multiple connections. It has slightly different interface from AcceptorDirect, so it cannot be considered a drop-in replacement. """ CLOSE_TIMEOUT = MSRPBindSessionTimeout.seconds * 2 def __init__(self, logger): ConnectBase.__init__(self, logger) self.ports = {} # maps interface -> port -> (use_tls, listening Port) self.queue = coros.queue() self.expected_local_uris = {} # maps local_uri -> Logger instance self.expected_remote_paths = {} # maps full_remote_path -> event self.new_full_remote_path_notifier = Notifier() self.factory = SpawnFactory(self._incoming_handler, MSRPTransport, local_uri=None, logger=self.logger) def prepare(self, local_uri=None, logger=None): """Start a listening port specified by local_uri if there isn't one on that port/interface already. Add `local_uri' to the list of expected URIs, so that incoming connections featuring this URI won't be rejected. If `logger' is provided use it for this connection instead of the default one. """ local_uri = local_uri or protocol.URI(port=2855) need_listen = True if local_uri.port: use_tls, listening_port = self.ports.get(local_uri.host, {}).get(local_uri.port, (None, None)) if listening_port is not None: if use_tls==local_uri.use_tls: need_listen = False else: listening_port.stopListening() sleep(0) # make the reactor really stop listening, so that the next listen() call won't fail self.ports.pop(local_uri.host, {}).pop(local_uri.port, None) else: # caller does not care about port number for (use_tls, port) in self.ports[local_uri.host]: if local_uri.use_tls==use_tls: local_uri.port = port.getHost().port need_listen = False if need_listen: port = self._listen(local_uri, self.factory) self.ports.setdefault(local_uri.host, {})[local_uri.port] = (local_uri.use_tls, port) self.expected_local_uris[local_uri] = logger self.local_uri = local_uri return [local_uri] def _incoming_handler(self, msrp): peer = msrp.getPeer() self.logger.info('Incoming connection from %s:%s', peer.host, peer.port) with MSRPBindSessionTimeout.timeout(): chunk = msrp.read_chunk() to_path = chunk.to_path if len(to_path) != 1: msrp.write_response(chunk, 400, 'Invalid To-Path', wait=False) msrp.loseConnection(wait=False) return to_path = to_path[0] if to_path in self.expected_local_uris: logger = self.expected_local_uris.pop(to_path) if logger is not None: msrp.logger = logger msrp.local_uri = to_path else: msrp.write_response(chunk, 481, 'Unknown To-Path', wait=False) msrp.loseConnection(wait=False) return from_path = tuple(chunk.from_path) # at this point, must wait for complete() function to be called which will # provide an event for this full_remote_path while True: event = self.expected_remote_paths.pop(from_path, None) if event is not None: break self.new_full_remote_path_notifier.wait() if event is not None: msrp._set_full_remote_path(list(from_path)) error = msrp.check_incoming_SEND_chunk(chunk) else: error = MSRPNoSuchSessionError if error is None: msrp.write_response(chunk, 200, 'OK') if 'Content-Type' in chunk.headers or chunk.size>0: # chunk must be made available to read_chunk() again because it has payload raise NotImplementedError if event is not None: event.send(msrp) else: msrp.write_response(chunk, error.code, error.comment) def complete(self, full_remote_path): """Wait until one of the incoming connections binds using provided full_remote_path. Return connected and bound MSRPTransport instance. If no such binding was made within MSRPBindSessionTimeout.seconds, raise MSRPBindSessionTimeout. """ full_remote_path = tuple(full_remote_path) event = coros.event() self.expected_remote_paths[full_remote_path] = event try: self.new_full_remote_path_notifier.send() with MSRPBindSessionTimeout.timeout(): return event.wait() finally: self.expected_remote_paths.pop(full_remote_path, None) def cleanup(self, local_uri): """Remove `local_uri' from the list of expected URIs""" self.expected_local_uris.pop(local_uri, None) def stopListening(self): """Close all the sockets that MSRPServer is listening on""" for interface, rest in self.ports.items(): for port, (use_tls, listening_port) in rest: listening_port.stopListening() self.ports = {} def close(self): """Stop listening. Wait for the spawned greenlets to finish""" self.stopListening() with timeout(self.CLOSE_TIMEOUT, None): self.factory.waitall() diff --git a/msrplib/digest.py b/msrplib/digest.py index 294c1e3..170b98f 100644 --- a/msrplib/digest.py +++ b/msrplib/digest.py @@ -1,114 +1,115 @@ -# Copyright (C) 2008-2012 AG Projects. See LICENSE for details +# Copyright (C) 2008-2021 AG Projects. See LICENSE for details + +from base64 import b64encode, b64decode from hashlib import md5 from time import time -from base64 import b64encode, b64decode import random def get_random_data(length): return ''.join(chr(random.randint(0, 255)) for x in range(length)) class LoginFailed(Exception): pass def calc_ha1(**parameters): ha1_text = "%(username)s:%(realm)s:%(password)s" % parameters return md5(ha1_text.encode('utf-8')).hexdigest() def calc_ha2_response(**parameters): ha2_text = "%(method)s:%(uri)s" % parameters return md5(ha2_text.encode('utf-8')).hexdigest() def calc_ha2_rspauth(**parameters): ha2_text = ":%(uri)s" % parameters return md5(ha2_text.encode('utf-8')).hexdigest() def calc_hash(**parameters): hash_text = "%(ha1)s:%(nonce)s:%(nc)s:%(cnonce)s:auth:%(ha2)s" % parameters return md5(hash_text.encode('utf-8')).hexdigest() def calc_responses(**parameters): if "ha1" in parameters: ha1 = parameters.pop("ha1") else: ha1 = calc_ha1(**parameters) ha2_response = calc_ha2_response(**parameters) ha2_rspauth = calc_ha2_rspauth(**parameters) response = calc_hash(ha1 = ha1, ha2 = ha2_response, **parameters) rspauth = calc_hash(ha1 = ha1, ha2 = ha2_rspauth, **parameters) return response, rspauth def process_www_authenticate(username, password, method, uri, **parameters): nc = "00000001" cnonce = get_random_data(16).encode().hex() parameters["username"] = username parameters["password"] = password parameters["method"] = method parameters["uri"] = uri response, rsp_auth = calc_responses(nc = nc, cnonce = cnonce, **parameters) authorization = {} authorization["username"] = username authorization["realm"] = parameters["realm"] authorization["nonce"] = parameters["nonce"] authorization["qop"] = "auth" authorization["nc"] = nc authorization["cnonce"] = cnonce authorization["response"] = response authorization["opaque"] = parameters["opaque"] return authorization, rsp_auth class AuthChallenger(object): def __init__(self, expire_time): self.expire_time = expire_time self.key = get_random_data(16) def generate_www_authenticate(self, realm, peer_ip): www_authenticate = {} www_authenticate["realm"] = realm www_authenticate["qop"] = "auth" nonce = get_random_data(16) + "%.3f:%s" % (time(), peer_ip) www_authenticate["nonce"] = b64encode(nonce) opaque = md5((nonce + self.key).encode()) www_authenticate["opaque"] = opaque.hexdigest() return www_authenticate def process_authorization_ha1(self, ha1, method, uri, peer_ip, **parameters): parameters["method"] = method parameters["uri"] = uri try: nonce = parameters["nonce"] opaque = parameters["opaque"] response = parameters["response"] except IndexError as e: raise LoginFailed("Parameter not present: %s", e.message) try: expected_response, rspauth = calc_responses(ha1 = ha1, **parameters) except: raise #raise LoginFailed("Parameters error") if response != expected_response: raise LoginFailed("Incorrect password") try: nonce_dec = b64decode(nonce) issued, nonce_ip = nonce_dec[16:].split(":", 1) issued = float(issued) except: raise LoginFailed("Could not decode nonce") if nonce_ip != peer_ip: raise LoginFailed("This challenge was not issued to you") expected_opaque = md5(nonce_dec + self.key).hexdigest() if opaque != expected_opaque: raise LoginFailed("This nonce/opaque combination was not issued by me") if issued + self.expire_time < time(): raise LoginFailed("This challenge has expired") authentication_info = {} authentication_info["qop"] = "auth" authentication_info["cnonce"] = parameters["cnonce"] authentication_info["nc"] = parameters["nc"] authentication_info["rspauth"] = rspauth return authentication_info def process_authorization_password(self, password, method, uri, peer_ip, **parameters): ha1 = calc_ha1(password = password, **parameters) return self.process_authorization_ha1(ha1, method, uri, peer_ip, **parameters) diff --git a/msrplib/protocol.py b/msrplib/protocol.py index 711e3eb..e25cd0c 100644 --- a/msrplib/protocol.py +++ b/msrplib/protocol.py @@ -1,815 +1,815 @@ -# Copyright (C) 2008-2012 AG Projects. See LICENSE for details +# Copyright (C) 2008-2021 AG Projects. See LICENSE for details import random import re from application.system import host as host_module from collections import deque, namedtuple from gnutls.interfaces.twisted import X509Credentials from twisted.internet.protocol import connectionDone from twisted.protocols.basic import LineReceiver from msrplib import MSRPError class ParsingError(MSRPError): pass class HeaderParsingError(ParsingError): def __init__(self, header, reason): self.header = header ParsingError.__init__(self, 'Error parsing {} header: {}'.format(header, reason)) # Header value data types (for decoded values) # ByteRange = namedtuple('ByteRange', ['start', 'end', 'total']) Status = namedtuple('Status', ['code', 'comment']) ContentDisposition = namedtuple('ContentDisposition', ['disposition', 'parameters']) # Header value types (describe how to encode/decode the value) # class SimpleHeaderType(object): data_type = object @staticmethod def decode(encoded): return encoded @staticmethod def encode(decoded): return decoded class UTF8HeaderType(object): data_type = str @staticmethod def decode(encoded): return encoded.decode('utf-8') @staticmethod def encode(decoded): return decoded.encode('utf-8') class URIHeaderType(object): data_type = deque @staticmethod def decode(encoded): return deque(URI.parse(uri) for uri in encoded.split(' ')) @staticmethod def encode(decoded): return ' '.join(str(uri) for uri in decoded) class IntegerHeaderType(object): data_type = int @staticmethod def decode(encoded): return int(encoded) @staticmethod def encode(decoded): return str(decoded) class LimitedChoiceHeaderType(SimpleHeaderType): allowed_values = frozenset() @classmethod def decode(cls, encoded): if encoded not in cls.allowed_values: raise ValueError('Invalid value: {!r}'.format(encoded)) return encoded class SuccessReportHeaderType(LimitedChoiceHeaderType): allowed_values = frozenset({'yes', 'no'}) class FailureReportHeaderType(LimitedChoiceHeaderType): allowed_values = frozenset({'yes', 'no', 'partial'}) class ByteRangeHeaderType(object): data_type = ByteRange regex = re.compile(r'(?P\d+)-(?P\*|\d+)/(?P\*|\d+)') @classmethod def decode(cls, encoded): match = cls.regex.match(encoded) if match is None: raise ValueError('Invalid byte range value: {!r}'.format(encoded)) start, end, total = match.groups() start = int(start) end = int(end) if end != '*' else None total = int(total) if total != '*' else None return ByteRange(start, end, total) @staticmethod def encode(decoded): start, end, total = decoded return '{}-{}/{}'.format(start, '*' if end is None else end, '*' if total is None else total) class StatusHeaderType(object): data_type = Status @staticmethod def decode(encoded): namespace, sep, rest = encoded.partition(' ') if namespace != '000' or sep != ' ': raise ValueError('Invalid status value: {!r}'.format(encoded)) code, _, comment = rest.partition(' ') if not code.isdigit() or len(code) != 3: raise ValueError('Invalid status code: {!r}'.format(code)) return Status(int(code), comment or None) @staticmethod def encode(decoded): code, comment = decoded if comment is None: return '000 {:03d}'.format(code) else: return '000 {:03d} {}'.format(code, comment) class ContentDispositionHeaderType(object): data_type = ContentDisposition regex = re.compile(r'(\w+)=("[^"]+"|[^";]+)') @classmethod def decode(cls, encoded): disposition, _, parameters = encoded.partition(';') if not disposition: raise ValueError('Invalid content disposition: {!r}'.format(encoded)) return ContentDisposition(disposition, {name: value.strip('"') for name, value in cls.regex.findall(parameters)}) @staticmethod def encode(decoded): disposition, parameters = decoded return '; '.join([disposition] + ['{}="{}"'.format(name, value) for name, value in parameters.items()]) class ParameterListHeaderType(object): data_type = dict regex = re.compile(r'(\w+)=("[^"]+"|[^",]+)') @classmethod def decode(cls, encoded): return {name: value.strip('"') for name, value in cls.regex.findall(encoded)} @staticmethod def encode(decoded): return ', '.join('{}="{}"'.format(name, value) for name, value in decoded.items()) class DigestHeaderType(ParameterListHeaderType): @classmethod def decode(cls, encoded): algorithm, sep, parameters = encoded.partition(' ') if algorithm != 'Digest' or sep != ' ': raise ValueError('Invalid Digest header value') return super(DigestHeaderType, cls).decode(parameters) @staticmethod def encode(decoded): return 'Digest ' + super(DigestHeaderType, DigestHeaderType).encode(decoded) # Header classes # class MSRPHeaderMeta(type): __classmap__ = {} name = None def __init__(cls, name, bases, dictionary): type.__init__(cls, name, bases, dictionary) if cls.name is not None: cls.__classmap__[cls.name] = cls def __call__(cls, *args, **kw): if cls.name is not None: return super(MSRPHeaderMeta, cls).__call__(*args, **kw) # specialized class, instantiated directly. else: return cls._instantiate_specialized_class(*args, **kw) # non-specialized class, instantiated as a more specialized class if available. def _instantiate_specialized_class(cls, name, value): if name in cls.__classmap__: return super(MSRPHeaderMeta, cls.__classmap__[name]).__call__(value) else: return super(MSRPHeaderMeta, cls).__call__(name, value) class MSRPHeader(object, metaclass=MSRPHeaderMeta): name = None type = SimpleHeaderType def __init__(self, name, value): self.name = name if isinstance(value, str): self.encoded = value else: self.decoded = value def __eq__(self, other): if isinstance(other, MSRPHeader): return self.name == other.name and self.decoded == other.decoded return NotImplemented def __ne__(self, other): return not self == other @property def encoded(self): if self._encoded is None: self._encoded = self.type.encode(self._decoded) return self._encoded @encoded.setter def encoded(self, encoded): self._encoded = encoded self._decoded = None @property def decoded(self): if self._decoded is None: try: self._decoded = self.type.decode(self._encoded) except Exception as e: raise HeaderParsingError(self.name, str(e)) return self._decoded @decoded.setter def decoded(self, decoded): if not isinstance(decoded, self.type.data_type): try: # noinspection PyArgumentList decoded = self.type.data_type(decoded) except Exception: raise TypeError('value must be an instance of {}'.format(self.type.data_type.__name__)) self._decoded = decoded self._encoded = None class MSRPNamedHeader(MSRPHeader): def __init__(self, value): MSRPHeader.__init__(self, self.name, value) class ToPathHeader(MSRPNamedHeader): name = 'To-Path' type = URIHeaderType class FromPathHeader(MSRPNamedHeader): name = 'From-Path' type = URIHeaderType class MessageIDHeader(MSRPNamedHeader): name = 'Message-ID' type = SimpleHeaderType class SuccessReportHeader(MSRPNamedHeader): name = 'Success-Report' type = SuccessReportHeaderType class FailureReportHeader(MSRPNamedHeader): name = 'Failure-Report' type = FailureReportHeaderType class ByteRangeHeader(MSRPNamedHeader): name = 'Byte-Range' type = ByteRangeHeaderType @property def start(self): return self.decoded.start @property def end(self): return self.decoded.end @property def total(self): return self.decoded.total class StatusHeader(MSRPNamedHeader): name = 'Status' type = StatusHeaderType @property def code(self): return self.decoded.code @property def comment(self): return self.decoded.comment class ExpiresHeader(MSRPNamedHeader): name = 'Expires' type = IntegerHeaderType class MinExpiresHeader(MSRPNamedHeader): name = 'Min-Expires' type = IntegerHeaderType class MaxExpiresHeader(MSRPNamedHeader): name = 'Max-Expires' type = IntegerHeaderType class UsePathHeader(MSRPNamedHeader): name = 'Use-Path' type = URIHeaderType class WWWAuthenticateHeader(MSRPNamedHeader): name = 'WWW-Authenticate' type = DigestHeaderType class AuthorizationHeader(MSRPNamedHeader): name = 'Authorization' type = DigestHeaderType class AuthenticationInfoHeader(MSRPNamedHeader): name = 'Authentication-Info' type = ParameterListHeaderType class ContentTypeHeader(MSRPNamedHeader): name = 'Content-Type' type = SimpleHeaderType class ContentIDHeader(MSRPNamedHeader): name = 'Content-ID' type = SimpleHeaderType class ContentDescriptionHeader(MSRPNamedHeader): name = 'Content-Description' type = SimpleHeaderType class ContentDispositionHeader(MSRPNamedHeader): name = 'Content-Disposition' type = ContentDispositionHeaderType class UseNicknameHeader(MSRPNamedHeader): name = 'Use-Nickname' type = UTF8HeaderType class HeaderOrderMapping(dict): __levels__ = { 0: ['To-Path'], 1: ['From-Path'], 2: ['Status', 'Message-ID', 'Byte-Range', 'Success-Report', 'Failure-Report'] + ['Authorization', 'Authentication-Info', 'WWW-Authenticate', 'Expires', 'Min-Expires', 'Max-Expires', 'Use-Path', 'Use-Nickname'], 3: ['Content-ID', 'Content-Description', 'Content-Disposition'], 4: ['Content-Type'] } def __init__(self): super(HeaderOrderMapping, self).__init__({name: level for level, name_list in list(self.__levels__.items()) for name in name_list}) def __missing__(self, key): return 3 if key.startswith('Content-') else 2 sort_key = dict.__getitem__ class HeaderOrdering(object): name_map = HeaderOrderMapping() sort_key = name_map.sort_key class MissingHeader(object): decoded = None class HeaderMapping(dict): def __init__(self, *args, **kw): super(HeaderMapping, self).__init__(*args, **kw) self.__modified__ = True def __repr__(self): return '{}({})'.format(self.__class__.__name__, super(HeaderMapping, self).__repr__()) def __setitem__(self, key, value): super(HeaderMapping, self).__setitem__(key, value) self.__modified__ = True def __delitem__(self, key): super(HeaderMapping, self).__delitem__(key) self.__modified__ = True def __copy__(self): return self.__class__(self) def clear(self): super(HeaderMapping, self).clear() self.__modified__ = True def copy(self): return self.__class__(self) def pop(self, *args): result = super(HeaderMapping, self).pop(*args) self.__modified__ = True return result def popitem(self): result = super(HeaderMapping, self).popitem() self.__modified__ = True return result def setdefault(self, *args): result = super(HeaderMapping, self).setdefault(*args) self.__modified__ = True return result def update(self, *args, **kw): super(HeaderMapping, self).update(*args, **kw) self.__modified__ = True class MSRPData(object): __immutable__ = frozenset({'method', 'code', 'comment', 'headers'}) # Immutable attributes (cannot be overwritten) def __init__(self, transaction_id, method=None, code=None, comment=None, headers=None, data=b'', contflag='$'): if method is None and code is None: raise ValueError('either method or code must be specified') elif method is not None and code is not None: raise ValueError('method and code cannot be both specified') elif code is None and comment is not None: raise ValueError('comment should only be specified when code is specified') self.transaction_id = transaction_id self.method = method self.code = code self.comment = comment self.headers = HeaderMapping(headers or {}) self.data = data self.contflag = contflag self.chunk_header = None # the chunk header (if the data was received from the network) self.chunk_footer = None # the chunk footer (if the data was received from the network) if method is not None: self.first_line = 'MSRP {} {}'.format(transaction_id, method) elif comment is None: self.first_line = 'MSRP {} {:03d}'.format(transaction_id, code) else: self.first_line = 'MSRP {} {:03d} {}'.format(transaction_id, code, comment) self.__modified__ = True def __setattr__(self, name, value): if name in self.__dict__: if name in self.__immutable__: raise AttributeError('Cannot overwrite attribute') elif name == 'transaction_id': self.first_line = self.first_line.replace(self.transaction_id, value) self.__modified__ = True super(MSRPData, self).__setattr__(name, value) def __delattr__(self, name): if name in self.__immutable__: raise AttributeError('Cannot delete attribute') super(MSRPData, self).__delattr__(name) def __str__(self): # TODO: make __str__ == encode()? return self.first_line def __repr__(self): description = self.first_line for name in sorted(self.headers, key=HeaderOrdering.sort_key): description += ' {}={!r}'.format(name, self.headers[name].encoded) description += ' len={}'.format(self.size) return '<{} at {:#x} {} {}>'.format(self.__class__.__name__, id(self), description, self.contflag) def __eq__(self, other): if isinstance(other, MSRPData): return self.first_line == other.first_line and self.headers == other.headers and self.data == other.data and self.contflag == other.contflag return NotImplemented def __ne__(self, other): return not self == other def copy(self): return self.__class__(self.transaction_id, self.method, self.code, self.comment, self.headers.copy(), self.data, self.contflag) def add_header(self, header): self.headers[header.name] = header def verify_headers(self): if 'To-Path' not in self.headers: raise HeaderParsingError('To-Path', 'header is missing') if 'From-Path' not in self.headers: raise HeaderParsingError('From-Path', 'header is missing') for header in self.headers.values(): _ = header.decoded @property def from_path(self): return self.headers.get('From-Path', MissingHeader).decoded @property def to_path(self): return self.headers.get('To-Path', MissingHeader).decoded @property def content_type(self): return self.headers.get('Content-Type', MissingHeader).decoded @property def message_id(self): return self.headers.get('Message-ID', MissingHeader).decoded @property def byte_range(self): return self.headers.get('Byte-Range', MissingHeader).decoded @property def status(self): return self.headers.get('Status', MissingHeader).decoded @property def failure_report(self): return self.headers.get('Failure-Report', MissingHeader).decoded or 'yes' @property def success_report(self): return self.headers.get('Success-Report', MissingHeader).decoded or 'no' @property def size(self): return len(self.data) @property def encoded_header(self): if self.__modified__ or self.headers.__modified__: lines = [self.first_line] + ['{}: {}'.format(name, self.headers[name].encoded) for name in sorted(self.headers, key=HeaderOrdering.sort_key)] if 'Content-Type' in self.headers: lines.append('\r\n') self.__dict__['encoded_header'] = '\r\n'.join(lines) self.__modified__ = self.headers.__modified__ = False return self.__dict__['encoded_header'] @property def encoded_footer(self): return '\r\n-------{}{}\r\n'.format(self.transaction_id, self.contflag) def encode(self): encoded_header = self.encoded_header if isinstance(self.encoded_header, bytes) else self.encoded_header.encode() data = self.data if isinstance(self.data, bytes) else self.data.encode() encoded_footer = self.encoded_footer if isinstance(self.encoded_footer, bytes) else self.encoded_footer.encode() return encoded_header + data + encoded_footer # noinspection PyProtectedMember class MSRPProtocol(LineReceiver): # TODO: _ in the method name is not legal, but sipsimple defined the FILE_OFFSET method first_line_re = re.compile(r'^MSRP ([A-Za-z0-9][A-Za-z0-9.+%=-]{3,31}) (?:([A-Z_]+)|(\d{3})(?: (.+))?)$') MAX_LENGTH = 16384 MAX_LINES = 64 def __init__(self, msrp_transport): self.msrp_transport = msrp_transport self.term_buf = b'' self.term_re = None self.term_substrings = [] self.data = None self.line_count = 0 def _reset(self): self.data = None self.line_count = 0 def connectionMade(self): self.msrp_transport._got_transport(self.transport) def lineLengthExceeded(self, line): self._reset() def lineReceived(self, line): try: decoded_line = line.decode('utf-8') except UnicodeDecodeError: decoded_line = None if self.data: if len(line) == 0: # The end-line that terminates the request MUST be composed of seven # "-" (minus sign) characters, the transaction ID as used in the start # line, and a flag character. If a body is present, the end-line MUST # be preceded by a CRLF that is not part of the body. If the chunk # represents the data that forms the end of the complete message, the # flag value MUST be a "$". If the sender is aborting an incomplete # message, and intends to send no further chunks in that message, the # flag MUST be a "#". Otherwise, the flag MUST be a "+". # # If the request contains a body, the sender MUST ensure that the end- # line (seven hyphens, the transaction identifier, and a continuation # flag) is not present in the body. If the end-line is present in the # body, the sender MUST choose a new transaction identifier that is not # present in the body, and add a CRLF if needed, and the end-line, # including the "$", "#", or "+" character. terminator = '\r\n-------' + self.data.transaction_id continue_flags = [c+'\r\n' for c in '$#+'] self.term_buf = b'' self.term_re = re.compile("^(.*)%s([$#+])\r\n(.*)$" % re.escape(terminator), re.DOTALL) self.term_substrings = [terminator[:i] for i in range(1, len(terminator)+1)] + [terminator+cont[:i] for cont in continue_flags for i in range(1, len(cont))] self.term_substrings.reverse() self.data.chunk_header += self.delimiter self.msrp_transport._data_start(self.data) self.setRawMode() else: match = self.term_re.match(decoded_line) if decoded_line else None if match: continuation = match.group(1) self.data.chunk_footer = line + self.delimiter self.msrp_transport._data_start(self.data) self.msrp_transport._data_end(continuation.encode()) self._reset() else: self.data.chunk_header += line + self.delimiter self.line_count += 1 if self.line_count > self.MAX_LINES: self.msrp_transport.logger.received_illegal_data(self.data.chunk_header, self.msrp_transport) self._reset() return try: name, value = decoded_line.split(': ', 1) except (ValueError, AttributeError) as e: return # let this pass silently, we'll just not read this line. TODO: review this (ignore or drop connection?) else: #print('MSRP Header: %s=%s' % (name, value)) self.data.add_header(MSRPHeader(name, value)) else: # this is a new message. TODO: drop connection if first line cannot be parsed? match = self.first_line_re.match(decoded_line) if decoded_line else None if match: transaction_id, method, code, comment = match.groups() code = int(code) if code is not None else None #print('MSRP Data start %s %s' % (method, transaction_id)) self.data = MSRPData(transaction_id, method, code, comment) self.data.chunk_header = line + self.delimiter self.term_re = re.compile(r'^-------{}([$#+])$'.format(re.escape(transaction_id))) else: self.msrp_transport.logger.received_illegal_data(line + self.delimiter, self.msrp_transport) def rawDataReceived(self, data): data = self.term_buf + data terminator = '\r\n-------' + self.data.transaction_id terminator = terminator.encode() contents_position = data.find(terminator) if contents_position > -1: # we got the last data for this message contents = data[:contents_position] leftover = data[contents_position+len(terminator):] continuation_position = leftover.find(b'\r\n') continuation = leftover[:continuation_position] extra = leftover[continuation_position+len(continuation)+1:] if contents: self.msrp_transport._data_write(contents, final=True) chunk_footer = '\r\n-------{}{}\r\n'.format(self.data.transaction_id, continuation.decode()) self.data.chunk_footer = chunk_footer.encode() self.msrp_transport._data_end(continuation) self._reset() self.setLineMode(extra) else: for term in self.term_substrings: if data and data.endswith(term.encode()): self.term_buf = data[-len(term.encode()):] data = data[:-len(term.encode())] break else: self.term_buf = b'' self.msrp_transport._data_write(data, final=False) def connectionLost(self, reason=connectionDone): self.msrp_transport.connection_lost(reason) class ConnectInfo(object): host = None use_tls = True port = 2855 def __init__(self, host=None, use_tls=None, port=None, credentials=None): if host is not None: self.host = host.decode() if isinstance(host, bytes) else host if use_tls is not None: self.use_tls = use_tls if port is not None: self.port = port self.credentials = credentials if self.use_tls and self.credentials is None: self.credentials = X509Credentials(None, None) @property def scheme(self): if self.use_tls: return 'msrps' else: return 'msrp' # use TLS_URI and TCP_URI ? class URI(ConnectInfo): _uri_re = re.compile(r'^(?P.*?)://(((?P.*?)@)?(?P.*?)(:(?P[0-9]+?))?)(/(?P.*?))?;(?P.*?)(;(?P.*))?$') def __init__(self, host=None, use_tls=None, user=None, port=None, session_id=None, transport="tcp", parameters=None, credentials=None): ConnectInfo.__init__(self, host or host_module.default_ip, use_tls=use_tls, port=port, credentials=credentials) if session_id is None: session_id = '%x' % random.getrandbits(80) if parameters is None: parameters = {} self.user = user self.transport = transport self.session_id = session_id self.parameters = parameters # noinspection PyTypeChecker @classmethod def parse(cls, value): match = cls._uri_re.match(value) if match is None: raise ParsingError('Cannot parse URI') uri_params = match.groupdict() scheme = uri_params.pop('scheme') if scheme not in ('msrp', 'msrps'): raise ParsingError('Invalid URI scheme: %r' % scheme) if uri_params['transport'] != 'tcp': raise ParsingError("Invalid URI transport: %r (only 'tcp' is accepted)" % uri_params['transport']) uri_params['use_tls'] = scheme == 'msrps' if uri_params['port'] is not None: uri_params['port'] = int(uri_params['port']) if uri_params['parameters'] is not None: try: uri_params['parameters'] = dict(param.split('=') for param in uri_params['parameters'].split(';')) except ValueError: raise ParsingError('Cannot parse URI parameters') return cls(**uri_params) def __repr__(self): arguments = 'host', 'use_tls', 'user', 'port', 'session_id', 'transport', 'parameters', 'credentials' return '{}({})'.format(self.__class__.__name__, ', '.join('{}={!r}'.format(name, getattr(self, name)) for name in arguments)) def __str__(self): user_part = '{}@'.format(self.user) if self.user else '' port_part = ':{}'.format(self.port) if self.port else '' session_part = '/{}'.format(self.session_id) if self.session_id else '' parameter_parts = [';{}={}'.format(name, value) for name, value in self.parameters.items()] if self.parameters else [] return ''.join([self.scheme, '://', user_part, self.host, port_part, session_part, ';', self.transport] + parameter_parts) def __eq__(self, other): if self is other: return True if isinstance(other, URI): # MSRP URI comparison according to section 6.1 of RFC 4975 self_items = self.use_tls, self.host.lower(), self.port, self.session_id, self.transport.lower() other_items = other.use_tls, other.host.lower(), other.port, other.session_id, other.transport.lower() return self_items == other_items return NotImplemented def __ne__(self, other): return not self == other def __hash__(self): return hash((self.use_tls, self.host.lower(), self.port, self.session_id, self.transport.lower())) diff --git a/msrplib/session.py b/msrplib/session.py index eea9666..851a7ff 100644 --- a/msrplib/session.py +++ b/msrplib/session.py @@ -1,350 +1,350 @@ -# Copyright (C) 2008-2012 AG Projects. See LICENSE for details +# Copyright (C) 2008-2021 AG Projects. See LICENSE for details # import traceback from time import time from twisted.internet.error import ConnectionClosed, ConnectionDone from twisted.python.failure import Failure from gnutls.errors import GNUTLSError from eventlib import api, coros, proc from eventlib.twistedutil.protocol import ValueQueue from msrplib import protocol, MSRPError from msrplib.transport import make_report, make_response, MSRPTransactionError ConnectionClosedErrors = (ConnectionClosed, GNUTLSError) class MSRPSessionError(MSRPError): pass class MSRPBadContentType(MSRPTransactionError): code = 415 comment = 'Unsupported media type' class LocalResponse(MSRPTransactionError): def __repr__(self): return '' % (self.code, self.comment) Response200OK = LocalResponse("OK", 200) Response408Timeout = LocalResponse("Timed out while waiting for transaction response", 408) def contains_mime_type(mimetypelist, mimetype): """Return True if mimetypelist contains mimetype. mimietypelist either contains the complete mime types, such as 'text/plain', or simple patterns, like 'text/*', or simply '*'. """ mimetype = mimetype.lower().partition(';')[0] for pattern in mimetypelist: pattern = pattern.lower() if pattern == '*': return True if pattern == mimetype: return True if pattern.endswith('/*') and mimetype.startswith(pattern[:-1]): return True return False class OutgoingChunk(object): __slots__ = ('chunk', 'response_callback') def __init__(self, chunk, response_callback=None): self.chunk = chunk self.response_callback = response_callback class MSRPSession(object): RESPONSE_TIMEOUT = 30 SHUTDOWN_TIMEOUT = 1 KEEPALIVE_INTERVAL = 60 def __init__(self, msrptransport, accept_types=['*'], on_incoming_cb=None, automatic_reports=True): self.msrp = msrptransport self.accept_types = accept_types self.automatic_reports = automatic_reports if not callable(on_incoming_cb): raise TypeError('on_incoming_cb must be callable: %r' % on_incoming_cb) self._on_incoming_cb = on_incoming_cb self.expected_responses = {} self.outgoing = coros.queue() self.reader_job = proc.spawn(self._reader) self.writer_job = proc.spawn(self._writer) self.state = 'CONNECTED' # -> 'FLUSHING' -> 'CLOSING' -> 'DONE' # in FLUSHING writer sends only while there's something in the outgoing queue # then it exits and sets state to 'CLOSING' which makes reader only pay attention # to responses and success reports. (XXX it could now discard incoming data chunks # with direct write() since writer is dead) self.reader_job.link(self.writer_job) self.last_expected_response = 0 self.keepalive_proc = proc.spawn(self._keepalive) def _get_logger(self): return self.msrp.logger def _set_logger(self, logger): self.msrp.logger = logger logger = property(_get_logger, _set_logger) def set_state(self, state): self.logger.debug('%s (was %s)', state, self.state) self.state = state @property def connected(self): return self.state=='CONNECTED' def shutdown(self, wait=True): """Send the messages already in queue then close the connection""" self.set_state('FLUSHING') self.keepalive_proc.kill() self.keepalive_proc = None self.outgoing.send(None) if wait: self.writer_job.wait(None, None) self.reader_job.wait(None, None) def _keepalive(self): while True: api.sleep(self.KEEPALIVE_INTERVAL) if not self.connected: return try: chunk = self.msrp.make_send_request() chunk.add_header(protocol.MSRPHeader('Keep-Alive', 'yes')) self.deliver_chunk(chunk) except MSRPTransactionError as e: if e.code == 408: self.msrp.loseConnection(wait=False) self.set_state('CLOSING') return def _handle_incoming_response(self, chunk): try: response_cb, timer = self.expected_responses.pop(chunk.transaction_id) except KeyError: pass else: if timer is not None: timer.cancel() response_cb(chunk) def _check_incoming_SEND(self, chunk): error = self.msrp.check_incoming_SEND_chunk(chunk) if error is not None: return error if chunk.data: if chunk.content_type is None: return MSRPBadContentType('Content-Type header missing') if not contains_mime_type(self.accept_types, chunk.content_type): return MSRPBadContentType def _handle_incoming_SEND(self, chunk): error = self._check_incoming_SEND(chunk) if error is None: code, comment = 200, 'OK' else: code, comment = error.code, error.comment response = make_response(chunk, code, comment) if response is not None: self.outgoing.send(OutgoingChunk(response)) if code == 200: self._on_incoming_cb(chunk) if self.automatic_reports: report = make_report(chunk, 200, 'OK') if report is not None: self.outgoing.send(OutgoingChunk(report)) def _handle_incoming_REPORT(self, chunk): self._on_incoming_cb(chunk) def _handle_incoming_NICKNAME(self, chunk): if 'Use-Nickname' not in chunk.headers or 'Success-Report' in chunk.headers or 'Failure-Report' in chunk.headers: response = make_response(chunk, 400, 'Bad request') self.outgoing.send(OutgoingChunk(response)) return self._on_incoming_cb(chunk) def _reader(self): """Wait forever for new chunks. Notify the user about the good ones through self._on_incoming_cb. If a response to a previously sent chunk is received, pop the corresponding response_cb from self.expected_responses and send the response there. """ error = Failure(ConnectionDone()) try: self.writer_job.link(self.reader_job) try: while self.state in ['CONNECTED', 'FLUSHING']: chunk = self.msrp.read_chunk() if chunk.method is None: # response self._handle_incoming_response(chunk) else: method = getattr(self, '_handle_incoming_%s' % chunk.method, None) if method is not None: method(chunk) else: response = make_response(chunk, 501, 'Method unknown') self.outgoing.send(OutgoingChunk(response)) except proc.LinkedExited: # writer has exited pass finally: self.writer_job.unlink(self.reader_job) self.writer_job.kill() self.logger.debug('reader: expecting responses only') delay = time() - self.last_expected_response if delay>=0 and self.expected_responses: # continue read the responses until the last timeout expires with api.timeout(delay, None): while self.expected_responses: chunk = self.msrp.read_chunk() if chunk.method is None: self._handle_incoming_response(chunk) else: self.logger.debug('dropping incoming %r', chunk) # read whatever left in the queue with api.timeout(0, None): while self.msrp._queue: chunk = self.msrp.read_chunk() if chunk.method is None: self._handle_incoming_response(chunk) else: self.logger.debug('dropping incoming %r', chunk) self.logger.debug('reader: done') except ConnectionClosedErrors as e: self.logger.debug('reader: exiting because of %r', e) error = Failure(e) except Exception: self.logger.exception('reader: captured unhandled exception:') error = Failure() raise finally: self._on_incoming_cb(error=error) self.msrp.loseConnection(wait=False) self.set_state('DONE') def _writer(self): try: while self.state=='CONNECTED' or (self.state=='FLUSHING' and self.outgoing): item = self.outgoing.wait() if item is None: break self._write_chunk(item.chunk, item.response_callback) except ConnectionClosedErrors + (proc.LinkedExited, proc.ProcExit) as e: self.logger.debug('writer: exiting because of %r' % e) except: self.logger.exception('writer: captured unhandled exception:') raise finally: self.msrp.loseConnection(wait=False) self.set_state('CLOSING') def _write_chunk(self, chunk, response_cb=None): assert chunk.transaction_id not in self.expected_responses, "MSRP transaction %r is already in progress" % chunk.transaction_id self.msrp.write_chunk(chunk) if response_cb is not None: timer = api.get_hub().schedule_call_global(self.RESPONSE_TIMEOUT, self._response_timeout, chunk.transaction_id, Response408Timeout) self.expected_responses[chunk.transaction_id] = (response_cb, timer) self.last_expected_response = time() + self.RESPONSE_TIMEOUT def _response_timeout(self, id, timeout_error): response_cb, timer = self.expected_responses.pop(id, (None, None)) if response_cb is not None: response_cb(timeout_error) if timer is not None: timer.cancel() def send_chunk(self, chunk, response_cb=None): """Send `chunk'. Report the result via `response_cb'. When `response_cb' argument is present, it will be used to report the transaction response to the caller. When a response is received or generated locally, `response_cb' is called with one argument. The function must do something quickly and must not block, because otherwise it would the reader greenlet. If no response was received after RESPONSE_TIMEOUT seconds, * 408 response is generated if Failure-Report was 'yes' or absent * 200 response is generated if Failure-Report was 'partial' or 'no' Note that it's rather wasteful to provide `response_cb' argument other than None for chunks with Failure-Report='no' since it will always fire 30 seconds later with 200 result (unless the other party is broken and ignores Failure-Report header) If sending is impossible raise MSRPSessionError. """ assert chunk.transaction_id not in self.expected_responses, "MSRP transaction %r is already in progress" % chunk.transaction_id if response_cb is not None and not callable(response_cb): raise TypeError('response_cb must be callable: %r' % (response_cb, )) if self.state != 'CONNECTED': raise MSRPSessionError('Cannot send chunk because MSRPSession is %s' % self.state) if self.msrp._disconnected_event.ready(): raise MSRPSessionError(str(self.msrp._disconnected_event.wait())) self.outgoing.send(OutgoingChunk(chunk, response_cb)) def send_report(self, chunk, code, reason): if chunk.method != 'SEND': raise ValueError('reports may only be sent for SEND chunks') report = make_report(chunk, code, reason) if report is not None: self.send_chunk(report) def deliver_chunk(self, chunk, event=None): """Send chunk, wait for the transaction response (if Failure-Report header is not 'no'). Return the transaction response if it's a success, raise MSRPTransactionError if it's not. If chunk's Failure-Report is 'no', return None immediately. """ if chunk.failure_report!='no' and event is None: event = coros.event() self.send_chunk(chunk, event.send) if event is not None: response = event.wait() if isinstance(response, Exception): raise response elif 200 <= response.code <= 299: return response raise MSRPTransactionError(comment=response.comment, code=response.code) def make_message(self, msg, content_type, message_id=None): chunk = self.msrp.make_send_request(data=msg, message_id=message_id) chunk.add_header(protocol.ContentTypeHeader(content_type)) return chunk def send_message(self, msg, content_type): chunk = self.make_message(msg, content_type) self.send_chunk(chunk) return chunk def deliver_message(self, msg, content_type): chunk = self.make_message(msg, content_type) self.deliver_chunk(chunk) return chunk class GreenMSRPSession(MSRPSession): def __init__(self, msrptransport, accept_types=['*']): MSRPSession.__init__(self, msrptransport, accept_types, on_incoming_cb=self._incoming_cb) self.incoming = ValueQueue() def receive_chunk(self): return self.incoming.wait() def _incoming_cb(self, value=None, error=None): if error is not None: self.incoming.send_exception(error.type, error.value, error.tb) else: self.incoming.send(value) # TODO: # 413 - requires special action both in reader and in writer # continuation: # # All MSRP endpoints MUST be able to receive the multipart/mixed [15] and multipart/alternative [15] media-types. diff --git a/msrplib/trafficlog.py b/msrplib/trafficlog.py index 23edcd1..c646ddf 100644 --- a/msrplib/trafficlog.py +++ b/msrplib/trafficlog.py @@ -1,36 +1,36 @@ -# Copyright (C) 2008-2012 AG Projects. See LICENSE for details +# Copyright (C) 2008-2021 AG Projects. See LICENSE for details import datetime # noinspection PyPackageRequirements from application import log __all__ = 'Logger', class Logger(log.ContextualLogger): logger = log.get_logger('msrplib') def __init__(self, prefix=None, log_traffic=False): super(Logger, self).__init__(logger=self.logger) self.prefix = prefix or '' self.log_traffic = log_traffic def apply_context(self, message): return '{}{}'.format(self.prefix, message) if message != '' else '' def received_chunk(self, data, transport): if self.log_traffic: address_line = '{local.host}:{local.port} <-- {remote.host}:{remote.port}'.format(local=transport.getHost(), remote=transport.getPeer()) self.info('{} {}\n\n{}'.format(datetime.datetime.now(), address_line, data.chunk_header + data.data + data.chunk_footer)) def sent_chunk(self, data, transport): if self.log_traffic: address_line = '{local.host}:{local.port} --> {remote.host}:{remote.port}'.format(local=transport.getHost(), remote=transport.getPeer()) self.info('{} {}\n\n{}'.format(datetime.datetime.now(), address_line, data.encoded_header + data.data + data.encoded_footer)) def received_illegal_data(self, data, transport): if self.log_traffic: address_line = '{local.host}:{local.port} <-- {remote.host}:{remote.port}'.format(local=transport.getHost(), remote=transport.getPeer()) self.info('[Bad Message] {} {}\n\n{}'.format(datetime.datetime.now(), address_line, data))