Class Markers

java.lang.Object
org.apache.pulsar.common.protocol.Markers

public class Markers extends Object
  • Constructor Details

    • Markers

      public Markers()
  • Method Details

    • isServerOnlyMarker

      public static boolean isServerOnlyMarker(MessageMetadata msgMetadata)
    • isReplicatedSubscriptionSnapshotMarker

      public static boolean isReplicatedSubscriptionSnapshotMarker(MessageMetadata msgMetadata)
    • newReplicatedSubscriptionsSnapshotRequest

      public static io.netty.buffer.ByteBuf newReplicatedSubscriptionsSnapshotRequest(String snapshotId, String sourceCluster)
    • parseReplicatedSubscriptionsSnapshotRequest

      public static ReplicatedSubscriptionsSnapshotRequest parseReplicatedSubscriptionsSnapshotRequest(io.netty.buffer.ByteBuf payload) throws IOException
      Throws:
      IOException
    • newReplicatedSubscriptionsSnapshotResponse

      public static io.netty.buffer.ByteBuf newReplicatedSubscriptionsSnapshotResponse(String snapshotId, String replyToCluster, String cluster, long ledgerId, long entryId)
    • parseReplicatedSubscriptionsSnapshotResponse

      public static ReplicatedSubscriptionsSnapshotResponse parseReplicatedSubscriptionsSnapshotResponse(io.netty.buffer.ByteBuf payload) throws IOException
      Throws:
      IOException
    • newReplicatedSubscriptionsSnapshot

      public static io.netty.buffer.ByteBuf newReplicatedSubscriptionsSnapshot(String snapshotId, String sourceCluster, long ledgerId, long entryId, Map<String,MarkersMessageIdData> clusterIds)
    • parseReplicatedSubscriptionsSnapshot

      public static ReplicatedSubscriptionsSnapshot parseReplicatedSubscriptionsSnapshot(io.netty.buffer.ByteBuf payload) throws IOException
      Throws:
      IOException
    • newReplicatedSubscriptionsUpdate

      public static io.netty.buffer.ByteBuf newReplicatedSubscriptionsUpdate(String subscriptionName, Map<String,MarkersMessageIdData> clusterIds)
    • parseReplicatedSubscriptionsUpdate

      public static ReplicatedSubscriptionsUpdate parseReplicatedSubscriptionsUpdate(io.netty.buffer.ByteBuf payload)
    • isTxnCommitMarker

      public static boolean isTxnCommitMarker(MessageMetadata msgMetadata)
    • isTxnMarker

      public static boolean isTxnMarker(MessageMetadata msgMetadata)
    • newTxnCommitMarker

      public static io.netty.buffer.ByteBuf newTxnCommitMarker(long sequenceId, long txnMostBits, long txnLeastBits)
    • isTxnAbortMarker

      public static boolean isTxnAbortMarker(MessageMetadata msgMetadata)
    • newTxnAbortMarker

      public static io.netty.buffer.ByteBuf newTxnAbortMarker(long sequenceId, long txnMostBits, long txnLeastBits)