python-awips/thrift/transport/TTransport.py

453 lines
13 KiB
Python
Raw Normal View History

2015-06-18 10:53:09 -06:00
#
# 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.
#
from struct import pack, unpack
from thrift.Thrift import TException
2018-06-19 09:19:08 -06:00
from ..compat import BufferIO
2015-06-18 10:53:09 -06:00
class TTransportException(TException):
2018-06-19 09:19:08 -06:00
"""Custom Transport Exception class"""
2015-06-18 10:53:09 -06:00
2018-06-19 09:19:08 -06:00
UNKNOWN = 0
NOT_OPEN = 1
ALREADY_OPEN = 2
TIMED_OUT = 3
END_OF_FILE = 4
NEGATIVE_SIZE = 5
SIZE_LIMIT = 6
2015-06-18 10:53:09 -06:00
2018-06-19 09:19:08 -06:00
def __init__(self, type=UNKNOWN, message=None):
TException.__init__(self, message)
self.type = type
2015-06-18 10:53:09 -06:00
2018-06-19 09:19:08 -06:00
class TTransportBase(object):
"""Base class for Thrift transport layer."""
2015-06-18 10:53:09 -06:00
2018-06-19 09:19:08 -06:00
def isOpen(self):
pass
2015-06-18 10:53:09 -06:00
2018-06-19 09:19:08 -06:00
def open(self):
pass
2015-06-18 10:53:09 -06:00
2018-06-19 09:19:08 -06:00
def close(self):
pass
2015-06-18 10:53:09 -06:00
2018-06-19 09:19:08 -06:00
def read(self, sz):
pass
2015-06-18 10:53:09 -06:00
2018-06-19 09:19:08 -06:00
def readAll(self, sz):
buff = b''
have = 0
while (have < sz):
chunk = self.read(sz - have)
have += len(chunk)
buff += chunk
2015-06-18 10:53:09 -06:00
2018-06-19 09:19:08 -06:00
if len(chunk) == 0:
raise EOFError()
2015-06-18 10:53:09 -06:00
2018-06-19 09:19:08 -06:00
return buff
2015-06-18 10:53:09 -06:00
2018-06-19 09:19:08 -06:00
def write(self, buf):
pass
2015-06-18 10:53:09 -06:00
2018-06-19 09:19:08 -06:00
def flush(self):
pass
2015-06-18 10:53:09 -06:00
# This class should be thought of as an interface.
2018-06-19 09:19:08 -06:00
class CReadableTransport(object):
"""base class for transports that are readable from C"""
2015-06-18 10:53:09 -06:00
2018-06-19 09:19:08 -06:00
# TODO(dreiss): Think about changing this interface to allow us to use
# a (Python, not c) StringIO instead, because it allows
# you to write after reading.
2015-06-18 10:53:09 -06:00
2018-06-19 09:19:08 -06:00
# NOTE: This is a classic class, so properties will NOT work
# correctly for setting.
@property
def cstringio_buf(self):
"""A cStringIO buffer that contains the current chunk we are reading."""
pass
2015-06-18 10:53:09 -06:00
2018-06-19 09:19:08 -06:00
def cstringio_refill(self, partialread, reqlen):
"""Refills cstringio_buf.
2015-06-18 10:53:09 -06:00
2018-06-19 09:19:08 -06:00
Returns the currently used buffer (which can but need not be the same as
the old cstringio_buf). partialread is what the C code has read from the
buffer, and should be inserted into the buffer before any more reads. The
return value must be a new, not borrowed reference. Something along the
lines of self._buf should be fine.
2015-06-18 10:53:09 -06:00
2018-06-19 09:19:08 -06:00
If reqlen bytes can't be read, throw EOFError.
"""
pass
2015-06-18 10:53:09 -06:00
2018-06-19 09:19:08 -06:00
class TServerTransportBase(object):
"""Base class for Thrift server transports."""
2015-06-18 10:53:09 -06:00
2018-06-19 09:19:08 -06:00
def listen(self):
pass
2015-06-18 10:53:09 -06:00
2018-06-19 09:19:08 -06:00
def accept(self):
pass
2015-06-18 10:53:09 -06:00
2018-06-19 09:19:08 -06:00
def close(self):
pass
2015-06-18 10:53:09 -06:00
2018-06-19 09:19:08 -06:00
class TTransportFactoryBase(object):
"""Base class for a Transport Factory"""
2015-06-18 10:53:09 -06:00
2018-06-19 09:19:08 -06:00
def getTransport(self, trans):
return trans
2015-06-18 10:53:09 -06:00
2018-06-19 09:19:08 -06:00
class TBufferedTransportFactory(object):
"""Factory transport that builds buffered transports"""
2015-06-18 10:53:09 -06:00
2018-06-19 09:19:08 -06:00
def getTransport(self, trans):
buffered = TBufferedTransport(trans)
return buffered
2015-06-18 10:53:09 -06:00
2018-06-19 09:19:08 -06:00
class TBufferedTransport(TTransportBase, CReadableTransport):
"""Class that wraps another transport and buffers its I/O.
2015-06-18 10:53:09 -06:00
2018-06-19 09:19:08 -06:00
The implementation uses a (configurable) fixed-size read buffer
but buffers all writes until a flush is performed.
"""
DEFAULT_BUFFER = 4096
def __init__(self, trans, rbuf_size=DEFAULT_BUFFER):
self.__trans = trans
self.__wbuf = BufferIO()
# Pass string argument to initialize read buffer as cStringIO.InputType
self.__rbuf = BufferIO(b'')
self.__rbuf_size = rbuf_size
def isOpen(self):
return self.__trans.isOpen()
def open(self):
return self.__trans.open()
def close(self):
return self.__trans.close()
def read(self, sz):
ret = self.__rbuf.read(sz)
if len(ret) != 0:
return ret
self.__rbuf = BufferIO(self.__trans.read(max(sz, self.__rbuf_size)))
return self.__rbuf.read(sz)
def write(self, buf):
try:
self.__wbuf.write(buf)
except Exception as e:
# on exception reset wbuf so it doesn't contain a partial function call
self.__wbuf = BufferIO()
raise e
self.__wbuf.getvalue()
def flush(self):
out = self.__wbuf.getvalue()
# reset wbuf before write/flush to preserve state on underlying failure
self.__wbuf = BufferIO()
self.__trans.write(out)
self.__trans.flush()
# Implement the CReadableTransport interface.
@property
def cstringio_buf(self):
return self.__rbuf
def cstringio_refill(self, partialread, reqlen):
retstring = partialread
if reqlen < self.__rbuf_size:
# try to make a read of as much as we can.
retstring += self.__trans.read(self.__rbuf_size)
# but make sure we do read reqlen bytes.
if len(retstring) < reqlen:
retstring += self.__trans.readAll(reqlen - len(retstring))
self.__rbuf = BufferIO(retstring)
return self.__rbuf
2015-06-18 10:53:09 -06:00
class TMemoryBuffer(TTransportBase, CReadableTransport):
2018-06-19 09:19:08 -06:00
"""Wraps a cBytesIO object as a TTransport.
2015-06-18 10:53:09 -06:00
2018-06-19 09:19:08 -06:00
NOTE: Unlike the C++ version of this class, you cannot write to it
then immediately read from it. If you want to read from a
TMemoryBuffer, you must either pass a string to the constructor.
TODO(dreiss): Make this work like the C++ version.
"""
2015-06-18 10:53:09 -06:00
2018-06-19 09:19:08 -06:00
def __init__(self, value=None):
"""value -- a value to read from for stringio
2015-06-18 10:53:09 -06:00
2018-06-19 09:19:08 -06:00
If value is set, this will be a transport for reading,
otherwise, it is for writing"""
if value is not None:
self._buffer = BufferIO(value)
else:
self._buffer = BufferIO()
2015-06-18 10:53:09 -06:00
2018-06-19 09:19:08 -06:00
def isOpen(self):
return not self._buffer.closed
2015-06-18 10:53:09 -06:00
2018-06-19 09:19:08 -06:00
def open(self):
pass
2015-06-18 10:53:09 -06:00
2018-06-19 09:19:08 -06:00
def close(self):
self._buffer.close()
2015-06-18 10:53:09 -06:00
2018-06-19 09:19:08 -06:00
def read(self, sz):
return self._buffer.read(sz)
2015-06-18 10:53:09 -06:00
2018-06-19 09:19:08 -06:00
def write(self, buf):
self._buffer.write(buf)
2015-06-18 10:53:09 -06:00
2018-06-19 09:19:08 -06:00
def flush(self):
pass
2015-06-18 10:53:09 -06:00
2018-06-19 09:19:08 -06:00
def getvalue(self):
return self._buffer.getvalue()
2015-06-18 10:53:09 -06:00
2018-06-19 09:19:08 -06:00
# Implement the CReadableTransport interface.
@property
def cstringio_buf(self):
return self._buffer
2015-06-18 10:53:09 -06:00
2018-06-19 09:19:08 -06:00
def cstringio_refill(self, partialread, reqlen):
# only one shot at reading...
raise EOFError()
2015-06-18 10:53:09 -06:00
2018-06-19 09:19:08 -06:00
class TFramedTransportFactory(object):
"""Factory transport that builds framed transports"""
2015-06-18 10:53:09 -06:00
2018-06-19 09:19:08 -06:00
def getTransport(self, trans):
framed = TFramedTransport(trans)
return framed
2015-06-18 10:53:09 -06:00
class TFramedTransport(TTransportBase, CReadableTransport):
2018-06-19 09:19:08 -06:00
"""Class that wraps another transport and frames its I/O when writing."""
def __init__(self, trans,):
self.__trans = trans
self.__rbuf = BufferIO(b'')
self.__wbuf = BufferIO()
def isOpen(self):
return self.__trans.isOpen()
def open(self):
return self.__trans.open()
def close(self):
return self.__trans.close()
def read(self, sz):
ret = self.__rbuf.read(sz)
if len(ret) != 0:
return ret
self.readFrame()
return self.__rbuf.read(sz)
def readFrame(self):
buff = self.__trans.readAll(4)
sz, = unpack('!i', buff)
self.__rbuf = BufferIO(self.__trans.readAll(sz))
def write(self, buf):
self.__wbuf.write(buf)
def flush(self):
wout = self.__wbuf.getvalue()
wsz = len(wout)
# reset wbuf before write/flush to preserve state on underlying failure
self.__wbuf = BufferIO()
# N.B.: Doing this string concatenation is WAY cheaper than making
# two separate calls to the underlying socket object. Socket writes in
# Python turn out to be REALLY expensive, but it seems to do a pretty
# good job of managing string buffer operations without excessive copies
buf = pack("!i", wsz) + wout
self.__trans.write(buf)
self.__trans.flush()
# Implement the CReadableTransport interface.
@property
def cstringio_buf(self):
return self.__rbuf
def cstringio_refill(self, prefix, reqlen):
# self.__rbuf will already be empty here because fastbinary doesn't
# ask for a refill until the previous buffer is empty. Therefore,
# we can start reading new frames immediately.
while len(prefix) < reqlen:
self.readFrame()
prefix += self.__rbuf.getvalue()
self.__rbuf = BufferIO(prefix)
return self.__rbuf
2015-06-18 10:53:09 -06:00
class TFileObjectTransport(TTransportBase):
2018-06-19 09:19:08 -06:00
"""Wraps a file-like object to make it work as a Thrift transport."""
def __init__(self, fileobj):
self.fileobj = fileobj
2015-06-18 10:53:09 -06:00
2018-06-19 09:19:08 -06:00
def isOpen(self):
return True
2015-06-18 10:53:09 -06:00
2018-06-19 09:19:08 -06:00
def close(self):
self.fileobj.close()
2015-06-18 10:53:09 -06:00
2018-06-19 09:19:08 -06:00
def read(self, sz):
return self.fileobj.read(sz)
2015-06-18 10:53:09 -06:00
2018-06-19 09:19:08 -06:00
def write(self, buf):
self.fileobj.write(buf)
2015-06-18 10:53:09 -06:00
2018-06-19 09:19:08 -06:00
def flush(self):
self.fileobj.flush()
class TSaslClientTransport(TTransportBase, CReadableTransport):
"""
SASL transport
"""
2015-06-18 10:53:09 -06:00
2018-06-19 09:19:08 -06:00
START = 1
OK = 2
BAD = 3
ERROR = 4
COMPLETE = 5
def __init__(self, transport, host, service, mechanism='GSSAPI',
**sasl_kwargs):
"""
transport: an underlying transport to use, typically just a TSocket
host: the name of the server, from a SASL perspective
service: the name of the server's service, from a SASL perspective
mechanism: the name of the preferred mechanism to use
All other kwargs will be passed to the puresasl.client.SASLClient
constructor.
"""
from puresasl.client import SASLClient
self.transport = transport
self.sasl = SASLClient(host, service, mechanism, **sasl_kwargs)
self.__wbuf = BufferIO()
self.__rbuf = BufferIO(b'')
def open(self):
if not self.transport.isOpen():
self.transport.open()
self.send_sasl_msg(self.START, self.sasl.mechanism)
self.send_sasl_msg(self.OK, self.sasl.process())
while True:
status, challenge = self.recv_sasl_msg()
if status == self.OK:
self.send_sasl_msg(self.OK, self.sasl.process(challenge))
elif status == self.COMPLETE:
if not self.sasl.complete:
raise TTransportException(
TTransportException.NOT_OPEN,
"The server erroneously indicated "
"that SASL negotiation was complete")
else:
break
else:
raise TTransportException(
TTransportException.NOT_OPEN,
"Bad SASL negotiation status: %d (%s)"
% (status, challenge))
def send_sasl_msg(self, status, body):
header = pack(">BI", status, len(body))
self.transport.write(header + body)
self.transport.flush()
def recv_sasl_msg(self):
header = self.transport.readAll(5)
status, length = unpack(">BI", header)
if length > 0:
payload = self.transport.readAll(length)
else:
payload = ""
return status, payload
def write(self, data):
self.__wbuf.write(data)
def flush(self):
data = self.__wbuf.getvalue()
encoded = self.sasl.wrap(data)
self.transport.write(''.join((pack("!i", len(encoded)), encoded)))
self.transport.flush()
self.__wbuf = BufferIO()
def read(self, sz):
ret = self.__rbuf.read(sz)
if len(ret) != 0:
return ret
self._read_frame()
return self.__rbuf.read(sz)
def _read_frame(self):
header = self.transport.readAll(4)
length, = unpack('!i', header)
encoded = self.transport.readAll(length)
self.__rbuf = BufferIO(self.sasl.unwrap(encoded))
def close(self):
self.sasl.dispose()
self.transport.close()
# based on TFramedTransport
@property
def cstringio_buf(self):
return self.__rbuf
def cstringio_refill(self, prefix, reqlen):
# self.__rbuf will already be empty here because fastbinary doesn't
# ask for a refill until the previous buffer is empty. Therefore,
# we can start reading new frames immediately.
while len(prefix) < reqlen:
self._read_frame()
prefix += self.__rbuf.getvalue()
self.__rbuf = BufferIO(prefix)
return self.__rbuf