You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@jclouds.apache.org by ad...@apache.org on 2014/10/05 19:28:09 UTC

[6/9] Remove nodepool, which hasn't been published in over a year.

http://git-wip-us.apache.org/repos/asf/jclouds-labs/blob/065071ca/nodepool/src/test/java/org/jclouds/nodepool/NodePoolComputeServiceContextTest.java
----------------------------------------------------------------------
diff --git a/nodepool/src/test/java/org/jclouds/nodepool/NodePoolComputeServiceContextTest.java b/nodepool/src/test/java/org/jclouds/nodepool/NodePoolComputeServiceContextTest.java
deleted file mode 100644
index 4a02b3b..0000000
--- a/nodepool/src/test/java/org/jclouds/nodepool/NodePoolComputeServiceContextTest.java
+++ /dev/null
@@ -1,63 +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.jclouds.nodepool;
-
-import static org.jclouds.nodepool.config.NodePoolProperties.POOL_ADMIN_ACCESS;
-import static org.testng.Assert.assertEquals;
-
-import java.io.File;
-import java.util.Properties;
-
-import org.jclouds.ContextBuilder;
-import org.jclouds.compute.ComputeService;
-import org.jclouds.logging.slf4j.config.SLF4JLoggingModule;
-import org.jclouds.nodepool.config.NodePoolProperties;
-import org.testng.annotations.Test;
-
-import com.google.common.base.Supplier;
-import com.google.inject.Key;
-import com.google.inject.TypeLiteral;
-
-@Test(groups = "unit", testName = "NodePoolComputeServiceContextTest")
-public class NodePoolComputeServiceContextTest {
-
-   public void testBinds() {
-      final String basedir = "target/" + this.getClass().getSimpleName();
-      new File(basedir).delete();
-
-      Properties overrides = new Properties();
-      overrides.setProperty(NodePoolProperties.BACKEND_PROVIDER, "stub");
-      overrides.setProperty(NodePoolProperties.BASEDIR, basedir);
-      // note no ssh module since we are stub and not trying ssh, yet
-      overrides.setProperty(NodePoolProperties.BACKEND_MODULES, SLF4JLoggingModule.class.getName());
-      overrides.setProperty(POOL_ADMIN_ACCESS, "adminUsername=pooluser,adminPassword=poolpass");
-
-      ComputeService stub = ContextBuilder.newBuilder("nodepool").credentials("foo", "bar").endpoint("gooend")
-               .apiVersion("1.1").buildVersion("1.1-2").overrides(overrides).buildInjector()
-               .getInstance(Key.get(new TypeLiteral<Supplier<ComputeService>>() {
-               }, Backend.class)).get();
-
-      assertEquals(stub.getContext().unwrap().getProviderMetadata().getEndpoint(), "gooend");
-      assertEquals(stub.getContext().unwrap().getProviderMetadata().getApiMetadata().getVersion(), "1.1");
-      assertEquals(stub.getContext().unwrap().getProviderMetadata().getApiMetadata().getBuildVersion().get(), "1.1-2");
-
-      stub.getContext().close();
-      new File(basedir).delete();
-
-   }
-
-}

