Class PulsarIO

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

public class PulsarIO extends Object
Class for reading and writing from Apache Pulsar. Support is currently incomplete, and there may be bugs; 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 PulsarIO.Read read()
      Read from Apache Pulsar. Support is currently incomplete, and there may be bugs; see https://github.com/apache/beam/issues/31078 for more info, and comment in that issue if you run into issues with this IO.
    • write

      public static PulsarIO.Write write()
      Write to Apache Pulsar. Support is currently incomplete, and there may be bugs; see https://github.com/apache/beam/issues/31078 for more info, and comment in that issue if you run into issues with this IO.