Class CommandProducer

java.lang.Object
org.apache.pulsar.common.api.proto.CommandProducer

public final class CommandProducer extends Object
  • Constructor Details

    • CommandProducer

      public CommandProducer()
  • Method Details

    • hasTopic

      public boolean hasTopic()
    • getTopic

      public String getTopic()
    • setTopic

      public CommandProducer setTopic(String topic)
    • clearTopic

      public CommandProducer clearTopic()
    • hasProducerId

      public boolean hasProducerId()
    • getProducerId

      public long getProducerId()
    • setProducerId

      public CommandProducer setProducerId(long producerId)
    • clearProducerId

      public CommandProducer clearProducerId()
    • hasRequestId

      public boolean hasRequestId()
    • getRequestId

      public long getRequestId()
    • setRequestId

      public CommandProducer setRequestId(long requestId)
    • clearRequestId

      public CommandProducer clearRequestId()
    • hasProducerName

      public boolean hasProducerName()
    • getProducerName

      public String getProducerName()
    • setProducerName

      public CommandProducer setProducerName(String producerName)
    • clearProducerName

      public CommandProducer clearProducerName()
    • hasEncrypted

      public boolean hasEncrypted()
    • isEncrypted

      public boolean isEncrypted()
    • setEncrypted

      public CommandProducer setEncrypted(boolean encrypted)
    • clearEncrypted

      public CommandProducer clearEncrypted()
    • getMetadatasCount

      public int getMetadatasCount()
    • getMetadataAt

      public KeyValue getMetadataAt(int idx)
    • getMetadatasList

      public List<KeyValue> getMetadatasList()
    • addMetadata

      public KeyValue addMetadata()
    • addAllMetadatas

      public CommandProducer addAllMetadatas(Iterable<KeyValue> metadatas)
    • clearMetadata

      public CommandProducer clearMetadata()
    • hasSchema

      public boolean hasSchema()
    • getSchema

      public Schema getSchema()
    • setSchema

      public Schema setSchema()
    • clearSchema

      public CommandProducer clearSchema()
    • hasEpoch

      public boolean hasEpoch()
    • getEpoch

      public long getEpoch()
    • setEpoch

      public CommandProducer setEpoch(long epoch)
    • clearEpoch

      public CommandProducer clearEpoch()
    • hasUserProvidedProducerName

      public boolean hasUserProvidedProducerName()
    • isUserProvidedProducerName

      public boolean isUserProvidedProducerName()
    • setUserProvidedProducerName

      public CommandProducer setUserProvidedProducerName(boolean userProvidedProducerName)
    • clearUserProvidedProducerName

      public CommandProducer clearUserProvidedProducerName()
    • hasProducerAccessMode

      public boolean hasProducerAccessMode()
    • getProducerAccessMode

      public ProducerAccessMode getProducerAccessMode()
    • setProducerAccessMode

      public CommandProducer setProducerAccessMode(ProducerAccessMode producerAccessMode)
    • clearProducerAccessMode

      public CommandProducer clearProducerAccessMode()
    • hasTopicEpoch

      public boolean hasTopicEpoch()
    • getTopicEpoch

      public long getTopicEpoch()
    • setTopicEpoch

      public CommandProducer setTopicEpoch(long topicEpoch)
    • clearTopicEpoch

      public CommandProducer clearTopicEpoch()
    • hasTxnEnabled

      public boolean hasTxnEnabled()
    • isTxnEnabled

      public boolean isTxnEnabled()
    • setTxnEnabled

      public CommandProducer setTxnEnabled(boolean txnEnabled)
    • clearTxnEnabled

      public CommandProducer clearTxnEnabled()
    • hasInitialSubscriptionName

      public boolean hasInitialSubscriptionName()
    • getInitialSubscriptionName

      public String getInitialSubscriptionName()
    • setInitialSubscriptionName

      public CommandProducer setInitialSubscriptionName(String initialSubscriptionName)
    • clearInitialSubscriptionName

      public CommandProducer clearInitialSubscriptionName()
    • writeTo

      public int writeTo(io.netty.buffer.ByteBuf _b)
    • getSerializedSize

      public int getSerializedSize()
    • parseFrom

      public void parseFrom(io.netty.buffer.ByteBuf _buffer, int _size)
    • clear

      public CommandProducer clear()
    • copyFrom

      public CommandProducer copyFrom(CommandProducer _other)
    • toByteArray

      public byte[] toByteArray()
    • parseFrom

      public void parseFrom(byte[] a)