Package org.apache.beam.sdk.io.rabbitmq
Class RabbitMqMessage
java.lang.Object
org.apache.beam.sdk.io.rabbitmq.RabbitMqMessage
- All Implemented Interfaces:
Serializable
It contains the message payload, and additional metadata like routing key or attributes. The main
reason of this class is that AMQP.BasicProperties doesn't provide a serializable public API.
- See Also:
-
Constructor Summary
ConstructorsConstructorDescriptionRabbitMqMessage
(byte[] body) RabbitMqMessage
(String routingKey, byte[] body, String contentType, String contentEncoding, Map<String, Object> headers, Integer deliveryMode, Integer priority, String correlationId, String replyTo, String expiration, String messageId, Date timestamp, String type, String userId, String appId, String clusterId) RabbitMqMessage
(String routingKey, com.rabbitmq.client.GetResponse delivery) -
Method Summary
-
Constructor Details
-
RabbitMqMessage
public RabbitMqMessage(byte[] body) -
RabbitMqMessage
-
RabbitMqMessage
public RabbitMqMessage(String routingKey, byte[] body, String contentType, String contentEncoding, Map<String, Object> headers, Integer deliveryMode, Integer priority, String correlationId, String replyTo, String expiration, String messageId, Date timestamp, String type, String userId, String appId, String clusterId)
-
-
Method Details
-
getRoutingKey
-
getBody
public byte[] getBody() -
getContentType
-
getContentEncoding
-
getHeaders
-
getDeliveryMode
-
getPriority
-
getCorrelationId
-
getReplyTo
-
getExpiration
-
getMessageId
-
getTimestamp
-
getType
-
getUserId
-
getAppId
-
getClusterId
-
createProperties
public com.rabbitmq.client.AMQP.BasicProperties createProperties() -
hashCode
public int hashCode() -
equals
-