You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@qpid.apache.org by ta...@apache.org on 2018/09/26 15:27:43 UTC

qpid-proton-j git commit: NO-JIRA Add a JMH test for the FrameWriter class for testing

Repository: qpid-proton-j
Updated Branches:
  refs/heads/master e6e78ac84 -> 232cd0077


NO-JIRA Add a JMH test for the FrameWriter class for testing


Project: http://git-wip-us.apache.org/repos/asf/qpid-proton-j/repo
Commit: http://git-wip-us.apache.org/repos/asf/qpid-proton-j/commit/232cd007
Tree: http://git-wip-us.apache.org/repos/asf/qpid-proton-j/tree/232cd007
Diff: http://git-wip-us.apache.org/repos/asf/qpid-proton-j/diff/232cd007

Branch: refs/heads/master
Commit: 232cd0077c462f578c916e7ffde24481fed25b59
Parents: e6e78ac
Author: Timothy Bish <ta...@gmail.com>
Authored: Wed Sep 26 11:27:03 2018 -0400
Committer: Timothy Bish <ta...@gmail.com>
Committed: Wed Sep 26 11:27:03 2018 -0400

----------------------------------------------------------------------
 .../engine/impl/FrameWriterBenchmark.java       | 132 +++++++++++++++++++
 1 file changed, 132 insertions(+)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/qpid-proton-j/blob/232cd007/tests/performance-jmh/src/main/java/org/apache/qpid/proton/engine/impl/FrameWriterBenchmark.java
----------------------------------------------------------------------
diff --git a/tests/performance-jmh/src/main/java/org/apache/qpid/proton/engine/impl/FrameWriterBenchmark.java b/tests/performance-jmh/src/main/java/org/apache/qpid/proton/engine/impl/FrameWriterBenchmark.java
new file mode 100644
index 0000000..e91f945
--- /dev/null
+++ b/tests/performance-jmh/src/main/java/org/apache/qpid/proton/engine/impl/FrameWriterBenchmark.java
@@ -0,0 +1,132 @@
+/*
+ * 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.qpid.proton.engine.impl;
+
+import java.nio.ByteBuffer;
+import java.util.concurrent.TimeUnit;
+
+import org.apache.qpid.proton.Proton;
+import org.apache.qpid.proton.amqp.Binary;
+import org.apache.qpid.proton.amqp.UnsignedInteger;
+import org.apache.qpid.proton.amqp.transport.Transfer;
+import org.apache.qpid.proton.codec.AMQPDefinedTypes;
+import org.apache.qpid.proton.codec.DecoderImpl;
+import org.apache.qpid.proton.codec.EncoderImpl;
+import org.apache.qpid.proton.codec.ReadableBuffer;
+import org.apache.qpid.proton.engine.impl.FrameWriter;
+import org.apache.qpid.proton.engine.impl.TransportImpl;
+import org.openjdk.jmh.annotations.Benchmark;
+import org.openjdk.jmh.annotations.BenchmarkMode;
+import org.openjdk.jmh.annotations.Measurement;
+import org.openjdk.jmh.annotations.Mode;
+import org.openjdk.jmh.annotations.OutputTimeUnit;
+import org.openjdk.jmh.annotations.Scope;
+import org.openjdk.jmh.annotations.Setup;
+import org.openjdk.jmh.annotations.State;
+import org.openjdk.jmh.annotations.Warmup;
+import org.openjdk.jmh.infra.Blackhole;
+import org.openjdk.jmh.profile.GCProfiler;
+import org.openjdk.jmh.runner.Runner;
+import org.openjdk.jmh.runner.RunnerException;
+import org.openjdk.jmh.runner.options.Options;
+import org.openjdk.jmh.runner.options.OptionsBuilder;
+
+/**
+ * Test performance of the FrameWriter class
+ */
+@State(Scope.Benchmark)
+@BenchmarkMode(Mode.AverageTime)
+@OutputTimeUnit(TimeUnit.NANOSECONDS)
+@Warmup(iterations = 5, time = 1)
+@Measurement(iterations = 5, time = 1)
+public class FrameWriterBenchmark {
+
+    private static final byte[] PAYLOAD_BYTES = {
+        0, 1, 2, 3, 4, 5, 6, 7, 8, 9, 10, 11, 12, 13, 14, 15,
+        0, 1, 2, 3, 4, 5, 6, 7, 8, 9, 10, 11, 12, 13, 14, 15,
+        0, 1, 2, 3, 4, 5, 6, 7, 8, 9, 10, 11, 12, 13, 14, 15,
+        0, 1, 2, 3, 4, 5, 6, 7, 8, 9, 10, 11, 12, 13, 14, 15,
+        0, 1, 2, 3, 4, 5, 6, 7, 8, 9, 10, 11, 12, 13, 14, 15,
+        0, 1, 2, 3, 4, 5, 6, 7, 8, 9, 10, 11, 12, 13, 14, 15,
+        0, 1, 2, 3, 4, 5, 6, 7, 8, 9, 10, 11, 12, 13, 14, 15,
+        0, 1, 2, 3, 4, 5, 6, 7, 8, 9, 10, 11, 12, 13, 14, 15
+    };
+
+    public static final int DEFAULT_BUFFER_SIZE = 8192;
+
+    private TransportImpl transport;
+    private FrameWriter frameWriter;
+    private ByteBuffer byteBuf;
+    private DecoderImpl decoder;
+    private EncoderImpl encoder;
+
+    private Transfer transfer;
+    private ReadableBuffer payload;
+
+    @Setup
+    public void init(Blackhole blackhole)
+    {
+        initProton();
+    }
+
+    public void initProton() {
+        byteBuf = ByteBuffer.allocate(DEFAULT_BUFFER_SIZE);
+        this.decoder = new DecoderImpl();
+        this.encoder = new EncoderImpl(decoder);
+        AMQPDefinedTypes.registerAllTypes(decoder, encoder);
+
+        transport = (TransportImpl) Proton.transport();
+        frameWriter = new FrameWriter(encoder, 16 * 1024, (byte) 0, null, transport);
+
+        transfer = new Transfer();
+        transfer.setDeliveryId(UnsignedInteger.ONE);
+        transfer.setHandle(UnsignedInteger.valueOf(16));
+        transfer.setDeliveryTag(new Binary(new byte[] { 0, 1}));
+        transfer.setMessageFormat(UnsignedInteger.ZERO);
+
+        payload = ReadableBuffer.ByteBufferReader.wrap(PAYLOAD_BYTES);
+    }
+
+    @Benchmark
+    public ByteBuffer writeTransferPerformative()
+    {
+        byteBuf.clear();
+
+        frameWriter.writeFrame(0, transfer, payload, null);
+        frameWriter.readBytes(byteBuf);
+
+        return byteBuf;
+    }
+
+    public static void main(String[] args) throws RunnerException
+    {
+        runBenchmark(FrameWriterBenchmark.class);
+    }
+
+    public static void runBenchmark(Class<?> benchmarkClass) throws RunnerException
+    {
+        final Options opt = new OptionsBuilder()
+            .include(benchmarkClass.getSimpleName())
+            .addProfiler(GCProfiler.class)
+            .shouldDoGC(true)
+            .warmupIterations(5)
+            .measurementIterations(5)
+            .forks(1)
+            .build();
+        new Runner(opt).run();
+    }
+}


---------------------------------------------------------------------
To unsubscribe, e-mail: commits-unsubscribe@qpid.apache.org
For additional commands, e-mail: commits-help@qpid.apache.org