You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@tuweni.apache.org by to...@apache.org on 2020/05/03 03:52:15 UTC

[incubator-tuweni] branch master updated: enable integration tests

This is an automated email from the ASF dual-hosted git repository.

toulmean pushed a commit to branch master
in repository https://gitbox.apache.org/repos/asf/incubator-tuweni.git


The following commit(s) were added to refs/heads/master by this push:
     new 97d94dd  enable integration tests
97d94dd is described below

commit 97d94dd112bad758171833be8ce1fdc674a74914
Author: Antoine Toulme <an...@lunar-ocean.com>
AuthorDate: Sat May 2 20:51:54 2020 -0700

    enable integration tests
---
 Jenkinsfile                                        |  2 +-
 build.gradle                                       | 44 +++++++++++++---------
 .../tuweni/devp2p/DiscoveryServiceJavaTest.java    |  0
 .../tuweni/devp2p/v5/NodeDiscoveryServiceTest.java |  0
 .../apache/tuweni/devp2p/DiscoveryServiceTest.kt   |  0
 .../tuweni/devp2p/v5/AbstractIntegrationTest.kt    |  0
 .../devp2p/v5/DefaultNodeDiscoveryServiceTest.kt   |  0
 .../org/apache/tuweni/devp2p/v5/IntegrationTest.kt |  0
 .../devp2p/v5/internal/DefaultUdpConnectorTest.kt  |  0
 .../tuweni/devp2p/v5/topic/TopicIntegrationTest.kt |  0
 .../main/kotlin/org/apache/tuweni/devp2p/Node.kt   |  2 +-
 .../main/kotlin/org/apache/tuweni/devp2p/Packet.kt | 18 ++++-----
 .../kotlin/org/apache/tuweni/devp2p/PacketType.kt  |  2 +-
 .../org/apache/tuweni/discovery/DNSResolverTest.kt |  0
 .../tuweni/ethstats/EthStatsReporterTest.java      |  0
 .../tuweni/gossip/GossipIntegrationTest.java       |  0
 .../org/apache/tuweni/gossip/GossipLoadTest.java   |  0
 .../org/apache/tuweni/relayer/RelayerAppTest.kt    |  0
 .../org/apache/tuweni/hobbits/InteractionTest.kt   |  0
 .../org/apache/tuweni/hobbits/RelayerTest.kt       |  0
 .../net/coroutines/CoroutineSocketChannelTest.kt   |  0
 plumtree/build.gradle                              |  3 +-
 .../plumtree/vertx/VertxGossipServerTest.java      |  2 +-
 .../tuweni/rlpx/vertx/VertxAcceptanceTest.java     |  8 ++--
 .../tuweni/rlpx/vertx/VertxRLPxServiceTest.java    |  7 ++--
 .../ScuttlebuttLocalDiscoveryServiceTest.java      |  0
 .../handshake/vertx/VertxIntegrationTest.java      |  0
 .../scuttlebutt/rpc/PatchworkIntegrationTest.java  |  0
 .../rpc/mux/PatchworkIntegrationTest.java          |  0
 29 files changed, 49 insertions(+), 39 deletions(-)

diff --git a/Jenkinsfile b/Jenkinsfile
index cd8d2ba..67e7da3 100644
--- a/Jenkinsfile
+++ b/Jenkinsfile
@@ -36,7 +36,7 @@ pipeline {
         stage('Build') {
             steps {
                 timeout(time: 60, unit: 'MINUTES') {
-                    sh "./gradlew allDependencies checkLicenses spotlessCheck test assemble"
+                    sh "./gradlew allDependencies checkLicenses spotlessCheck assemble test integrationTest"
                 }
             }
         }
diff --git a/build.gradle b/build.gradle
index 5d5638b..27ddeb0 100644
--- a/build.gradle
+++ b/build.gradle
@@ -169,26 +169,36 @@ subprojects {
     }
   }
 
