rad
3.0.0
|
Subscriber is a protobuf-aware subscriber and uses ZmqSubscriber for the lower level protocol. More...
Public Member Functions | |
def | __init__ (self, *handler, list topic_types, zmq.asyncio.Context zmq_ctx, unknown_handler=None, asyncio.AbstractEventLoop loop=None) |
bool | is_closed (self) |
Returns true if subscriber is not running, false otherwise. More... | |
def | start (self) |
Start reading from socket. More... | |
def | stop (self) |
Stop reading from socket. More... | |
def | connect (self, str endpoint) |
Connect to endpoint. More... | |
def | disconnect (self, str endpoint) |
Disconnect from endpoint. More... | |
def | subscribe (self, topic_name) |
Subscribe on the topic topic_name . More... | |
def | unsubscribe (self, topic_name) |
Unsubscribe to topic identified by topic_name . More... | |
Subscriber is a protobuf-aware subscriber and uses ZmqSubscriber for the lower level protocol.
def rad.services.pubsub.Subscriber.__init__ | ( | self, | |
* | handler, | ||
list | topic_types, | ||
zmq.asyncio.Context | zmq_ctx, | ||
unknown_handler = None , |
|||
asyncio.AbstractEventLoop | loop = None |
||
) |
def rad.services.pubsub.Subscriber.connect | ( | self, | |
str | endpoint | ||
) |
Connect to endpoint.
def rad.services.pubsub.Subscriber.disconnect | ( | self, | |
str | endpoint | ||
) |
Disconnect from endpoint.
bool rad.services.pubsub.Subscriber.is_closed | ( | self | ) |
Returns true if subscriber is not running, false otherwise.
def rad.services.pubsub.Subscriber.start | ( | self | ) |
Start reading from socket.
@todo: Return future instead?
def rad.services.pubsub.Subscriber.stop | ( | self | ) |
Stop reading from socket.
@todo: Return future instead?
def rad.services.pubsub.Subscriber.subscribe | ( | self, | |
topic_name | |||
) |
Subscribe on the topic topic_name
.
def rad.services.pubsub.Subscriber.unsubscribe | ( | self, | |
topic_name | |||
) |
Unsubscribe to topic identified by topic_name
.