http://git-wip-us.apache.org/repos/asf/jclouds-labs/blob/065071ca/nodepool/src/test/java/org/jclouds/nodepool/NodePoolComputeServiceLiveTest.java
----------------------------------------------------------------------
diff --git a/nodepool/src/test/java/org/jclouds/nodepool/NodePoolComputeServiceLiveTest.java b/nodepool/src/test/java/org/jclouds/nodepool/NodePoolComputeServiceLiveTest.java
deleted file mode 100644
index cd32e92..0000000
--- a/nodepool/src/test/java/org/jclouds/nodepool/NodePoolComputeServiceLiveTest.java
+++ /dev/null
@@ -1,251 +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.jclouds.nodepool;
-
-import static org.jclouds.compute.config.ComputeServiceProperties.TIMEOUT_PORT_OPEN;
-import static org.jclouds.compute.config.ComputeServiceProperties.TIMEOUT_SCRIPT_COMPLETE;
-import static org.jclouds.nodepool.config.NodePoolProperties.BASEDIR;
-import static org.jclouds.nodepool.config.NodePoolProperties.MAX_SIZE;
-import static org.jclouds.nodepool.config.NodePoolProperties.MIN_SIZE;
-import static org.jclouds.nodepool.config.NodePoolProperties.POOL_ADMIN_ACCESS;
-import static org.testng.Assert.assertEquals;
-import static org.testng.Assert.assertNotNull;
-import static org.testng.Assert.assertSame;
-import static org.testng.Assert.assertTrue;
-
-import java.util.NoSuchElementException;
-import java.util.Properties;
-
-import org.jclouds.compute.RunNodesException;
-import org.jclouds.compute.domain.NodeMetadata;
-import org.jclouds.compute.internal.BaseComputeServiceLiveTest;
-import org.jclouds.compute.predicates.NodePredicates;
-import org.jclouds.logging.config.LoggingModule;
-import org.jclouds.logging.slf4j.config.SLF4JLoggingModule;
-import org.jclouds.rest.AuthorizationException;
-import org.jclouds.sshj.config.SshjSshClientModule;
-import org.jclouds.utils.Closeables2;
-import org.testng.annotations.AfterClass;
-import org.testng.annotations.Test;
-
-import com.google.common.collect.Iterables;
-import com.google.common.collect.Sets;
-import com.google.inject.Module;
-
-public class NodePoolComputeServiceLiveTest extends BaseComputeServiceLiveTest {
-
-   private final String basedir = "target/" + this.getClass().getSimpleName().toLowerCase();
-
-   public NodePoolComputeServiceLiveTest() {
-      provider = "nodepool";
-   }
-
-   @Override
-   protected Properties setupProperties() {
-      Properties contextProperties = super.setupProperties();
-      contextProperties.setProperty(BASEDIR, basedir);
-      contextProperties.setProperty("nodepool.identity", "pooluser");
-      contextProperties.setProperty(POOL_ADMIN_ACCESS, "adminUsername=pooluser,adminPassword=poolpassword");
-      contextProperties.setProperty(TIMEOUT_SCRIPT_COMPLETE, (1200 * 1000) + "");
-      contextProperties.setProperty(TIMEOUT_PORT_OPEN, (1200 * 1000) + "");
-      contextProperties.setProperty(BASEDIR, basedir);
-      contextProperties.setProperty(POOL_ADMIN_ACCESS, "adminUsername=pooluser,adminPassword=poolpassword");
-      contextProperties.setProperty(MAX_SIZE, 2 + "");
-      contextProperties.setProperty(MIN_SIZE, 1 + "");
-      return contextProperties;
-   }
-
-   @AfterClass(groups = { "integration", "live" })
-   @Override
-   protected void tearDownContext() {
-      Closeables2.closeQuietly(context);
-   }
-
-   @Override
-   protected Module getSshModule() {
-      return new SshjSshClientModule();
-   }
-
-   @Override
-   protected LoggingModule getLoggingModule() {
-      return new SLF4JLoggingModule();
-   }
-
-   @Override
-   @Test(enabled = true, groups = "live")
-   public void testCreateAndRunAService() throws Exception {
-      createAndRunAServiceInGroup(group);
-   }
-
-   @Test(enabled = true, groups = "live", dependsOnMethods = "testCreateAndRunAService")
-   public void testRebuildPoolStateFromStore() {
-      tearDownContext();
-      setupContext();
-      assertSame(client.listNodes().size(), 1);
-      assertEquals(((NodeMetadata) Iterables.get(client.listNodes(), 0)).getGroup(), this.group);
-   }
-
-   @Test(enabled = true, groups = "live", dependsOnMethods = "testRebuildPoolStateFromStore")
-   public void testIncreasePoolAllowed() throws RunNodesException {
-      client.createNodesInGroup(this.group, 1);
-      assertSame(client.listNodes().size(), 2);
-   }
-
-   @Test(enabled = true, groups = "live", dependsOnMethods = "testIncreasePoolAllowed")
-   public void testIncreasePoolNotAllowed() throws RunNodesException {
-      boolean caughtException = false;
-      try {
-         client.createNodesInGroup(this.group, 1);
-      } catch (Exception e) {
-         caughtException = true;
-      }
-      assertTrue(caughtException, "expected an exception to be thrown");
-   }
-
-   @Test(enabled = true, groups = "live", dependsOnMethods = "testIncreasePoolNotAllowed")
-   public void testGetBackendComputeServiceContext() {
-      NodePoolComputeServiceContext ctx = context.utils().injector().getInstance(NodePoolComputeServiceContext.class);
-      assertNotNull(ctx.getBackendContext());
-      assertSame(
-               Sets.filter(ctx.getBackendContext().getComputeService().listNodesDetailsMatching(NodePredicates.all()),
-                        NodePredicates.inGroup(ctx.getPoolGroupName())).size(), 2);
-   }
-
-   @Test(enabled = true, groups = "live", dependsOnMethods = "testGetBackendComputeServiceContext")
-   public void testDestroyPoolNodes() {
-      client.destroyNodesMatching(NodePredicates.inGroup(this.group));
-      // after we destroy all nodes we should still have minsize nodes in the pool
-      NodePoolComputeServiceContext ctx = context.utils().injector().getInstance(NodePoolComputeServiceContext.class);
-      assertSame(ctx.getPoolStats().currentSize(), 1);
-   }
-
-   @Test(enabled = true, groups = "live", dependsOnMethods = "testDestroyPoolNodes")
-   public void testDestroyPool() {
-      // TODO get the ctx without the injector
-      NodePoolComputeServiceContext ctx = context.utils().injector().getInstance(NodePoolComputeServiceContext.class);
-      ctx.destroyPool();
-      assertSame(
-               Sets.filter(ctx.getBackendContext().getComputeService().listNodesDetailsMatching(NodePredicates.all()),
-                        NodePredicates.inGroup(ctx.getPoolGroupName())).size(), 0);
-   }
-
-   @Override
-   @Test(enabled = false)
-   public void testAScriptExecutionAfterBootWithBasicTemplate() throws Exception {
-   }
-
-   @Override
-   @Test(enabled = false)
-   public void testCompareSizes() throws Exception {
-   }
-
-   @Override
-   @Test(enabled = false)
-   public void testConcurrentUseOfComputeServiceToCreateNodes() throws Exception {
-   }
-
-   @Override
-   @Test(enabled = false, expectedExceptions = AuthorizationException.class)
-   public void testCorrectAuthException() throws Exception {
-   }
-
-   @Override
-   @Test(enabled = false, expectedExceptions = NoSuchElementException.class)
-   public void testCorrectExceptionRunningNodesNotFound() throws Exception {
-   }
-
-   @Override
-   @Test(enabled = false, dependsOnMethods = "testCreateTwoNodesWithRunScript")
-   public void testCreateAnotherNodeWithANewContextToEnsureSharedMemIsntRequired() throws Exception {
-   }
-
-   @Override
-   @Test(enabled = false, dependsOnMethods = "testConcurrentUseOfComputeServiceToCreateNodes")
-   public void testCreateTwoNodesWithRunScript() throws Exception {
-   }
-
-   @Override
-   @Test(enabled = false, dependsOnMethods = "testCreateAnotherNodeWithANewContextToEnsureSharedMemIsntRequired")
-   public void testCredentialsCache() throws Exception {
-   }
-
-   @Override
-   @Test(enabled = false, dependsOnMethods = { "testListNodes", "testGetNodesWithDetails" })
-   public void testDestroyNodes() {
-   }
-
-   @Override
-   @Test(enabled = false, dependsOnMethods = "testCreateAnotherNodeWithANewContextToEnsureSharedMemIsntRequired")
-   public void testGet() throws Exception {
-   }
-
-   @Override
-   @Test(enabled = false, groups = { "integration", "live" })
-   public void testGetAssignableLocations() throws Exception {
-   }
-
-   @Override
-   @Test(enabled = false, dependsOnMethods = "testSuspendResume")
-   public void testGetNodesWithDetails() throws Exception {
-   }
-
-   @Override
-   @Test(enabled = false)
-   public void testImageById() {
-   }
-
-   @Override
-   @Test(enabled = false)
-   public void testImagesCache() throws Exception {
-   }
-
-   @Override
-   @Test(enabled = false)
-   public void testListImages() throws Exception {
-   }
-
-   @Override
-   @Test(enabled = false, dependsOnMethods = "testSuspendResume")
-   public void testListNodes() throws Exception {
-   }
-
-   @Override
-   @Test(enabled = false)
-   public void testListSizes() throws Exception {
-   }
-
-   @Override
-   @Test(enabled = false)
-   public void testOptionToNotBlock() throws Exception {
-   }
-
-   @Override
-   @Test(enabled = false, dependsOnMethods = "testGet")
-   public void testReboot() throws Exception {
-   }
-
-   @Override
-   @Test(enabled = false, dependsOnMethods = "testReboot")
-   public void testSuspendResume() throws Exception {
-   }
-
-   @Override
-   @Test(enabled = false, dependsOnMethods = "testImagesCache")
-   public void testTemplateMatch() throws Exception {
-   }
-
-}

