Uses of Class
org.apache.pulsar.common.api.proto.BaseCommand
-
Packages that use BaseCommand Package Description org.apache.pulsar.common.api.proto org.apache.pulsar.common.protocol Common protocol. -
-
Uses of BaseCommand in org.apache.pulsar.common.api.proto
Methods in org.apache.pulsar.common.api.proto with parameters of type BaseCommand Modifier and Type Method Description BaseCommandBaseCommand. copyFrom(BaseCommand _other) -
Uses of BaseCommand in org.apache.pulsar.common.protocol
Methods in org.apache.pulsar.common.protocol that return BaseCommand Modifier and Type Method Description static BaseCommandCommands. newConnectedCommand(int clientProtocolVersion, int maxMessageSize)static BaseCommandCommands. newConsumerStatsResponseCommand(ServerError serverError, java.lang.String errMsg, long requestId)static BaseCommandCommands. newEndTxn(long requestId, long txnIdLeastBits, long txnIdMostBits, TxnAction txnAction)static BaseCommandCommands. newErrorCommand(long requestId, ServerError serverError, java.lang.String message)static BaseCommandCommands. newGetOrCreateSchemaResponseCommand(long requestId, SchemaVersion schemaVersion)static BaseCommandCommands. newGetOrCreateSchemaResponseErrorCommand(long requestId, ServerError error, java.lang.String errorMessage)static BaseCommandCommands. newGetSchemaResponseCommand(long requestId, org.apache.pulsar.common.schema.SchemaInfo schemaInfo, SchemaVersion version)static BaseCommandCommands. newGetSchemaResponseErrorCommand(long requestId, ServerError error, java.lang.String errorMessage)static BaseCommandCommands. newGetTopicsOfNamespaceResponseCommand(java.util.List<java.lang.String> topics, long requestId)static BaseCommandCommands. newLookupErrorResponseCommand(ServerError error, java.lang.String errorMsg, long requestId)static BaseCommandCommands. newLookupResponseCommand(java.lang.String brokerServiceUrl, java.lang.String brokerServiceUrlTls, boolean authoritative, CommandLookupTopicResponse.LookupType lookupType, long requestId, boolean proxyThroughServiceUrl)static BaseCommandCommands. newMessageCommand(long consumerId, long ledgerId, long entryId, int partition, int redeliveryCount, long[] ackSet, long consumerEpoch)static BaseCommandCommands. newPartitionMetadataResponseCommand(int partitions, long requestId)static BaseCommandCommands. newPartitionMetadataResponseCommand(ServerError error, java.lang.String errorMsg, long requestId)static BaseCommandCommands. newProducerSuccessCommand(long requestId, java.lang.String producerName, long lastSequenceId, SchemaVersion schemaVersion, java.util.Optional<java.lang.Long> topicEpoch, boolean isProducerReady)static BaseCommandCommands. newProducerSuccessCommand(long requestId, java.lang.String producerName, SchemaVersion schemaVersion)static BaseCommandCommands. newSendErrorCommand(long producerId, long sequenceId, ServerError error, java.lang.String errorMsg)static BaseCommandCommands. newSendReceiptCommand(long producerId, long sequenceId, long highestId, long ledgerId, long entryId)static BaseCommandCommands. newSuccessCommand(long requestId)static BaseCommandCommands. newTcClientConnectResponse(long requestId, ServerError error, java.lang.String message)Methods in org.apache.pulsar.common.protocol with parameters of type BaseCommand Modifier and Type Method Description protected voidPulsarDecoder. interceptCommand(BaseCommand command)static ByteBufPairCommands. serializeCommandMessageWithSize(BaseCommand cmd, io.netty.buffer.ByteBuf metadataAndPayload)static io.netty.buffer.ByteBufCommands. serializeWithSize(BaseCommand cmd)
-