Examples of startup()

  • org.apache.directory.server.core.DirectoryService.startup()
    Starts up this service. @throws Exception if failed to start up
  • org.apache.directory.server.core.api.DirectoryService.startup()
    Starts up this service. @throws Exception if failed to start up
  • org.apache.geronimo.network.protocol.ServerSocketAcceptor.startup()
  • org.apache.hadoop.hbase.LocalHBaseCluster.startup()
    Start the cluster.
  • org.apache.hadoop.hbase.MiniZooKeeperCluster.startup()
    @param baseDir @return ClientPort server bound to. @throws IOException @throws InterruptedException
  • org.apache.hadoop.hbase.zookeeper.MiniZooKeeperCluster.startup()
  • org.apache.hivemind.internal.RegistryInfrastructure.startup()
    Invoked once, just after the registry infrastructure is constructed. One time startup operations occur, including execution of any contributions to hivemind.Startup. @since 1.1
  • org.apache.ldap.server.DirectoryService.startup()
    Starts up this service. @param listener a listener that listens to the lifecycle of this service @param environment JNDI {@link InitialContext} environment @throws NamingException if failed to start up
  • org.apache.maven.archiva.scheduled.ArchivaTaskScheduler.startup()
  • org.apache.oodt.cas.catalog.server.channel.CommunicationChannelServer.startup()
  • org.apache.pivot.wtk.Application.startup()
    Called when the application is starting up. @param display The display on which this application was started. @param properties Initialization properties passed to the application.
  • org.apache.webbeans.spi.plugins.OpenWebBeansPlugin.startUp()
    initialise the plugin. This is called once after the very plugin has been loaded. @throws WebBeansConfigurationException
  • org.apache.zookeeper.server.NIOServerCnxn.Factory.startup()
  • org.apache.zookeeper.server.ServerCnxnFactory.startup()
  • org.asteriskjava.fastagi.DefaultAgiServer.startup()
  • org.datastorm.controller.Controller.startUp()
  • org.datastorm.controller.IController.startUp()
  • org.dspace.servicemanager.spring.SpringServiceManager.startup()
  • org.eclipse.dependencyactivator.activation.IActivationStartup.startup()
  • org.eclipse.persistence.sessions.server.ConnectionPool.startUp()
    INTERNAL: Allocate the minimum connections.
  • org.erlide.runtime.ErtsProcess.startUp()
  • org.geowebcache.diskquota.DiskQuotaMonitor.startUp()
    Starts up the tile usage and disk usage monitors

    Preconditions:

    Postconditions:

    @throws ConfigurationException @see {@link #shutDown(int)}
  • org.gephi.project.api.ProjectController.startup()
  • org.hpi.data.InvokerDataLoader.startup()
  • org.jacoco.agent.rt.internal.output.FileOutput.startup()
  • org.jacoco.core.runtime.IRuntime.startup()
    Starts the coverage runtime. This method MUST be called before any class instrumented for this runtime is loaded. @throws Exception any internal problem during startup
  • org.jacoco.core.runtime.LoggerRuntime.startup()
  • org.jacoco.core.runtime.SystemPropertiesRuntime.startup()
  • org.jboss.as.server.Bootstrap.startup()
    Calls {@link #bootstrap(Configuration,List)} to bootstrap the container. The value for the returned futurebecomes available when all installed services have been started/failed. @param configuration the server configuration @param extraServices additional services to start and stop with the server instance @return the future service container
  • org.jboss.jca.core.workmanager.transport.remote.jgroups.JGroupsTransport.startup()
  • org.jvnet.glassfish.comms.admin.monitor.MonitoringAdapter.startup()
  • org.jvnet.glassfish.comms.admin.monitor.MonitoringStartup.startup()
  • org.opentripplanner.routing.impl.GraphScanner.startup()
    Based on the autoRegister list, automatically register all routerIds for which we can find a graph file in a subdirectory of the resourceBase path. Also register and load the graph for the defaultRouterId and warn if no routerIds are registered.
  • org.orion.as.bootstrap.Server.startup()
  • org.pentaho.platform.api.engine.IPentahoSystemListener.startup()
    Notification of system startup. This event fires at the end of system initialization, after all system components have started successfully.
  • org.pentaho.platform.api.repository2.unified.IBackingRepositoryLifecycleManager.startup()
    To be called before any (non-admin) users interact with the backing repository.
  • org.pentaho.platform.plugin.action.chartbeans.ChartBeansSystemListener.startup()
  • org.pentaho.platform.plugin.action.kettle.KettleSystemListener.startup()
  • org.rssowl.core.persist.service.IModelSearch.startup()
    Makes the IModelSearch capable of indexing entities and returning results.
    Note that this method can be called multiple times with no side-effects. @throws PersistenceException
  • org.rssowl.ui.internal.ApplicationServer.startup()
    Attempts to start the server. Will throw an IOException in case of a problem. @throws IOException in case of a problem starting the server. @throws UnknownHostException in case the host is unknown. @throws BindException in case of a failure binding the server to a port.
  • org.rssowl.ui.internal.services.SyncItemsManager.startup()
    Deserialize Items from Filesystem @throws IOException @throws ClassNotFoundException
  • org.sdnplatform.sync.internal.SyncTorture.startUp()
  • org.shiftone.jrat.core.spi.MethodHandlerFactory.startup()
    It is recommended that handler factories that require shutdown notification implement the ShutdownListener interface and call context.addShutdownListener(this) in their startup method. @see org.shiftone.jrat.core.shutdown.ShutdownListener
  • org.voltdb.regressionsuites.LocalCluster.startUp()

  • Examples of org.eclipse.dependencyactivator.activation.IActivationStartup.startup()

            IActivationStartup startup = (IActivationStartup) plugin;
            alreadyStartedBundles.add(clazz);
            logger.info("activate bundle by '" + clazz //$NON-NLS-1$
                + "' because of the activation of '" + dependencyBundle //$NON-NLS-1$
                + "'"); //$NON-NLS-1$
            startup.startup();
          } catch (CoreException e) {
            // TODO Auto-generated catch block
            e.printStackTrace();
          }
        }
    View Full Code Here

    Examples of org.eclipse.persistence.sessions.server.ConnectionPool.startUp()

            if (ClassConstants.ServerSession_Class.isAssignableFrom(getSession().getClass())) {
                Iterator enumtr = ((ServerSession)getSession()).getConnectionPools().values().iterator();
                while (enumtr.hasNext()) {
                    ConnectionPool pool = (ConnectionPool)enumtr.next();
                    pool.shutDown();
                    pool.startUp();
                }
            } else if (ClassConstants.PublicInterfaceDatabaseSession_Class.isAssignableFrom(getSession().getClass())) {
                getSession().getAccessor().reestablishConnection(getSession());
            }
        }
    View Full Code Here

    Examples of org.erlide.runtime.ErtsProcess.startUp()

            ErlLogger.debug("Create backend " + data.getNodeName());

            final ErtsProcess erts;
            if (data.isManaged()) {
                erts = new ErtsProcess(data);
                erts.startUp();

                if (data.getLaunch() != null) {
                    final Map<String, String> map = Maps.newHashMap();
                    final IProcess proc = DebugPlugin.newProcess(data.getLaunch(),
                            erts.getProcess(), data.getNodeName(), map);
    View Full Code Here

    Examples of org.geowebcache.diskquota.DiskQuotaMonitor.startUp()

                provider.reloadQuotaStore();
               
                // restart the monitor, the quota store might have been changed and pointed to another DB
                // and we need to re-init the tile pages
                monitor.shutDown(1);
                monitor.startUp();
            } catch(Exception e) {
                log.log(Level.SEVERE, "Failed to reload the disk quoa configuration", e);
            }
        }
    View Full Code Here

    Examples of org.gephi.project.api.ProjectController.startup()

        private void initGephi() {
            final ProjectController pc = Lookup.getDefault().lookup(ProjectController.class);
            WindowManager.getDefault().invokeWhenUIReady(new Runnable() {

                public void run() {
                    pc.startup();
                    DragNDropFrameAdapter.register();
                }
            });
        }
    }
    View Full Code Here

    Examples of org.hpi.data.InvokerDataLoader.startup()

          SSDContextManager ssdCtx = SSDContextManager.build(settingsFile);
          SSDRootObject ssdSettingsData = ssdCtx.getRootObject();
         
          // load the configuration and first data to FactoryManager and as well instatiating the data watcher to invokers folders
          InvokerDataLoader dataLoader = new InvokerDataLoader();
          dataLoader.startup(ssdSettingsData);
         
          // getting the keep session time alive to session manager startup
          int keepSessionAlive = Integer.parseInt(
            ssdSettingsData.getNode(HPIConstants.CONFIGURATIONS_CONFIG_SERVER)
              .getNode(HPIConstants.CONFIGURATIONS_SESSION_MANAGER)
    View Full Code Here

    Examples of org.jacoco.agent.rt.internal.output.FileOutput.startup()

        File destFile = folder.newFile("jacoco.exec");
        AgentOptions options = new AgentOptions();
        options.setDestfile(destFile.getAbsolutePath());

        FileOutput controller = new FileOutput();
        controller.startup(options, new RuntimeData());

        assertTrue("Execution data file should be created", destFile.exists());
        assertEquals("Execution data file should be empty", 0,
            destFile.length());
      }
    View Full Code Here

    Examples of org.jacoco.core.runtime.IRuntime.startup()

      }

      private ExecutionDataStore execute(final ClassReader reader)
          throws Exception {
        IRuntime runtime = new SystemPropertiesRuntime();
        runtime.startup();
        final byte[] bytes = new Instrumenter(runtime).instrument(reader);
        final TargetLoader loader = new TargetLoader(target, bytes);
        run(loader.getTargetClass());
        final ExecutionDataStore store = new ExecutionDataStore();
        runtime.collect(store, false);
    View Full Code Here

    Examples of org.jacoco.core.runtime.LoggerRuntime.startup()

        final byte[] instrumented = instr
            .instrument(getTargetClass(targetName));

        // Now we're ready to run our instrumented class and need to startup the
        // runtime first:
        runtime.startup();

        // In this tutorial we use a special class loader to directly load the
        // instrumented class definition from a byte[] instances.
        final MemoryClassLoader memoryClassLoader = new MemoryClassLoader();
        memoryClassLoader.addDefinition(targetName, instrumented);
    View Full Code Here

    Examples of org.jacoco.core.runtime.SystemPropertiesRuntime.startup()

      }

      private ExecutionDataStore execute(final ClassReader reader)
          throws Exception {
        IRuntime runtime = new SystemPropertiesRuntime();
        runtime.startup();
        final byte[] bytes = new Instrumenter(runtime).instrument(reader);
        final TargetLoader loader = new TargetLoader(target, bytes);
        run(loader.getTargetClass());
        final ExecutionDataStore store = new ExecutionDataStore();
        runtime.collect(store, false);
    View Full Code Here
    TOP
    Copyright © 2018 www.massapi.com. All rights reserved.
    All source code are property of their respective owners. Java is a trademark of Sun Microsystems, Inc and owned by ORACLE Inc. Contact coftware#gmail.com.