source_code
stringlengths
45
7.24k
function_name
stringlengths
1
111
messages
list
def x(self, reason): self._server._disconnect_client(self._conn_key, self, reason)
disconnect
[ { "content": "Given the source code of a python function, suggest a fitting name for the function.", "role": "system" }, { "content": "def x(self, reason):\n self._server._disconnect_client(self._conn_key, self, reason)\n", "role": "user" }, { "content": "disconnect", "role": "assistant" } ]
def x(self, msg): assert msg.mtype == Message.INFORM return self._send_message(msg)
inform
[ { "content": "Given the source code of a python function, suggest a fitting name for the function.", "role": "system" }, { "content": "def x(self, msg):\n assert msg.mtype == Message.INFORM\n return self._send_message(msg)\n", "role": "user" }, { "content": "inform", "role": "assistant" } ]
def x(self, inform, orig_req): assert inform.mtype == Message.INFORM assert inform.name == orig_req.name inform.mid = orig_req.mid return self._send_message(inform)
reply_inform
[ { "content": "Given the source code of a python function, suggest a fitting name for the function.", "role": "system" }, { "content": "def x(self, inform, orig_req):\n assert inform.mtype == Message.INFORM\n assert inform.name == orig_req.name\n inform.mid = orig_req.mid\n return self._send_message(inform)\n", "role": "user" }, { "content": "reply_inform", "role": "assistant" } ]
def x(self, msg): assert msg.mtype == Message.INFORM return self._mass_send_message(msg)
mass_inform
[ { "content": "Given the source code of a python function, suggest a fitting name for the function.", "role": "system" }, { "content": "def x(self, msg):\n assert msg.mtype == Message.INFORM\n return self._mass_send_message(msg)\n", "role": "user" }, { "content": "mass_inform", "role": "assistant" } ]
def x(self, reply, orig_req): assert reply.mtype == Message.REPLY assert reply.name == orig_req.name reply.mid = orig_req.mid return self._send_message(reply)
reply
[ { "content": "Given the source code of a python function, suggest a fitting name for the function.", "role": "system" }, { "content": "def x(self, reply, orig_req):\n assert reply.mtype == Message.REPLY\n assert reply.name == orig_req.name\n reply.mid = orig_req.mid\n return self._send_message(reply)\n", "role": "user" }, { "content": "reply", "role": "assistant" } ]
def x(self, timeout=None): if self._running.isSet(): raise RuntimeError('Server already started') self._stopped.clear() self.ioloop = self._ioloop_manager.get_ioloop() self._ioloop_manager.start() self._tcp_server = tornado.tcpserver.TCPServer(self.ioloop, max_buffer_size=self.MAX_MSG_SIZE) self._tcp_server.handle_stream = self._handle_stream self._server_sock = self._bind_socket(self._bindaddr) self._bindaddr = self._server_sock.getsockname() self.ioloop.add_callback(self._install) if timeout: return self._running.wait(timeout)
start
[ { "content": "Given the source code of a python function, suggest a fitting name for the function.", "role": "system" }, { "content": "def x(self, timeout=None):\n if self._running.isSet():\n raise RuntimeError('Server already started')\n self._stopped.clear()\n self.ioloop = self._ioloop_manager.get_ioloop()\n self._ioloop_manager.start()\n self._tcp_server = tornado.tcpserver.TCPServer(self.ioloop,\n max_buffer_size=self.MAX_MSG_SIZE)\n self._tcp_server.handle_stream = self._handle_stream\n self._server_sock = self._bind_socket(self._bindaddr)\n self._bindaddr = self._server_sock.getsockname()\n self.ioloop.add_callback(self._install)\n if timeout:\n return self._running.wait(timeout)\n", "role": "user" }, { "content": "start", "role": "assistant" } ]
def x(self, timeout=1.0): if timeout: self._running.wait(timeout) return self._ioloop_manager.stop(callback=self._uninstall)
stop
[ { "content": "Given the source code of a python function, suggest a fitting name for the function.", "role": "system" }, { "content": "def x(self, timeout=1.0):\n if timeout:\n self._running.wait(timeout)\n return self._ioloop_manager.stop(callback=self._uninstall)\n", "role": "user" }, { "content": "stop", "role": "assistant" } ]
def x(self, timeout=None): t0 = time.time() self._ioloop_manager.join(timeout=timeout) if timeout: self._stopped.wait(timeout - (time.time() - t0))
join
[ { "content": "Given the source code of a python function, suggest a fitting name for the function.", "role": "system" }, { "content": "def x(self, timeout=None):\n t0 = time.time()\n self._ioloop_manager.join(timeout=timeout)\n if timeout:\n self._stopped.wait(timeout - (time.time() - t0))\n", "role": "user" }, { "content": "join", "role": "assistant" } ]
def x(self, bindaddr): sock = socket.socket(socket.AF_INET, socket.SOCK_STREAM) sock.setsockopt(socket.SOL_SOCKET, socket.SO_REUSEADDR, 1) sock.setblocking(0) try: sock.bind(bindaddr) except Exception: self._logger.exception('Unable to bind to %s' % str(bindaddr)) raise sock.listen(self.BACKLOG) return sock
bind_socket
[ { "content": "Given the source code of a python function, suggest a fitting name for the function.", "role": "system" }, { "content": "def x(self, bindaddr):\n sock = socket.socket(socket.AF_INET, socket.SOCK_STREAM)\n sock.setsockopt(socket.SOL_SOCKET, socket.SO_REUSEADDR, 1)\n sock.setblocking(0)\n try:\n sock.bind(bindaddr)\n except Exception:\n self._logger.exception('Unable to bind to %s' % str(bindaddr))\n raise\n sock.listen(self.BACKLOG)\n return sock\n", "role": "user" }, { "content": "bind_socket", "role": "assistant" } ]
def x(self, stream, address): try: assert get_thread_ident() == self.ioloop_thread_id stream.set_close_callback(partial(self._stream_closed_callback, stream) ) stream.set_nodelay(True) stream.max_write_buffer_size = self.MAX_WRITE_BUFFER_SIZE stream.KATCPServer_address = address stream.KATCPServer_closing = False client_conn = self.client_connection_factory(self, stream) self._connections[stream] = client_conn try: yield gen.maybe_future(self._device.on_client_connect(client_conn)) except Exception: e_type, e_value, trace = sys.exc_info() reason = '\n'.join(traceback.format_exception(e_type, e_value, trace, self._tb_limit)) log_msg = 'Device error initialising connection {0}'.format(reason) self._logger.error(log_msg) stream.write(str(Message.inform('log', log_msg))) stream.close(exc_info=True) else: self._line_read_loop(stream, client_conn) except Exception: self._logger.error( 'Unhandled exception trying to handle new connection', exc_info =True)
handle_stream
[ { "content": "Given the source code of a python function, suggest a fitting name for the function.", "role": "system" }, { "content": "def x(self, stream, address):\n try:\n assert get_thread_ident() == self.ioloop_thread_id\n stream.set_close_callback(partial(self._stream_closed_callback, stream)\n )\n stream.set_nodelay(True)\n stream.max_write_buffer_size = self.MAX_WRITE_BUFFER_SIZE\n stream.KATCPServer_address = address\n stream.KATCPServer_closing = False\n client_conn = self.client_connection_factory(self, stream)\n self._connections[stream] = client_conn\n try:\n yield gen.maybe_future(self._device.on_client_connect(client_conn))\n except Exception:\n e_type, e_value, trace = sys.exc_info()\n reason = '\\n'.join(traceback.format_exception(e_type, e_value,\n trace, self._tb_limit))\n log_msg = 'Device error initialising connection {0}'.format(reason)\n self._logger.error(log_msg)\n stream.write(str(Message.inform('log', log_msg)))\n stream.close(exc_info=True)\n else:\n self._line_read_loop(stream, client_conn)\n except Exception:\n self._logger.error(\n 'Unhandled exception trying to handle new connection', exc_info\n =True)\n", "role": "user" }, { "content": "handle_stream", "role": "assistant" } ]
def x(self, stream): try: addr = ':'.join(str(part) for part in stream.KATCPServer_address) except AttributeError: addr = '<error>' self._logger.warn('Could not determine address of stream', exc_info =True) return addr
get_address
[ { "content": "Given the source code of a python function, suggest a fitting name for the function.", "role": "system" }, { "content": "def x(self, stream):\n try:\n addr = ':'.join(str(part) for part in stream.KATCPServer_address)\n except AttributeError:\n addr = '<error>'\n self._logger.warn('Could not determine address of stream', exc_info\n =True)\n return addr\n", "role": "user" }, { "content": "get_address", "role": "assistant" } ]
def x(self, stream, msg): assert get_thread_ident() == self.ioloop_thread_id try: if stream.KATCPServer_closing: raise RuntimeError( 'Stream is closing so we cannot accept any more writes') return stream.write(str(msg) + '\n') except Exception: addr = self.get_address(stream) self._logger.warn('Could not send message {0!r} to {1}'.format(str( msg), addr), exc_info=True) stream.close(exc_info=True)
send_message
[ { "content": "Given the source code of a python function, suggest a fitting name for the function.", "role": "system" }, { "content": "def x(self, stream, msg):\n assert get_thread_ident() == self.ioloop_thread_id\n try:\n if stream.KATCPServer_closing:\n raise RuntimeError(\n 'Stream is closing so we cannot accept any more writes')\n return stream.write(str(msg) + '\\n')\n except Exception:\n addr = self.get_address(stream)\n self._logger.warn('Could not send message {0!r} to {1}'.format(str(\n msg), addr), exc_info=True)\n stream.close(exc_info=True)\n", "role": "user" }, { "content": "send_message", "role": "assistant" } ]
def x(self, stream): assert get_thread_ident() == self.ioloop_thread_id stream.KATCPServer_closing = True return stream.write('\n')
flush_on_close
[ { "content": "Given the source code of a python function, suggest a fitting name for the function.", "role": "system" }, { "content": "def x(self, stream):\n assert get_thread_ident() == self.ioloop_thread_id\n stream.KATCPServer_closing = True\n return stream.write('\\n')\n", "role": "user" }, { "content": "flush_on_close", "role": "assistant" } ]
def x(self, stream, msg): return self.call_from_thread(partial(self.send_message, stream, msg))
send_message_from_thread
[ { "content": "Given the source code of a python function, suggest a fitting name for the function.", "role": "system" }, { "content": "def x(self, stream, msg):\n return self.call_from_thread(partial(self.send_message, stream, msg))\n", "role": "user" }, { "content": "send_message_from_thread", "role": "assistant" } ]
def x(self, msg): for stream in self._connections.keys(): if not stream.closed(): self.send_message(stream, msg)
mass_send_message
[ { "content": "Given the source code of a python function, suggest a fitting name for the function.", "role": "system" }, { "content": "def x(self, msg):\n for stream in self._connections.keys():\n if not stream.closed():\n self.send_message(stream, msg)\n", "role": "user" }, { "content": "mass_send_message", "role": "assistant" } ]
def x(self, rep_msg): self._post_reply() return self.client_connection.reply(rep_msg, self.msg)
reply_with_message
[ { "content": "Given the source code of a python function, suggest a fitting name for the function.", "role": "system" }, { "content": "def x(self, rep_msg):\n self._post_reply()\n return self.client_connection.reply(rep_msg, self.msg)\n", "role": "user" }, { "content": "reply_with_message", "role": "assistant" } ]
def x(self, client_conn, msg): MAX_QUEUE_SIZE = 30 if len(self._msg_queue) >= MAX_QUEUE_SIZE: raise RuntimeError( 'MessageHandlerThread unhandled message queue full, not handling message' ) ready_future = Future() self._msg_queue.append((ready_future, client_conn, msg)) self._wake.set() return ready_future
on_message
[ { "content": "Given the source code of a python function, suggest a fitting name for the function.", "role": "system" }, { "content": "def x(self, client_conn, msg):\n MAX_QUEUE_SIZE = 30\n if len(self._msg_queue) >= MAX_QUEUE_SIZE:\n raise RuntimeError(\n 'MessageHandlerThread unhandled message queue full, not handling message'\n )\n ready_future = Future()\n self._msg_queue.append((ready_future, client_conn, msg))\n self._wake.set()\n return ready_future\n", "role": "user" }, { "content": "on_message", "role": "assistant" } ]
def x(self, timeout=1.0): if timeout: self._running.wait(timeout) self._running.clear() self._wake.set()
stop
[ { "content": "Given the source code of a python function, suggest a fitting name for the function.", "role": "system" }, { "content": "def x(self, timeout=1.0):\n if timeout:\n self._running.wait(timeout)\n self._running.clear()\n self._wake.set()\n", "role": "user" }, { "content": "stop", "role": "assistant" } ]
def x(self, level_name, msg, name, timestamp=None): if timestamp is None: timestamp = time.time() katcp_version = self.PROTOCOL_INFO.major timestamp_msg = ('%.6f' % timestamp if katcp_version >= SEC_TS_KATCP_MAJOR else str(int(timestamp * 1000))) return Message.inform('log', level_name, timestamp_msg, name, msg)
create_log_inform
[ { "content": "Given the source code of a python function, suggest a fitting name for the function.", "role": "system" }, { "content": "def x(self, level_name, msg, name, timestamp=None):\n if timestamp is None:\n timestamp = time.time()\n katcp_version = self.PROTOCOL_INFO.major\n timestamp_msg = ('%.6f' % timestamp if katcp_version >=\n SEC_TS_KATCP_MAJOR else str(int(timestamp * 1000)))\n return Message.inform('log', level_name, timestamp_msg, name, msg)\n", "role": "user" }, { "content": "create_log_inform", "role": "assistant" } ]
def x(self, client_conn, msg): self._logger.debug('received: {0!s}'.format(msg)) if msg.mtype == msg.REQUEST: return self.handle_request(client_conn, msg) elif msg.mtype == msg.INFORM: return self.handle_inform(client_conn, msg) elif msg.mtype == msg.REPLY: return self.handle_reply(client_conn, msg) else: reason = "Unexpected message type received by server ['%s']." % (msg,) client_conn.inform(self.create_log_inform('error', reason, 'root'))
handle_message
[ { "content": "Given the source code of a python function, suggest a fitting name for the function.", "role": "system" }, { "content": "def x(self, client_conn, msg):\n self._logger.debug('received: {0!s}'.format(msg))\n if msg.mtype == msg.REQUEST:\n return self.handle_request(client_conn, msg)\n elif msg.mtype == msg.INFORM:\n return self.handle_inform(client_conn, msg)\n elif msg.mtype == msg.REPLY:\n return self.handle_reply(client_conn, msg)\n else:\n reason = \"Unexpected message type received by server ['%s'].\" % (msg,)\n client_conn.inform(self.create_log_inform('error', reason, 'root'))\n", "role": "user" }, { "content": "handle_message", "role": "assistant" } ]
def x(self, connection, msg): if msg.name in self._inform_handlers: try: self._inform_handlers[msg.name](self, connection, msg) except Exception: e_type, e_value, trace = sys.exc_info() reason = '\n'.join(traceback.format_exception(e_type, e_value, trace, self._tb_limit)) self._logger.error('Inform %s FAIL: %s' % (msg.name, reason)) else: self._logger.warn('%s INVALID: Unknown inform.' % (msg.name,))
handle_inform
[ { "content": "Given the source code of a python function, suggest a fitting name for the function.", "role": "system" }, { "content": "def x(self, connection, msg):\n if msg.name in self._inform_handlers:\n try:\n self._inform_handlers[msg.name](self, connection, msg)\n except Exception:\n e_type, e_value, trace = sys.exc_info()\n reason = '\\n'.join(traceback.format_exception(e_type, e_value,\n trace, self._tb_limit))\n self._logger.error('Inform %s FAIL: %s' % (msg.name, reason))\n else:\n self._logger.warn('%s INVALID: Unknown inform.' % (msg.name,))\n", "role": "user" }, { "content": "handle_inform", "role": "assistant" } ]
def x(self, connection, msg): if isinstance(connection, ClientRequestConnection): self._logger.warn( """Deprecation warning: do not use self.inform() within a reply handler context -- use req.inform() Traceback: %s""" , ''.join(traceback.format_stack())) connection = connection.client_connection connection.inform(msg)
inform
[ { "content": "Given the source code of a python function, suggest a fitting name for the function.", "role": "system" }, { "content": "def x(self, connection, msg):\n if isinstance(connection, ClientRequestConnection):\n self._logger.warn(\n \"\"\"Deprecation warning: do not use self.inform() within a reply handler context -- use req.inform()\nTraceback:\n %s\"\"\"\n , ''.join(traceback.format_stack()))\n connection = connection.client_connection\n connection.inform(msg)\n", "role": "user" }, { "content": "inform", "role": "assistant" } ]
def x(self, msg): assert msg.mtype == Message.INFORM self._server.mass_send_message_from_thread(msg)
mass_inform
[ { "content": "Given the source code of a python function, suggest a fitting name for the function.", "role": "system" }, { "content": "def x(self, msg):\n assert msg.mtype == Message.INFORM\n self._server.mass_send_message_from_thread(msg)\n", "role": "user" }, { "content": "mass_inform", "role": "assistant" } ]
def x(self, connection, reply, orig_req): if isinstance(connection, ClientRequestConnection): self._logger.warn( """Deprecation warning: do not use self.reply() within a reply handler context -- use req.reply(*msg_args) or req.reply_with_message(msg) Traceback: %s""" , ''.join(traceback.format_stack())) connection = connection.client_connection connection.reply(reply, orig_req)
reply
[ { "content": "Given the source code of a python function, suggest a fitting name for the function.", "role": "system" }, { "content": "def x(self, connection, reply, orig_req):\n if isinstance(connection, ClientRequestConnection):\n self._logger.warn(\n \"\"\"Deprecation warning: do not use self.reply() within a reply handler context -- use req.reply(*msg_args)\nor req.reply_with_message(msg) Traceback:\n %s\"\"\"\n , ''.join(traceback.format_stack()))\n connection = connection.client_connection\n connection.reply(reply, orig_req)\n", "role": "user" }, { "content": "reply", "role": "assistant" } ]
def x(self, connection, inform, orig_req): if isinstance(connection, ClientRequestConnection): self._logger.warn( """Deprecation warning: do not use self.reply_inform() within a reply handler context -- use req.inform(*inform_arguments) Traceback: %s""" , ''.join(traceback.format_stack())) connection = connection.client_connection connection.reply_inform(inform, orig_req)
reply_inform
[ { "content": "Given the source code of a python function, suggest a fitting name for the function.", "role": "system" }, { "content": "def x(self, connection, inform, orig_req):\n if isinstance(connection, ClientRequestConnection):\n self._logger.warn(\n \"\"\"Deprecation warning: do not use self.reply_inform() within a reply handler context -- use req.inform(*inform_arguments)\nTraceback:\n %s\"\"\"\n , ''.join(traceback.format_stack()))\n connection = connection.client_connection\n connection.reply_inform(inform, orig_req)\n", "role": "user" }, { "content": "reply_inform", "role": "assistant" } ]
def x(self, ioloop=None): self._server.set_ioloop(ioloop) self.ioloop = self._server.ioloop
set_ioloop
[ { "content": "Given the source code of a python function, suggest a fitting name for the function.", "role": "system" }, { "content": "def x(self, ioloop=None):\n self._server.set_ioloop(ioloop)\n self.ioloop = self._server.ioloop\n", "role": "user" }, { "content": "set_ioloop", "role": "assistant" } ]
def x(self, thread_safe=True, handler_thread=True): if handler_thread: assert thread_safe, 'handler_thread=True requires thread_safe=True' self._server.client_connection_factory = (ThreadsafeClientConnection if thread_safe else ClientConnection) if handler_thread: self._handler_thread = MessageHandlerThread(self.handle_message, self.create_log_inform, self._logger) self.on_message = self._handler_thread.on_message else: self.on_message = return_future(self.handle_message) self._handler_thread = None self._concurrency_options = ObjectDict(thread_safe=thread_safe, handler_thread=handler_thread)
set_concurrency_options
[ { "content": "Given the source code of a python function, suggest a fitting name for the function.", "role": "system" }, { "content": "def x(self, thread_safe=True, handler_thread=True):\n if handler_thread:\n assert thread_safe, 'handler_thread=True requires thread_safe=True'\n self._server.client_connection_factory = (ThreadsafeClientConnection if\n thread_safe else ClientConnection)\n if handler_thread:\n self._handler_thread = MessageHandlerThread(self.handle_message,\n self.create_log_inform, self._logger)\n self.on_message = self._handler_thread.on_message\n else:\n self.on_message = return_future(self.handle_message)\n self._handler_thread = None\n self._concurrency_options = ObjectDict(thread_safe=thread_safe,\n handler_thread=handler_thread)\n", "role": "user" }, { "content": "set_concurrency_options", "role": "assistant" } ]
def x(self, timeout=None): if self._handler_thread and self._handler_thread.isAlive(): raise RuntimeError('Message handler thread already started') self._server.start(timeout) self.ioloop = self._server.ioloop if self._handler_thread: self._handler_thread.set_ioloop(self.ioloop) self._handler_thread.start(timeout)
start
[ { "content": "Given the source code of a python function, suggest a fitting name for the function.", "role": "system" }, { "content": "def x(self, timeout=None):\n if self._handler_thread and self._handler_thread.isAlive():\n raise RuntimeError('Message handler thread already started')\n self._server.start(timeout)\n self.ioloop = self._server.ioloop\n if self._handler_thread:\n self._handler_thread.set_ioloop(self.ioloop)\n self._handler_thread.start(timeout)\n", "role": "user" }, { "content": "start", "role": "assistant" } ]
def x(self, timeout=None): self._server.join(timeout) if self._handler_thread: self._handler_thread.join(timeout)
join
[ { "content": "Given the source code of a python function, suggest a fitting name for the function.", "role": "system" }, { "content": "def x(self, timeout=None):\n self._server.join(timeout)\n if self._handler_thread:\n self._handler_thread.join(timeout)\n", "role": "user" }, { "content": "join", "role": "assistant" } ]
def x(self, timeout=1.0): stopped = self._server.stop(timeout) if self._handler_thread: self._handler_thread.stop(timeout) return stopped
stop
[ { "content": "Given the source code of a python function, suggest a fitting name for the function.", "role": "system" }, { "content": "def x(self, timeout=1.0):\n stopped = self._server.stop(timeout)\n if self._handler_thread:\n self._handler_thread.stop(timeout)\n return stopped\n", "role": "user" }, { "content": "stop", "role": "assistant" } ]
def x(self, timeout=None): in_ioloop = self._server.in_ioloop_thread() if in_ioloop: f = tornado_Future() else: f = Future() def x(): f.set_result(None) self.ioloop.add_callback(cb) if in_ioloop: return f else: f.result(timeout)
sync_with_ioloop
[ { "content": "Given the source code of a python function, suggest a fitting name for the function.", "role": "system" }, { "content": "def x(self, timeout=None):\n in_ioloop = self._server.in_ioloop_thread()\n if in_ioloop:\n f = tornado_Future()\n else:\n f = Future()\n\n def x():\n f.set_result(None)\n self.ioloop.add_callback(cb)\n if in_ioloop:\n return f\n else:\n f.result(timeout)\n", "role": "user" }, { "content": "sync_with_ioloop", "role": "assistant" } ]
def x(self, client_conn): assert get_thread_ident() == self._server.ioloop_thread_id self._client_conns.add(client_conn) self._strategies[client_conn] = {} katcp_version = self.PROTOCOL_INFO.major if katcp_version >= VERSION_CONNECT_KATCP_MAJOR: client_conn.inform(Message.inform('version-connect', 'katcp-protocol', self.PROTOCOL_INFO)) client_conn.inform(Message.inform('version-connect', 'katcp-library', 'katcp-python-%s' % katcp.__version__)) client_conn.inform(Message.inform('version-connect', 'katcp-device', self.version(), self.build_state())) else: client_conn.inform(Message.inform('version', self.version())) client_conn.inform(Message.inform('build-state', self.build_state()))
on_client_connect
[ { "content": "Given the source code of a python function, suggest a fitting name for the function.", "role": "system" }, { "content": "def x(self, client_conn):\n assert get_thread_ident() == self._server.ioloop_thread_id\n self._client_conns.add(client_conn)\n self._strategies[client_conn] = {}\n katcp_version = self.PROTOCOL_INFO.major\n if katcp_version >= VERSION_CONNECT_KATCP_MAJOR:\n client_conn.inform(Message.inform('version-connect',\n 'katcp-protocol', self.PROTOCOL_INFO))\n client_conn.inform(Message.inform('version-connect',\n 'katcp-library', 'katcp-python-%s' % katcp.__version__))\n client_conn.inform(Message.inform('version-connect', 'katcp-device',\n self.version(), self.build_state()))\n else:\n client_conn.inform(Message.inform('version', self.version()))\n client_conn.inform(Message.inform('build-state', self.build_state()))\n", "role": "user" }, { "content": "on_client_connect", "role": "assistant" } ]
def x(self, client_conn, remove_client=False): assert get_thread_ident() == self._server.ioloop_thread_id getter = self._strategies.pop if remove_client else self._strategies.get strategies = getter(client_conn, None) if strategies is not None: for sensor, strategy in list(strategies.items()): strategy.cancel() del strategies[sensor]
clear_strategies
[ { "content": "Given the source code of a python function, suggest a fitting name for the function.", "role": "system" }, { "content": "def x(self, client_conn, remove_client=False):\n assert get_thread_ident() == self._server.ioloop_thread_id\n getter = self._strategies.pop if remove_client else self._strategies.get\n strategies = getter(client_conn, None)\n if strategies is not None:\n for sensor, strategy in list(strategies.items()):\n strategy.cancel()\n del strategies[sensor]\n", "role": "user" }, { "content": "clear_strategies", "role": "assistant" } ]
def x(self, client_conn, msg, connection_valid): f = tornado_Future() @gen.coroutine def x(): self.clear_strategies(client_conn, remove_client=True) if connection_valid: client_conn.inform(Message.inform('disconnect', msg)) yield client_conn.flush_on_close() try: self._client_conns.remove(client_conn) self.ioloop.add_callback(lambda : chain_future(remove_strategies(), f)) except Exception: f.set_exc_info(sys.exc_info()) return f
on_client_disconnect
[ { "content": "Given the source code of a python function, suggest a fitting name for the function.", "role": "system" }, { "content": "def x(self, client_conn, msg, connection_valid):\n f = tornado_Future()\n\n @gen.coroutine\n def x():\n self.clear_strategies(client_conn, remove_client=True)\n if connection_valid:\n client_conn.inform(Message.inform('disconnect', msg))\n yield client_conn.flush_on_close()\n try:\n self._client_conns.remove(client_conn)\n self.ioloop.add_callback(lambda : chain_future(remove_strategies(), f))\n except Exception:\n f.set_exc_info(sys.exc_info())\n return f\n", "role": "user" }, { "content": "on_client_disconnect", "role": "assistant" } ]
def x(self, sensor): if isinstance(sensor, basestring): sensor_name = sensor else: sensor_name = sensor.name sensor = self._sensors.pop(sensor_name) def x(): for conn_strategies in self._strategies.values(): strategy = conn_strategies.pop(sensor, None) if strategy: strategy.cancel() self.ioloop.add_callback(cancel_sensor_strategies)
remove_sensor
[ { "content": "Given the source code of a python function, suggest a fitting name for the function.", "role": "system" }, { "content": "def x(self, sensor):\n if isinstance(sensor, basestring):\n sensor_name = sensor\n else:\n sensor_name = sensor.name\n sensor = self._sensors.pop(sensor_name)\n\n def x():\n for conn_strategies in self._strategies.values():\n strategy = conn_strategies.pop(sensor, None)\n if strategy:\n strategy.cancel()\n self.ioloop.add_callback(cancel_sensor_strategies)\n", "role": "user" }, { "content": "remove_sensor", "role": "assistant" } ]
def x(self, sensor_name): sensor = self._sensors.get(sensor_name, None) if not sensor: raise ValueError("Unknown sensor '%s'." % (sensor_name,)) return sensor
get_sensor
[ { "content": "Given the source code of a python function, suggest a fitting name for the function.", "role": "system" }, { "content": "def x(self, sensor_name):\n sensor = self._sensors.get(sensor_name, None)\n if not sensor:\n raise ValueError(\"Unknown sensor '%s'.\" % (sensor_name,))\n return sensor\n", "role": "user" }, { "content": "get_sensor", "role": "assistant" } ]
def x(self, req, msg): f = Future() @gen.coroutine def x(): req.reply('ok') yield gen.moment self.stop(timeout=None) raise AsyncReply self.ioloop.add_callback(lambda : chain_future(_halt(), f)) return f
request_halt
[ { "content": "Given the source code of a python function, suggest a fitting name for the function.", "role": "system" }, { "content": "def x(self, req, msg):\n f = Future()\n\n @gen.coroutine\n def x():\n req.reply('ok')\n yield gen.moment\n self.stop(timeout=None)\n raise AsyncReply\n self.ioloop.add_callback(lambda : chain_future(_halt(), f))\n return f\n", "role": "user" }, { "content": "request_halt", "role": "assistant" } ]
def x(self, req, msg): if not msg.arguments: for name, method in sorted(self._request_handlers.items()): doc = method.__doc__ req.inform(name, doc) num_methods = len(self._request_handlers) return req.make_reply('ok', str(num_methods)) else: name = msg.arguments[0] if name in self._request_handlers: method = self._request_handlers[name] doc = method.__doc__.strip() req.inform(name, doc) return req.make_reply('ok', '1') return req.make_reply('fail', 'Unknown request method.')
request_help
[ { "content": "Given the source code of a python function, suggest a fitting name for the function.", "role": "system" }, { "content": "def x(self, req, msg):\n if not msg.arguments:\n for name, method in sorted(self._request_handlers.items()):\n doc = method.__doc__\n req.inform(name, doc)\n num_methods = len(self._request_handlers)\n return req.make_reply('ok', str(num_methods))\n else:\n name = msg.arguments[0]\n if name in self._request_handlers:\n method = self._request_handlers[name]\n doc = method.__doc__.strip()\n req.inform(name, doc)\n return req.make_reply('ok', '1')\n return req.make_reply('fail', 'Unknown request method.')\n", "role": "user" }, { "content": "request_help", "role": "assistant" } ]
def x(self, req, request): timeout_hints = {} if request: if request not in self._request_handlers: raise FailReply('Unknown request method') timeout_hint = getattr(self._request_handlers[request], 'request_timeout_hint', None) timeout_hint = timeout_hint or 0 timeout_hints[request] = timeout_hint else: for request_, handler in self._request_handlers.items(): timeout_hint = getattr(handler, 'request_timeout_hint', None) if timeout_hint: timeout_hints[request_] = timeout_hint cnt = len(timeout_hints) for request_name, timeout_hint in sorted(timeout_hints.items()): req.inform(request_name, float(timeout_hint)) return 'ok', cnt
request_request_timeout_hint
[ { "content": "Given the source code of a python function, suggest a fitting name for the function.", "role": "system" }, { "content": "def x(self, req, request):\n timeout_hints = {}\n if request:\n if request not in self._request_handlers:\n raise FailReply('Unknown request method')\n timeout_hint = getattr(self._request_handlers[request],\n 'request_timeout_hint', None)\n timeout_hint = timeout_hint or 0\n timeout_hints[request] = timeout_hint\n else:\n for request_, handler in self._request_handlers.items():\n timeout_hint = getattr(handler, 'request_timeout_hint', None)\n if timeout_hint:\n timeout_hints[request_] = timeout_hint\n cnt = len(timeout_hints)\n for request_name, timeout_hint in sorted(timeout_hints.items()):\n req.inform(request_name, float(timeout_hint))\n return 'ok', cnt\n", "role": "user" }, { "content": "request_request_timeout_hint", "role": "assistant" } ]
def x(self, req, msg): if self._restart_queue is None: raise FailReply('No restart queue registered -- cannot restart.') f = tornado_Future() @gen.coroutine def x(): self._restart_queue.put_nowait(self) req.reply('ok') raise AsyncReply self.ioloop.add_callback(lambda : chain_future(_restart(), f)) return f
request_restart
[ { "content": "Given the source code of a python function, suggest a fitting name for the function.", "role": "system" }, { "content": "def x(self, req, msg):\n if self._restart_queue is None:\n raise FailReply('No restart queue registered -- cannot restart.')\n f = tornado_Future()\n\n @gen.coroutine\n def x():\n self._restart_queue.put_nowait(self)\n req.reply('ok')\n raise AsyncReply\n self.ioloop.add_callback(lambda : chain_future(_restart(), f))\n return f\n", "role": "user" }, { "content": "request_restart", "role": "assistant" } ]
def x(self, req, msg): clients = self._client_conns num_clients = len(clients) for conn in clients: addr = conn.address req.inform(addr) return req.make_reply('ok', str(num_clients))
request_client_list
[ { "content": "Given the source code of a python function, suggest a fitting name for the function.", "role": "system" }, { "content": "def x(self, req, msg):\n clients = self._client_conns\n num_clients = len(clients)\n for conn in clients:\n addr = conn.address\n req.inform(addr)\n return req.make_reply('ok', str(num_clients))\n", "role": "user" }, { "content": "request_client_list", "role": "assistant" } ]
def x(self, req, msg): versions = [('katcp-protocol', (self.PROTOCOL_INFO, None)), ( 'katcp-library', ('katcp-python-%s' % katcp.__version__, katcp. __version__)), ('katcp-device', (self.version(), self.build_state()))] extra_versions = sorted(self.extra_versions.items()) for name, (version, build_state) in (versions + extra_versions): if build_state is None: inform_args = name, version else: inform_args = name, version, build_state req.inform(*inform_args) num_versions = len(versions) + len(extra_versions) return req.make_reply('ok', str(num_versions))
request_version_list
[ { "content": "Given the source code of a python function, suggest a fitting name for the function.", "role": "system" }, { "content": "def x(self, req, msg):\n versions = [('katcp-protocol', (self.PROTOCOL_INFO, None)), (\n 'katcp-library', ('katcp-python-%s' % katcp.__version__, katcp.\n __version__)), ('katcp-device', (self.version(), self.build_state()))]\n extra_versions = sorted(self.extra_versions.items())\n for name, (version, build_state) in (versions + extra_versions):\n if build_state is None:\n inform_args = name, version\n else:\n inform_args = name, version, build_state\n req.inform(*inform_args)\n num_versions = len(versions) + len(extra_versions)\n return req.make_reply('ok', str(num_versions))\n", "role": "user" }, { "content": "request_version_list", "role": "assistant" } ]
def x(self, req, msg): exact, name_filter = construct_name_filter(msg.arguments[0] if msg. arguments else None) sensors = [(name, sensor) for name, sensor in sorted(self._sensors. iteritems()) if name_filter(name)] if exact and not sensors: return req.make_reply('fail', 'Unknown sensor name.') self._send_sensor_value_informs(req, sensors) return req.make_reply('ok', str(len(sensors)))
request_sensor_list
[ { "content": "Given the source code of a python function, suggest a fitting name for the function.", "role": "system" }, { "content": "def x(self, req, msg):\n exact, name_filter = construct_name_filter(msg.arguments[0] if msg.\n arguments else None)\n sensors = [(name, sensor) for name, sensor in sorted(self._sensors.\n iteritems()) if name_filter(name)]\n if exact and not sensors:\n return req.make_reply('fail', 'Unknown sensor name.')\n self._send_sensor_value_informs(req, sensors)\n return req.make_reply('ok', str(len(sensors)))\n", "role": "user" }, { "content": "request_sensor_list", "role": "assistant" } ]
def x(self, req, msg): exact, name_filter = construct_name_filter(msg.arguments[0] if msg. arguments else None) sensors = [(name, sensor) for name, sensor in sorted(self._sensors. iteritems()) if name_filter(name)] if exact and not sensors: return req.make_reply('fail', 'Unknown sensor name.') katcp_version = self.PROTOCOL_INFO.major for name, sensor in sensors: timestamp, status, value = sensor.read_formatted(katcp_version) req.inform(timestamp, '1', name, status, value) return req.make_reply('ok', str(len(sensors)))
request_sensor_value
[ { "content": "Given the source code of a python function, suggest a fitting name for the function.", "role": "system" }, { "content": "def x(self, req, msg):\n exact, name_filter = construct_name_filter(msg.arguments[0] if msg.\n arguments else None)\n sensors = [(name, sensor) for name, sensor in sorted(self._sensors.\n iteritems()) if name_filter(name)]\n if exact and not sensors:\n return req.make_reply('fail', 'Unknown sensor name.')\n katcp_version = self.PROTOCOL_INFO.major\n for name, sensor in sensors:\n timestamp, status, value = sensor.read_formatted(katcp_version)\n req.inform(timestamp, '1', name, status, value)\n return req.make_reply('ok', str(len(sensors)))\n", "role": "user" }, { "content": "request_sensor_value", "role": "assistant" } ]
def x(self, req, msg): f = Future() self.ioloop.add_callback(lambda : chain_future(self. _handle_sensor_sampling(req, msg), f)) return f
request_sensor_sampling
[ { "content": "Given the source code of a python function, suggest a fitting name for the function.", "role": "system" }, { "content": "def x(self, req, msg):\n f = Future()\n self.ioloop.add_callback(lambda : chain_future(self.\n _handle_sensor_sampling(req, msg), f))\n return f\n", "role": "user" }, { "content": "request_sensor_sampling", "role": "assistant" } ]
def x(self, req): f = Future() @gen.coroutine def x(): self.clear_strategies(req.client_connection) raise gen.Return(('ok',)) self.ioloop.add_callback(lambda : chain_future(_clear_strategies(), f)) return f
request_sensor_sampling_clear
[ { "content": "Given the source code of a python function, suggest a fitting name for the function.", "role": "system" }, { "content": "def x(self, req):\n f = Future()\n\n @gen.coroutine\n def x():\n self.clear_strategies(req.client_connection)\n raise gen.Return(('ok',))\n self.ioloop.add_callback(lambda : chain_future(_clear_strategies(), f))\n return f\n", "role": "user" }, { "content": "request_sensor_sampling_clear", "role": "assistant" } ]
def x(self, level=None): if level is None: level = self._log_level return self.LEVELS[level]
level_name
[ { "content": "Given the source code of a python function, suggest a fitting name for the function.", "role": "system" }, { "content": "def x(self, level=None):\n if level is None:\n level = self._log_level\n return self.LEVELS[level]\n", "role": "user" }, { "content": "level_name", "role": "assistant" } ]
def x(self, level_name): try: return self.LEVELS.index(level_name) except ValueError: raise ValueError("Unknown logging level name '%s'" % (level_name,))
level_from_name
[ { "content": "Given the source code of a python function, suggest a fitting name for the function.", "role": "system" }, { "content": "def x(self, level_name):\n try:\n return self.LEVELS.index(level_name)\n except ValueError:\n raise ValueError(\"Unknown logging level name '%s'\" % (level_name,))\n", "role": "user" }, { "content": "level_from_name", "role": "assistant" } ]
def x(self, level): self._log_level = level if self._python_logger: try: level = self.PYTHON_LEVEL.get(level) except ValueError as err: raise FailReply("Unknown logging level '%s'" % level) self._python_logger.setLevel(level)
set_log_level
[ { "content": "Given the source code of a python function, suggest a fitting name for the function.", "role": "system" }, { "content": "def x(self, level):\n self._log_level = level\n if self._python_logger:\n try:\n level = self.PYTHON_LEVEL.get(level)\n except ValueError as err:\n raise FailReply(\"Unknown logging level '%s'\" % level)\n self._python_logger.setLevel(level)\n", "role": "user" }, { "content": "set_log_level", "role": "assistant" } ]
def x(self, level, msg, *args, **kwargs): timestamp = kwargs.get('timestamp') python_msg = msg if self._python_logger is not None: if timestamp is not None: python_msg = ' '.join(('katcp timestamp: %r' % timestamp, python_msg)) self._python_logger.log(self.PYTHON_LEVEL[level], python_msg, *args) if level >= self._log_level: name = kwargs.get('name') if name is None: name = self._root_logger_name try: inform_msg = msg % args except TypeError: inform_msg = '{} {}'.format(msg, args if args else '').strip() self._device_server.mass_inform(self._device_server. create_log_inform(self.level_name(level), inform_msg, name, timestamp=timestamp))
log
[ { "content": "Given the source code of a python function, suggest a fitting name for the function.", "role": "system" }, { "content": "def x(self, level, msg, *args, **kwargs):\n timestamp = kwargs.get('timestamp')\n python_msg = msg\n if self._python_logger is not None:\n if timestamp is not None:\n python_msg = ' '.join(('katcp timestamp: %r' % timestamp,\n python_msg))\n self._python_logger.log(self.PYTHON_LEVEL[level], python_msg, *args)\n if level >= self._log_level:\n name = kwargs.get('name')\n if name is None:\n name = self._root_logger_name\n try:\n inform_msg = msg % args\n except TypeError:\n inform_msg = '{} {}'.format(msg, args if args else '').strip()\n self._device_server.mass_inform(self._device_server.\n create_log_inform(self.level_name(level), inform_msg, name,\n timestamp=timestamp))\n", "role": "user" }, { "content": "log", "role": "assistant" } ]
def x(self, msg, *args, **kwargs): self.log(self.WARN, msg, *args, **kwargs)
warn
[ { "content": "Given the source code of a python function, suggest a fitting name for the function.", "role": "system" }, { "content": "def x(self, msg, *args, **kwargs):\n self.log(self.WARN, msg, *args, **kwargs)\n", "role": "user" }, { "content": "warn", "role": "assistant" } ]
def x(cls, logger, msg): level, timestamp, name, message = tuple(msg.arguments) log_string = '%s %s: %s' % (timestamp, name, message) logger.log({'trace': 0, 'debug': logging.DEBUG, 'info': logging.INFO, 'warn': logging.WARN, 'error': logging.ERROR, 'fatal': logging. FATAL}[level], log_string)
log_to_python
[ { "content": "Given the source code of a python function, suggest a fitting name for the function.", "role": "system" }, { "content": "def x(cls, logger, msg):\n level, timestamp, name, message = tuple(msg.arguments)\n log_string = '%s %s: %s' % (timestamp, name, message)\n logger.log({'trace': 0, 'debug': logging.DEBUG, 'info': logging.INFO,\n 'warn': logging.WARN, 'error': logging.ERROR, 'fatal': logging.\n FATAL}[level], log_string)\n", "role": "user" }, { "content": "log_to_python", "role": "assistant" } ]
def x(self, sock, msg): return katcp.Message.reply(msg.name, 'ok', *msg.arguments)
request_echo
[ { "content": "Given the source code of a python function, suggest a fitting name for the function.", "role": "system" }, { "content": "def x(self, sock, msg):\n return katcp.Message.reply(msg.name, 'ok', *msg.arguments)\n", "role": "user" }, { "content": "request_echo", "role": "assistant" } ]
def x(coro): def x(self, f): try: f.result() except Exception: self._logger.exception( 'Unhandled exception calling coroutine {0!r}'.format(coro)) @wraps(coro) def x(self, *args, **kwargs): try: f = coro(self, *args, **kwargs) except Exception: f = tornado_Future() f.set_exc_info(sys.exc_info()) f.add_done_callback(partial(log_cb, self)) return f return wrapped_coro
log_coroutine_exceptions
[ { "content": "Given the source code of a python function, suggest a fitting name for the function.", "role": "system" }, { "content": "def x(coro):\n\n def x(self, f):\n try:\n f.result()\n except Exception:\n self._logger.exception(\n 'Unhandled exception calling coroutine {0!r}'.format(coro))\n\n @wraps(coro)\n def x(self, *args, **kwargs):\n try:\n f = coro(self, *args, **kwargs)\n except Exception:\n f = tornado_Future()\n f.set_exc_info(sys.exc_info())\n f.add_done_callback(partial(log_cb, self))\n return f\n return wrapped_coro\n", "role": "user" }, { "content": "log_coroutine_exceptions", "role": "assistant" } ]
def x(logger, f, ignore=()): def x(f): try: f.result() except ignore: pass except Exception: logger.exception('Unhandled exception returned by future') f.add_done_callback(log_cb)
log_future_exceptions
[ { "content": "Given the source code of a python function, suggest a fitting name for the function.", "role": "system" }, { "content": "def x(logger, f, ignore=()):\n\n def x(f):\n try:\n f.result()\n except ignore:\n pass\n except Exception:\n logger.exception('Unhandled exception returned by future')\n f.add_done_callback(log_cb)\n", "role": "user" }, { "content": "log_future_exceptions", "role": "assistant" } ]
def x(obj): def x(fn): docs = [obj.__doc__] if fn.__doc__: docs.append(fn.__doc__) fn.__doc__ = '\n\n'.join(docs) return fn return deco
steal_docstring_from
[ { "content": "Given the source code of a python function, suggest a fitting name for the function.", "role": "system" }, { "content": "def x(obj):\n\n def x(fn):\n docs = [obj.__doc__]\n if fn.__doc__:\n docs.append(fn.__doc__)\n fn.__doc__ = '\\n\\n'.join(docs)\n return fn\n return deco\n", "role": "user" }, { "content": "steal_docstring_from", "role": "assistant" } ]
def x(obj): if hasattr(obj, '__func__'): return id(obj.__func__), id(obj.__self__) elif hasattr(obj, 'im_func'): return id(obj.im_func), id(obj.im_self) elif isinstance(obj, (basestring, unicode)): return obj else: return id(obj)
hashable_identity
[ { "content": "Given the source code of a python function, suggest a fitting name for the function.", "role": "system" }, { "content": "def x(obj):\n if hasattr(obj, '__func__'):\n return id(obj.__func__), id(obj.__self__)\n elif hasattr(obj, 'im_func'):\n return id(obj.im_func), id(obj.im_self)\n elif isinstance(obj, (basestring, unicode)):\n return obj\n else:\n return id(obj)\n", "role": "user" }, { "content": "hashable_identity", "role": "assistant" } ]
def x(*futures, **kwargs): timeout = kwargs.get('timeout', None) ioloop = kwargs.get('ioloop', None) or tornado.ioloop.IOLoop.current() any_future = tornado_Future() def x(done_future): if not any_future.done(): try: any_future.set_result(done_future.result()) except Exception: any_future.set_exc_info(done_future.exc_info()) for f in futures: if f._callbacks: try: f._callbacks.remove(handle_done) except ValueError: pass for f in futures: f.add_done_callback(handle_done) if any_future.done(): break if timeout: return with_timeout(ioloop.time() + timeout, any_future, ioloop) else: return any_future
until_any
[ { "content": "Given the source code of a python function, suggest a fitting name for the function.", "role": "system" }, { "content": "def x(*futures, **kwargs):\n timeout = kwargs.get('timeout', None)\n ioloop = kwargs.get('ioloop', None) or tornado.ioloop.IOLoop.current()\n any_future = tornado_Future()\n\n def x(done_future):\n if not any_future.done():\n try:\n any_future.set_result(done_future.result())\n except Exception:\n any_future.set_exc_info(done_future.exc_info())\n for f in futures:\n if f._callbacks:\n try:\n f._callbacks.remove(handle_done)\n except ValueError:\n pass\n for f in futures:\n f.add_done_callback(handle_done)\n if any_future.done():\n break\n if timeout:\n return with_timeout(ioloop.time() + timeout, any_future, ioloop)\n else:\n return any_future\n", "role": "user" }, { "content": "until_any", "role": "assistant" } ]
def x(timeout=None, ioloop=None): ioloop = ioloop or tornado.ioloop.IOLoop.current() t0 = ioloop.time() def x(): return timeout - (ioloop.time() - t0) if timeout else None def x(f): if not timeout: return f else: remaining = _remaining() deadline = ioloop.time() + remaining return with_timeout(deadline, f, ioloop) maybe_timeout.remaining = _remaining return maybe_timeout
future_timeout_manager
[ { "content": "Given the source code of a python function, suggest a fitting name for the function.", "role": "system" }, { "content": "def x(timeout=None, ioloop=None):\n ioloop = ioloop or tornado.ioloop.IOLoop.current()\n t0 = ioloop.time()\n\n def x():\n return timeout - (ioloop.time() - t0) if timeout else None\n\n def x(f):\n if not timeout:\n return f\n else:\n remaining = _remaining()\n deadline = ioloop.time() + remaining\n return with_timeout(deadline, f, ioloop)\n maybe_timeout.remaining = _remaining\n return maybe_timeout\n", "role": "user" }, { "content": "future_timeout_manager", "role": "assistant" } ]
def x(*args, **kwargs): done_at_least = kwargs.pop('done_at_least', None) timeout = kwargs.pop('timeout', None) if done_at_least is None: done_at_least = len(args) + len(kwargs) wait_iterator = tornado.gen.WaitIterator(*args, **kwargs) maybe_timeout = future_timeout_manager(timeout) results = [] while not wait_iterator.done(): result = yield maybe_timeout(wait_iterator.next()) results.append((wait_iterator.current_index, result)) if len(results) >= done_at_least: break raise tornado.gen.Return(results)
until_some
[ { "content": "Given the source code of a python function, suggest a fitting name for the function.", "role": "system" }, { "content": "def x(*args, **kwargs):\n done_at_least = kwargs.pop('done_at_least', None)\n timeout = kwargs.pop('timeout', None)\n if done_at_least is None:\n done_at_least = len(args) + len(kwargs)\n wait_iterator = tornado.gen.WaitIterator(*args, **kwargs)\n maybe_timeout = future_timeout_manager(timeout)\n results = []\n while not wait_iterator.done():\n result = yield maybe_timeout(wait_iterator.next())\n results.append((wait_iterator.current_index, result))\n if len(results) >= done_at_least:\n break\n raise tornado.gen.Return(results)\n", "role": "user" }, { "content": "until_some", "role": "assistant" } ]
def x(self, arg): if isinstance(arg, float): return repr(arg) elif isinstance(arg, bool): return str(int(arg)) else: try: return str(arg) except UnicodeEncodeError: logger.error( 'Error casting message argument to str! Trying to encode argument to ascii.' ) if not isinstance(arg, unicode): arg = arg.decode('utf-8') return arg.encode('ascii', 'replace')
format_argument
[ { "content": "Given the source code of a python function, suggest a fitting name for the function.", "role": "system" }, { "content": "def x(self, arg):\n if isinstance(arg, float):\n return repr(arg)\n elif isinstance(arg, bool):\n return str(int(arg))\n else:\n try:\n return str(arg)\n except UnicodeEncodeError:\n logger.error(\n 'Error casting message argument to str! Trying to encode argument to ascii.'\n )\n if not isinstance(arg, unicode):\n arg = arg.decode('utf-8')\n return arg.encode('ascii', 'replace')\n", "role": "user" }, { "content": "format_argument", "role": "assistant" } ]
def x(self): return self.mtype == self.REPLY and self.arguments and self.arguments[0 ] == self.OK
reply_ok
[ { "content": "Given the source code of a python function, suggest a fitting name for the function.", "role": "system" }, { "content": "def x(self):\n return self.mtype == self.REPLY and self.arguments and self.arguments[0\n ] == self.OK\n", "role": "user" }, { "content": "reply_ok", "role": "assistant" } ]
def x(cls, name, *args, **kwargs): mid = kwargs.pop('mid', None) if len(kwargs) > 0: raise TypeError('Invalid keyword argument(s): %r' % kwargs) return cls(cls.REQUEST, name, args, mid)
request
[ { "content": "Given the source code of a python function, suggest a fitting name for the function.", "role": "system" }, { "content": "def x(cls, name, *args, **kwargs):\n mid = kwargs.pop('mid', None)\n if len(kwargs) > 0:\n raise TypeError('Invalid keyword argument(s): %r' % kwargs)\n return cls(cls.REQUEST, name, args, mid)\n", "role": "user" }, { "content": "request", "role": "assistant" } ]
def x(cls, name, *args, **kwargs): mid = kwargs.pop('mid', None) if len(kwargs) > 0: raise TypeError('Invalid keyword argument(s): %r' % kwargs) return cls(cls.REPLY, name, args, mid)
reply
[ { "content": "Given the source code of a python function, suggest a fitting name for the function.", "role": "system" }, { "content": "def x(cls, name, *args, **kwargs):\n mid = kwargs.pop('mid', None)\n if len(kwargs) > 0:\n raise TypeError('Invalid keyword argument(s): %r' % kwargs)\n return cls(cls.REPLY, name, args, mid)\n", "role": "user" }, { "content": "reply", "role": "assistant" } ]
def x(cls, req_msg, *args): return cls(cls.REPLY, req_msg.name, args, req_msg.mid)
reply_to_request
[ { "content": "Given the source code of a python function, suggest a fitting name for the function.", "role": "system" }, { "content": "def x(cls, req_msg, *args):\n return cls(cls.REPLY, req_msg.name, args, req_msg.mid)\n", "role": "user" }, { "content": "reply_to_request", "role": "assistant" } ]
def x(cls, name, *args, **kwargs): mid = kwargs.pop('mid', None) if len(kwargs) > 0: raise TypeError('Invalid keyword argument(s): %r' % kwargs) return cls(cls.INFORM, name, args, mid)
inform
[ { "content": "Given the source code of a python function, suggest a fitting name for the function.", "role": "system" }, { "content": "def x(cls, name, *args, **kwargs):\n mid = kwargs.pop('mid', None)\n if len(kwargs) > 0:\n raise TypeError('Invalid keyword argument(s): %r' % kwargs)\n return cls(cls.INFORM, name, args, mid)\n", "role": "user" }, { "content": "inform", "role": "assistant" } ]
def x(cls, req_msg, *args): return cls(cls.INFORM, req_msg.name, args, req_msg.mid)
reply_inform
[ { "content": "Given the source code of a python function, suggest a fitting name for the function.", "role": "system" }, { "content": "def x(cls, req_msg, *args):\n return cls(cls.INFORM, req_msg.name, args, req_msg.mid)\n", "role": "user" }, { "content": "reply_inform", "role": "assistant" } ]
def x(self, match): char = match.group(1) if char in self.ESCAPE_LOOKUP: return self.ESCAPE_LOOKUP[char] elif not char: raise KatcpSyntaxError('Escape slash at end of argument.') else: raise KatcpSyntaxError('Invalid escape character %r.' % (char,))
unescape_match
[ { "content": "Given the source code of a python function, suggest a fitting name for the function.", "role": "system" }, { "content": "def x(self, match):\n char = match.group(1)\n if char in self.ESCAPE_LOOKUP:\n return self.ESCAPE_LOOKUP[char]\n elif not char:\n raise KatcpSyntaxError('Escape slash at end of argument.')\n else:\n raise KatcpSyntaxError('Invalid escape character %r.' % (char,))\n", "role": "user" }, { "content": "unescape_match", "role": "assistant" } ]
def x(self, arg): match = self.SPECIAL_RE.search(arg) if match: raise KatcpSyntaxError('Unescaped special %r.' % (match.group(),)) return self.UNESCAPE_RE.sub(self._unescape_match, arg)
parse_arg
[ { "content": "Given the source code of a python function, suggest a fitting name for the function.", "role": "system" }, { "content": "def x(self, arg):\n match = self.SPECIAL_RE.search(arg)\n if match:\n raise KatcpSyntaxError('Unescaped special %r.' % (match.group(),))\n return self.UNESCAPE_RE.sub(self._unescape_match, arg)\n", "role": "user" }, { "content": "parse_arg", "role": "assistant" } ]
def x(self, line): if not line: raise KatcpSyntaxError('Empty message received.') type_char = line[0] if type_char not in self.TYPE_SYMBOL_LOOKUP: raise KatcpSyntaxError('Bad type character %r.' % (type_char,)) mtype = self.TYPE_SYMBOL_LOOKUP[type_char] parts = self.WHITESPACE_RE.split(line) if not parts[-1]: del parts[-1] name = parts[0][1:] arguments = [self._parse_arg(x) for x in parts[1:]] match = self.NAME_RE.match(name) if match: name = match.group('name') mid = match.group('id') else: raise KatcpSyntaxError('Bad message name (and possibly id) %r.' % ( name,)) return Message(mtype, name, arguments, mid)
parse
[ { "content": "Given the source code of a python function, suggest a fitting name for the function.", "role": "system" }, { "content": "def x(self, line):\n if not line:\n raise KatcpSyntaxError('Empty message received.')\n type_char = line[0]\n if type_char not in self.TYPE_SYMBOL_LOOKUP:\n raise KatcpSyntaxError('Bad type character %r.' % (type_char,))\n mtype = self.TYPE_SYMBOL_LOOKUP[type_char]\n parts = self.WHITESPACE_RE.split(line)\n if not parts[-1]:\n del parts[-1]\n name = parts[0][1:]\n arguments = [self._parse_arg(x) for x in parts[1:]]\n match = self.NAME_RE.match(name)\n if match:\n name = match.group('name')\n mid = match.group('id')\n else:\n raise KatcpSyntaxError('Bad message name (and possibly id) %r.' % (\n name,))\n return Message(mtype, name, arguments, mid)\n", "role": "user" }, { "content": "parse", "role": "assistant" } ]
def x(cls, version_str): match = cls.VERSION_RE.match(version_str) if match: major = int(match.group('major')) minor = int(match.group('minor')) flags = set(match.group('flags') or '') else: major, minor, flags = None, None, set() return cls(major, minor, flags)
parse_version
[ { "content": "Given the source code of a python function, suggest a fitting name for the function.", "role": "system" }, { "content": "def x(cls, version_str):\n match = cls.VERSION_RE.match(version_str)\n if match:\n major = int(match.group('major'))\n minor = int(match.group('minor'))\n flags = set(match.group('flags') or '')\n else:\n major, minor, flags = None, None, set()\n return cls(major, minor, flags)\n", "role": "user" }, { "content": "parse_version", "role": "assistant" } ]
def x(mcs, handler): protocol_info = mcs.PROTOCOL_INFO protocol_version = protocol_info.major, protocol_info.minor protocol_flags = protocol_info.flags min_protocol_version = getattr(handler, '_minimum_katcp_version', None) protocol_version_ok = (min_protocol_version is None or protocol_version >= min_protocol_version) required_katcp_protocol_flags = getattr(handler, '_has_katcp_protocol_flags', None) protocol_flags_ok = required_katcp_protocol_flags is None or all(flag in protocol_flags for flag in required_katcp_protocol_flags) return protocol_version_ok and protocol_flags_ok
check_protocol
[ { "content": "Given the source code of a python function, suggest a fitting name for the function.", "role": "system" }, { "content": "def x(mcs, handler):\n protocol_info = mcs.PROTOCOL_INFO\n protocol_version = protocol_info.major, protocol_info.minor\n protocol_flags = protocol_info.flags\n min_protocol_version = getattr(handler, '_minimum_katcp_version', None)\n protocol_version_ok = (min_protocol_version is None or protocol_version >=\n min_protocol_version)\n required_katcp_protocol_flags = getattr(handler,\n '_has_katcp_protocol_flags', None)\n protocol_flags_ok = required_katcp_protocol_flags is None or all(flag in\n protocol_flags for flag in required_katcp_protocol_flags)\n return protocol_version_ok and protocol_flags_ok\n", "role": "user" }, { "content": "check_protocol", "role": "assistant" } ]
def x(cls, name, description=None, unit='', params=None, default=None, initial_status=None): return cls(cls.INTEGER, name, description, unit, params, default, initial_status)
integer
[ { "content": "Given the source code of a python function, suggest a fitting name for the function.", "role": "system" }, { "content": "def x(cls, name, description=None, unit='', params=None, default=None,\n initial_status=None):\n return cls(cls.INTEGER, name, description, unit, params, default,\n initial_status)\n", "role": "user" }, { "content": "integer", "role": "assistant" } ]
def x(cls, name, description=None, unit='', params=None, default=None, initial_status=None): return cls(cls.FLOAT, name, description, unit, params, default, initial_status)
float
[ { "content": "Given the source code of a python function, suggest a fitting name for the function.", "role": "system" }, { "content": "def x(cls, name, description=None, unit='', params=None, default=None,\n initial_status=None):\n return cls(cls.FLOAT, name, description, unit, params, default,\n initial_status)\n", "role": "user" }, { "content": "float", "role": "assistant" } ]
def x(cls, name, description=None, unit='', default=None, initial_status=None): return cls(cls.BOOLEAN, name, description, unit, None, default, initial_status)
boolean
[ { "content": "Given the source code of a python function, suggest a fitting name for the function.", "role": "system" }, { "content": "def x(cls, name, description=None, unit='', default=None, initial_status=None):\n return cls(cls.BOOLEAN, name, description, unit, None, default,\n initial_status)\n", "role": "user" }, { "content": "boolean", "role": "assistant" } ]
def x(cls, name, description=None, unit='', default=None, initial_status=None): return cls(cls.LRU, name, description, unit, None, default, initial_status)
lru
[ { "content": "Given the source code of a python function, suggest a fitting name for the function.", "role": "system" }, { "content": "def x(cls, name, description=None, unit='', default=None, initial_status=None):\n return cls(cls.LRU, name, description, unit, None, default, initial_status)\n", "role": "user" }, { "content": "lru", "role": "assistant" } ]
def x(cls, name, description=None, unit='', default=None, initial_status=None): return cls(cls.STRING, name, description, unit, None, default, initial_status)
string
[ { "content": "Given the source code of a python function, suggest a fitting name for the function.", "role": "system" }, { "content": "def x(cls, name, description=None, unit='', default=None, initial_status=None):\n return cls(cls.STRING, name, description, unit, None, default,\n initial_status)\n", "role": "user" }, { "content": "string", "role": "assistant" } ]
def x(cls, name, description=None, unit='', params=None, default=None, initial_status=None): return cls(cls.DISCRETE, name, description, unit, params, default, initial_status)
discrete
[ { "content": "Given the source code of a python function, suggest a fitting name for the function.", "role": "system" }, { "content": "def x(cls, name, description=None, unit='', params=None, default=None,\n initial_status=None):\n return cls(cls.DISCRETE, name, description, unit, params, default,\n initial_status)\n", "role": "user" }, { "content": "discrete", "role": "assistant" } ]
def x(cls, name, description=None, unit='', default=None, initial_status=None): return cls(cls.TIMESTAMP, name, description, unit, None, default, initial_status)
timestamp
[ { "content": "Given the source code of a python function, suggest a fitting name for the function.", "role": "system" }, { "content": "def x(cls, name, description=None, unit='', default=None, initial_status=None):\n return cls(cls.TIMESTAMP, name, description, unit, None, default,\n initial_status)\n", "role": "user" }, { "content": "timestamp", "role": "assistant" } ]
def x(cls, name, description=None, unit='', default=None, initial_status=None): return cls(cls.ADDRESS, name, description, unit, None, default, initial_status)
address
[ { "content": "Given the source code of a python function, suggest a fitting name for the function.", "role": "system" }, { "content": "def x(cls, name, description=None, unit='', default=None, initial_status=None):\n return cls(cls.ADDRESS, name, description, unit, None, default,\n initial_status)\n", "role": "user" }, { "content": "address", "role": "assistant" } ]
def x(self, reading): for o in list(self._observers): o.update(self, reading)
notify
[ { "content": "Given the source code of a python function, suggest a fitting name for the function.", "role": "system" }, { "content": "def x(self, reading):\n for o in list(self._observers):\n o.update(self, reading)\n", "role": "user" }, { "content": "notify", "role": "assistant" } ]
def x(self, timestamp, status, value): reading = self._current_reading = Reading(timestamp, status, value) self.notify(reading)
set
[ { "content": "Given the source code of a python function, suggest a fitting name for the function.", "role": "system" }, { "content": "def x(self, timestamp, status, value):\n reading = self._current_reading = Reading(timestamp, status, value)\n self.notify(reading)\n", "role": "user" }, { "content": "set", "role": "assistant" } ]
def x(self, raw_timestamp, raw_status, raw_value, major=DEFAULT_KATCP_MAJOR): timestamp = self.TIMESTAMP_TYPE.decode(raw_timestamp, major) status = self.STATUS_NAMES[raw_status] value = self.parse_value(raw_value, major) self.set(timestamp, status, value)
set_formatted
[ { "content": "Given the source code of a python function, suggest a fitting name for the function.", "role": "system" }, { "content": "def x(self, raw_timestamp, raw_status, raw_value, major=DEFAULT_KATCP_MAJOR):\n timestamp = self.TIMESTAMP_TYPE.decode(raw_timestamp, major)\n status = self.STATUS_NAMES[raw_status]\n value = self.parse_value(raw_value, major)\n self.set(timestamp, status, value)\n", "role": "user" }, { "content": "set_formatted", "role": "assistant" } ]
def x(self, reading, major=DEFAULT_KATCP_MAJOR): timestamp, status, value = reading return self.TIMESTAMP_TYPE.encode(timestamp, major), self.STATUSES[status ], self._formatter(value, True, major)
format_reading
[ { "content": "Given the source code of a python function, suggest a fitting name for the function.", "role": "system" }, { "content": "def x(self, reading, major=DEFAULT_KATCP_MAJOR):\n timestamp, status, value = reading\n return self.TIMESTAMP_TYPE.encode(timestamp, major), self.STATUSES[status\n ], self._formatter(value, True, major)\n", "role": "user" }, { "content": "format_reading", "role": "assistant" } ]
def x(self, value, status=NOMINAL, timestamp=None, major=DEFAULT_KATCP_MAJOR): self._kattype.check(value, major) if timestamp is None: timestamp = time.time() self.set(timestamp, status, value)
set_value
[ { "content": "Given the source code of a python function, suggest a fitting name for the function.", "role": "system" }, { "content": "def x(self, value, status=NOMINAL, timestamp=None, major=DEFAULT_KATCP_MAJOR):\n self._kattype.check(value, major)\n if timestamp is None:\n timestamp = time.time()\n self.set(timestamp, status, value)\n", "role": "user" }, { "content": "set_value", "role": "assistant" } ]
def x(cls, type_string): if type_string in cls.SENSOR_TYPE_LOOKUP: return cls.SENSOR_TYPE_LOOKUP[type_string] else: raise KatcpSyntaxError('Invalid sensor type string %s' % type_string)
parse_type
[ { "content": "Given the source code of a python function, suggest a fitting name for the function.", "role": "system" }, { "content": "def x(cls, type_string):\n if type_string in cls.SENSOR_TYPE_LOOKUP:\n return cls.SENSOR_TYPE_LOOKUP[type_string]\n else:\n raise KatcpSyntaxError('Invalid sensor type string %s' % type_string)\n", "role": "user" }, { "content": "parse_type", "role": "assistant" } ]
def x(cls, sensor_type, formatted_params, major=DEFAULT_KATCP_MAJOR): typeclass, _value = cls.SENSOR_TYPES[sensor_type] if sensor_type == cls.DISCRETE: kattype = typeclass([]) else: kattype = typeclass() return [kattype.decode(x, major) for x in formatted_params]
parse_params
[ { "content": "Given the source code of a python function, suggest a fitting name for the function.", "role": "system" }, { "content": "def x(cls, sensor_type, formatted_params, major=DEFAULT_KATCP_MAJOR):\n typeclass, _value = cls.SENSOR_TYPES[sensor_type]\n if sensor_type == cls.DISCRETE:\n kattype = typeclass([])\n else:\n kattype = typeclass()\n return [kattype.decode(x, major) for x in formatted_params]\n", "role": "user" }, { "content": "parse_params", "role": "assistant" } ]
def x(self): self._flag = True old_future = self._waiting_future self._waiting_future = tornado_Future() old_future.set_result(True)
set
[ { "content": "Given the source code of a python function, suggest a fitting name for the function.", "role": "system" }, { "content": "def x(self):\n self._flag = True\n old_future = self._waiting_future\n self._waiting_future = tornado_Future()\n old_future.set_result(True)\n", "role": "user" }, { "content": "set", "role": "assistant" } ]
def x(self, ioloop, timeout=None): f = Future() def x(): return gen.chain_future(self.until_set(), f) ioloop.add_callback(cb) try: f.result(timeout) return True except TimeoutError: return self._flag
wait_with_ioloop
[ { "content": "Given the source code of a python function, suggest a fitting name for the function.", "role": "system" }, { "content": "def x(self, ioloop, timeout=None):\n f = Future()\n\n def x():\n return gen.chain_future(self.until_set(), f)\n ioloop.add_callback(cb)\n try:\n f.result(timeout)\n return True\n except TimeoutError:\n return self._flag\n", "role": "user" }, { "content": "wait_with_ioloop", "role": "assistant" } ]
def x(self, state, timeout=None): if state not in self._valid_states: raise ValueError('State must be one of {0}, not {1}'.format(self. _valid_states, state)) if state != self._state: if timeout: return with_timeout(self._ioloop.time() + timeout, self. _waiting_futures[state], self._ioloop) else: return self._waiting_futures[state] else: f = tornado_Future() f.set_result(True) return f
until_state
[ { "content": "Given the source code of a python function, suggest a fitting name for the function.", "role": "system" }, { "content": "def x(self, state, timeout=None):\n if state not in self._valid_states:\n raise ValueError('State must be one of {0}, not {1}'.format(self.\n _valid_states, state))\n if state != self._state:\n if timeout:\n return with_timeout(self._ioloop.time() + timeout, self.\n _waiting_futures[state], self._ioloop)\n else:\n return self._waiting_futures[state]\n else:\n f = tornado_Future()\n f.set_result(True)\n return f\n", "role": "user" }, { "content": "until_state", "role": "assistant" } ]
def x(self, *states, **kwargs): timeout = kwargs.get('timeout', None) state_futures = (self.until_state(s, timeout=timeout) for s in states) return until_any(*state_futures)
until_state_in
[ { "content": "Given the source code of a python function, suggest a fitting name for the function.", "role": "system" }, { "content": "def x(self, *states, **kwargs):\n timeout = kwargs.get('timeout', None)\n state_futures = (self.until_state(s, timeout=timeout) for s in states)\n return until_any(*state_futures)\n", "role": "user" }, { "content": "until_state_in", "role": "assistant" } ]
def x(self, fut): done = self.done = fut.done() if done and not self.prev_done: self.done_since = self.ioloop.time() self.prev_done = done
check_future
[ { "content": "Given the source code of a python function, suggest a fitting name for the function.", "role": "system" }, { "content": "def x(self, fut):\n done = self.done = fut.done()\n if done and not self.prev_done:\n self.done_since = self.ioloop.time()\n self.prev_done = done\n", "role": "user" }, { "content": "check_future", "role": "assistant" } ]
def x(self): delta = self.ioloop.time() - self.done_since if self.done and delta > self.max_loop_latency: return True return False
time_to_yield
[ { "content": "Given the source code of a python function, suggest a fitting name for the function.", "role": "system" }, { "content": "def x(self):\n delta = self.ioloop.time() - self.done_since\n if self.done and delta > self.max_loop_latency:\n return True\n return False\n", "role": "user" }, { "content": "time_to_yield", "role": "assistant" } ]
def x(client, exception, *msg_parms, **kwargs): timeout = kwargs.get('timeout', None) req_msg = Message.request(*msg_parms) if timeout is not None: reply, informs = client.blocking_request(req_msg, timeout=timeout) else: reply, informs = client.blocking_request(req_msg) if not reply.reply_ok(): raise exception( 'Unexpected failure reply "{2}"\n with device at {0}, request \n"{1}"' .format(client.bind_address_string, req_msg, reply)) return reply, informs
request_check
[ { "content": "Given the source code of a python function, suggest a fitting name for the function.", "role": "system" }, { "content": "def x(client, exception, *msg_parms, **kwargs):\n timeout = kwargs.get('timeout', None)\n req_msg = Message.request(*msg_parms)\n if timeout is not None:\n reply, informs = client.blocking_request(req_msg, timeout=timeout)\n else:\n reply, informs = client.blocking_request(req_msg)\n if not reply.reply_ok():\n raise exception(\n 'Unexpected failure reply \"{2}\"\\n with device at {0}, request \\n\"{1}\"'\n .format(client.bind_address_string, req_msg, reply))\n return reply, informs\n", "role": "user" }, { "content": "request_check", "role": "assistant" } ]
def x(self, time_seconds): if self.protocol_flags.major >= SEC_TS_KATCP_MAJOR: return time_seconds else: device_time = time_seconds * SEC_TO_MS_FAC if self.protocol_flags.major < FLOAT_TS_KATCP_MAJOR: device_time = int(device_time) return device_time
convert_seconds
[ { "content": "Given the source code of a python function, suggest a fitting name for the function.", "role": "system" }, { "content": "def x(self, time_seconds):\n if self.protocol_flags.major >= SEC_TS_KATCP_MAJOR:\n return time_seconds\n else:\n device_time = time_seconds * SEC_TO_MS_FAC\n if self.protocol_flags.major < FLOAT_TS_KATCP_MAJOR:\n device_time = int(device_time)\n return device_time\n", "role": "user" }, { "content": "convert_seconds", "role": "assistant" } ]
def x(self): assert get_thread_ident() == self.ioloop_thread_id self._last_msg_id += 1 return str(self._last_msg_id)
next_id
[ { "content": "Given the source code of a python function, suggest a fitting name for the function.", "role": "system" }, { "content": "def x(self):\n assert get_thread_ident() == self.ioloop_thread_id\n self._last_msg_id += 1\n return str(self._last_msg_id)\n", "role": "user" }, { "content": "next_id", "role": "assistant" } ]
def x(self, msg): if len(msg.arguments) < 2: return name = msg.arguments[0] self.versions[name] = tuple(msg.arguments[1:]) if msg.arguments[0] == 'katcp-protocol': protocol_flags = ProtocolFlags.parse_version(msg.arguments[1]) self._set_protocol_from_inform(protocol_flags, msg)
inform_version_connect
[ { "content": "Given the source code of a python function, suggest a fitting name for the function.", "role": "system" }, { "content": "def x(self, msg):\n if len(msg.arguments) < 2:\n return\n name = msg.arguments[0]\n self.versions[name] = tuple(msg.arguments[1:])\n if msg.arguments[0] == 'katcp-protocol':\n protocol_flags = ProtocolFlags.parse_version(msg.arguments[1])\n self._set_protocol_from_inform(protocol_flags, msg)\n", "role": "user" }, { "content": "inform_version_connect", "role": "assistant" } ]
def x(self, msg, use_mid): if use_mid is None: use_mid = self._server_supports_ids if msg.mid is None: mid = self._next_id() if use_mid: msg.mid = mid return mid else: return msg.mid
get_mid_and_update_msg
[ { "content": "Given the source code of a python function, suggest a fitting name for the function.", "role": "system" }, { "content": "def x(self, msg, use_mid):\n if use_mid is None:\n use_mid = self._server_supports_ids\n if msg.mid is None:\n mid = self._next_id()\n if use_mid:\n msg.mid = mid\n return mid\n else:\n return msg.mid\n", "role": "user" }, { "content": "get_mid_and_update_msg", "role": "assistant" } ]
def x(self, msg, use_mid=None): mid = self._get_mid_and_update_msg(msg, use_mid) self.send_request(msg) return mid
request
[ { "content": "Given the source code of a python function, suggest a fitting name for the function.", "role": "system" }, { "content": "def x(self, msg, use_mid=None):\n mid = self._get_mid_and_update_msg(msg, use_mid)\n self.send_request(msg)\n return mid\n", "role": "user" }, { "content": "request", "role": "assistant" } ]
def x(self, msg): assert msg.mtype == Message.REQUEST if msg.mid and not self._server_supports_ids: raise KatcpVersionError('Message IDs not supported by server') self.send_message(msg)
send_request
[ { "content": "Given the source code of a python function, suggest a fitting name for the function.", "role": "system" }, { "content": "def x(self, msg):\n assert msg.mtype == Message.REQUEST\n if msg.mid and not self._server_supports_ids:\n raise KatcpVersionError('Message IDs not supported by server')\n self.send_message(msg)\n", "role": "user" }, { "content": "send_request", "role": "assistant" } ]