Package org.apache.beam.sdk.io.pulsar
Class PulsarIO
java.lang.Object
org.apache.beam.sdk.io.pulsar.PulsarIO
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.
-
Nested Class Summary
Nested Classes -
Method Summary
Modifier and TypeMethodDescriptionstatic PulsarIO.Read
read()
Read from Apache Pulsar.static PulsarIO.Write
write()
Write to Apache Pulsar.
-
Method Details
-
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
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.
-