public interface IEventDataScheme extends Serializable
Modifier and Type | Method and Description |
---|---|
List<Object> |
deserialize(org.apache.qpid.amqp_1_0.client.Message message)
Deserialize an AMQP Message into a Tuple.
|
Fields |
getOutputFields()
Retrieve the Fields that are present on tuples created by this object.
|
List<Object> deserialize(org.apache.qpid.amqp_1_0.client.Message message)
Deserialize an AMQP Message into a Tuple.
message
- The Message to Deserialize.for the list of fields the tuple will contain.
Fields getOutputFields()
Retrieve the Fields that are present on tuples created by this object.
Copyright © 2019 The Apache Software Foundation. All Rights Reserved.