Class PubsubClient.TopicPath

java.lang.Object
org.apache.beam.sdk.io.gcp.pubsub.PubsubClient.TopicPath
All Implemented Interfaces:
Serializable
Enclosing class:
PubsubClient

public static class PubsubClient.TopicPath extends Object implements Serializable
Path representing a Pubsub topic.
See Also:
  • Method Details

    • getPath

      public String getPath()
    • getName

      public String getName()
    • getDataCatalogSegments

      public List<String> getDataCatalogSegments()
      Returns the data catalog segments. This method is fail-safe. If topic path is malformed, it returns an empty string.
    • getFullPath

      public String getFullPath()
    • equals

      public boolean equals(@Nullable Object o)
      Overrides:
      equals in class Object
    • hashCode

      public int hashCode()
      Overrides:
      hashCode in class Object
    • toString

      public String toString()
      Overrides:
      toString in class Object