public abstract static class RabbitMqIO.Write extends PTransform<PCollection<RabbitMqMessage>,PCollection<?>>
PTransform
to publish messages to a RabbitMQ server.name, resourceHints
Constructor and Description |
---|
Write() |
Modifier and Type | Method and Description |
---|---|
PCollection<?> |
expand(PCollection<RabbitMqMessage> input)
Override this method to specify how this
PTransform should be expanded on the given
InputT . |
RabbitMqIO.Write |
withExchange(java.lang.String exchange)
Defines the existing exchange where the messages will be sent.
|
RabbitMqIO.Write |
withExchange(java.lang.String exchange,
java.lang.String exchangeType)
Defines the to-be-declared exchange where the messages will be sent.
|
RabbitMqIO.Write |
withQueue(java.lang.String queue)
Defines the queue where the messages will be sent.
|
RabbitMqIO.Write |
withQueueDeclare(boolean queueDeclare)
If the queue is not declared by another application,
RabbitMqIO can declare the queue
itself. |
RabbitMqIO.Write |
withUri(java.lang.String uri) |
compose, compose, getAdditionalInputs, getDefaultOutputCoder, getDefaultOutputCoder, getDefaultOutputCoder, getKindString, getName, getResourceHints, populateDisplayData, setResourceHints, toString, validate, validate
public RabbitMqIO.Write withUri(java.lang.String uri)
public RabbitMqIO.Write withExchange(java.lang.String exchange, java.lang.String exchangeType)
By calling this function exchangeDeclare
will be set to true
.
To publish to an existing exchange, use withExchange(String)
public RabbitMqIO.Write withExchange(java.lang.String exchange)
By calling this function exchangeDeclare
will be set to false
public RabbitMqIO.Write withQueue(java.lang.String queue)
RabbitMqIO
if you set withQueueDeclare(boolean)
to true
.public RabbitMqIO.Write withQueueDeclare(boolean queueDeclare)
RabbitMqIO
can declare the queue
itself.queueDeclare
- true
to declare the queue, false
else.public PCollection<?> expand(PCollection<RabbitMqMessage> input)
PTransform
PTransform
should be expanded on the given
InputT
.
NOTE: This method should not be called directly. Instead apply the PTransform
should
be applied to the InputT
using the apply
method.
Composite transforms, which are defined in terms of other transforms, should return the output of one of the composed transforms. Non-composite transforms, which do not apply any transforms internally, should return a new unbound output and register evaluators (via backend-specific registration methods).
expand
in class PTransform<PCollection<RabbitMqMessage>,PCollection<?>>