T
- The type created by the deserialization schema.public interface PubSubDeserializationSchema<T> extends Serializable, ResultTypeQueryable<T>
Modifier and Type | Method and Description |
---|---|
T |
deserialize(com.google.pubsub.v1.PubsubMessage message)
Deserializes a PubsubMessage.
|
default void |
deserialize(com.google.pubsub.v1.PubsubMessage message,
Collector<T> out)
Deserializes the PubSub record.
|
boolean |
isEndOfStream(T nextElement)
Method to decide whether the element signals the end of the stream.
|
default void |
open(DeserializationSchema.InitializationContext context)
Initialization method for the schema.
|
getProducedType
default void open(DeserializationSchema.InitializationContext context) throws Exception
deserialize(com.google.pubsub.v1.PubsubMessage)
and thus suitable for one time setup work.
The provided DeserializationSchema.InitializationContext
can be used to access
additional features such as e.g. registering user metrics.
context
- Contextual information that can be used during initialization.Exception
boolean isEndOfStream(T nextElement)
nextElement
- The element to test for the end-of-stream signal.T deserialize(com.google.pubsub.v1.PubsubMessage message) throws Exception
message
- PubsubMessage to be deserialized.Exception
default void deserialize(com.google.pubsub.v1.PubsubMessage message, Collector<T> out) throws Exception
Can output multiple records through the Collector
. Note that number and size of
the produced records should be relatively small. Depending on the source implementation
records can be buffered in memory or collecting records might delay emitting checkpoint
barrier.
message
- PubsubMessage to be deserialized.out
- The collector to put the resulting messages.Exception
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.