Class WriteToPulsarDoFn

java.lang.Object
org.apache.beam.sdk.transforms.DoFn<byte[],Void>
org.apache.beam.sdk.io.pulsar.WriteToPulsarDoFn
All Implemented Interfaces:
Serializable, HasDisplayData

@UnboundedPerElement public class WriteToPulsarDoFn extends DoFn<byte[],Void>
Transform for writing 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.
See Also:
  • Method Details

    • setup

      @Setup public void setup() throws org.apache.pulsar.client.api.PulsarClientException
      Throws:
      org.apache.pulsar.client.api.PulsarClientException
    • processElement

      @ProcessElement public void processElement(@Element byte[] messageToSend) throws Exception
      Throws:
      Exception
    • teardown

      @Teardown public void teardown() throws org.apache.pulsar.client.api.PulsarClientException
      Throws:
      org.apache.pulsar.client.api.PulsarClientException