Class PulsarIO

java.lang.Object
org.apache.beam.sdk.io.pulsar.PulsarIO

public class PulsarIO extends Object
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.
  • 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 converting Message that returned by Pulsar client to a custom type understood by Beam.
    • read

      public static PulsarIO.Read<PulsarMessage> read()
    • write

      public static PulsarIO.Write 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.