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 2021/08/11 10:07:55 UTC

[GitHub] [james-project] vttranlina opened a new pull request #590: James 3544 webadmin upload repository cleanup

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


   Ref : https://issues.apache.org/jira/browse/JAMES-3544
   
   https://github.com/linagora/james-project/issues/4357
   
   
   


-- 
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: notifications-unsubscribe@james.apache.org

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 #590: James 3544 webadmin upload repository cleanup

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


   https://github.com/apache/james-project/pull/590/commits/b2d9f09463d911e87dbed4cd6ee8ae003ff57bb4 especially is a best practice we should not have had been missing!


-- 
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: notifications-unsubscribe@james.apache.org

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 #590: James 3544 webadmin upload repository cleanup

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


   Write more tests for the `BucketNameGenerator` too maybe?


-- 
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: notifications-unsubscribe@james.apache.org

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] Arsnael commented on pull request #590: James 3544 webadmin upload repository cleanup

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


   Can you push what you tried @vttranlina ?


-- 
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: notifications-unsubscribe@james.apache.org

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] vttranlina commented on pull request #590: James 3544 webadmin upload repository cleanup

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


   > > Has a problem with org.apache.james.jmap.cassandra.upload.CassandraUploadRepository#purge method when delete list bucket.
   > 
   > Can you be more precise?
   
   You can run `org.apache.james.webadmin.data.jmap.JmapUploadRoutesTest#cleanUploadTaskShouldSuccessWhenMixCase`
   It removes only one expired bucket. (My expect: It have to remove two expired buckets)


-- 
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: notifications-unsubscribe@james.apache.org

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] vttranlina commented on pull request #590: James 3544 webadmin upload repository cleanup

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


   > > You can run `org.apache.james.webadmin.data.jmap.JmapUploadRoutesTest#cleanUploadTaskShouldSuccessWhenMixCase`
   > > It removes only one expired bucket. (My expect: It have to remove two expired buckets)
   > 
   > Not sure what is wrong but could possibly be your mocks on the Clock (mocks are evil^^). If you apply @chibenwa suggestion to use `UpdatableTickingClock`, you have a better chance of having your test working IMO. Try this first, if still not working then we will need to dig more :)
   
   I tried `UpdatableTickingClock` on local, It still not works


-- 
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: notifications-unsubscribe@james.apache.org

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] Arsnael commented on a change in pull request #590: James 3544 webadmin upload repository cleanup

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