http://git-wip-us.apache.org/repos/asf/jclouds-labs/blob/065071ca/nodepool/src/test/java/org/jclouds/nodepool/config/BindBackendComputeServiceTest.java
----------------------------------------------------------------------
diff --git a/nodepool/src/test/java/org/jclouds/nodepool/config/BindBackendComputeServiceTest.java b/nodepool/src/test/java/org/jclouds/nodepool/config/BindBackendComputeServiceTest.java
deleted file mode 100644
index 754bb6a..0000000
--- a/nodepool/src/test/java/org/jclouds/nodepool/config/BindBackendComputeServiceTest.java
+++ /dev/null
@@ -1,82 +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.jclouds.nodepool.config;
-
-import static org.easymock.EasyMock.createNiceMock;
-import static org.jclouds.nodepool.config.NodePoolProperties.POOL_ADMIN_ACCESS;
-import static org.testng.Assert.assertEquals;
-
-import java.io.File;
-import java.util.Properties;
-
-import org.jclouds.ContextBuilder;
-import org.jclouds.compute.ComputeService;
-import org.jclouds.domain.LoginCredentials;
-import org.jclouds.logging.slf4j.config.SLF4JLoggingModule;
-import org.jclouds.nodepool.Backend;
-import org.jclouds.ssh.SshClient;
-import org.testng.annotations.Test;
-
-import com.google.common.base.Supplier;
-import com.google.common.net.HostAndPort;
-import com.google.inject.AbstractModule;
-import com.google.inject.Key;
-import com.google.inject.Scopes;
-import com.google.inject.TypeLiteral;
-
-@Test(groups = "unit", testName = "BindBackendComputeServiceTest")
-public class BindBackendComputeServiceTest {
-
-   public void testBinds() {
-      final String basedir = "target/" + this.getClass().getSimpleName();
-      new File(basedir).delete();
-
-      Properties overrides = new Properties();
-      overrides.setProperty(NodePoolProperties.BACKEND_PROVIDER, "stub");
-      overrides.setProperty(NodePoolProperties.BASEDIR, basedir);
-      // note no ssh module since we are stub and not trying ssh, yet
-      overrides.setProperty(NodePoolProperties.BACKEND_MODULES, SLF4JLoggingModule.class.getName() + ","
-               + StubSshClientModule.class.getName());
-      overrides.setProperty(POOL_ADMIN_ACCESS, "adminUsername=pooluser,adminPassword=poolpass");
-
-      ComputeService stub = ContextBuilder.newBuilder("nodepool").credentials("foo", "bar").endpoint("gooend")
-               .apiVersion("1.1").buildVersion("1.1-2").overrides(overrides).buildInjector()
-               .getInstance(Key.get(new TypeLiteral<Supplier<ComputeService>>() {
-               }, Backend.class)).get();
-
-      assertEquals(stub.getContext().unwrap().getProviderMetadata().getEndpoint(), "gooend");
-      assertEquals(stub.getContext().unwrap().getProviderMetadata().getApiMetadata().getVersion(), "1.1");
-      assertEquals(stub.getContext().unwrap().getProviderMetadata().getApiMetadata().getBuildVersion().get(), "1.1-2");
-
-      stub.getContext().close();
-      new File(basedir).delete();
-
-   }
-
-   public static class StubSshClientModule extends AbstractModule {
-
-      protected void configure() {
-         bind(SshClient.Factory.class).to(Factory.class).in(Scopes.SINGLETON);
-      }
-
-      private static class Factory implements SshClient.Factory {
-         public SshClient create(HostAndPort socket, LoginCredentials credentials) {
-            return createNiceMock(SshClient.class);
-         }
-      }
-   }
-}

