You are viewing a plain text version of this content. The canonical link for it is here.
Posted to notifications@james.apache.org by GitBox <gi...@apache.org> on 2020/12/01 08:27:15 UTC

[GitHub] [james-project] mbaechler opened a new pull request #268: Add jenkins file 2

mbaechler opened a new pull request #268:
URL: https://github.com/apache/james-project/pull/268


   


----------------------------------------------------------------
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.

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



---------------------------------------------------------------------
To unsubscribe, e-mail: notifications-unsubscribe@james.apache.org
For additional commands, e-mail: notifications-help@james.apache.org


[GitHub] [james-project] mbaechler closed pull request #268: Add jenkins file 2

Posted by GitBox <gi...@apache.org>.
mbaechler closed pull request #268:
URL: https://github.com/apache/james-project/pull/268


   


----------------------------------------------------------------
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.

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



---------------------------------------------------------------------
To unsubscribe, e-mail: notifications-unsubscribe@james.apache.org
For additional commands, e-mail: notifications-help@james.apache.org


[GitHub] [james-project] jeantil commented on a change in pull request #268: Add jenkins file 2

Posted by GitBox <gi...@apache.org>.
jeantil commented on a change in pull request #268:
URL: https://github.com/apache/james-project/pull/268#discussion_r533307460



