rad
3.0.0
|
Subscriber provides the capability to subscribe to protobuf ZMQ topics and being notified through callbacks to a (shared for all topics) handler. More...
Public Member Functions | |
def | __init__ (self, *zmq.asyncio.Context zmq_ctx, asyncio.AbstractEventLoop loop, handler) |
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) |
Unbinds socket and shuts down all related tasks to this Replier. 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... | |
def | __init__ (self, *zmq.asyncio.Context zmq_ctx, asyncio.AbstractEventLoop loop, handler) |
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) |
Unbinds socket and shuts down all related tasks to this Replier. 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 provides the capability to subscribe to protobuf ZMQ topics and being notified through callbacks to a (shared for all topics) handler.
def rad.services.pubsub.ZmqSubscriber.__init__ | ( | self, | |
*zmq.asyncio.Context | zmq_ctx, | ||
asyncio.AbstractEventLoop | loop, | ||
handler | |||
) |
def rad.services.pubsub.ZmqSubscriber.__init__ | ( | self, | |
*zmq.asyncio.Context | zmq_ctx, | ||
asyncio.AbstractEventLoop | loop, | ||
handler | |||
) |
def rad.services.pubsub.ZmqSubscriber.connect | ( | self, | |
str | endpoint | ||
) |
Connect to endpoint.
def rad.services.pubsub.ZmqSubscriber.connect | ( | self, | |
str | endpoint | ||
) |
Connect to endpoint.
def rad.services.pubsub.ZmqSubscriber.disconnect | ( | self, | |
str | endpoint | ||
) |
Disconnect from endpoint.
def rad.services.pubsub.ZmqSubscriber.disconnect | ( | self, | |
str | endpoint | ||
) |
Disconnect from endpoint.
bool rad.services.pubsub.ZmqSubscriber.is_closed | ( | self | ) |
Returns true if subscriber is not running, false otherwise.
bool rad.services.pubsub.ZmqSubscriber.is_closed | ( | self | ) |
Returns true if subscriber is not running, false otherwise.
def rad.services.pubsub.ZmqSubscriber.start | ( | self | ) |
Start reading from socket.
@todo: Return future instead?
def rad.services.pubsub.ZmqSubscriber.start | ( | self | ) |
Start reading from socket.
@todo: Return future instead?
def rad.services.pubsub.ZmqSubscriber.stop | ( | self | ) |
Unbinds socket and shuts down all related tasks to this Replier.
The ZmqMsgReplier is essentially dead after this.
def rad.services.pubsub.ZmqSubscriber.stop | ( | self | ) |
Unbinds socket and shuts down all related tasks to this Replier.
The ZmqMsgReplier is essentially dead after this.
def rad.services.pubsub.ZmqSubscriber.subscribe | ( | self, | |
topic_name | |||
) |
Subscribe on the topic topic_name
.
def rad.services.pubsub.ZmqSubscriber.subscribe | ( | self, | |
topic_name | |||
) |
Subscribe on the topic topic_name
.
def rad.services.pubsub.ZmqSubscriber.unsubscribe | ( | self, | |
topic_name | |||
) |
Unsubscribe to topic identified by topic_name
.
def rad.services.pubsub.ZmqSubscriber.unsubscribe | ( | self, | |
topic_name | |||
) |
Unsubscribe to topic identified by topic_name
.