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.apache.cxf.ws.discovery.internal.WSDiscoveryServiceImpl.startup()

        public static void main(String[] arg) throws Exception {
            try {
                Bus bus = BusFactory.getDefaultBus();
                Endpoint ep = Endpoint.publish("http://localhost:51919/Foo/Snarf", new FooImpl());
                WSDiscoveryServiceImpl service = new WSDiscoveryServiceImpl(bus);
                service.startup();
               
                //this service will just generate an error.  However, the probes should still
                //work to probe the above stuff.
                WSDiscoveryServiceImpl s2 = new WSDiscoveryServiceImpl() {
                    public ProbeMatchesType handleProbe(ProbeType pt) {
    View Full Code Here

    Examples of org.apache.directory.server.configuration.ApacheDS.startup()

                ApacheDS apacheDS = ( ApacheDS ) factory.getBean( "apacheDS" );
                File workingDirFile = new File( configF.getParentFile(), "work" );
                apacheDS.getDirectoryService().setWorkingDirectory( workingDirFile );
               
                // Now, launch the server, and check that the ObjectClass index has been created in OS' tmp directory
                apacheDS.startup();
               
                File tmpOCdb = new File( tmpDir, "dc.db" );
                assertTrue( tmpOCdb.exists() );
       
                File tmpOClg = new File( tmpDir, "dc.lg" );
    View Full Code Here

    Examples of org.apache.directory.server.core.DirectoryService.startup()

            else
            {
                LOG.info( "server: using default settings ..." );
                DefaultDirectoryServiceFactory.DEFAULT.init( "default" );
                DirectoryService directoryService = DefaultDirectoryServiceFactory.DEFAULT.getDirectoryService();
                directoryService.startup();
                ldapServer = new LdapServer();
                ldapServer.setDirectoryService( directoryService );
                TcpTransport tcpTransportSsl = new TcpTransport( 10636 );
                tcpTransportSsl.enableSSL( true );
                ldapServer.setTransports( new TcpTransport( 10389 ), tcpTransportSsl );
    View Full Code Here

    Examples of org.apache.directory.server.core.api.DirectoryService.startup()

            // Store the default directories
            directoryService.setInstanceLayout( instanceLayout );

            directoryService.setCacheService( cacheService );

            directoryService.startup();

            AttributeType ocAt = schemaManager.lookupAttributeTypeRegistry( SchemaConstants.OBJECT_CLASS_AT );
            MANDATORY_ENTRY_ATOP_MAP.put( ocAt.getName(), new AttributeTypeOptions( ocAt ) );

            AttributeType uuidAt = schemaManager.lookupAttributeTypeRegistry( SchemaConstants.ENTRY_UUID_AT );
    View Full Code Here

    Examples of org.apache.geronimo.network.protocol.ServerSocketAcceptor.startup()

            ServerSocketAcceptor ssa = new ServerSocketAcceptor();
            ssa.setSelectorManager(sm);
            ssa.setTimeOut(5 * 1000);
            ssa.setUri(new URI("async://localhost:0/?tcp.nodelay=true&tcp.backlog=5#"));
            ssa.setAcceptorListener(pf);
            ssa.startup();

            ControlClientProtocolStack clientStack = new ControlClientProtocolStack();
            clientStack.setClassLoader(Thread.currentThread().getContextClassLoader());
            clientStack.setThreadPool(tp);
            clientStack.setClockPool(cp);
    View Full Code Here

    Examples of org.apache.hadoop.hbase.LocalHBaseCluster.startup()

            // Need to have the zk cluster shutdown when master is shutdown.
            // Run a subclass that does the zk cluster shutdown on its way out.
            LocalHBaseCluster cluster = new LocalHBaseCluster(conf, 1, 1,
                                                              LocalHMaster.class, HRegionServer.class);
            ((LocalHMaster)cluster.getMaster(0)).setZKCluster(zooKeeperCluster);
            cluster.startup();
            waitOnMasterThreads(cluster);
          } else {
            HMaster master = HMaster.constructMaster(masterClass, conf);
            if (master.isStopped()) {
              LOG.info("Won't bring the Master up as a shutdown is requested");
    View Full Code Here

    Examples of org.apache.hadoop.hbase.MiniZooKeeperCluster.startup()

                if (zkClientPort == 0) {
                  throw new IOException("No config value for hbase.zookeeper.property.clientPort");
                }
                zooKeeperCluster.setTickTime(conf.getInt("hbase.zookeeper.property.tickTime", 3000));
                zooKeeperCluster.setClientPort(zkClientPort);
                int clientPort = zooKeeperCluster.startup(zkDataPath);
                if (clientPort != zkClientPort) {
                  String errorMsg = "Couldnt start ZK at requested address of " +
                      zkClientPort + ", instead got: " + clientPort + ". Aborting. Why? " +
                      "Because clients (eg shell) wont be able to find this ZK quorum";
                  System.err.println(errorMsg);
    View Full Code Here

    Examples of org.apache.hadoop.hbase.zookeeper.MiniZooKeeperCluster.startup()

        MiniZooKeeperCluster zooKeeperCluster = null;
        Configuration conf = getConf();
        if (this.miniCluster) {
          dfsCluster = new MiniDFSCluster(conf, 2, true, (String[])null);
          zooKeeperCluster = new MiniZooKeeperCluster();
          int zooKeeperPort = zooKeeperCluster.startup(new File(System.getProperty("java.io.tmpdir")));

          // mangle the conf so that the fs parameter points to the minidfs we
          // just started up
          FileSystem fs = dfsCluster.getFileSystem();
          conf.set("fs.default.name", fs.getUri().toString());
    View Full Code Here

    Examples of org.apache.hivemind.internal.RegistryInfrastructure.startup()

                RegistryInitializationListener listener = (RegistryInitializationListener) i.next();

                listener.registryInitialized(infrastructure);
            }
           
            infrastructure.startup();

            return new RegistryImpl(infrastructure);
        }
       
        /**
     
    View Full Code Here

    Examples of org.apache.ldap.server.DirectoryService.startup()

            {
                service.sync();
            }
            else if( cfg instanceof StartupConfiguration )
            {
                service.startup( this, env );
            }
            else if( cfg instanceof AddDirectoryPartitionConfiguration )
            {
                new DirectoryPartitionNexusProxy(
                        service.getJndiContext( principal, credential, authentication, providerUrl ),
    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.