##########
File path: mailbox/event/event-rabbitmq/src/main/java/org/apache/james/mailbox/events/KeyRegistrationHandler.java
##########
@@ -118,13 +118,13 @@ private void declareQueue(Sender sender) {
     }
 
     void stop() {
-        receiverSubscriber.filter(Predicate.not(Disposable::isDisposed))
-            .ifPresent(Disposable::dispose);
-        receiver.close();
         sender.delete(QueueSpecification.queue(registrationQueue.asString()))
             .timeout(TOPOLOGY_CHANGES_TIMEOUT)
             .retryWhen(Retry.backoff(retryBackoff.getMaxRetries(), retryBackoff.getFirstBackoff()).jitter(retryBackoff.getJitterFactor()).scheduler(Schedulers.elastic()))
             .block();
+        receiverSubscriber.filter(Predicate.not(Disposable::isDisposed))
+                .ifPresent(Disposable::dispose);
+        receiver.close();

Review comment:
       I was hoping that the build would pass but it just failed 2hours in on mailsShouldBeWellReceivedByBothRecipient{GuiceJamesServer} – org.apache.james.WithCassandraBlobStoreTest
   (https://builds.apache.org/blue/organizations/jenkins/james%2FApacheJames/detail/PR-268/1/tests)
   so yeah I will put a separate PR for the rabbitmq fix




----------------------------------------------------------------
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.

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



---------------------------------------------------------------------
To unsubscribe, e-mail: notifications-unsubscribe@james.apache.org
For additional commands, e-mail: notifications-help@james.apache.org


[GitHub] [james-project] chibenwa commented on a change in pull request #268: Add jenkins file 2

Posted by GitBox <gi...@apache.org>.
chibenwa commented on a change in pull request #268:
URL: https://github.com/apache/james-project/pull/268#discussion_r533153780



##########
File path: mailbox/event/event-rabbitmq/src/main/java/org/apache/james/mailbox/events/KeyRegistrationHandler.java
##########
@@ -118,13 +118,13 @@ private void declareQueue(Sender sender) {
     }
 
     void stop() {
-        receiverSubscriber.filter(Predicate.not(Disposable::isDisposed))
-            .ifPresent(Disposable::dispose);
-        receiver.close();
         sender.delete(QueueSpecification.queue(registrationQueue.asString()))
             .timeout(TOPOLOGY_CHANGES_TIMEOUT)
             .retryWhen(Retry.backoff(retryBackoff.getMaxRetries(), retryBackoff.getFirstBackoff()).jitter(retryBackoff.getJitterFactor()).scheduler(Schedulers.elastic()))
             .block();
+        receiverSubscriber.filter(Predicate.not(Disposable::isDisposed))
+                .ifPresent(Disposable::dispose);
+        receiver.close();

Review comment:
       Nice catch!




----------------------------------------------------------------
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.

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



---------------------------------------------------------------------
To unsubscribe, e-mail: notifications-unsubscribe@james.apache.org
For additional commands, e-mail: notifications-help@james.apache.org


[GitHub] [james-project] mbaechler commented on pull request #268: Add jenkins file 2

Posted by GitBox <gi...@apache.org>.
mbaechler commented on pull request #268:
URL: https://github.com/apache/james-project/pull/268#issuecomment-775791801


   replaced by @jeantil https://github.com/apache/james-project/pull/264


----------------------------------------------------------------
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.

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



---------------------------------------------------------------------
To unsubscribe, e-mail: notifications-unsubscribe@james.apache.org
For additional commands, e-mail: notifications-help@james.apache.org


[GitHub] [james-project] chibenwa commented on a change in pull request #268: Add jenkins file 2

Posted by GitBox <gi...@apache.org>.
chibenwa commented on a change in pull request #268:
URL: https://github.com/apache/james-project/pull/268#discussion_r533312483



##########
File path: mailbox/event/event-rabbitmq/src/main/java/org/apache/james/mailbox/events/KeyRegistrationHandler.java
##########
@@ -118,13 +118,13 @@ private void declareQueue(Sender sender) {
     }
 
     void stop() {
-        receiverSubscriber.filter(Predicate.not(Disposable::isDisposed))
-            .ifPresent(Disposable::dispose);
-        receiver.close();
         sender.delete(QueueSpecification.queue(registrationQueue.asString()))
             .timeout(TOPOLOGY_CHANGES_TIMEOUT)
             .retryWhen(Retry.backoff(retryBackoff.getMaxRetries(), retryBackoff.getFirstBackoff()).jitter(retryBackoff.getJitterFactor()).scheduler(Schedulers.elastic()))
             .block();
+        receiverSubscriber.filter(Predicate.not(Disposable::isDisposed))
+                .ifPresent(Disposable::dispose);
+        receiver.close();

Review comment:
       Just for the record, do you have an idea of which kind of INFRA this builds runs on? 
   
   (cpu, memory, disk, virtualization setup?)




----------------------------------------------------------------
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.

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



---------------------------------------------------------------------
To unsubscribe, e-mail: notifications-unsubscribe@james.apache.org
For additional commands, e-mail: notifications-help@james.apache.org


[GitHub] [james-project] jeantil commented on a change in pull request #268: Add jenkins file 2

Posted by GitBox <gi...@apache.org>.
jeantil commented on a change in pull request #268:
URL: https://github.com/apache/james-project/pull/268#discussion_r534136650



##########
File path: mailbox/event/event-rabbitmq/src/main/java/org/apache/james/mailbox/events/KeyRegistrationHandler.java
##########
@@ -118,13 +118,13 @@ private void declareQueue(Sender sender) {
     }
 
     void stop() {
-        receiverSubscriber.filter(Predicate.not(Disposable::isDisposed))
-            .ifPresent(Disposable::dispose);
-        receiver.close();
         sender.delete(QueueSpecification.queue(registrationQueue.asString()))
             .timeout(TOPOLOGY_CHANGES_TIMEOUT)
             .retryWhen(Retry.backoff(retryBackoff.getMaxRetries(), retryBackoff.getFirstBackoff()).jitter(retryBackoff.getJitterFactor()).scheduler(Schedulers.elastic()))
             .block();
+        receiverSubscriber.filter(Predicate.not(Disposable::isDisposed))
+                .ifPresent(Disposable::dispose);
+        receiver.close();

Review comment:
       > Maybe this dude deserve a separated PR, we can open it in an extra PR to be merged faster don't you think?
   
   done in https://github.com/apache/james-project/pull/269




----------------------------------------------------------------
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.

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



---------------------------------------------------------------------
To unsubscribe, e-mail: notifications-unsubscribe@james.apache.org
For additional commands, e-mail: notifications-help@james.apache.org


[GitHub] [james-project] jeantil commented on a change in pull request #268: Add jenkins file 2

Posted by GitBox <gi...@apache.org>.
jeantil commented on a change in pull request #268:
URL: https://github.com/apache/james-project/pull/268#discussion_r544123834



##########
File path: server/data/data-cassandra/src/test/java/org/apache/james/dlp/eventsourcing/cassandra/CassandraEventSourcingDLPConfigurationStoreTest.java
##########
@@ -20,8 +20,14 @@
 package org.apache.james.dlp.eventsourcing.cassandra;
 
 import org.apache.james.dlp.api.DLPConfigurationStoreContract;
+import org.apache.james.junit.categories.Unstable;
+import org.junit.jupiter.api.Tag;
 import org.junit.jupiter.api.extension.ExtendWith;
-
+/*
+Caused by: org.testcontainers.containers.ContainerFetchException: Can't get Docker image: RemoteDockerImage(imageName=<resolving>, imagePullPolicy=DefaultPullPolicy())
+Caused by: com.github.dockerjava.api.exception.DockerClientException: Could not build image: unable to find image "sha256:0122a9f1514ea667d656281fb4892bf0f7ce894ed45cfd8250b7cfbc9efacd4d"

Review comment:
       At this stage, I don't really care the reason, I'll tag everything that fails unstable to reach a reproductible build which isn't the case for now.
   Note that tests tagged unstable still run in the next stage which I have never been able to reach at this point because new failures keep popping up all over the place all the time ! 
   Once I have separated stable reproductible tests from unstable tests we can all take a bit of time to understand the root cause of each failure by analysing the logs and fixing the root cause. 
   If the root cause is really an issue in the CI plateform, we will be able to open an INFRA  ticket with qualified information so that they can fix it, at which point we will be able to untag all the corresponding tests




----------------------------------------------------------------
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.

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



---------------------------------------------------------------------
To unsubscribe, e-mail: notifications-unsubscribe@james.apache.org
For additional commands, e-mail: notifications-help@james.apache.org


[GitHub] [james-project] jeantil commented on a change in pull request #268: Add jenkins file 2

Posted by GitBox <gi...@apache.org>.
jeantil commented on a change in pull request #268:
URL: https://github.com/apache/james-project/pull/268#discussion_r537299214



##########
File path: server/testing/src/main/java/org/apache/james/junit/categories/Unstable.java
##########
@@ -0,0 +1,5 @@
+package org.apache.james.junit.categories;

Review comment:
       yes, I'm surprised this is not enforced by the build :)  but this is a test I'm having issues configuring some of the modules 
   ```
   	modified:   server/protocols/jmap-draft-integration-testing/cassandra-jmap-draft-integration-testing/pom.xml
   	modified:   server/protocols/jmap-draft-integration-testing/rabbitmq-jmap-draft-integration-testing/pom.xml
   	modified:   server/protocols/jmap-rfc-8621-integration-tests/distributed-jmap-rfc-8621-integration-tests/pom.xml
   	modified:   server/protocols/webadmin-integration-test/distributed-webadmin-integration-test/pom.xml
   ```
   but I wanted to test the parallel stage setup but it's not working out so great :( https://builds.apache.org/blue/organizations/jenkins/james%2FApacheJames/detail/PR-268/3/pipeline




----------------------------------------------------------------
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.

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



---------------------------------------------------------------------
To unsubscribe, e-mail: notifications-unsubscribe@james.apache.org
For additional commands, e-mail: notifications-help@james.apache.org


[GitHub] [james-project] chibenwa commented on a change in pull request #268: Add jenkins file 2

Posted by GitBox <gi...@apache.org>.
chibenwa commented on a change in pull request #268:
URL: https://github.com/apache/james-project/pull/268#discussion_r544115366



##########
File path: server/data/data-cassandra/src/test/java/org/apache/james/dlp/eventsourcing/cassandra/CassandraEventSourcingDLPConfigurationStoreTest.java
##########
@@ -20,8 +20,14 @@
 package org.apache.james.dlp.eventsourcing.cassandra;
 
 import org.apache.james.dlp.api.DLPConfigurationStoreContract;
+import org.apache.james.junit.categories.Unstable;
+import org.junit.jupiter.api.Tag;
 import org.junit.jupiter.api.extension.ExtendWith;
-
+/*
+Caused by: org.testcontainers.containers.ContainerFetchException: Can't get Docker image: RemoteDockerImage(imageName=<resolving>, imagePullPolicy=DefaultPullPolicy())
+Caused by: com.github.dockerjava.api.exception.DockerClientException: Could not build image: unable to find image "sha256:0122a9f1514ea667d656281fb4892bf0f7ce894ed45cfd8250b7cfbc9efacd4d"

Review comment:
       Actually this likely means all testcontainers based tests are not stable on the Apache CI.
   
   Do you confirm?
   
   Maybe we could be finding a way to tern them all off at once, while waiting of a stable solution for running them on Apache INFRA?




----------------------------------------------------------------
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.

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



---------------------------------------------------------------------
To unsubscribe, e-mail: notifications-unsubscribe@james.apache.org
For additional commands, e-mail: notifications-help@james.apache.org


[GitHub] [james-project] jeantil commented on a change in pull request #268: Add jenkins file 2

Posted by GitBox <gi...@apache.org>.
jeantil commented on a change in pull request #268:
URL: https://github.com/apache/james-project/pull/268#discussion_r541941162



##########
File path: metrics/metrics-tests/pom.xml
##########
@@ -35,6 +35,11 @@
             <artifactId>james-server-util</artifactId>
             <scope>test</scope>
         </dependency>
+        <dependency>
+            <groupId>${james.groupId}</groupId>
+            <artifactId>james-server-testing</artifactId>
+            <scope>test</scope>
+        </dependency>

Review comment:
       Because I had an unstable test in metrics in the last run, I didn't realize that it would introduce a cyclic dependency.I have fixed this by moving the `Unstable` tag to testing-base 




----------------------------------------------------------------
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.

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



---------------------------------------------------------------------
To unsubscribe, e-mail: notifications-unsubscribe@james.apache.org
For additional commands, e-mail: notifications-help@james.apache.org


[GitHub] [james-project] jeantil commented on a change in pull request #268: Add jenkins file 2

Posted by GitBox <gi...@apache.org>.
jeantil commented on a change in pull request #268:
URL: https://github.com/apache/james-project/pull/268#discussion_r533154727



##########
File path: mailbox/event/event-rabbitmq/src/main/java/org/apache/james/mailbox/events/KeyRegistrationHandler.java
##########
@@ -118,13 +118,13 @@ private void declareQueue(Sender sender) {
     }
 
     void stop() {
-        receiverSubscriber.filter(Predicate.not(Disposable::isDisposed))
-            .ifPresent(Disposable::dispose);
-        receiver.close();
         sender.delete(QueueSpecification.queue(registrationQueue.asString()))
             .timeout(TOPOLOGY_CHANGES_TIMEOUT)
             .retryWhen(Retry.backoff(retryBackoff.getMaxRetries(), retryBackoff.getFirstBackoff()).jitter(retryBackoff.getJitterFactor()).scheduler(Schedulers.elastic()))
             .block();
+        receiverSubscriber.filter(Predicate.not(Disposable::isDisposed))
+                .ifPresent(Disposable::dispose);
+        receiver.close();

Review comment:
       CI : "It's Over 9000!"




----------------------------------------------------------------
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.

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



---------------------------------------------------------------------
To unsubscribe, e-mail: notifications-unsubscribe@james.apache.org
For additional commands, e-mail: notifications-help@james.apache.org


[GitHub] [james-project] jeantil commented on a change in pull request #268: Add jenkins file 2

Posted by GitBox <gi...@apache.org>.
jeantil commented on a change in pull request #268:
URL: https://github.com/apache/james-project/pull/268#discussion_r544116895



##########
File path: server/data/data-cassandra/src/test/java/org/apache/james/dlp/eventsourcing/cassandra/CassandraEventSourcingDLPConfigurationStoreTest.java
##########
@@ -20,8 +20,14 @@
 package org.apache.james.dlp.eventsourcing.cassandra;
 
 import org.apache.james.dlp.api.DLPConfigurationStoreContract;
+import org.apache.james.junit.categories.Unstable;
+import org.junit.jupiter.api.Tag;
 import org.junit.jupiter.api.extension.ExtendWith;
-
+/*
+Caused by: org.testcontainers.containers.ContainerFetchException: Can't get Docker image: RemoteDockerImage(imageName=<resolving>, imagePullPolicy=DefaultPullPolicy())
+Caused by: com.github.dockerjava.api.exception.DockerClientException: Could not build image: unable to find image "sha256:0122a9f1514ea667d656281fb4892bf0f7ce894ed45cfd8250b7cfbc9efacd4d"

Review comment:
       I don't know, only cassandra related tests have failed , there are many other non cassandra related tests which use test containers which did not fail 
   and I am very surprised by the image name: 
    "sha256:0122a9f1514ea667d656281fb4892bf0f7ce894ed45cfd8250b7cfbc9efacd4d
   
   is this some kind of snapshot cassandra image ? 




----------------------------------------------------------------
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.

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



---------------------------------------------------------------------
To unsubscribe, e-mail: notifications-unsubscribe@james.apache.org
For additional commands, e-mail: notifications-help@james.apache.org


[GitHub] [james-project] jeantil commented on pull request #268: Add jenkins file 2

Posted by GitBox <gi...@apache.org>.
jeantil commented on pull request #268:
URL: https://github.com/apache/james-project/pull/268#issuecomment-752233662


   test this please


----------------------------------------------------------------
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.

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



---------------------------------------------------------------------
To unsubscribe, e-mail: notifications-unsubscribe@james.apache.org
For additional commands, e-mail: notifications-help@james.apache.org


[GitHub] [james-project] chibenwa commented on a change in pull request #268: Add jenkins file 2

Posted by GitBox <gi...@apache.org>.
chibenwa commented on a change in pull request #268:
URL: https://github.com/apache/james-project/pull/268#discussion_r544119058



##########
File path: server/data/data-cassandra/src/test/java/org/apache/james/dlp/eventsourcing/cassandra/CassandraEventSourcingDLPConfigurationStoreTest.java
##########
@@ -20,8 +20,14 @@
 package org.apache.james.dlp.eventsourcing.cassandra;
 
 import org.apache.james.dlp.api.DLPConfigurationStoreContract;
+import org.apache.james.junit.categories.Unstable;
+import org.junit.jupiter.api.Tag;
 import org.junit.jupiter.api.extension.ExtendWith;
-
+/*
+Caused by: org.testcontainers.containers.ContainerFetchException: Can't get Docker image: RemoteDockerImage(imageName=<resolving>, imagePullPolicy=DefaultPullPolicy())
+Caused by: com.github.dockerjava.api.exception.DockerClientException: Could not build image: unable to find image "sha256:0122a9f1514ea667d656281fb4892bf0f7ce894ed45cfd8250b7cfbc9efacd4d"

Review comment:
       We rely on a custom, less resource hungry image than the default one: (DockerCassandra)
   
   ```
           cassandraContainer = new GenericContainer<>(
               new ImageFromDockerfile(imageName,doNotDeleteImageAfterUsage)
                   .withDockerfileFromBuilder(builder ->
                       additionalSteps.applyStep(builder
                           .from("cassandra:3.11.3")
                           .env("ENV CASSANDRA_CONFIG", "/etc/cassandra")
                           .run("echo \"-Xms" + CASSANDRA_MEMORY + "M\" >> " + JVM_OPTIONS)
                           .run("echo \"-Xmx" + CASSANDRA_MEMORY + "M\" >> " + JVM_OPTIONS)
                           .run("sed", "-i", "s/auto_snapshot: true/auto_snapshot: false/g", "/etc/cassandra/cassandra.yaml")
                           .run("echo 'authenticator: PasswordAuthenticator' >> /etc/cassandra/cassandra.yaml")
                           .run("echo 'authorizer: org.apache.cassandra.auth.CassandraAuthorizer' >> /etc/cassandra/cassandra.yaml"))
                           .build()))
               .withTmpFs(ImmutableMap.of("/var/lib/cassandra", "rw,noexec,nosuid,size=200m"))
               .withExposedPorts(CASSANDRA_PORT)
               .withLogConsumer(DockerCassandra::displayDockerLog);
   ```




----------------------------------------------------------------
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.

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



---------------------------------------------------------------------
To unsubscribe, e-mail: notifications-unsubscribe@james.apache.org
For additional commands, e-mail: notifications-help@james.apache.org


[GitHub] [james-project] chibenwa commented on pull request #268: Add jenkins file 2

Posted by GitBox <gi...@apache.org>.
chibenwa commented on pull request #268:
URL: https://github.com/apache/james-project/pull/268#issuecomment-744033224


   My eyes are bleeding but I found a way to make MimeMessageCopyOnWrite mutability madness kinda threadsafe https://github.com/apache/james-project/pull/280
   
   I will need to polish it (tomorrow!) and add the zillions lock calls to make all methods safe, not only just getSubject/setSubject.


----------------------------------------------------------------
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.

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



---------------------------------------------------------------------
To unsubscribe, e-mail: notifications-unsubscribe@james.apache.org
For additional commands, e-mail: notifications-help@james.apache.org


[GitHub] [james-project] jeantil commented on a change in pull request #268: Add jenkins file 2

Posted by GitBox <gi...@apache.org>.
jeantil commented on a change in pull request #268:
URL: https://github.com/apache/james-project/pull/268#discussion_r533323155



##########
File path: mailbox/event/event-rabbitmq/src/main/java/org/apache/james/mailbox/events/KeyRegistrationHandler.java
##########
@@ -118,13 +118,13 @@ private void declareQueue(Sender sender) {
     }
 
     void stop() {
-        receiverSubscriber.filter(Predicate.not(Disposable::isDisposed))
-            .ifPresent(Disposable::dispose);
-        receiver.close();
         sender.delete(QueueSpecification.queue(registrationQueue.asString()))
             .timeout(TOPOLOGY_CHANGES_TIMEOUT)
             .retryWhen(Retry.backoff(retryBackoff.getMaxRetries(), retryBackoff.getFirstBackoff()).jitter(retryBackoff.getJitterFactor()).scheduler(Schedulers.elastic()))
             .block();
+        receiverSubscriber.filter(Predicate.not(Disposable::isDisposed))
+                .ifPresent(Disposable::dispose);
+        receiver.close();

Review comment:
       I don't know about CPU and virtualization setup but the nodes seem to have 48GB of RAM and 4B of disk according to https://cwiki.apache.org/confluence/display/INFRA/Jenkins+node+labels




----------------------------------------------------------------
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.

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



---------------------------------------------------------------------
To unsubscribe, e-mail: notifications-unsubscribe@james.apache.org
For additional commands, e-mail: notifications-help@james.apache.org


[GitHub] [james-project] chibenwa commented on a change in pull request #268: Add jenkins file 2

Posted by GitBox <gi...@apache.org>.
chibenwa commented on a change in pull request #268:
URL: https://github.com/apache/james-project/pull/268#discussion_r537205225



##########
File path: server/container/guice/cassandra-guice/src/test/java/org/apache/james/WithCassandraBlobStoreTest.java
##########
@@ -19,11 +19,19 @@
 
 package org.apache.james;
 
+import org.apache.james.junit.categories.Unstable;
+import org.junit.jupiter.api.Tag;
 import org.junit.jupiter.api.extension.RegisterExtension;
 
 class WithCassandraBlobStoreTest implements MailsShouldBeWellReceived {
     @RegisterExtension
     static JamesServerExtension jamesServerExtension = WithCassandraBlobStoreImmutableTest.baseExtensionBuilder()
         .lifeCycle(JamesServerExtension.Lifecycle.PER_TEST)
         .build();
+
+    @Override
+    @Tag(Unstable.TAG)

Review comment:
       Nice, a simple code inspection would allow to find them all.

##########
File path: server/testing/src/main/java/org/apache/james/junit/categories/Unstable.java
##########
@@ -0,0 +1,5 @@
+package org.apache.james.junit.categories;

Review comment:
       We are missing the compulsary Apache v2 license :-/




----------------------------------------------------------------
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.

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



---------------------------------------------------------------------
To unsubscribe, e-mail: notifications-unsubscribe@james.apache.org
For additional commands, e-mail: notifications-help@james.apache.org


[GitHub] [james-project] chibenwa commented on a change in pull request #268: Add jenkins file 2

Posted by GitBox <gi...@apache.org>.
chibenwa commented on a change in pull request #268:
URL: https://github.com/apache/james-project/pull/268#discussion_r544119058



##########
File path: server/data/data-cassandra/src/test/java/org/apache/james/dlp/eventsourcing/cassandra/CassandraEventSourcingDLPConfigurationStoreTest.java
##########
@@ -20,8 +20,14 @@
 package org.apache.james.dlp.eventsourcing.cassandra;
 
 import org.apache.james.dlp.api.DLPConfigurationStoreContract;
+import org.apache.james.junit.categories.Unstable;
+import org.junit.jupiter.api.Tag;
 import org.junit.jupiter.api.extension.ExtendWith;
-
+/*
+Caused by: org.testcontainers.containers.ContainerFetchException: Can't get Docker image: RemoteDockerImage(imageName=<resolving>, imagePullPolicy=DefaultPullPolicy())
+Caused by: com.github.dockerjava.api.exception.DockerClientException: Could not build image: unable to find image "sha256:0122a9f1514ea667d656281fb4892bf0f7ce894ed45cfd8250b7cfbc9efacd4d"

Review comment:
       We rely on a custom, less resource hungry image than the default one: (DockerCassandra.java)
   
   ```
           cassandraContainer = new GenericContainer<>(
               new ImageFromDockerfile(imageName,doNotDeleteImageAfterUsage)
                   .withDockerfileFromBuilder(builder ->
                       additionalSteps.applyStep(builder
                           .from("cassandra:3.11.3")
                           .env("ENV CASSANDRA_CONFIG", "/etc/cassandra")
                           .run("echo \"-Xms" + CASSANDRA_MEMORY + "M\" >> " + JVM_OPTIONS)
                           .run("echo \"-Xmx" + CASSANDRA_MEMORY + "M\" >> " + JVM_OPTIONS)
                           .run("sed", "-i", "s/auto_snapshot: true/auto_snapshot: false/g", "/etc/cassandra/cassandra.yaml")
                           .run("echo 'authenticator: PasswordAuthenticator' >> /etc/cassandra/cassandra.yaml")
                           .run("echo 'authorizer: org.apache.cassandra.auth.CassandraAuthorizer' >> /etc/cassandra/cassandra.yaml"))
                           .build()))
               .withTmpFs(ImmutableMap.of("/var/lib/cassandra", "rw,noexec,nosuid,size=200m"))
               .withExposedPorts(CASSANDRA_PORT)
               .withLogConsumer(DockerCassandra::displayDockerLog);
   ```




----------------------------------------------------------------
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.

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



---------------------------------------------------------------------
To unsubscribe, e-mail: notifications-unsubscribe@james.apache.org
For additional commands, e-mail: notifications-help@james.apache.org


[GitHub] [james-project] chibenwa commented on a change in pull request #268: Add jenkins file 2

Posted by GitBox <gi...@apache.org>.
chibenwa commented on a change in pull request #268:
URL: https://github.com/apache/james-project/pull/268#discussion_r541940727



##########
File path: metrics/metrics-tests/pom.xml
##########
@@ -35,6 +35,11 @@
             <artifactId>james-server-util</artifactId>
             <scope>test</scope>
         </dependency>
+        <dependency>
+            <groupId>${james.groupId}</groupId>
+            <artifactId>james-server-testing</artifactId>
+            <scope>test</scope>
+        </dependency>

Review comment:
       This addition causes 
   
   ```
   Caused by: org.codehaus.plexus.util.dag.CycleDetectedException: Edge between 'Vertex{label='org.apache.james:james-server-testing:3.6.0-SNAPSHOT'}' and 'Vertex{label='org.apache.james:apache-mailet-api:3.6.0-SNAPSHOT'}' introduces to cycle in the graph org.apache.james:apache-mailet-api:3.6.0-SNAPSHOT --> org.apache.james:apache-james-mailbox-api:3.6.0-SNAPSHOT --> org.apache.james:metrics-tests:3.6.0-SNAPSHOT --> org.apache.james:james-server-testing:3.6.0-SNAPSHOT --> org.apache.james:apache-mailet-api:3.6.0-SNAPSHOT
   ```
   
   Why did you added this for?




----------------------------------------------------------------
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.

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



---------------------------------------------------------------------
To unsubscribe, e-mail: notifications-unsubscribe@james.apache.org
For additional commands, e-mail: notifications-help@james.apache.org


[GitHub] [james-project] jeantil commented on a change in pull request #268: Add jenkins file 2

Posted by GitBox <gi...@apache.org>.
jeantil commented on a change in pull request #268:
URL: https://github.com/apache/james-project/pull/268#discussion_r533323155



##########
File path: mailbox/event/event-rabbitmq/src/main/java/org/apache/james/mailbox/events/KeyRegistrationHandler.java
##########
@@ -118,13 +118,13 @@ private void declareQueue(Sender sender) {
     }
 
     void stop() {
-        receiverSubscriber.filter(Predicate.not(Disposable::isDisposed))
-            .ifPresent(Disposable::dispose);
-        receiver.close();
         sender.delete(QueueSpecification.queue(registrationQueue.asString()))
             .timeout(TOPOLOGY_CHANGES_TIMEOUT)
             .retryWhen(Retry.backoff(retryBackoff.getMaxRetries(), retryBackoff.getFirstBackoff()).jitter(retryBackoff.getJitterFactor()).scheduler(Schedulers.elastic()))
             .block();
+        receiverSubscriber.filter(Predicate.not(Disposable::isDisposed))
+                .ifPresent(Disposable::dispose);
+        receiver.close();

Review comment:
       I don't know about CPU and virtualization setup but the nodes seem to have 48GB of RAM and 4TB of disk according to https://cwiki.apache.org/confluence/display/INFRA/Jenkins+node+labels




----------------------------------------------------------------
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.

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



---------------------------------------------------------------------
To unsubscribe, e-mail: notifications-unsubscribe@james.apache.org
For additional commands, e-mail: notifications-help@james.apache.org


[GitHub] [james-project] chibenwa commented on a change in pull request #268: Add jenkins file 2

Posted by GitBox <gi...@apache.org>.
chibenwa commented on a change in pull request #268:
URL: https://github.com/apache/james-project/pull/268#discussion_r533156638



##########
File path: mailbox/event/event-rabbitmq/src/main/java/org/apache/james/mailbox/events/KeyRegistrationHandler.java
##########
@@ -118,13 +118,13 @@ private void declareQueue(Sender sender) {
     }
 
     void stop() {
-        receiverSubscriber.filter(Predicate.not(Disposable::isDisposed))
-            .ifPresent(Disposable::dispose);
-        receiver.close();
         sender.delete(QueueSpecification.queue(registrationQueue.asString()))
             .timeout(TOPOLOGY_CHANGES_TIMEOUT)
             .retryWhen(Retry.backoff(retryBackoff.getMaxRetries(), retryBackoff.getFirstBackoff()).jitter(retryBackoff.getJitterFactor()).scheduler(Schedulers.elastic()))
             .block();
+        receiverSubscriber.filter(Predicate.not(Disposable::isDisposed))
+                .ifPresent(Disposable::dispose);
+        receiver.close();

Review comment:
       Maybe this dude deserve a separated PR, we can open it in an extra PR to be merged faster don't you think?




----------------------------------------------------------------
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.

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



---------------------------------------------------------------------
To unsubscribe, e-mail: notifications-unsubscribe@james.apache.org
For additional commands, e-mail: notifications-help@james.apache.org


[GitHub] [james-project] jeantil commented on a change in pull request #268: Add jenkins file 2

Posted by GitBox <gi...@apache.org>.
jeantil commented on a change in pull request #268:
URL: https://github.com/apache/james-project/pull/268#discussion_r544116895



##########
File path: server/data/data-cassandra/src/test/java/org/apache/james/dlp/eventsourcing/cassandra/CassandraEventSourcingDLPConfigurationStoreTest.java
##########
@@ -20,8 +20,14 @@
 package org.apache.james.dlp.eventsourcing.cassandra;
 
 import org.apache.james.dlp.api.DLPConfigurationStoreContract;
+import org.apache.james.junit.categories.Unstable;
+import org.junit.jupiter.api.Tag;
 import org.junit.jupiter.api.extension.ExtendWith;
-
+/*
+Caused by: org.testcontainers.containers.ContainerFetchException: Can't get Docker image: RemoteDockerImage(imageName=<resolving>, imagePullPolicy=DefaultPullPolicy())
+Caused by: com.github.dockerjava.api.exception.DockerClientException: Could not build image: unable to find image "sha256:0122a9f1514ea667d656281fb4892bf0f7ce894ed45cfd8250b7cfbc9efacd4d"

Review comment:
       I don't know, only cassandra related tests have failed this time round and I am very surprised by the image name: 
    "sha256:0122a9f1514ea667d656281fb4892bf0f7ce894ed45cfd8250b7cfbc9efacd4d
   
   is this some kind of snapshot cassandra image ? 




----------------------------------------------------------------
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.

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



---------------------------------------------------------------------
To unsubscribe, e-mail: notifications-unsubscribe@james.apache.org
For additional commands, e-mail: notifications-help@james.apache.org


[GitHub] [james-project] jeantil commented on pull request #268: Add jenkins file 2

Posted by GitBox <gi...@apache.org>.
jeantil commented on pull request #268:
URL: https://github.com/apache/james-project/pull/268#issuecomment-752898520


   test this please 
   
   (wondering if the trigger only works on PRs opened by members of the project as I saw ans update to PR 285 appear in https://builds.apache.org/job/james/job/ApacheJames/indexing/events but I don't see my comment on PR264 not sure if it is the comment or the commit that triggers the event)


----------------------------------------------------------------
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.

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



---------------------------------------------------------------------
To unsubscribe, e-mail: notifications-unsubscribe@james.apache.org
For additional commands, e-mail: notifications-help@james.apache.org