Interface | Description |
---|---|
RMQDeserializationSchema<T> |
Interface for the set of methods required to parse an RMQ delivery.
|
RMQDeserializationSchema.RMQCollector<T> |
Special collector for RMQ messages.
|
RMQSinkPublishOptions<IN> |
The message computation provides methods to compute the message routing key and/or the
properties.
|
SerializableReturnListener |
A serializable
ReturnListener . |
Class | Description |
---|---|
RMQSink<IN> |
A Sink for publishing data into RabbitMQ.
|
RMQSource<OUT> |
RabbitMQ source (consumer) which reads from a queue and acknowledges messages on checkpoints.
|
Copyright © 2014–2021 The Apache Software Foundation. All rights reserved.