-  sourceSets {
-    integrationTest {
-      java.srcDir 'src/integration-test/java'
-      kotlin.srcDir 'src/integration-test/kotlin'
-      resources.srcDir 'src/integration-test/resources'
-      compileClasspath += main.output
-      runtimeClasspath += main.output
+  plugins.withId('java', { _ ->
+    sourceSets {
+      integrationTest {
+        compileClasspath += sourceSets.main.output + sourceSets.test.output
+        runtimeClasspath += sourceSets.main.output + sourceSets.test.output
+      }
     }
-  }
 
-  configurations {
-    integrationTestImplementation.extendsFrom testImplementation
-    integrationTestRuntime.extendsFrom testRuntime
-  }
+    configurations {
+      integrationTestImplementation.extendsFrom testImplementation
+      integrationTestRuntime.extendsFrom testRuntime
+    }
+    dependencies {
+      integrationTestRuntime 'org.junit.jupiter:junit-jupiter-engine'
+      integrationTestRuntime 'ch.qos.logback:logback-classic'
+    }
 
-  task integrationTest(type: Test) {
-    testClassesDirs = sourceSets.integrationTest.output.classesDirs
-    classpath = sourceSets.integrationTest.runtimeClasspath
-  }
-  rootProject.integrationTest.dependsOn project.integrationTest
+    task integrationTest(type: Test) {
+      description = 'Runs integration tests.'
+      group = 'verification'
+
+      testClassesDirs = sourceSets.integrationTest.output.classesDirs
+      classpath = sourceSets.integrationTest.runtimeClasspath
+
+      useJUnitPlatform() { includeEngines 'spek', 'junit-jupiter' }
+      timeout = Duration.ofMinutes(30)
+    }
+
+    rootProject.integrationTest.dependsOn integrationTest
+  })
 
   //////
   // Parallel build execution
diff --git a/devp2p/src/integration-test/java/org/apache/tuweni/devp2p/DiscoveryServiceJavaTest.java b/devp2p/src/integrationTest/java/org/apache/tuweni/devp2p/DiscoveryServiceJavaTest.java
similarity index 100%
rename from devp2p/src/integration-test/java/org/apache/tuweni/devp2p/DiscoveryServiceJavaTest.java
rename to devp2p/src/integrationTest/java/org/apache/tuweni/devp2p/DiscoveryServiceJavaTest.java
diff --git a/devp2p/src/integration-test/java/org/apache/tuweni/devp2p/v5/NodeDiscoveryServiceTest.java b/devp2p/src/integrationTest/java/org/apache/tuweni/devp2p/v5/NodeDiscoveryServiceTest.java
similarity index 100%
rename from devp2p/src/integration-test/java/org/apache/tuweni/devp2p/v5/NodeDiscoveryServiceTest.java
rename to devp2p/src/integrationTest/java/org/apache/tuweni/devp2p/v5/NodeDiscoveryServiceTest.java
diff --git a/devp2p/src/integration-test/kotlin/org/apache/tuweni/devp2p/DiscoveryServiceTest.kt b/devp2p/src/integrationTest/kotlin/org/apache/tuweni/devp2p/DiscoveryServiceTest.kt
similarity index 100%
rename from devp2p/src/integration-test/kotlin/org/apache/tuweni/devp2p/DiscoveryServiceTest.kt
rename to devp2p/src/integrationTest/kotlin/org/apache/tuweni/devp2p/DiscoveryServiceTest.kt
diff --git a/devp2p/src/integration-test/kotlin/org/apache/tuweni/devp2p/v5/AbstractIntegrationTest.kt b/devp2p/src/integrationTest/kotlin/org/apache/tuweni/devp2p/v5/AbstractIntegrationTest.kt
similarity index 100%
rename from devp2p/src/integration-test/kotlin/org/apache/tuweni/devp2p/v5/AbstractIntegrationTest.kt
rename to devp2p/src/integrationTest/kotlin/org/apache/tuweni/devp2p/v5/AbstractIntegrationTest.kt
diff --git a/devp2p/src/integration-test/kotlin/org/apache/tuweni/devp2p/v5/DefaultNodeDiscoveryServiceTest.kt b/devp2p/src/integrationTest/kotlin/org/apache/tuweni/devp2p/v5/DefaultNodeDiscoveryServiceTest.kt
similarity index 100%
rename from devp2p/src/integration-test/kotlin/org/apache/tuweni/devp2p/v5/DefaultNodeDiscoveryServiceTest.kt
rename to devp2p/src/integrationTest/kotlin/org/apache/tuweni/devp2p/v5/DefaultNodeDiscoveryServiceTest.kt
diff --git a/devp2p/src/integration-test/kotlin/org/apache/tuweni/devp2p/v5/IntegrationTest.kt b/devp2p/src/integrationTest/kotlin/org/apache/tuweni/devp2p/v5/IntegrationTest.kt
similarity index 100%
rename from devp2p/src/integration-test/kotlin/org/apache/tuweni/devp2p/v5/IntegrationTest.kt
rename to devp2p/src/integrationTest/kotlin/org/apache/tuweni/devp2p/v5/IntegrationTest.kt
diff --git a/devp2p/src/integration-test/kotlin/org/apache/tuweni/devp2p/v5/internal/DefaultUdpConnectorTest.kt b/devp2p/src/integrationTest/kotlin/org/apache/tuweni/devp2p/v5/internal/DefaultUdpConnectorTest.kt
similarity index 100%
rename from devp2p/src/integration-test/kotlin/org/apache/tuweni/devp2p/v5/internal/DefaultUdpConnectorTest.kt
rename to devp2p/src/integrationTest/kotlin/org/apache/tuweni/devp2p/v5/internal/DefaultUdpConnectorTest.kt
diff --git a/devp2p/src/integration-test/kotlin/org/apache/tuweni/devp2p/v5/topic/TopicIntegrationTest.kt b/devp2p/src/integrationTest/kotlin/org/apache/tuweni/devp2p/v5/topic/TopicIntegrationTest.kt
similarity index 100%
rename from devp2p/src/integration-test/kotlin/org/apache/tuweni/devp2p/v5/topic/TopicIntegrationTest.kt
rename to devp2p/src/integrationTest/kotlin/org/apache/tuweni/devp2p/v5/topic/TopicIntegrationTest.kt
diff --git a/devp2p/src/main/kotlin/org/apache/tuweni/devp2p/Node.kt b/devp2p/src/main/kotlin/org/apache/tuweni/devp2p/Node.kt
index f5e38d1..6cd656d 100644
--- a/devp2p/src/main/kotlin/org/apache/tuweni/devp2p/Node.kt
+++ b/devp2p/src/main/kotlin/org/apache/tuweni/devp2p/Node.kt
@@ -20,7 +20,7 @@ import org.apache.tuweni.crypto.SECP256K1
 import org.apache.tuweni.rlp.RLPReader
 import org.apache.tuweni.rlp.RLPWriter
 
-internal data class Node(
+data class Node(
   val endpoint: Endpoint,
   val nodeId: SECP256K1.PublicKey
 ) {
diff --git a/devp2p/src/main/kotlin/org/apache/tuweni/devp2p/Packet.kt b/devp2p/src/main/kotlin/org/apache/tuweni/devp2p/Packet.kt
index 27ad0a9..c4f3f17 100644
--- a/devp2p/src/main/kotlin/org/apache/tuweni/devp2p/Packet.kt
+++ b/devp2p/src/main/kotlin/org/apache/tuweni/devp2p/Packet.kt
@@ -25,14 +25,14 @@ import org.apache.tuweni.rlp.RLPException
 import org.apache.tuweni.rlp.RLPWriter
 import java.nio.ByteBuffer
 
-internal class DecodingException(message: String, cause: Throwable? = null) : Exception(message, cause)
+class DecodingException(message: String, cause: Throwable? = null) : Exception(message, cause)
 
-internal data class SigHash(val signature: SECP256K1.Signature, val hash: Bytes32)
+data class SigHash(val signature: SECP256K1.Signature, val hash: Bytes32)
 
 private fun msecToSec(time: Long) = (time + 999) / 1000
 private fun secToMsec(time: Long) = time * 1000
 
-internal sealed class Packet(
+sealed class Packet(
   val nodeId: SECP256K1.PublicKey,
   private val signature: SECP256K1.Signature,
   val hash: Bytes32,
@@ -108,7 +108,7 @@ internal sealed class Packet(
   }
 }
 
-internal class PingPacket private constructor(
+class PingPacket private constructor(
   nodeId: SECP256K1.PublicKey,
   signature: SECP256K1.Signature,
   hash: Bytes32,
@@ -185,7 +185,7 @@ internal class PingPacket private constructor(
   }
 }
 
-internal class PongPacket private constructor(
+class PongPacket private constructor(
   nodeId: SECP256K1.PublicKey,
   signature: SECP256K1.Signature,
   hash: Bytes32,
@@ -252,7 +252,7 @@ internal class PongPacket private constructor(
   }
 }
 
-internal class FindNodePacket private constructor(
+class FindNodePacket private constructor(
   nodeId: SECP256K1.PublicKey,
   signature: SECP256K1.Signature,
   hash: Bytes32,
@@ -306,7 +306,7 @@ internal class FindNodePacket private constructor(
   }
 }
 
-internal class NeighborsPacket private constructor(
+class NeighborsPacket private constructor(
   nodeId: SECP256K1.PublicKey,
   signature: SECP256K1.Signature,
   hash: Bytes32,
@@ -387,7 +387,7 @@ internal class NeighborsPacket private constructor(
   }
 }
 
-internal class ENRRequestPacket private constructor(
+class ENRRequestPacket private constructor(
   nodeId: SECP256K1.PublicKey,
   signature: SECP256K1.Signature,
   hash: Bytes32,
@@ -437,7 +437,7 @@ internal class ENRRequestPacket private constructor(
   }
 }
 
-internal class ENRResponsePacket private constructor(
+class ENRResponsePacket private constructor(
   nodeId: SECP256K1.PublicKey,
   signature: SECP256K1.Signature,
   hash: Bytes32,
diff --git a/devp2p/src/main/kotlin/org/apache/tuweni/devp2p/PacketType.kt b/devp2p/src/main/kotlin/org/apache/tuweni/devp2p/PacketType.kt
index c46934c..2c40ded 100644
--- a/devp2p/src/main/kotlin/org/apache/tuweni/devp2p/PacketType.kt
+++ b/devp2p/src/main/kotlin/org/apache/tuweni/devp2p/PacketType.kt
@@ -20,7 +20,7 @@ import org.apache.tuweni.bytes.Bytes
 import org.apache.tuweni.bytes.Bytes32
 import org.apache.tuweni.crypto.SECP256K1
 
-internal enum class PacketType(
+enum class PacketType(
   val typeId: Byte
 ) {
 
diff --git a/dns-discovery/src/test/kotlin/org/apache/tuweni/discovery/DNSResolverTest.kt b/dns-discovery/src/integrationTest/kotlin/org/apache/tuweni/discovery/DNSResolverTest.kt
similarity index 100%
rename from dns-discovery/src/test/kotlin/org/apache/tuweni/discovery/DNSResolverTest.kt
rename to dns-discovery/src/integrationTest/kotlin/org/apache/tuweni/discovery/DNSResolverTest.kt
diff --git a/ethstats/src/integration-test/java/org/apache/tuweni/ethstats/EthStatsReporterTest.java b/ethstats/src/integrationTest/java/org/apache/tuweni/ethstats/EthStatsReporterTest.java
similarity index 100%
rename from ethstats/src/integration-test/java/org/apache/tuweni/ethstats/EthStatsReporterTest.java
rename to ethstats/src/integrationTest/java/org/apache/tuweni/ethstats/EthStatsReporterTest.java
diff --git a/gossip/src/integration-test/java/org/apache/tuweni/gossip/GossipIntegrationTest.java b/gossip/src/integrationTest/java/org/apache/tuweni/gossip/GossipIntegrationTest.java
similarity index 100%
rename from gossip/src/integration-test/java/org/apache/tuweni/gossip/GossipIntegrationTest.java
rename to gossip/src/integrationTest/java/org/apache/tuweni/gossip/GossipIntegrationTest.java
diff --git a/gossip/src/integration-test/java/org/apache/tuweni/gossip/GossipLoadTest.java b/gossip/src/integrationTest/java/org/apache/tuweni/gossip/GossipLoadTest.java
similarity index 100%
rename from gossip/src/integration-test/java/org/apache/tuweni/gossip/GossipLoadTest.java
rename to gossip/src/integrationTest/java/org/apache/tuweni/gossip/GossipLoadTest.java
diff --git a/hobbits-relayer/src/integration-test/kotlin/org/apache/tuweni/relayer/RelayerAppTest.kt b/hobbits-relayer/src/integrationTest/kotlin/org/apache/tuweni/relayer/RelayerAppTest.kt
similarity index 100%
rename from hobbits-relayer/src/integration-test/kotlin/org/apache/tuweni/relayer/RelayerAppTest.kt
rename to hobbits-relayer/src/integrationTest/kotlin/org/apache/tuweni/relayer/RelayerAppTest.kt
diff --git a/hobbits/src/integration-test/kotlin/org/apache/tuweni/hobbits/InteractionTest.kt b/hobbits/src/integrationTest/kotlin/org/apache/tuweni/hobbits/InteractionTest.kt
similarity index 100%
rename from hobbits/src/integration-test/kotlin/org/apache/tuweni/hobbits/InteractionTest.kt
rename to hobbits/src/integrationTest/kotlin/org/apache/tuweni/hobbits/InteractionTest.kt
diff --git a/hobbits/src/integration-test/kotlin/org/apache/tuweni/hobbits/RelayerTest.kt b/hobbits/src/integrationTest/kotlin/org/apache/tuweni/hobbits/RelayerTest.kt
similarity index 100%
rename from hobbits/src/integration-test/kotlin/org/apache/tuweni/hobbits/RelayerTest.kt
rename to hobbits/src/integrationTest/kotlin/org/apache/tuweni/hobbits/RelayerTest.kt
diff --git a/net-coroutines/src/integration-test/kotlin/org/apache/tuweni/net/coroutines/CoroutineSocketChannelTest.kt b/net-coroutines/src/integrationTest/kotlin/org/apache/tuweni/net/coroutines/CoroutineSocketChannelTest.kt
similarity index 100%
rename from net-coroutines/src/integration-test/kotlin/org/apache/tuweni/net/coroutines/CoroutineSocketChannelTest.kt
rename to net-coroutines/src/integrationTest/kotlin/org/apache/tuweni/net/coroutines/CoroutineSocketChannelTest.kt
diff --git a/plumtree/build.gradle b/plumtree/build.gradle
index dd612bb..e465769 100644
--- a/plumtree/build.gradle
+++ b/plumtree/build.gradle
@@ -20,9 +20,10 @@ dependencies {
   compileOnly 'io.vertx:vertx-core'
 
   testCompile project(':junit')
-  testCompile 'io.vertx:vertx-core'
   testCompile 'org.bouncycastle:bcprov-jdk15on'
   testCompile 'org.junit.jupiter:junit-jupiter-api'
   testCompile 'org.junit.jupiter:junit-jupiter-params'
   testRuntime 'org.junit.jupiter:junit-jupiter-engine'
+
+  integrationTestCompile 'io.vertx:vertx-core'
 }
diff --git a/plumtree/src/integration-test/java/org/apache/tuweni/plumtree/vertx/VertxGossipServerTest.java b/plumtree/src/integrationTest/java/org/apache/tuweni/plumtree/vertx/VertxGossipServerTest.java
similarity index 99%
rename from plumtree/src/integration-test/java/org/apache/tuweni/plumtree/vertx/VertxGossipServerTest.java
rename to plumtree/src/integrationTest/java/org/apache/tuweni/plumtree/vertx/VertxGossipServerTest.java
index efb856b..fe29581 100644
--- a/plumtree/src/integration-test/java/org/apache/tuweni/plumtree/vertx/VertxGossipServerTest.java
+++ b/plumtree/src/integrationTest/java/org/apache/tuweni/plumtree/vertx/VertxGossipServerTest.java
@@ -10,7 +10,7 @@
  * 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 java.org.apache.tuweni.plumtree.vertx;
+package org.apache.tuweni.plumtree.vertx;
 
 import static org.junit.jupiter.api.Assertions.assertEquals;
 import static org.junit.jupiter.api.Assertions.assertNull;
diff --git a/rlpx/src/integration-test/java/org/apache/tuweni/rlpx/vertx/VertxAcceptanceTest.java b/rlpx/src/integrationTest/java/org/apache/tuweni/rlpx/vertx/VertxAcceptanceTest.java
similarity index 97%
rename from rlpx/src/integration-test/java/org/apache/tuweni/rlpx/vertx/VertxAcceptanceTest.java
rename to rlpx/src/integrationTest/java/org/apache/tuweni/rlpx/vertx/VertxAcceptanceTest.java
index a14a092..921588f 100644
--- a/rlpx/src/integration-test/java/org/apache/tuweni/rlpx/vertx/VertxAcceptanceTest.java
+++ b/rlpx/src/integrationTest/java/org/apache/tuweni/rlpx/vertx/VertxAcceptanceTest.java
@@ -135,11 +135,11 @@ class VertxAcceptanceTest {
       service.connectTo(secondKp.publicKey(), new InetSocketAddress("localhost", secondService.actualPort()));
 
       Thread.sleep(3000);
-      Assertions.assertEquals(1, repository.asMap().size());
-      Assertions.assertEquals(1, secondRepository.asMap().size());
+      assertEquals(1, repository.asMap().size());
+      assertEquals(1, secondRepository.asMap().size());
 
-      Assertions.assertEquals(1, sp.handler.messages.size());
-      Assertions.assertEquals(1, secondSp.handler.messages.size());
+      assertEquals(1, sp.handler.messages.size());
+      assertEquals(1, secondSp.handler.messages.size());
 
       AsyncCompletion completion = ((DefaultWireConnection) repository.asMap().values().iterator().next()).sendPing();
       completion.join();
diff --git a/rlpx/src/integration-test/java/org/apache/tuweni/rlpx/vertx/VertxRLPxServiceTest.java b/rlpx/src/integrationTest/java/org/apache/tuweni/rlpx/vertx/VertxRLPxServiceTest.java
similarity index 96%
rename from rlpx/src/integration-test/java/org/apache/tuweni/rlpx/vertx/VertxRLPxServiceTest.java
rename to rlpx/src/integrationTest/java/org/apache/tuweni/rlpx/vertx/VertxRLPxServiceTest.java
index fd8bdc5..47f3213 100644
--- a/rlpx/src/integration-test/java/org/apache/tuweni/rlpx/vertx/VertxRLPxServiceTest.java
+++ b/rlpx/src/integrationTest/java/org/apache/tuweni/rlpx/vertx/VertxRLPxServiceTest.java
@@ -35,10 +35,9 @@ class VertxRLPxServiceTest {
 
   @Test
   void invalidPort(@VertxInstance Vertx vertx) {
-    Assertions
-        .assertThrows(
-            IllegalArgumentException.class,
-            () -> new VertxRLPxService(vertx, -1, "localhost", 30, SECP256K1.KeyPair.random(), new ArrayList<>(), "a"));
+    assertThrows(
+        IllegalArgumentException.class,
+        () -> new VertxRLPxService(vertx, -1, "localhost", 30, SECP256K1.KeyPair.random(), new ArrayList<>(), "a"));
   }
 
   @Test
diff --git a/scuttlebutt-discovery/src/integration-test/java/org/apache/tuweni/scuttlebutt/discovery/ScuttlebuttLocalDiscoveryServiceTest.java b/scuttlebutt-discovery/src/integrationTest/java/org/apache/tuweni/scuttlebutt/discovery/ScuttlebuttLocalDiscoveryServiceTest.java
similarity index 100%
rename from scuttlebutt-discovery/src/integration-test/java/org/apache/tuweni/scuttlebutt/discovery/ScuttlebuttLocalDiscoveryServiceTest.java
rename to scuttlebutt-discovery/src/integrationTest/java/org/apache/tuweni/scuttlebutt/discovery/ScuttlebuttLocalDiscoveryServiceTest.java
diff --git a/scuttlebutt-handshake/src/integration-test/java/org/apache/tuweni/scuttlebutt/handshake/vertx/VertxIntegrationTest.java b/scuttlebutt-handshake/src/integrationTest/java/org/apache/tuweni/scuttlebutt/handshake/vertx/VertxIntegrationTest.java
similarity index 100%
rename from scuttlebutt-handshake/src/integration-test/java/org/apache/tuweni/scuttlebutt/handshake/vertx/VertxIntegrationTest.java
rename to scuttlebutt-handshake/src/integrationTest/java/org/apache/tuweni/scuttlebutt/handshake/vertx/VertxIntegrationTest.java
diff --git a/scuttlebutt-rpc/src/integration-test/java/org/apache/tuweni/scuttlebutt/rpc/PatchworkIntegrationTest.java b/scuttlebutt-rpc/src/integrationTest/java/org/apache/tuweni/scuttlebutt/rpc/PatchworkIntegrationTest.java
similarity index 100%
rename from scuttlebutt-rpc/src/integration-test/java/org/apache/tuweni/scuttlebutt/rpc/PatchworkIntegrationTest.java
rename to scuttlebutt-rpc/src/integrationTest/java/org/apache/tuweni/scuttlebutt/rpc/PatchworkIntegrationTest.java
diff --git a/scuttlebutt-rpc/src/integration-test/java/org/apache/tuweni/scuttlebutt/rpc/mux/PatchworkIntegrationTest.java b/scuttlebutt-rpc/src/integrationTest/java/org/apache/tuweni/scuttlebutt/rpc/mux/PatchworkIntegrationTest.java
similarity index 100%
rename from scuttlebutt-rpc/src/integration-test/java/org/apache/tuweni/scuttlebutt/rpc/mux/PatchworkIntegrationTest.java
rename to scuttlebutt-rpc/src/integrationTest/java/org/apache/tuweni/scuttlebutt/rpc/mux/PatchworkIntegrationTest.java


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