You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@mina.apache.org by lg...@apache.org on 2019/09/22 16:55:15 UTC

[mina-sshd] branch master updated: Removed unused TreeLockExecutor class

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

lgoldstein pushed a commit to branch master
in repository https://gitbox.apache.org/repos/asf/mina-sshd.git


The following commit(s) were added to refs/heads/master by this push:
     new af38c08  Removed unused TreeLockExecutor class
af38c08 is described below

commit af38c0804adf2c06bc9c0caaed96b24c20405586
Author: Lyor Goldstein <lg...@apache.org>
AuthorDate: Sun Sep 22 20:04:22 2019 +0300

    Removed unused TreeLockExecutor class
---
 .../subsystem/sftp/SftpSubsystemFactory.java       |  2 +-
 .../server/subsystem/sftp/TreeLockExecutor.java    | 75 ----------------------
 2 files changed, 1 insertion(+), 76 deletions(-)

diff --git a/sshd-sftp/src/main/java/org/apache/sshd/server/subsystem/sftp/SftpSubsystemFactory.java b/sshd-sftp/src/main/java/org/apache/sshd/server/subsystem/sftp/SftpSubsystemFactory.java
index 4158abc..9b71f61 100644
--- a/sshd-sftp/src/main/java/org/apache/sshd/server/subsystem/sftp/SftpSubsystemFactory.java
+++ b/sshd-sftp/src/main/java/org/apache/sshd/server/subsystem/sftp/SftpSubsystemFactory.java
@@ -102,7 +102,7 @@ public class SftpSubsystemFactory
     }
 
     /**
-     * @param service The {@link Supplier} of {@link CloseableExecutorService}-s to be used by the
+     * @param provider The {@link Supplier} of {@link CloseableExecutorService}-s to be used by the
      * {@link SftpSubsystem} command when starting execution. If {@code null} then a single-threaded
      * ad-hoc service is used.
      */
diff --git a/sshd-sftp/src/main/java/org/apache/sshd/server/subsystem/sftp/TreeLockExecutor.java b/sshd-sftp/src/main/java/org/apache/sshd/server/subsystem/sftp/TreeLockExecutor.java
deleted file mode 100644
index 4fed80d..0000000
--- a/sshd-sftp/src/main/java/org/apache/sshd/server/subsystem/sftp/TreeLockExecutor.java
+++ /dev/null
@@ -1,75 +0,0 @@
-/*
- * 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.sshd.server.subsystem.sftp;
-
-import java.io.Closeable;
-import java.nio.file.Path;
-import java.util.concurrent.BlockingQueue;
-import java.util.concurrent.ExecutorService;
-import java.util.concurrent.Future;
-import java.util.concurrent.LinkedBlockingQueue;
-import java.util.concurrent.TimeUnit;
-import java.util.function.Function;
-
-public class TreeLockExecutor implements Closeable {
-
-    private static final Runnable CLOSE = () -> { /* do nothing - just a marker */ };
-
-    private final ExecutorService executor;
-    private final BlockingQueue<Runnable> queue = new LinkedBlockingQueue<>();
-    private final Future<?> future;
-    private final Function<String, Path> resolver;
-
-    public TreeLockExecutor(ExecutorService executor, Function<String, Path> resolver) {
-        this.executor = executor;
-        this.resolver = resolver;
-        this.future = executor.submit(this::run);
-    }
-
-    public void submit(Runnable work, String... paths) {
-        queue.add(work);
-    }
-
-    protected void run() {
-        while (true) {
-            try {
-                Runnable work = queue.take();
-                if (work == CLOSE) {
-                    break;
-                }
-                work.run();
-            } catch (Throwable t) {
-                // ignore
-            }
-        }
-    }
-
-    @Override
-    public void close() {
-        queue.clear();
-        queue.add(CLOSE);
-        try {
-            future.get(5, TimeUnit.SECONDS);
-        } catch (Exception e) {
-            // Ignore
-        }
-        future.cancel(true);
-    }
-}