http://git-wip-us.apache.org/repos/asf/jclouds-labs/blob/065071ca/nodepool/src/test/java/org/jclouds/nodepool/config/BindInputStreamToFilesystemBlobStoreTest.java
----------------------------------------------------------------------
diff --git a/nodepool/src/test/java/org/jclouds/nodepool/config/BindInputStreamToFilesystemBlobStoreTest.java b/nodepool/src/test/java/org/jclouds/nodepool/config/BindInputStreamToFilesystemBlobStoreTest.java
deleted file mode 100644
index 84ca720..0000000
--- a/nodepool/src/test/java/org/jclouds/nodepool/config/BindInputStreamToFilesystemBlobStoreTest.java
+++ /dev/null
@@ -1,62 +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.jclouds.nodepool.config;
-
-import static org.testng.Assert.assertEquals;
-
-import java.io.File;
-import java.io.InputStream;
-import java.util.Map;
-
-import org.jclouds.logging.slf4j.config.SLF4JLoggingModule;
-import org.testng.annotations.Test;
-
-import com.google.common.base.Supplier;
-import com.google.common.collect.ImmutableSet;
-import com.google.inject.AbstractModule;
-import com.google.inject.Guice;
-import com.google.inject.Key;
-import com.google.inject.TypeLiteral;
-import com.google.inject.name.Names;
-
-@Test(groups = "unit", testName = "BindInputStreamToFilesystemBlobStoreTest")
-public class BindInputStreamToFilesystemBlobStoreTest {
-
-   public void testCreatesDir() {
-      final String basedir = "target/" + this.getClass().getSimpleName();
-      new File(basedir).delete();
-      Map<String, InputStream> file = Guice
-               .createInjector(new AbstractModule() {
-                  @Override
-                  protected void configure() {
-                     bindConstant().annotatedWith(Names.named(NodePoolProperties.BASEDIR)).to(basedir);
-                     bindConstant().annotatedWith(Names.named(NodePoolProperties.METADATA_CONTAINER)).to("barr");
-                     bindConstant().annotatedWith(Names.named(NodePoolProperties.POOL_ADMIN_ACCESS)).to(
-                              "adminUsername=pooluser,adminPassword=poolpass");
-                     bindConstant().annotatedWith(Names.named(NodePoolProperties.BACKEND_MODULES)).to(
-                              SLF4JLoggingModule.class.getName());
-                  }
-               }, new BindInputStreamToFilesystemBlobStore())
-               .getInstance(Key.get(new TypeLiteral<Supplier<Map<String, InputStream>>>() {
-               }, Names.named("METADATA"))).get();
-
-      assert (new File(basedir + "/barr").exists());
-      assertEquals(file.keySet(), ImmutableSet.of());
-      new File(basedir).delete();
-   }
-
-}

