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 de.scoopgmbh.copper.persistent.PersistentScottyEngine.startup()

        logger.info("running testNotifyWithoutEarlyResponseHandling");
        final ConfigurableApplicationContext context = createContext(dsContext);
        cleanDB(context.getBean(DataSource.class));
        final PersistentScottyEngine engine = context.getBean(PersistentScottyEngine.class);
        try {
          engine.startup();
          new RetryingTransaction<Void>(context.getBean(DataSource.class)) {
            @Override
            protected Void execute() throws Exception {
              try {
                Response<?> response = new Response<String>("CID#withEarlyResponse", "TEST", null);
    View Full Code Here

    Examples of de.scoopgmbh.copper.persistent.PersistentScottyEngine.startup()

        cleanDB(context.getBean(DataSource.class));
        final PersistentScottyEngine engineRed = context.getBean("persistent.engine.red",PersistentScottyEngine.class);
        final PersistentScottyEngine engineBlue = context.getBean("persistent.engine.blue",PersistentScottyEngine.class);
        final BackChannelQueue backChannelQueue = context.getBean(BackChannelQueue.class);
        engineRed.startup();
        engineBlue.startup();
        try {
          assertEquals(EngineState.STARTED,engineRed.getEngineState());
          assertEquals(EngineState.STARTED,engineBlue.getEngineState());

          for (int i=0; i<NUMB; i++) {
    View Full Code Here

    Examples of kafka.server.KafkaServer.startup()

            return servers.get(index);
        }

        public static KafkaServer createServer(KafkaConfig config) {
            KafkaServer server = new KafkaServer(config, kafka.utils.SystemTime$.MODULE$);
            server.startup();
            return server;
        }

        public static Properties createBrokerConfig(int nodeId, int port, int zkPort, String dir) {
            Properties props = new Properties();
    View Full Code Here

    Examples of kafka.server.KafkaServerStartable.startup()

            props.put("broker.id", "1");
            props.put("log.dir", logDir);
            props.put("zookeeper.connect",zkConnect);
            KafkaConfig kafkaConfig = new KafkaConfig(props);
            KafkaServerStartable server = new KafkaServerStartable(kafkaConfig);
            server.startup();
            return server;
        }

        private void produceJsonMessage(){
            produceMessage(topic,mesg);
    View Full Code Here

    Examples of mx4j.tools.config.ConfigurationLoader.startup()

             Note: requires file path to be passed as program argument */
          String path = args[0];
          Reader reader = new BufferedReader(new FileReader(path));

          // Read and execute the 'startup' section of the XML file
          loader.startup(reader);

          reader.close();

          System.out.println("Application configured successfully");
       }
    View Full Code Here

    Examples of net.floodlightcontroller.core.OFMessageFilterManager.startUp()

            fmCntx.addService(IFloodlightProviderService.class, mfp);
            fmCntx.addService(IThreadPoolService.class, mtp);
            String sid = null;

            mfm.init(fmCntx);
            mfm.startUp(fmCntx);

            ConcurrentHashMap <String, String> filter;
            int i;

            //Adding the filter works -- adds up to the maximum filter size.
    View Full Code Here

    Examples of net.floodlightcontroller.core.test.MockThreadPoolService.startUp()

            frm.init(fmc);
            deviceService.init(fmc);
            restApi.init(fmc);
            getMockFloodlightProvider().init(fmc);
            entityClassifier.init(fmc);
            tps.startUp(fmc);
            vns.init(fmc);
            frm.startUp(fmc);
            deviceService.startUp(fmc);
            restApi.startUp(fmc);
            getMockFloodlightProvider().startUp(fmc);
    View Full Code Here

    Examples of net.floodlightcontroller.debugcounter.DebugCounter.startUp()

            ppt.startUp(fmc);
            restApi.startUp(fmc);
            memstorage.startUp(fmc);
            tp.startUp(fmc);
            debugCounterService.startUp(fmc);
            debugEventService.startUp(fmc);
            syncService.startUp(fmc);
            cm.startUp(fmc);

            storeClient =
    View Full Code Here

    Examples of net.floodlightcontroller.debugevent.DebugEvent.startUp()

            ppt.startUp(fmc);
            restApi.startUp(fmc);
            memstorage.startUp(fmc);
            tp.startUp(fmc);
            debugCounterService.startUp(fmc);
            debugEventService.startUp(fmc);
            syncService.startUp(fmc);
            cm.startUp(fmc);

            storeClient =
                    syncService.getStoreClient(Controller.SWITCH_SYNC_STORE_NAME,
    View Full Code Here

    Examples of net.floodlightcontroller.devicemanager.internal.DefaultEntityClassifier.startUp()

            frm.startUp(fmc);
            deviceService.startUp(fmc);
            restApi.startUp(fmc);
            getMockFloodlightProvider().startUp(fmc);
            vns.startUp(fmc);
            entityClassifier.startUp(fmc);

            topology.addListener(deviceService);
            expectLastCall().times(1);
            replay(topology);
            // Mock switches
    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.