You are viewing a plain text version of this content. The canonical link for it is here.
Posted to dev@avalon.apache.org by le...@apache.org on 2001/04/06 17:41:33 UTC

cvs commit: jakarta-avalon-phoenix/proposal/4.0/src/java/org/apache/phoenix/facilities ApplicationManager.java ClassManager.java ConfigurationManager.java Facility.java LogManager.java Manager.java SecurityManager.java ThreadManager.java

leosimons    01/04/06 08:41:33

  Added:       proposal/4.0/src/java/org/apache/phoenix Restart.java
                        Shutdown.java Start.java
               proposal/4.0/src/java/org/apache/phoenix/applications
                        Application.java ApplicationException.java
                        ServerApplication.java
                        ServerApplicationFactory.java
               proposal/4.0/src/java/org/apache/phoenix/core Block.java
                        BlockContext.java Embeddor.java Kernel.java
                        ServerKernel.java
               proposal/4.0/src/java/org/apache/phoenix/engine
                        PhoenixEmbeddor.java PhoenixKernel.java
               proposal/4.0/src/java/org/apache/phoenix/engine/applications
                        DefaultServerApplication.java
                        DefaultServerApplicationFactory.java
               proposal/4.0/src/java/org/apache/phoenix/engine/deployer
                        DefaultDeployer.java
               proposal/4.0/src/java/org/apache/phoenix/engine/facilities
                        ApplicationManagerImpl.java ClassManagerImpl.java
                        ConfigurationManagerImpl.java LogManagerImpl.java
                        ManagerImpl.java SecurityManagerImpl.java
                        ThreadManagerImpl.java
               proposal/4.0/src/java/org/apache/phoenix/facilities
                        ApplicationManager.java ClassManager.java
                        ConfigurationManager.java Facility.java
                        LogManager.java Manager.java SecurityManager.java
                        ThreadManager.java
  Log:
  Updating the proposal. I've made extensive changes.
  Many of the files are now empty interfaces or empty
  implementations, but at least the thing will now compile
  (when the current avalon4 proposal is used together
  with apache.log and javax.management as required
  libs).
  
  Revision  Changes    Path
  1.3       +0 -0      jakarta-avalon-phoenix/proposal/4.0/src/java/org/apache/phoenix/Restart.java
  
  
  
  
  1.3       +1 -1      jakarta-avalon-phoenix/proposal/4.0/src/java/org/apache/phoenix/Shutdown.java
  
  
  
  
  1.3       +28 -10    jakarta-avalon-phoenix/proposal/4.0/src/java/org/apache/phoenix/Start.java
  
  
  
  
  1.3       +0 -0      jakarta-avalon-phoenix/proposal/4.0/src/java/org/apache/phoenix/applications/Application.java
  
  
  
  
  1.3       +0 -0      jakarta-avalon-phoenix/proposal/4.0/src/java/org/apache/phoenix/applications/ApplicationException.java
  
  
  
  
  1.3       +1 -0      jakarta-avalon-phoenix/proposal/4.0/src/java/org/apache/phoenix/applications/ServerApplication.java
  
  
  
  
  1.1                  jakarta-avalon-phoenix/proposal/4.0/src/java/org/apache/phoenix/applications/ServerApplicationFactory.java
  
  Index: ServerApplicationFactory.java
  ===================================================================
  /*
   * Copyright (C) The Apache Software Foundation. All rights reserved.
   *
   * This software is published under the terms of the Apache Software License
   * version 1.1, a copy of which has been included with this distribution in
   * the LICENSE file.
   */
  package org.apache.phoenix.applications;
  
  import org.apache.framework.context.Contextualizable;
  import org.apache.framework.configuration.Configurable;
  
  /**
   *
   * @author <a href="mailto:mail@leosimons.com">Leo Simons</a>
   */
  public interface ServerApplicationFactory
  {
      public ServerApplication getApplication();
  }
  
  
  1.3       +0 -0      jakarta-avalon-phoenix/proposal/4.0/src/java/org/apache/phoenix/core/Block.java
  
  
  
  
  1.3       +0 -0      jakarta-avalon-phoenix/proposal/4.0/src/java/org/apache/phoenix/core/BlockContext.java
  
  
  
  
  1.3       +0 -0      jakarta-avalon-phoenix/proposal/4.0/src/java/org/apache/phoenix/core/Embeddor.java
  
  
  
  
  1.3       +0 -0      jakarta-avalon-phoenix/proposal/4.0/src/java/org/apache/phoenix/core/Kernel.java
  
  
  
  
  1.3       +2 -1      jakarta-avalon-phoenix/proposal/4.0/src/java/org/apache/phoenix/core/ServerKernel.java
  
  
  
  
  1.3       +115 -47   jakarta-avalon-phoenix/proposal/4.0/src/java/org/apache/phoenix/engine/PhoenixEmbeddor.java
  
  
  
  
  1.3       +66 -48    jakarta-avalon-phoenix/proposal/4.0/src/java/org/apache/phoenix/engine/PhoenixKernel.java
  
  
  
  
  1.3       +38 -347   jakarta-avalon-phoenix/proposal/4.0/src/java/org/apache/phoenix/engine/applications/DefaultServerApplication.java
  
  
  
  
  1.1                  jakarta-avalon-phoenix/proposal/4.0/src/java/org/apache/phoenix/engine/applications/DefaultServerApplicationFactory.java
  
  Index: DefaultServerApplicationFactory.java
  ===================================================================
  /*
   * Copyright (C) The Apache Software Foundation. All rights reserved.
   *
   * This software is published under the terms of the Apache Software License
   * version 1.1, a copy of which has been included with this distribution in
   * the LICENSE file.
   */
  package org.apache.phoenix.engine.applications;
  
  import org.apache.phoenix.applications.ServerApplication;
  import org.apache.phoenix.applications.ServerApplicationFactory;
  
  /**
   *
   * @author <a href="mailto:mail@leosimons.com">Leo Simons</a>
   */
  public class DefaultServerApplicationFactory implements ServerApplicationFactory
  {
      public ServerApplication getApplication()
      {
          return null;
      }
  }
  
  
  1.1                  jakarta-avalon-phoenix/proposal/4.0/src/java/org/apache/phoenix/engine/deployer/DefaultDeployer.java
  
  Index: DefaultDeployer.java
  ===================================================================
  /*
   * Copyright (C) The Apache Software Foundation. All rights reserved.
   *
   * This software is published under the terms of the Apache Software License
   * version 1.1, a copy of which has been included with this distribution in
   * the LICENSE file.
   */
  package org.apache.phoenix.engine.deployer;
  
  import java.io.File;
  
  import org.apache.avalon.camelot.Deployer;
  import org.apache.avalon.camelot.AbstractDeployer;
  import org.apache.avalon.camelot.DeploymentException;
  
  /**
   *
   * @author <a href="mailto:mail@leosimons.com">Leo Simons</a>
   */
  public class DefaultDeployer extends AbstractDeployer implements Deployer
  {
          public void deployFromFile( String location, File file ) throws DeploymentException
          {
          }
  }
  
  
  1.1                  jakarta-avalon-phoenix/proposal/4.0/src/java/org/apache/phoenix/engine/facilities/ApplicationManagerImpl.java
  
  Index: ApplicationManagerImpl.java
  ===================================================================
  /*
   * Copyright (C) The Apache Software Foundation. All rights reserved.
   *
   * This software is published under the terms of the Apache Software License
   * version 1.1, a copy of which has been included with this distribution in
   * the LICENSE file.
   */
  package org.apache.phoenix.engine.facilities;
  
  import org.apache.phoenix.facilities.ApplicationManager;
  
  /**
   *
   * @author <a href="mailto:mail@leosimons.com">Leo Simons</a>
   */
  public class ApplicationManagerImpl implements ApplicationManager
  {
  }
  
  
  1.1                  jakarta-avalon-phoenix/proposal/4.0/src/java/org/apache/phoenix/engine/facilities/ClassManagerImpl.java
  
  Index: ClassManagerImpl.java
  ===================================================================
  /*
   * Copyright (C) The Apache Software Foundation. All rights reserved.
   *
   * This software is published under the terms of the Apache Software License
   * version 1.1, a copy of which has been included with this distribution in
   * the LICENSE file.
   */
  package org.apache.phoenix.engine.facilities;
  import org.apache.phoenix.facilities.ClassManager;
  
  /**
   *
   * @author <a href="mailto:mail@leosimons.com">Leo Simons</a>
   */
  public class ClassManagerImpl implements ClassManager
  {
  }
  
  
  1.1                  jakarta-avalon-phoenix/proposal/4.0/src/java/org/apache/phoenix/engine/facilities/ConfigurationManagerImpl.java
  
  Index: ConfigurationManagerImpl.java
  ===================================================================
  /*
   * Copyright (C) The Apache Software Foundation. All rights reserved.
   *
   * This software is published under the terms of the Apache Software License
   * version 1.1, a copy of which has been included with this distribution in
   * the LICENSE file.
   */
  package org.apache.phoenix.engine.facilities;
  
  import org.apache.phoenix.facilities.ConfigurationManager;
  
  /**
   *
   * @author <a href="mailto:mail@leosimons.com">Leo Simons</a>
   */
  public class ConfigurationManagerImpl implements ConfigurationManager
  {
  }
  
  
  1.1                  jakarta-avalon-phoenix/proposal/4.0/src/java/org/apache/phoenix/engine/facilities/LogManagerImpl.java
  
  Index: LogManagerImpl.java
  ===================================================================
  /*
   * Copyright (C) The Apache Software Foundation. All rights reserved.
   *
   * This software is published under the terms of the Apache Software License
   * version 1.1, a copy of which has been included with this distribution in
   * the LICENSE file.
   */
  package org.apache.phoenix.engine.facilities;
  
  import org.apache.phoenix.facilities.LogManager;
  
  /**
   *
   * @author <a href="mailto:mail@leosimons.com">Leo Simons</a>
   */
  public class LogManagerImpl implements LogManager
  {
  }
  
  
  1.1                  jakarta-avalon-phoenix/proposal/4.0/src/java/org/apache/phoenix/engine/facilities/ManagerImpl.java
  
  Index: ManagerImpl.java
  ===================================================================
  /*
   * Copyright (C) The Apache Software Foundation. All rights reserved.
   *
   * This software is published under the terms of the Apache Software License
   * version 1.1, a copy of which has been included with this distribution in
   * the LICENSE file.
   */
  package org.apache.phoenix.engine.facilities;
  
  import javax.management.MBeanServer;
  
  import org.apache.framework.context.Context;
  import org.apache.framework.configuration.Configuration;
  
  import org.apache.phoenix.facilities.Manager;
  
  import org.apache.log.Logger;
  
  /**
   *
   * @author <a href="mailto:mail@leosimons.com">Leo Simons</a>
   */
  public class ManagerImpl implements Manager
  {
      public ManagerImpl()
      {
      }
      public ManagerImpl( MBeanServer mBeanServer )
      {
      }
  
      /////////////////////////
      /// LIFECYCLE METHODS ///
      /////////////////////////
      public void setLogger( Logger logger )
      {
      }
      public void contextualize( Context context )
      {
      }
      public void configure( Configuration configuration )
      {
      }
      public void init()
      {
      }
      public void start()
      {
      }
      public void run()
      {
      }
      public void suspend()
      {
      }
      public void resume()
      {
      }
      public void stop()
      {
      }
      public void dispose()
      {
      }
  }
  
  
  1.1                  jakarta-avalon-phoenix/proposal/4.0/src/java/org/apache/phoenix/engine/facilities/SecurityManagerImpl.java
  
  Index: SecurityManagerImpl.java
  ===================================================================
  /*
   * Copyright (C) The Apache Software Foundation. All rights reserved.
   *
   * This software is published under the terms of the Apache Software License
   * version 1.1, a copy of which has been included with this distribution in
   * the LICENSE file.
   */
  package org.apache.phoenix.engine.facilities;
  
  import org.apache.phoenix.facilities.SecurityManager;
  
  /**
   *
   * @author <a href="mailto:mail@leosimons.com">Leo Simons</a>
   */
  public class SecurityManagerImpl implements SecurityManager
  {
  }
  
  
  1.1                  jakarta-avalon-phoenix/proposal/4.0/src/java/org/apache/phoenix/engine/facilities/ThreadManagerImpl.java
  
  Index: ThreadManagerImpl.java
  ===================================================================
  /*
   * Copyright (C) The Apache Software Foundation. All rights reserved.
   *
   * This software is published under the terms of the Apache Software License
   * version 1.1, a copy of which has been included with this distribution in
   * the LICENSE file.
   */
  package org.apache.phoenix.engine.facilities;
  
  import org.apache.phoenix.facilities.ThreadManager;
  
  /**
   *
   * @author <a href="mailto:mail@leosimons.com">Leo Simons</a>
   */
  public class ThreadManagerImpl implements ThreadManager
  {
  }
  
  
  1.1                  jakarta-avalon-phoenix/proposal/4.0/src/java/org/apache/phoenix/facilities/ApplicationManager.java
  
  Index: ApplicationManager.java
  ===================================================================
  /*
   * Copyright (C) The Apache Software Foundation. All rights reserved.
   *
   * This software is published under the terms of the Apache Software License
   * version 1.1, a copy of which has been included with this distribution in
   * the LICENSE file.
   */
  package org.apache.phoenix.facilities;
  
  /**
   *
   * @author <a href="mailto:mail@leosimons.com">Leo Simons</a>
   */
  public interface ApplicationManager extends Facility
  {
  }
  
  
  1.1                  jakarta-avalon-phoenix/proposal/4.0/src/java/org/apache/phoenix/facilities/ClassManager.java
  
  Index: ClassManager.java
  ===================================================================
  /*
   * Copyright (C) The Apache Software Foundation. All rights reserved.
   *
   * This software is published under the terms of the Apache Software License
   * version 1.1, a copy of which has been included with this distribution in
   * the LICENSE file.
   */
  package org.apache.phoenix.facilities;
  
  /**
   *
   * @author <a href="mailto:mail@leosimons.com">Leo Simons</a>
   */
  public interface ClassManager extends Facility
  {
  }
  
  
  1.1                  jakarta-avalon-phoenix/proposal/4.0/src/java/org/apache/phoenix/facilities/ConfigurationManager.java
  
  Index: ConfigurationManager.java
  ===================================================================
  /*
   * Copyright (C) The Apache Software Foundation. All rights reserved.
   *
   * This software is published under the terms of the Apache Software License
   * version 1.1, a copy of which has been included with this distribution in
   * the LICENSE file.
   */
  package org.apache.phoenix.facilities;
  
  /**
   *
   * @author <a href="mailto:mail@leosimons.com">Leo Simons</a>
   */
  public interface ConfigurationManager extends Facility
  {
  }
  
  
  1.3       +6 -6      jakarta-avalon-phoenix/proposal/4.0/src/java/org/apache/phoenix/facilities/Facility.java
  
  
  
  
  1.1                  jakarta-avalon-phoenix/proposal/4.0/src/java/org/apache/phoenix/facilities/LogManager.java
  
  Index: LogManager.java
  ===================================================================
  /*
   * Copyright (C) The Apache Software Foundation. All rights reserved.
   *
   * This software is published under the terms of the Apache Software License
   * version 1.1, a copy of which has been included with this distribution in
   * the LICENSE file.
   */
  package org.apache.phoenix.facilities;
  
  /**
   *
   * @author <a href="mailto:mail@leosimons.com">Leo Simons</a>
   */
  public interface LogManager extends Facility
  {
  }
  
  
  1.1                  jakarta-avalon-phoenix/proposal/4.0/src/java/org/apache/phoenix/facilities/Manager.java
  
  Index: Manager.java
  ===================================================================
  /*
   * Copyright (C) The Apache Software Foundation. All rights reserved.
   *
   * This software is published under the terms of the Apache Software License
   * version 1.1, a copy of which has been included with this distribution in
   * the LICENSE file.
   */
  package org.apache.phoenix.facilities;
  
  import javax.management.MBeanServer;
  
  import org.apache.framework.lifecycle.Suspendable;
  import org.apache.framework.lifecycle.Resumable;
  import org.apache.framework.lifecycle.Stoppable;
  import org.apache.framework.lifecycle.Disposable;
  
  
  /**
   *
   *
   * <h3>Contract</h3>
   * <p>Besides the interface, the Manager implementation should provide at least
   * an empty public constructor and a public constructor that accepts a
   * <code>javax.management.MBeanServer</code> as its argument.</p>
   *
   *
   * @author <a href="mail@leosimons.com">Leo Simons</a>
   */
  public interface Manager extends Facility, Runnable, Suspendable, Resumable, Stoppable, Disposable
      // and thus Component
  {
  }
  
  
  1.1                  jakarta-avalon-phoenix/proposal/4.0/src/java/org/apache/phoenix/facilities/SecurityManager.java
  
  Index: SecurityManager.java
  ===================================================================
  /*
   * Copyright (C) The Apache Software Foundation. All rights reserved.
   *
   * This software is published under the terms of the Apache Software License
   * version 1.1, a copy of which has been included with this distribution in
   * the LICENSE file.
   */
  package org.apache.phoenix.facilities;
  
  /**
   *
   * @author <a href="mailto:mail@leosimons.com">Leo Simons</a>
   */
  public interface SecurityManager extends Facility
  {
  }
  
  
  1.1                  jakarta-avalon-phoenix/proposal/4.0/src/java/org/apache/phoenix/facilities/ThreadManager.java
  
  Index: ThreadManager.java
  ===================================================================
  /*
   * Copyright (C) The Apache Software Foundation. All rights reserved.
   *
   * This software is published under the terms of the Apache Software License
   * version 1.1, a copy of which has been included with this distribution in
   * the LICENSE file.
   */
  package org.apache.phoenix.facilities;
  
  /**
   *
   * @author <a href="mailto:mail@leosimons.com">Leo Simons</a>
   */
  public interface ThreadManager extends Facility
  {
  }
  
  

---------------------------------------------------------------------
To unsubscribe, e-mail: avalon-dev-unsubscribe@jakarta.apache.org
For additional commands, e-mail: avalon-dev-help@jakarta.apache.org