http://git-wip-us.apache.org/repos/asf/jclouds-labs/blob/065071ca/nodepool/src/test/resources/logback.xml
----------------------------------------------------------------------
diff --git a/nodepool/src/test/resources/logback.xml b/nodepool/src/test/resources/logback.xml
deleted file mode 100644
index 4f0c2ef..0000000
--- a/nodepool/src/test/resources/logback.xml
+++ /dev/null
@@ -1,71 +0,0 @@
-<?xml version="1.0"?>
-<configuration scan="false">
-  <appender name="FILE" class="ch.qos.logback.core.FileAppender">
-    <file>target/test-data/jclouds.log</file>
-
-    <layout class="ch.qos.logback.classic.PatternLayout">
-      <Pattern>%d %-5p [%c] (%t) %m%n</Pattern>
-    </layout>
-  </appender>
-
-  <appender name="WIREFILE" class="ch.qos.logback.core.FileAppender">
-    <file>target/test-data/jclouds-wire.log</file>
-
-    <layout class="ch.qos.logback.classic.PatternLayout">
-      <Pattern>%d %-5p [%c] (%t) %m%n</Pattern>
-    </layout>
-  </appender>
-
-  <appender name="COMPUTEFILE" class="ch.qos.logback.core.FileAppender">
-    <file>target/test-data/jclouds-compute.log</file>
-
-    <layout class="ch.qos.logback.classic.PatternLayout">
-      <Pattern>%d %-5p [%c] (%t) %m%n</Pattern>
-    </layout>
-  </appender>
-
-  <appender name="SSHFILE" class="ch.qos.logback.core.FileAppender">
-    <file>target/test-data/jclouds-ssh.log</file>
-
-    <layout class="ch.qos.logback.classic.PatternLayout">
-      <Pattern>%d %-5p [%c] (%t) %m%n</Pattern>
-    </layout>
-  </appender>
-
-  <appender name="CONSOLE" class="ch.qos.logback.core.ConsoleAppender">
-    <encoder>
-      <Pattern>%-4r [%thread] %-5level - %msg%n</Pattern>
-    </encoder>
-  </appender>
-
-  <root>
-    <level value="DEBUG" />
-    <appender-ref ref="CONSOLE" />
-  </root>
-
-  <logger name="org.jclouds">
-    <level value="INFO" />
-    <appender-ref ref="FILE" />
-  </logger>
-
-  <logger name="jclouds.wire">
-    <level value="WARN" />
-    <appender-ref ref="WIREFILE" />
-  </logger>
-
-  <logger name="jclouds.headers">
-    <level value="WARN" />
-    <appender-ref ref="WIREFILE" />
-  </logger>
-
-  <logger name="jclouds.compute">
-    <level value="INFO" />
-    <appender-ref ref="COMPUTEFILE" />
-  </logger>
-
-  <logger name="jclouds.ssh">
-    <level value="INFO" />
-    <appender-ref ref="SSHFILE" />
-  </logger>
-
-</configuration>