##########
File path: server/protocols/webadmin/webadmin-jmap/src/main/java/org/apache/james/webadmin/data/jmap/UploadRepositoryCleanupTask.java
##########
@@ -0,0 +1,120 @@
+/****************************************************************
+ * 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.james.webadmin.data.jmap;
+
+import static org.apache.james.webadmin.data.jmap.UploadRepositoryCleanupTask.CleanupScope.EXPIRED;
+
+import java.time.Clock;
+import java.time.Instant;
+import java.util.Arrays;
+import java.util.Optional;
+
+import org.apache.james.jmap.cassandra.upload.CassandraUploadRepository;
+import org.apache.james.task.Task;
+import org.apache.james.task.TaskExecutionDetails;
+import org.apache.james.task.TaskType;
+import org.slf4j.Logger;
+import org.slf4j.LoggerFactory;
+
+import com.google.common.base.Preconditions;
+
+import reactor.core.publisher.Mono;
+import reactor.core.scheduler.Schedulers;
+
+public class UploadRepositoryCleanupTask implements Task {
+    private static final Logger LOGGER = LoggerFactory.getLogger(UploadRepositoryCleanupTask.class);
+    public static final TaskType TASK_TYPE = TaskType.of("UploadRepositoryCleanupTask");
+
+    enum CleanupScope {
+        EXPIRED;
+
+        static class CleanupScopeInvalidException extends IllegalArgumentException {
+        }
+
+        public static Optional<CleanupScope> from(String name) {
+            Preconditions.checkNotNull(name);
+            return Arrays.stream(CleanupScope.values())
+                .filter(value -> name.equalsIgnoreCase(EXPIRED.name()))

Review comment:
       ```suggestion
                   .filter(value -> name.equalsIgnoreCase(value))
   ```
   Or what is the point or streaming values if you check against the same one each time in your stream? Even if there is only one value :)




-- 
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: notifications-unsubscribe@james.apache.org

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 #590: James 3544 webadmin upload repository cleanup

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


   > Has a problem with org.apache.james.jmap.cassandra.upload.CassandraUploadRepository#purge method when delete list bucket. 
   
   Can you be more precise?


-- 
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: notifications-unsubscribe@james.apache.org

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] vttranlina commented on pull request #590: James 3544 webadmin upload repository cleanup

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


   Has a problem with `org.apache.james.jmap.cassandra.upload.CassandraUploadRepository#purge` method when delete list bucket.
   


-- 
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: notifications-unsubscribe@james.apache.org

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 #590: James 3544 webadmin upload repository cleanup

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



##########
File path: server/protocols/webadmin/webadmin-jmap/src/test/java/org/apache/james/webadmin/data/jmap/JmapUploadRoutesTest.java
##########
@@ -0,0 +1,326 @@
+/****************************************************************
+ * 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.james.webadmin.data.jmap;
+
+import static io.restassured.RestAssured.given;
+import static io.restassured.http.ContentType.JSON;
+import static org.assertj.core.api.Assertions.assertThat;
+import static org.assertj.core.api.AssertionsForClassTypes.assertThatThrownBy;
+import static org.eclipse.jetty.http.HttpStatus.BAD_REQUEST_400;
+import static org.hamcrest.Matchers.notNullValue;
+import static org.mockito.Mockito.mock;
+import static org.mockito.Mockito.when;
+
+import java.io.InputStream;
+import java.nio.charset.StandardCharsets;
+import java.time.Clock;
+import java.time.Duration;
+import java.time.ZonedDateTime;
+import java.util.List;
+import java.util.Map;
+
+import org.apache.james.backends.cassandra.CassandraClusterExtension;
+import org.apache.james.backends.cassandra.components.CassandraModule;
+import org.apache.james.blob.api.BlobStore;
+import org.apache.james.blob.api.BucketName;
+import org.apache.james.blob.api.HashBlobId;
+import org.apache.james.blob.memory.MemoryBlobStoreDAO;
+import org.apache.james.core.Username;
+import org.apache.james.jmap.api.model.UploadId;
+import org.apache.james.jmap.api.model.UploadNotFoundException;
+import org.apache.james.jmap.cassandra.upload.BucketNameGenerator;
+import org.apache.james.jmap.cassandra.upload.CassandraUploadRepository;
+import org.apache.james.jmap.cassandra.upload.UploadConfiguration;
+import org.apache.james.jmap.cassandra.upload.UploadDAO;
+import org.apache.james.jmap.cassandra.upload.UploadModule;
+import org.apache.james.json.DTOConverter;
+import org.apache.james.mailbox.model.ContentType;
+import org.apache.james.server.blob.deduplication.DeDuplicationBlobStore;
+import org.apache.james.task.Hostname;
+import org.apache.james.task.MemoryTaskManager;
+import org.apache.james.webadmin.WebAdminServer;
+import org.apache.james.webadmin.WebAdminUtils;
+import org.apache.james.webadmin.routes.TasksRoutes;
+import org.apache.james.webadmin.utils.JsonTransformer;
+import org.eclipse.jetty.http.HttpStatus;
+import org.hamcrest.Matchers;
+import org.junit.jupiter.api.AfterEach;
+import org.junit.jupiter.api.BeforeEach;
+import org.junit.jupiter.api.Test;
+import org.junit.jupiter.api.extension.RegisterExtension;
+import org.testcontainers.shaded.org.apache.commons.io.IOUtils;
+
+import io.restassured.RestAssured;
+import reactor.core.publisher.Flux;
+import reactor.core.publisher.Mono;
+
+public class JmapUploadRoutesTest {
+
+    private static final String BASE_PATH = "/jmap/uploads";
+    private static final ContentType CONTENT_TYPE = ContentType.of("text/html");
+    private static final Username USERNAME = Username.of("Bob");
+    private static final InputStream DATA = IOUtils.toInputStream("DATA 123", StandardCharsets.UTF_8);
+
+    private WebAdminServer webAdminServer;
+    private MemoryTaskManager taskManager;
+    private BlobStore blobStore;
+    private BucketNameGenerator bucketNameGenerator;
+    private CassandraUploadRepository cassandraUploadRepository;
+    private Clock clock;
+
+    @RegisterExtension
+    static CassandraClusterExtension cassandraCluster = new CassandraClusterExtension(CassandraModule.aggregateModules(
+        UploadModule.MODULE));
+
+    @BeforeEach
+    void setUp() throws Exception {
+        taskManager = new MemoryTaskManager(new Hostname("foo"));
+        clock = mock(Clock.class);
+        bucketNameGenerator = new BucketNameGenerator(clock);
+        blobStore = new DeDuplicationBlobStore(new MemoryBlobStoreDAO(),
+            BucketName.of("default"),
+            new HashBlobId.Factory());
+
+        cassandraUploadRepository = new CassandraUploadRepository(new UploadDAO(cassandraCluster.getCassandraCluster().getConf(),
+            new HashBlobId.Factory(),
+            new UploadConfiguration(Duration.ofSeconds(5))),
+            blobStore,
+            bucketNameGenerator);
+
+        JsonTransformer jsonTransformer = new JsonTransformer();
+        TasksRoutes tasksRoutes = new TasksRoutes(taskManager, jsonTransformer, DTOConverter.of(UploadCleanupTaskAdditionalInformationDTO.SERIALIZATION_MODULE));
+        webAdminServer = WebAdminUtils.createWebAdminServer(new JmapUploadRoutes(cassandraUploadRepository, taskManager, jsonTransformer), tasksRoutes).start();
+
+        RestAssured.requestSpecification = WebAdminUtils.buildRequestSpecification(webAdminServer)
+            .setBasePath(BASE_PATH)
+            .build();
+    }
+
+    @AfterEach
+    void stop() {
+        webAdminServer.destroy();
+        taskManager.stop();
+    }
+
+    @Test
+    void deleteUploadShouldReturnErrorWhenScopeInvalid() {
+        Map<String, Object> errors = given()
+            .queryParam("scope", "invalid")
+            .delete()
+        .then()
+            .statusCode(BAD_REQUEST_400)
+            .contentType(JSON)
+            .extract()
+            .body()
+            .jsonPath()
+            .getMap(".");
+
+        assertThat(errors)
+            .containsEntry("statusCode", BAD_REQUEST_400)
+            .containsEntry("type", "InvalidArgument")
+            .containsEntry("message", "Invalid arguments supplied in the user request")
+            .containsEntry("details", "'scope' is missing or invalid");
+    }
+
+    @Test
+    void deleteUploadShouldReturnErrorWhenMissingScope() {
+        Map<String, Object> errors = given()
+            .delete()
+        .then()
+            .statusCode(BAD_REQUEST_400)
+            .contentType(JSON)
+            .extract()
+            .body()
+            .jsonPath()
+            .getMap(".");
+
+        assertThat(errors)
+            .containsEntry("statusCode", BAD_REQUEST_400)
+            .containsEntry("type", "InvalidArgument")
+            .containsEntry("message", "Invalid arguments supplied in the user request")
+            .containsEntry("details", "'scope' is missing or invalid");
+    }
+
+    @Test
+    void deleteUploadShouldReturnTaskId() {
+        given()
+            .queryParam("scope", "expired")
+            .delete()
+        .then()
+            .statusCode(HttpStatus.CREATED_201)
+            .body("taskId", notNullValue());
+    }
+
+    @Test
+    void cleanUploadTaskShouldReturnDetail() {
+        String taskId = given()
+            .queryParam("scope", "expired")
+            .delete()
+            .jsonPath()
+            .get("taskId");
+
+        given()
+            .basePath(TasksRoutes.BASE)
+        .when()
+            .get(taskId + "/await")
+        .then()
+            .body("status", Matchers.is("completed"))
+            .body("taskId", Matchers.is(notNullValue()))
+            .body("type", Matchers.is(UploadRepositoryCleanupTask.TASK_TYPE.asString()))
+            .body("startedDate", Matchers.is(notNullValue()))
+            .body("submitDate", Matchers.is(notNullValue()))
+            .body("completedDate", Matchers.is(notNullValue()))
+            .body("additionalInformation.scope", Matchers.is("expired"));
+    }
+
+    @Test
+    void cleanUploadTaskShouldRemoveExpiredBucket() {
+        ZonedDateTime timeStamp = ZonedDateTime.parse("2020-10-30T14:12:00Z");
+        when(clock.instant()).thenReturn(timeStamp.toInstant());
+        BucketName expiredBucket = bucketNameGenerator.current().asBucketName();
+
+        Mono.from(cassandraUploadRepository.upload(DATA, CONTENT_TYPE, USERNAME)).block();
+
+        when(clock.instant()).thenReturn(timeStamp.plusWeeks(3).toInstant());

Review comment:
       Use `UpdatableTickingClock` so that we do not have a mock in there...




-- 
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: notifications-unsubscribe@james.apache.org

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] vttranlina commented on pull request #590: James 3544 webadmin upload repository cleanup

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


   Rebase master & squash fixup


-- 
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: notifications-unsubscribe@james.apache.org

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 merged pull request #590: James 3544 webadmin upload repository cleanup

Posted by GitBox <gi...@apache.org>.
chibenwa merged pull request #590:
URL: https://github.com/apache/james-project/pull/590


   


-- 
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: notifications-unsubscribe@james.apache.org

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] vttranlina commented on pull request #590: James 3544 webadmin upload repository cleanup

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


   > Write more tests for the `BucketNameGenerator` too maybe?
   
   I'm not sure, I have just check it, it is already, `BucketNameGeneratorTest`, 
   I tried more tests, but IMO it's duplicated with the old test, maybe unnecessary!


-- 
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: notifications-unsubscribe@james.apache.org

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 #590: James 3544 webadmin upload repository cleanup

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


   Can you squash the fixups @vttranlina ?


-- 
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: notifications-unsubscribe@james.apache.org

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] Arsnael commented on pull request #590: James 3544 webadmin upload repository cleanup

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


   > You can run `org.apache.james.webadmin.data.jmap.JmapUploadRoutesTest#cleanUploadTaskShouldSuccessWhenMixCase`
   > It removes only one expired bucket. (My expect: It have to remove two expired buckets)
   
   Not  sure what is wrong but could possibly be your mocks on the Clock (mocks are evil^^). If you apply @chibenwa suggestion to use `UpdatableTickingClock`, you have a better chance of having your test working IMO. Try this first, if still not working then we will need to dig more :)


-- 
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: notifications-unsubscribe@james.apache.org

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 #590: James 3544 webadmin upload repository cleanup

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


   `The file /home/jenkins/jenkins-agent/workspace/james_ApacheJames_PR-590/server/protocols/webadmin/webadmin-jmap/pom.xml is not sorted`
   
   Good luck, I hate that crap!


-- 
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: notifications-unsubscribe@james.apache.org

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 #590: James 3544 webadmin upload repository cleanup

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


   ```
   Unable to create injector, see the following errors:
   
   1) [Guice/MissingImplementation]: No implementation for Session was bound.
   
   Requested by:
   1  : UploadDAO.<init>(UploadDAO.java:134)
   ```
   
   Guice bindings needs to be cleaned up. We don't want this endpoint for memory.


-- 
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: notifications-unsubscribe@james.apache.org

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