Class RabbitMqMessage

java.lang.Object
org.apache.beam.sdk.io.rabbitmq.RabbitMqMessage
All Implemented Interfaces:
Serializable

public class RabbitMqMessage extends Object implements 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 Details

  • Method Details

    • getRoutingKey

      public String getRoutingKey()
    • getBody

      public byte[] getBody()
    • getContentType

      public String getContentType()
    • getContentEncoding

      public String getContentEncoding()
    • getHeaders

      public Map<String,Object> getHeaders()
    • getDeliveryMode

      public Integer getDeliveryMode()
    • getPriority

      public Integer getPriority()
    • getCorrelationId

      public String getCorrelationId()
    • getReplyTo

      public String getReplyTo()
    • getExpiration

      public String getExpiration()
    • getMessageId

      public String getMessageId()
    • getTimestamp

      public Date getTimestamp()
    • getType

      public String getType()
    • getUserId

      public String getUserId()
    • getAppId

      public String getAppId()
    • getClusterId

      public String getClusterId()
    • createProperties

      public com.rabbitmq.client.AMQP.BasicProperties createProperties()
    • hashCode

      public int hashCode()
      Overrides:
      hashCode in class Object
    • equals

      public boolean equals(@Nullable Object obj)
      Overrides:
      equals in class Object