You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@pulsar.apache.org by GitBox <gi...@apache.org> on 2021/11/08 08:54:56 UTC

[GitHub] [pulsar] liangyepianzhou commented on a change in pull request #11933: [Transaction] Add transaction perf

liangyepianzhou commented on a change in pull request #11933:
URL: https://github.com/apache/pulsar/pull/11933#discussion_r744514948



##########
File path: pulsar-testclient/src/main/java/org/apache/pulsar/testclient/PerformanceTransaction.java
##########
@@ -0,0 +1,701 @@
+/**
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ *   http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
+ */
+package org.apache.pulsar.testclient;
+
+import static java.util.concurrent.TimeUnit.NANOSECONDS;
+import static org.apache.pulsar.testclient.utils.PerformanceUtils.buildTransaction;
+
+import com.beust.jcommander.JCommander;
+import com.beust.jcommander.Parameter;
+import com.beust.jcommander.ParameterException;
+import com.beust.jcommander.Parameters;
+import com.fasterxml.jackson.databind.ObjectMapper;
+import com.fasterxml.jackson.databind.ObjectWriter;
+import com.google.common.collect.Lists;
+import java.io.FileInputStream;
+import java.io.FileOutputStream;
+import java.io.IOException;
+import java.io.PrintStream;
+import java.text.DecimalFormat;
+import java.util.Collections;
+import java.util.Iterator;
+import java.util.List;
+import java.util.Properties;
+import java.util.Random;
+import java.util.concurrent.ExecutionException;
+import java.util.concurrent.ExecutorService;
+import java.util.concurrent.Future;
+import java.util.concurrent.LinkedBlockingQueue;
+import java.util.concurrent.ThreadPoolExecutor;
+import java.util.concurrent.TimeUnit;
+import java.util.concurrent.atomic.AtomicBoolean;
+import java.util.concurrent.atomic.AtomicLong;
+import java.util.concurrent.atomic.AtomicReference;
+import java.util.concurrent.atomic.LongAdder;
+import org.HdrHistogram.Histogram;
+import org.HdrHistogram.HistogramLogWriter;
+import org.HdrHistogram.Recorder;
+import org.apache.curator.shaded.com.google.common.util.concurrent.RateLimiter;
+import org.apache.pulsar.client.admin.PulsarAdmin;
+import org.apache.pulsar.client.admin.PulsarAdminBuilder;
+import org.apache.pulsar.client.admin.PulsarAdminException;
+import org.apache.pulsar.client.api.Consumer;
+import org.apache.pulsar.client.api.ConsumerBuilder;
+import org.apache.pulsar.client.api.Message;
+import org.apache.pulsar.client.api.Producer;
+import org.apache.pulsar.client.api.ProducerBuilder;
+import org.apache.pulsar.client.api.PulsarClient;
+import org.apache.pulsar.client.api.PulsarClientException;
+import org.apache.pulsar.client.api.Schema;
+import org.apache.pulsar.client.api.SubscriptionInitialPosition;
+import org.apache.pulsar.client.api.SubscriptionType;
+import org.apache.pulsar.client.api.transaction.Transaction;
+import org.apache.pulsar.common.partition.PartitionedTopicMetadata;
+import org.apache.pulsar.testclient.utils.PaddingDecimalFormat;
+import org.slf4j.Logger;
+import org.slf4j.LoggerFactory;
+
+public class PerformanceTransaction {
+
+
+    private static final LongAdder totalNumEndTxnOpFailed = new LongAdder();
+    private static final LongAdder totalNumEndTxnOpSuccess = new LongAdder();
+    private static final LongAdder numTxnOpSuccess = new LongAdder();
+    private static final LongAdder totalNumTxnOpenTxnFail = new LongAdder();
+    private static final LongAdder totalNumTxnOpenTxnSuccess = new LongAdder();
+
+    private static final LongAdder numMessagesAckFailed = new LongAdder();
+    private static final LongAdder numMessagesAckSuccess = new LongAdder();
+    private static final LongAdder numMessagesSendFailed = new LongAdder();
+    private static final LongAdder numMessagesSendSuccess = new LongAdder();
+
+    private static final Recorder messageAckRecorder =
+            new Recorder(TimeUnit.SECONDS.toMicros(120000), 5);
+    private static final Recorder messageAckCumulativeRecorder =
+            new Recorder(TimeUnit.SECONDS.toMicros(120000), 5);
+
+    private static final Recorder messageSendRecorder =
+            new Recorder(TimeUnit.SECONDS.toMicros(120000), 5);
+    private static final Recorder messageSendRCumulativeRecorder =
+            new Recorder(TimeUnit.SECONDS.toMicros(120000), 5);
+
+
+    @Parameters(commandDescription = "Test pulsar transaction performance.")
+    static class Arguments {
+
+        @Parameter(names = {"-h", "--help"}, description = "Help message", help = true)
+        boolean help;
+
+        @Parameter(names = {"--conf-file"}, description = "Configuration file")
+        public String confFile;
+
+        @Parameter(names = "--topics-c", description = "All topics that need ack for a transaction", required =
+                true)
+        public List<String> consumerTopic = Collections.singletonList("test-consume");
+
+        @Parameter(names = "--topics-p", description = "All topics that need produce for a transaction",
+                required = true)
+        public List<String> producerTopic = Collections.singletonList("test-produce");
+
+        @Parameter(names = {"-threads", "--num-test-threads"}, description = "Number of test threads."
+                + "This thread is for a new transaction to ack messages from consumer topics and produce message to "
+                + "producer topics, and then commit or abort this transaction. "
+                + "Increasing the number of threads increases the parallelism of the performance test, "
+                + "thereby increasing the intensity of the stress test.")
+        public int numTestThreads = 1;
+
+        @Parameter(names = {"-au", "--admin-url"}, description = "Pulsar Admin URL")
+        public String adminURL;
+
+        @Parameter(names = {"-u", "--service-url"}, description = "Pulsar Service URL")
+        public String serviceURL;
+
+        @Parameter(names = {"-np",
+                "--partitions"}, description = "Create partitioned topics with a given number of partitions, 0 means"
+                + "not trying to create a topic")
+        public Integer partitions = null;
+
+        @Parameter(names = {"-c",
+                "--max-connections"}, description = "Max number of TCP connections to a single broker")
+        public int maxConnections = 100;
+
+        @Parameter(names = {"-time",
+                "--test-duration"}, description = "Test duration (in second). 0 means keeping publishing")
+        public long testTime = 0;
+
+        @Parameter(names = {"-ioThreads", "--num-io-threads"}, description = "Set the number of threads to be " +
+                "used for handling connections to brokers. The default value is 1.")
+        public int ioThreads = 1;
+
+        @Parameter(names = {"-ss",
+                "--subscriptions"}, description = "A list of subscriptions to consume (for example, sub1,sub2)")
+        public List<String> subscriptions = Collections.singletonList("sub");
+
+        @Parameter(names = {"-ns", "--num-subscriptions"}, description = "Number of subscriptions (per topic)")
+        public int numSubscriptions = 1;
+
+        @Parameter(names = {"-sp", "--subscription-position"}, description = "Subscription position")
+        private SubscriptionInitialPosition subscriptionInitialPosition = SubscriptionInitialPosition.Earliest;
+
+        @Parameter(names = {"-st", "--subscription-type"}, description = "Subscription type")
+        public SubscriptionType subscriptionType = SubscriptionType.Shared;
+
+        @Parameter(names = {"-q", "--receiver-queue-size"}, description = "Size of the receiver queue")
+        public int receiverQueueSize = 1000;
+
+        @Parameter(names = {"-tto", "--txn-timeout"}, description = "Set the time value of transaction timeout,"
+                + " and the time unit is second. (After --txn-enable setting to true, --txn-timeout takes effect)")
+        public long transactionTimeout = 5;
+
+        @Parameter(names = {"-ntxn",
+                "--number-txn"}, description = "Set the number of transaction. 0 means keeping open."
+                + "If transaction disabled, it means the number of tasks. The task or transaction produces or "
+                + "consumes a specified number of messages.")
+        public long numTransactions = 0;
+
+        @Parameter(names = {"-nmp", "--numMessage-perTransaction-produce"},
+                description = "Set the number of messages produced in  a transaction."
+                        + "If transaction disabled, it means the number of messages produced in a task.")
+        public int numMessagesProducedPerTransaction = 1;
+
+        @Parameter(names = {"-nmc", "--numMessage-perTransaction-consume"},
+                description = "Set the number of messages consumed in a transaction."
+                        + "If transaction disabled, it means the number of messages consumed in a task.")
+        public int numMessagesReceivedPerTransaction = 1;
+
+        @Parameter(names = {"--txn-disEnable"}, description = "Disable transaction")
+        public boolean isDisEnableTransaction = false;
+
+        @Parameter(names = {"-abort"}, description = "Abort the transaction. (After --txn-disEnable "
+                + "setting to false, -abort takes effect)")
+        public boolean isAbortTransaction = false;
+
+        @Parameter(names = "-txnRate", description = "Set the rate of opened transaction or task. 0 means no limit")
+        public int openTxnRate = 0;
+    }
+
+    public static void main(String[] args)
+            throws IOException, PulsarAdminException, ExecutionException, InterruptedException {
+        final Arguments arguments = new Arguments();
+        JCommander jc = new JCommander(arguments);
+        jc.setProgramName("pulsar-perf transaction");
+
+        try {
+            jc.parse(args);
+        } catch (ParameterException e) {
+            System.out.println(e.getMessage());
+            jc.usage();
+            PerfClientUtils.exit(-1);
+        }
+
+        if (arguments.help) {
+            jc.usage();
+            PerfClientUtils.exit(-1);
+        }
+
+
+        if (arguments.confFile != null) {
+            Properties prop = new Properties(System.getProperties());
+            prop.load(new FileInputStream(arguments.confFile));
+
+            if (arguments.serviceURL == null) {
+                arguments.serviceURL = prop.getProperty("brokerServiceUrl");
+            }
+
+            if (arguments.serviceURL == null) {
+                arguments.serviceURL = prop.getProperty("webServiceUrl");
+            }
+
+            // fallback to previous-version serviceUrl property to maintain backward-compatibility
+            if (arguments.serviceURL == null) {
+                arguments.serviceURL = prop.getProperty("serviceUrl", "http://localhost:8080/");
+            }
+
+            if (arguments.adminURL == null) {
+                arguments.adminURL = prop.getProperty("webServiceUrl");
+            }
+            if (arguments.adminURL == null) {
+                arguments.adminURL = prop.getProperty("adminURL", "http://localhost:8080/");
+            }
+        }
+
+
+        // Dump config variables
+        PerfClientUtils.printJVMInformation(log);
+
+        ObjectMapper m = new ObjectMapper();
+        ObjectWriter w = m.writerWithDefaultPrettyPrinter();
+        log.info("Starting Pulsar perf transaction with config: {}", w.writeValueAsString(arguments));
+
+        final byte[] payloadBytes = new byte[1024];
+        Random random = new Random(0);
+        for (int i = 0; i < payloadBytes.length; ++i) {
+            payloadBytes[i] = (byte) (random.nextInt(26) + 65);
+        }
+        if (arguments.partitions != null) {
+            PulsarAdminBuilder clientBuilder = PulsarAdmin.builder()
+                    .serviceHttpUrl(arguments.adminURL);
+            try (PulsarAdmin client = clientBuilder.build()) {
+                for (String topic : arguments.producerTopic) {
+                    log.info("Creating  produce partitioned topic {} with {} partitions", topic, arguments.partitions);
+                    try {
+                        client.topics().createPartitionedTopic(topic, arguments.partitions);
+                    } catch (PulsarAdminException.ConflictException alreadyExists) {
+                        if (log.isDebugEnabled()) {
+                            log.debug("Topic {} already exists: {}", topic, alreadyExists);
+                        }
+                        PartitionedTopicMetadata partitionedTopicMetadata =
+                                client.topics().getPartitionedTopicMetadata(topic);
+                        if (partitionedTopicMetadata.partitions != arguments.partitions) {
+                            log.error(
+                                    "Topic {} already exists but it has a wrong number of partitions: {}, expecting {}",
+                                    topic, partitionedTopicMetadata.partitions, arguments.partitions);
+                            PerfClientUtils.exit(-1);
+                        }
+                    }
+                }
+            }
+        }
+
+        PulsarClient client =
+                PulsarClient.builder().enableTransaction(!arguments.isDisEnableTransaction)
+                        .serviceUrl(arguments.serviceURL)
+                        .connectionsPerBroker(arguments.maxConnections)
+                        .statsInterval(0, TimeUnit.SECONDS)
+                        .ioThreads(arguments.ioThreads)
+                        .build();
+
+        ExecutorService executorService = new ThreadPoolExecutor(arguments.numTestThreads,
+                arguments.numTestThreads,
+                0L, TimeUnit.MILLISECONDS,
+                new LinkedBlockingQueue<Runnable>());
+
+
+        long startTime = System.nanoTime();
+        long testEndTime = startTime + (long) (arguments.testTime * 1e9);
+        Runtime.getRuntime().addShutdownHook(new Thread(() -> {
+            if (!arguments.isDisEnableTransaction) {
+                printTxnAggregatedThroughput(startTime);
+            } else {
+                printAggregatedThroughput(startTime);
+            }
+            printAggregatedStats();
+        }));
+
+        // start perf test
+        AtomicBoolean executing = new AtomicBoolean(true);
+
+            RateLimiter rateLimiter = arguments.openTxnRate > 0
+                    ? RateLimiter.create(arguments.openTxnRate)
+                    : null;
+            for(int i = 0; i < arguments.numTestThreads; i++) {
+                executorService.submit(() -> {
+                    //The producer and consumer clients are built in advance, and then this thread is
+                    //responsible for the production and consumption tasks of the transaction through the loop.
+                    //A thread may perform tasks of multiple transactions in a traversing manner.
+                    List<Producer<byte[]>> producers = null;
+                    List<List<Consumer<byte[]>>> consumers = null;
+                    try {
+                        producers = buildProducers(client, arguments);
+                        consumers = buildConsumer(client, arguments);
+                    } catch (Exception e) {
+                        log.error("Failed to build Producer/Consumer with exception : ", e);
+                        executorService.shutdownNow();
+                        PerfClientUtils.exit(-1);
+                    }
+                    AtomicReference<Transaction> atomicReference = buildTransaction(client,
+                            !arguments.isDisEnableTransaction, arguments.transactionTimeout);
+                    //The while loop has no break, and finally ends the execution through the shutdownNow of
+                    //0the executorService
+                    while (true) {
+                        if (arguments.numTransactions > 0) {
+                            if (totalNumEndTxnOpFailed.sum()
+                                    + totalNumTxnOpenTxnSuccess.sum() >= arguments.numTransactions) {
+                                log.info("------------------- DONE -----------------------");
+                                executing.compareAndSet(true, false);
+                                executorService.shutdownNow();
+                                break;
+                            }
+                        }
+                        if (arguments.testTime > 0) {
+                            if (System.nanoTime() > testEndTime) {
+                                log.info("------------------- DONE -----------------------");
+                                executing.compareAndSet(true, false);
+                                executorService.shutdownNow();
+                                break;
+                            }
+                        }
+
+                        Transaction transaction = atomicReference.get();
+                        for (List<Consumer<byte[]>> subscriptions : consumers) {
+                                for (Consumer<byte[]> consumer : subscriptions) {
+                                    for (int j = 0; j < arguments.numMessagesReceivedPerTransaction; j++) {
+                                        Message message = null;
+                                        try {
+                                            message = consumer.receive();
+                                        } catch (PulsarClientException e) {
+                                            log.error("Receive message failed", e);
+                                            executorService.shutdownNow();

Review comment:
       Yes, I have done this




-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: commits-unsubscribe@pulsar.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org