Package org.apache.beam.sdk.io.pulsar
Class PulsarIO
java.lang.Object
org.apache.beam.sdk.io.pulsar.PulsarIO
IO connector for reading and writing from Apache Pulsar. Support is currently experimental, and
there may be bugs or performance issues; see https://github.com/apache/beam/issues/31078 for more
info, and comment in that issue if you run into issues with this IO.
-
Nested Class Summary
Nested Classes -
Method Summary
Modifier and TypeMethodDescriptionstatic PulsarIO.Read<PulsarMessage> read()The same asread(SerializableFunction), but returnsPCollection<PulsarMessage>.static <T> PulsarIO.Read<T> read(SerializableFunction<org.apache.pulsar.client.api.Message, T> fn) Read from Apache Pulsar.static PulsarIO.Writewrite()Write to Apache Pulsar.
-
Method Details
-
read
public static <T> PulsarIO.Read<T> read(SerializableFunction<org.apache.pulsar.client.api.Message, T> fn) Read from Apache Pulsar.Support is currently experimental, and there may be bugs or performance issues; see https://github.com/apache/beam/issues/31078 for more info, and comment in that issue if you run into issues with this IO.
- Parameters:
fn- a mapping function convertingMessagethat returned by Pulsar client to a custom type understood by Beam.
-
read
The same asread(SerializableFunction), but returnsPCollection<PulsarMessage>. -
write
Write to Apache Pulsar. Support is currently experimental, and there may be bugs or performance issues; see https://github.com/apache/beam/issues/31078 for more info, and comment in that issue if you run into issues with this IO.
-