Examples of start()

  • org.apache.camel.Consumer.start()
  • org.apache.camel.ConsumerTemplate.start()
  • org.apache.camel.Endpoint.start()
  • org.apache.camel.PollingConsumer.start()
  • org.apache.camel.Producer.start()
  • org.apache.camel.ProducerTemplate.start()
  • org.apache.camel.Service.start()
    Starts the service @throws Exception
  • org.apache.camel.component.cxf.CxfConsumer.start()
  • org.apache.camel.component.cxf.CxfProducer.start()
  • org.apache.camel.component.xmlsecurity.api.ValidationFailedHandler.start()
  • org.apache.camel.example.jms.JmsBroker.start()
  • org.apache.camel.impl.DefaultCamelContext.start()
  • org.apache.camel.impl.DefaultProducerTemplate.start()
  • org.apache.camel.impl.DefaultUnitOfWork.start()
  • org.apache.camel.loanbroker.webservice.version.bank.BankServer.start()
  • org.apache.camel.loanbroker.webservice.version.credit.CreditAgencyServer.start()
  • org.apache.camel.processor.SendProcessor.start()
  • org.apache.camel.processor.aggregate.AggregateProcessor.start()
  • org.apache.camel.spi.UnitOfWork.start()
  • org.apache.camel.spring.Main.start()
  • org.apache.camel.spring.SpringCamelContext.start()
  • org.apache.camel.support.TimerListenerManager.start()
  • org.apache.cassandra.db.composites.Composite.start()
  • org.apache.cassandra.db.filter.SliceQueryFilter.start()
  • org.apache.cassandra.repair.RepairSession.start()
    Start RepairJob on given ColumnFamilies. This first validates if all replica are available, and if they are, creates RepairJobs and submit to run on given executor. @param executor Executor to run validation
  • org.apache.cassandra.service.EmbeddedCassandraService.start()
  • org.apache.cassandra.service.StorageService.start()
  • org.apache.cassandra.stress.StressAction.start()
  • org.apache.catalina.Container.start()
  • org.apache.catalina.Context.start()
  • org.apache.catalina.Executor.start()
  • org.apache.catalina.Lifecycle.start()
    Prepare for the beginning of active use of the public methods of this component. This method should be called before any of the public methods of this component are utilized. It should also send a LifecycleEvent of type START_EVENT to any registered listeners. @exception LifecycleException if this component detects a fatal errorthat prevents this component from being used
  • org.apache.catalina.Server.start()
  • org.apache.catalina.cluster.tcp.ReplicationListener.start()
  • org.apache.catalina.connector.Connector.start()
    Begin processing requests via this Connector. @exception LifecycleException if a fatal startup error occurs
  • org.apache.catalina.core.ContainerBase.start()
    Prepare for active use of the public methods of this Component. @exception LifecycleException if this component detects a fatal errorthat prevents it from being started
  • org.apache.catalina.core.StandardContext.start()
    Start this Context component. @exception LifecycleException if a startup error occurs
  • org.apache.catalina.core.StandardEngine.start()
    Start this Engine component. @exception LifecycleException if a startup error occurs
  • org.apache.catalina.core.StandardServer.start()
    Prepare for the beginning of active use of the public methods of this component. This method should be called before any of the public methods of this component are utilized. It should also send a LifecycleEvent of type START_EVENT to any registered listeners. @exception LifecycleException if this component detects a fatal errorthat prevents this component from being used
  • org.apache.catalina.core.StandardService.start()
    Prepare for the beginning of active use of the public methods of this component. This method should be called before any of the public methods of this component are utilized. It should also send a LifecycleEvent of type START_EVENT to any registered listeners. @exception LifecycleException if this component detects a fatal errorthat prevents this component from being used
  • org.apache.catalina.core.StandardThreadExecutor.start()
  • org.apache.catalina.core.StandardWrapper.start()
    Start this component, pre-loading the servlet if the load-on-startup value is set appropriately. @exception LifecycleException if a fatal error occurs during startup
  • org.apache.catalina.logger.FileLogger.start()
    Prepare for the beginning of active use of the public methods of this component. This method should be called after configure(), and before any of the public methods of the component are utilized. @exception LifecycleException if this component detects a fatal errorthat prevents this component from being used
  • org.apache.catalina.startup.Catalina.start()
    Start a new server instance.
  • org.apache.catalina.startup.Embedded.start()
    Prepare for the beginning of active use of the public methods of this component. This method should be called after configure(), and before any of the public methods of the component are utilized. @exception LifecycleException if this component detects a fatal errorthat prevents this component from being used
  • org.apache.catalina.startup.TesterMapRealm.start()
  • org.apache.catalina.startup.Tomcat.start()
    Start the server. @throws LifecycleException
  • org.apache.catalina.tribes.Channel.start()
    Starts up the channel. This can be called multiple times for individual services to start The svc parameter can be the logical or value of any constants @param svc int value of
    DEFAULT - will start all services
    MBR_RX_SEQ - starts the membership receiver
    MBR_TX_SEQ - starts the membership broadcaster
    SND_TX_SEQ - starts the replication transmitter
    SND_RX_SEQ - starts the replication receiver
    @throws ChannelException if a startup error occurs or the service is already started.
  • org.apache.catalina.tribes.ManagedChannel.start()
  • org.apache.catalina.tribes.group.GroupChannel.start()
    Starts up the channel. This can be called multiple times for individual services to start The svc parameter can be the logical or value of any constants @param svc int value of
    DEFAULT - will start all services
    MBR_RX_SEQ - starts the membership receiver
    MBR_TX_SEQ - starts the membership broadcaster
    SND_TX_SEQ - starts the replication transmitter
    SND_RX_SEQ - starts the replication receiver
    @throws ChannelException if a startup error occurs or the service is already started.
  • org.apache.catalina.tribes.transport.nio.NioReceiver.start()
    start cluster receiver @throws IOException @see org.apache.catalina.tribes.ChannelReceiver#start()
  • org.apache.catalina.webresources.StandardRoot.start()
  • org.apache.chemistry.opencmis.util.repository.TimeLogger.start()
  • org.apache.clerezza.triaxrs.testutils.BodyCheckerThread.start()
  • org.apache.click.MockContainer.start()
    Starts the container and configure it for testing {@link org.apache.click.Page} instances.

    During configuration a full mock servlet stack is created consisting of:

    You can provide your own Mock implementations and set them on the container using the appropriate setter method for example: {@link #setRequest(org.apache.click.servlet.MockRequest)}.

    Please note that you must set the mock objects on the container before calling start().

    You also have full access to the mock objects after starting the container by using the appropriate getter method for example: {@link #getRequest()}.

    Below is an example of how to start the container:

     public class TestPages extends junit.framework.TestCase { public void testAll() { String webApplicationDir = "c:/dev/app/web"; MockContainer container = new MockContainer(webApplicationDir); container.start(); ... container.stop(); } } 
    @see #stop()
  • org.apache.cocoon.portal.event.EventConverter.start()
    This notifies the converter that a new event processing phase starts
  • org.apache.commons.httpclient.util.IdleConnectionTimeoutThread.start()
  • org.apache.commons.io.monitor.FileAlterationMonitor.start()
    Start monitoring. @throws Exception if an error occurs initializing the observer
  • org.apache.commons.jci.monitor.FilesystemAlterationMonitor.start()
  • org.apache.commons.lang.time.StopWatch.start()

    Start the stopwatch.

    This method starts a new timing session, clearing any previous values.

    @throws IllegalStateException if the StopWatch is already running.
  • org.apache.commons.lang3.time.StopWatch.start()

    Start the stopwatch.

    This method starts a new timing session, clearing any previous values.

    @throws IllegalStateException if the StopWatch is already running.
  • org.apache.commons.launcher.StreamConnector.start()
  • org.apache.commons.vfs2.impl.DefaultFileMonitor.start()
    Starts monitoring the files that have been added.
  • org.apache.coyote.ProtocolHandler.start()
    Start the protocol.
  • org.apache.curator.CuratorZookeeperClient.start()
    Must be called after construction @throws IOException errors
  • org.apache.curator.framework.CuratorFramework.start()
    Start the client. Most mutator methods will not work until the client is started
  • org.apache.curator.framework.recipes.cache.NodeCache.start()
    Start the cache. The cache is not started automatically. You must call this method. @throws Exception errors
  • org.apache.curator.framework.recipes.cache.PathChildrenCache.start()
    Start the cache. The cache is not started automatically. You must call this method. @throws Exception errors
  • org.apache.curator.framework.recipes.leader.LeaderLatch.start()
    Add this instance to the leadership election and attempt to acquire leadership. @throws Exception errors
  • org.apache.curator.framework.recipes.leader.LeaderSelector.start()
    Attempt leadership. This attempt is done in the background - i.e. this method returns immediately.

    IMPORTANT: previous versions allowed this method to be called multiple times. This is no longer supported. Use {@link #requeue()} for this purpose.
  • org.apache.curator.framework.recipes.nodes.PersistentEphemeralNode.start()
    You must call start() to initiate the persistent ephemeral node. An attempt to create the node in the background will be started
  • org.apache.curator.framework.recipes.shared.SharedCount.start()
    The shared count must be started before it can be used. Call {@link #close()} when you arefinished with the shared count @throws Exception ZK errors, interruptions, etc.
  • org.apache.curator.test.TestingCluster.start()
    Start the ensemble. The cluster must be started before use. @throws Exception errors
  • org.apache.cxf.dosgi.discovery.local.internal.Activator.start()
  • org.apache.cxf.dosgi.dsw.Activator.start()
  • org.apache.cxf.endpoint.DummyServer.start()
  • org.apache.cxf.endpoint.Server.start()
  • org.apache.cxf.endpoint.ServerImpl.start()
  • org.apache.cxf.systest.ws.rm.RetransmissionQueueTest.Server.start()
  • org.apache.cxf.transport.jms.util.AbstractMessageListenerContainer.start()
  • org.apache.cxf.transport.jms.util.MessageListenerContainer.start()
  • org.apache.cxf.ws.eventing.backend.notification.NotificatorService.start()
    Starts this NotificatorService. You MUST run this method on every instance before starting to pass any events to it. Run it only once.
  • org.apache.deltacloud.client.Instance.start()
  • org.apache.deltacloud.client.internal.test.fakes.ServerFake.start()
  • org.apache.derby.drda.NetworkServerControl.start()
    Start a Network Server This method will launch a separate thread and start Network Server. This method may return before the server is ready to accept connections. Use the ping method to verify that the server has started.

    Note: an alternate method to starting the Network Server with the API, is to use the derby.drda.startNetworkServer property in cloudscape.properties. @param consoleWriter PrintWriter to which server console will be output. Null will disable console output. @exception Exception if there is an error starting the server. @see #shutdown

  • org.apache.derby.impl.drda.NetworkServerControlImpl.start()
    Start a network server. Launches a separate thread with DRDAServerStarter. Want to use Monitor.startModule, so it can all get shutdown when Derby shuts down, but can't get it working right now. @param consoleWriter PrintWriter to which server console will be output. Null will disable console output. @exception Exception throws an exception if an error occurs
  • org.apache.derbyTesting.system.nstest.init.NWServerThread.start()
  • org.apache.derbyTesting.system.nstest.utils.MemCheck.start()
  • org.apache.derbyTesting.system.nstest.utils.SequenceReader.start()
  • org.apache.derbyTesting.system.sttest.tools.MemCheck.start()
  • org.apache.directmemory.measures.MonitorService.start()
  • org.apache.directory.server.kerberos.kdc.KdcServer.start()
    @throws IOException if we cannot bind to the sockets
  • org.apache.directory.server.ldap.LdapServer.start()
    @throws IOException if we cannot bind to the specified port @throws Exception if the LDAP server cannot be started
  • org.apache.directory.server.ldap.replication.ReplicationConsumer.start()
    starts the consumer
  • org.apache.directory.server.ldap.replication.consumer.PingerThread.start()
  • org.apache.directory.server.ldap.replication.consumer.ReplicationConsumer.start()
    starts the consumer
  • org.apache.directory.studio.ldapservers.model.LdapServerAdapter.start()
    This method is called when a server needs to be started. @param server the server @param monitor the progress monitor @throws Exception if an error occurs when starting the server
  • org.apache.drill.exec.coord.ZKClusterCoordinator.start()
  • org.apache.drill.exec.coord.zk.ZKClusterCoordinator.start()
  • org.apache.drill.exec.store.sys.local.LocalPStoreProvider.start()
  • org.apache.drill.exec.vector.complex.writer.BaseWriter.ListWriter.start()
  • org.apache.drill.exec.vector.complex.writer.BaseWriter.MapWriter.start()
  • org.apache.droids.api.Droid.start()
    Invoke an instance of the worker used in the droid
  • org.apache.droids.impl.SysoutCrawlingDroid.start()
  • org.apache.droids.robot.crawler.CrawlingDroid.start()
  • org.apache.falcon.JobTrackerService.start()
  • org.apache.falcon.util.EmbeddedServer.start()
  • org.apache.felix.cm.integration.helper.ConfigureThread.start()
  • org.apache.felix.cm.integration.helper.ManagedServiceFactoryThread.start()
  • org.apache.felix.cm.integration.helper.ManagedServiceThread.start()
  • org.apache.felix.example.extenderbased.host.Activator.start()
    Displays the applications window and starts extension tracking; everything is done on the Swing event thread to avoid synchronization and repainting issues. @param context The context of the bundle.
  • org.apache.felix.example.servicebased.host.Activator.start()
    Displays the applications window and starts service tracking; everything is done on the Swing event thread to avoid synchronization and repainting issues. @param context The context of the bundle.
  • org.apache.felix.framework.Felix.start()
    This method starts the framework instance, which will transition the framework from start level 0 to its active start level as specified in its configuration properties (1 by default). If the init() was not explicitly invoked before calling this method, then it will be implicitly invoked before starting the framework. @throws org.osgi.framework.BundleException if any error occurs.
  • org.apache.felix.gogo.runtime.threadio.ThreadIOImpl.start()
  • org.apache.felix.ipojo.ComponentFactory.start()
  • org.apache.felix.ipojo.ComponentInstance.start()
    Starts the component instance.
  • org.apache.felix.ipojo.HandlerManagerFactory.start()
  • org.apache.felix.ipojo.api.PrimitiveComponentType.start()
    Starts the component type. @see org.apache.felix.ipojo.api.ComponentType#start()
  • org.apache.felix.ipojo.composite.util.SourceManager.start()
    Start the context management.
  • org.apache.felix.ipojo.extender.internal.declaration.DefaultExtensionDeclaration.start()
  • org.apache.felix.ipojo.extender.internal.declaration.DefaultInstanceDeclaration.start()
  • org.apache.felix.ipojo.extender.internal.declaration.DefaultTypeDeclaration.start()
  • org.apache.felix.karaf.admin.Instance.start()
  • org.apache.felix.karaf.shell.commands.utils.PumpStreamHandler.start()
    Start pumping the streams.
  • org.apache.flink.client.LocalExecutor.start()
  • org.apache.flink.client.minicluster.NepheleMiniCluster.start()
  • org.apache.flink.client.web.WebInterfaceServer.start()
    Starts the web frontend server. @throws Exception Thrown, if the start fails.
  • org.apache.flink.runtime.io.network.netty.NettyConnectionManager.start()
  • org.apache.flink.runtime.ipc.Server.start()
    Starts the service. Must be called before any calls will be handled.
  • org.apache.flink.runtime.operators.testutils.TaskCancelThread.start()
  • org.apache.flume.Channel.start()
  • org.apache.flume.PollableSink.start()
  • org.apache.flume.PollableSource.start()
  • org.apache.flume.Sink.start()
  • org.apache.flume.SinkRunner.start()
  • org.apache.flume.Source.start()
  • org.apache.flume.agent.embedded.EmbeddedAgent.start()
    Started the agent. Can only be called after a successful call to configure(). @throws FlumeException if a component cannot be started @throws IllegalStateException if the agent has not been configured or isalready started
  • org.apache.flume.channel.MemoryChannel.start()
  • org.apache.flume.channel.file.FileChannel.start()
  • org.apache.flume.channel.recoverable.memory.RecoverableMemoryChannel.start()
  • org.apache.flume.instrumentation.MonitorService.start()
  • org.apache.flume.sink.LoggerSink.start()
  • org.apache.flume.sink.hbase.HBaseSink.start()
  • org.apache.flume.source.AvroSource.start()
  • org.apache.flume.source.twitter.TwitterSource.start()
  • org.apache.fop.configuration.ConfigurationReader.start()
    intantiates parser and starts parsing of config file
  • org.apache.fop.dom.svg.SVGArea.start()
  • org.apache.fop.layout.BlockArea.start()
  • org.apache.ftpserver.FtpServer.start()
    Start the server. Open a new listener thread. @throws FtpException
  • org.apache.fulcrum.yaafi.interceptor.util.StopWatch.start()

    Start the stopwatch.

    This method starts a new timing session, clearing any previous values.

    @throws IllegalStateException if the StopWatch is already running.
  • org.apache.geronimo.concurrent.thread.ManagedThread.start()
  • org.apache.geronimo.gbean.runtime.GBeanInstance.start()
    Moves this GBeanInstance to the starting state and then attempts to move this MBean immediately to the running state. @throws IllegalStateException If the gbean is disabled
  • org.apache.geronimo.gshell.common.io.PumpStreamHandler.start()
  • org.apache.geronimo.gshell.io.PumpStreamHandler.start()
  • org.apache.geronimo.jetty7.handler.EJBWebServiceContext.start()
  • org.apache.geronimo.jetty8.handler.EJBWebServiceContext.start()
  • org.apache.geronimo.kernel.config.ConfigurationManager.start()
    Start the gbeans in this configuration. You must have called loadGBeans before calling this method. @param configID @throws InvalidConfigException
  • org.apache.geronimo.testsuite.common.selenium.EclipseSelenium.start()
  • org.apache.giraph.comm.netty.NettyServer.start()
    Start the server with the appropriate port
  • org.apache.hadoop.chukwa.datacollection.adaptor.Adaptor.start()
    Start this adaptor @param type the application type, who is starting this adaptor @param status the status string to use for configuration. @param offset the stream offset of the first byte sent by this adaptor @throws AdaptorException
  • org.apache.hadoop.chukwa.datacollection.connector.ChunkCatcherConnector.start()
  • org.apache.hadoop.chukwa.datacollection.connector.http.HttpConnector.start()
  • org.apache.hadoop.chukwa.datacollection.test.ConsoleOutConnector.start()
  • org.apache.hadoop.chukwa.inputtools.mdl.ErStreamHandler.start()
  • org.apache.hadoop.gateway.services.security.SSLService.start()
  • org.apache.hadoop.gateway.services.security.impl.DefaultAliasService.start()
  • org.apache.hadoop.gateway.services.topology.impl.DefaultTopologyService.start()
  • org.apache.hadoop.hbase.Chore.start()
  • org.apache.hadoop.hbase.MasterAddressTracker.start()
  • org.apache.hadoop.hbase.catalog.CatalogTracker.start()
    Starts the catalog tracker. Determines current availability of catalog tables and ensures all further transitions of either region are tracked. @throws IOException @throws InterruptedException
  • org.apache.hadoop.hbase.coordination.BaseCoordinatedStateManager.start()
  • org.apache.hadoop.hbase.coordination.ZkCoordinatedStateManager.start()
  • org.apache.hadoop.hbase.http.HttpServer.start()
    Start the server. Does not wait for the server to start.
  • org.apache.hadoop.hbase.http.InfoServer.start()
  • org.apache.hadoop.hbase.ipc.TestDelayedRpc.TestThread.start()
  • org.apache.hadoop.hbase.master.HMaster.start()
  • org.apache.hadoop.hbase.master.cleaner.HFileCleaner.start()
  • org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceManager.NodeFailoverWorker.start()
  • org.apache.hadoop.hbase.security.token.AuthenticationTokenSecretManager.start()
  • org.apache.hadoop.hbase.util.InfoServer.start()
    Start the server. Does not wait for the server to start.
  • org.apache.hadoop.hbase.util.JVMClusterUtil.MasterThread.start()
  • org.apache.hadoop.hbase.util.MultiThreadedReader.start()
  • org.apache.hadoop.hbase.util.MultiThreadedWriter.start()
  • org.apache.hadoop.hbase.zookeeper.MasterAddressTracker.start()
  • org.apache.hadoop.hbase.zookeeper.RootRegionTracker.start()
  • org.apache.hadoop.hdfs.AppendTestUtil.WriterThread.start()
  • org.apache.hadoop.hdfs.nfs.nfs3.Nfs3.start()
  • org.apache.hadoop.hdfs.notifier.benchmark.TxnConsumer.start()
  • org.apache.hadoop.hdfs.notifier.benchmark.TxnGenerator.start()
  • org.apache.hadoop.hdfs.qjournal.client.HttpImageUploadChannel.start()
    Create an image upload channel, based on image txid and other metadata.
  • org.apache.hadoop.hdfs.qjournal.server.JournalNode.start()
    Start listening for edits via RPC.
  • org.apache.hadoop.hdfs.server.datanode.DataStorage.RollbackThread.start()
  • org.apache.hadoop.hdfs.server.datanode.DataStorage.UpgradeThread.start()
  • org.apache.hadoop.hdfs.server.datanode.FSDataset.AsyncBlockReport.start()
  • org.apache.hadoop.hive.ql.exec.TaskRunner.start()
  • org.apache.hadoop.hive.ql.exec.Utilities.StreamPrinter.start()
  • org.apache.hadoop.http.HttpServer.start()
    Start the server. Does not wait for the server to start.
  • org.apache.hadoop.http.HttpServer2.start()
    Start the server. Does not wait for the server to start.
  • org.apache.hadoop.ipc.RPC.Server.start()
  • org.apache.hadoop.ipc.Server.start()
    Starts the service. Must be called before any calls will be handled.
  • org.apache.hadoop.mapred.ControlledMapReduceJob.ControlledMapReduceJobRunner.start()
  • org.apache.hadoop.mapred.StatusHttpServer.start()
    Start the server. Does not wait for the server to start.
  • org.apache.hadoop.mapred.TaskTracker.TaskLauncher.start()
  • org.apache.hadoop.mapreduce.test.system.TTClient.start()
  • org.apache.hadoop.mapreduce.v2.MiniMRYarnCluster.start()
  • org.apache.hadoop.mapreduce.v2.app.commit.CommitterEventHandler.start()
  • org.apache.hadoop.mapreduce.v2.app.rm.RMContainerAllocator.start()
  • org.apache.hadoop.mapreduce.v2.hs.JobHistoryServer.start()
  • org.apache.hadoop.metrics2.MetricsSystem.start()
  • org.apache.hadoop.metrics2.impl.MetricsSystemImpl.start()
  • org.apache.hadoop.raid.ParallelStreamReader.start()
  • org.apache.hadoop.service.Service.start()
    Start the service. The transition MUST be from {@link STATE#INITED} to {@link STATE#STARTED}unless the operation failed and an exception was raised, in which case {@link #stop()} MUST be invoked and the service enter the state{@link STATE#STOPPED}. @throws RuntimeException on any failure during the operation
  • org.apache.hadoop.test.system.process.RemoteProcess.start()
    Start a given daemon process.
    @throws IOException if startup fails.
  • org.apache.hadoop.util.Daemon.start()
  • org.apache.hadoop.yarn.client.YarnClient.start()
  • org.apache.hadoop.yarn.client.YarnClientImpl.start()
  • org.apache.hadoop.yarn.client.api.AHSClient.start()
  • org.apache.hadoop.yarn.client.api.NMClient.start()
  • org.apache.hadoop.yarn.client.api.TimelineClient.start()
  • org.apache.hadoop.yarn.client.api.YarnClient.start()
  • org.apache.hadoop.yarn.event.AsyncDispatcher.start()
  • org.apache.hadoop.yarn.event.DrainDispatcher.start()
  • org.apache.hadoop.yarn.event.InlineDispatcher.start()
  • org.apache.hadoop.yarn.server.MiniYARNCluster.start()
  • org.apache.hadoop.yarn.server.api.AuxiliaryService.start()
  • org.apache.hadoop.yarn.server.nodemanager.DeletionService.start()
  • org.apache.hadoop.yarn.server.nodemanager.LocalDirsHandlerService.start()
    Method used to start the disk health monitoring, if enabled.
  • org.apache.hadoop.yarn.server.nodemanager.containermanager.AuxServices.start()
  • org.apache.hadoop.yarn.server.nodemanager.recovery.NMMemoryStateStoreService.start()
  • org.apache.hadoop.yarn.server.resourcemanager.MockRM.start()
  • org.apache.hadoop.yarn.server.resourcemanager.MockRMWithCustomAMLauncher.start()
  • org.apache.hadoop.yarn.server.resourcemanager.NMLivelinessMonitor.start()
  • org.apache.hadoop.yarn.server.resourcemanager.ResourceManager.start()
  • org.apache.hadoop.yarn.server.resourcemanager.TestAMAuthorization.MockRMWithAMS.start()
  • org.apache.hadoop.yarn.server.resourcemanager.recovery.RMStateStore.start()
  • org.apache.hadoop.yarn.server.resourcemanager.resourcetracker.InlineDispatcher.start()
  • org.apache.hadoop.yarn.server.resourcemanager.scheduler.fifo.FifoScheduler.start()
  • org.apache.hadoop.yarn.server.resourcemanager.security.NMTokenSecretManagerInRM.start()
  • org.apache.hadoop.yarn.server.resourcemanager.security.RMContainerTokenSecretManager.start()
  • org.apache.hadoop.yarn.server.webproxy.WebAppProxyServer.start()
  • org.apache.hama.bsp.sync.ZooKeeperSyncServerImpl.start()
  • org.apache.hama.ipc.Server.start()
    Starts the service. Must be called before any calls will be handled.
  • org.apache.harmony.jndi.provider.ldap.mock.MockLdapServer.start()
  • org.apache.hedwig.server.netty.PubSubServer.start()
  • org.apache.helix.HelixController.start()
  • org.apache.helix.HelixParticipant.start()
  • org.apache.helix.HelixService.start()
    start helix service
  • org.apache.helix.ipc.netty.NettyHelixIPCService.start()
    Starts message handling server, creates client bootstrap, and bootstraps partition routing table.
  • org.apache.helix.task.TaskDriver.start()
    Schedules a new workflow
  • org.apache.helix.webapp.HelixAdminWebApp.start()
  • org.apache.hive.common.util.StreamPrinter.start()
  • org.apache.hive.ptest.execution.LogDirectoryCleaner.start()
  • org.apache.hive.service.server.HiveServer2.start()
  • org.apache.http.impl.bootstrap.HttpServer.start()
  • org.apache.http.impl.conn.GetConnThread.start()
  • org.apache.http.impl.nio.bootstrap.HttpServer.start()
  • org.apache.http.impl.nio.client.CloseableHttpAsyncClient.start()
  • org.apache.http.impl.nio.client.DefaultHttpAsyncClient.start()
  • org.apache.http.localserver.HttpServerNio.start()
  • org.apache.http.localserver.LocalTestServer.start()
    Starts this test server. Use {@link #getServicePort getServicePort}to obtain the port number afterwards.
  • org.apache.http.nio.client.HttpAsyncClient.start()
  • org.apache.ivory.util.EmbeddedServer.start()
  • org.apache.ivy.core.IvyThread.start()
  • org.apache.jackrabbit.core.cluster.ClusterNode.start()
    Starts this cluster node. @throws ClusterException if an error occurs
  • org.apache.jackrabbit.mk.model.TraversingNodeDiffHandler.start()
  • org.apache.jackrabbit.mk.server.Server.start()
    Start this server. @throws IOException if an I/O error occurs
  • org.apache.jackrabbit.oak.plugins.observation.ChangeProcessor.start()
    Start this change processor @param whiteboard the whiteboard instance to used for scheduling individualruns of this change processor. @throws IllegalStateException if started already
  • org.apache.jackrabbit.oak.plugins.segment.standby.client.StandbyClient.start()
  • org.apache.jackrabbit.oak.plugins.segment.standby.server.StandbyServer.start()
  • org.apache.jackrabbit.oak.spi.whiteboard.WhiteboardExecutor.start()
  • org.apache.james.imapserver.netty.IMAPServer.start()
  • org.apache.jena.atlas.logging.ProgressLogger.start()
  • org.apache.jena.fuseki.server.SPARQLServer.start()
    Initialize the {@link SPARQLServer} instance.
  • org.apache.jena.riot.lang.StreamRDFCounting.start()
  • org.apache.jena.riot.system.StreamRDF.start()
    Start parsing
  • org.apache.jetspeed.aggregator.Worker.start()
  • org.apache.jetspeed.aggregator.impl.WorkerMonitorImpl.start()
  • org.apache.jetspeed.components.SpringComponentManager.start()
  • org.apache.jetspeed.daemon.DaemonThread.start()
  • org.apache.jetspeed.deployment.impl.StandardDeploymentManager.start()

    start

    @see org.picocontainer.Startable#start()
  • org.apache.jetspeed.tools.pamanager.servletcontainer.ApplicationServerManager.start()

    start

    Starts the application represented by the context path, appPath @param appPath path to restart @return container-specific status message @throws HttpException @throws IOException
  • org.apache.jmeter.JMeter.start()
    Takes the command line arguments and uses them to determine how to startup JMeter. Called reflectively by {@link NewDriver#main(String[])}
  • org.apache.juddi.v3.client.config.UDDIClerkManager.start()
    Initializes the UDDI Clerk. @throws ConfigurationException
  • org.apache.juddi.v3.client.config.UDDIClient.start()
    Initializes the UDDI Clerk. @throws ConfigurationException
  • org.apache.juddi.v3.client.embed.EmbeddedRegistry.start()
  • org.apache.karaf.admin.Instance.start()
  • org.apache.karaf.cellar.core.event.EventConsumer.start()
    Start the consumer.
  • org.apache.karaf.features.internal.service.BootFeaturesInstaller.start()
    Install boot features
  • org.apache.karaf.instance.core.Instance.start()
  • org.apache.karaf.shell.commands.utils.PumpStreamHandler.start()
    Start pumping the streams.
  • org.apache.karaf.util.process.PumpStreamHandler.start()
    Start pumping the streams.
  • org.apache.log4j.jmx.Agent.start()
  • org.apache.logging.log4j.Timer.start()
    Start the timer.
  • org.apache.logging.log4j.core.Appender.start()
  • org.apache.logging.log4j.core.LoggerContext.start()
  • org.apache.logging.log4j.core.Timer.start()
    Start the timer.
  • org.apache.logging.log4j.core.appender.ConsoleAppender.start()
  • org.apache.logging.log4j.core.appender.FileAppender.start()
  • org.apache.logging.log4j.core.appender.JMSQueueAppender.start()
  • org.apache.logging.log4j.core.appender.JMSTopicAppender.start()
  • org.apache.logging.log4j.core.appender.SocketAppender.start()
  • org.apache.logging.log4j.core.util.Timer.start()
  • org.apache.logging.log4j.test.appender.InMemoryAppender.start()
  • org.apache.logging.log4j.test.appender.ListAppender.start()
  • org.apache.lucene.benchmark.stats.TimeData.start()
    Start counting elapsed time.
  • org.apache.lucene.search.highlight.SynonymTokenizer.TestHighlightRunner.start()
  • org.apache.lucene.search.spans.Spans.start()
    Returns the start position of the current match. Initially invalid.
  • org.apache.maven.embedder.MavenEmbedder.start()
  • org.apache.mesos.MesosSchedulerDriver.start()
    See SchedulerDriver for descriptions of these.
  • org.apache.mesos.SchedulerDriver.start()
    Starts the scheduler driver. This needs to be called before any other driver calls are made.
  • org.apache.mina.io.filter.IoThreadPoolFilter.start()
  • org.apache.mina.protocol.filter.ProtocolThreadPoolFilter.start()
  • org.apache.muse.osgi.soa.core.web.WebApp.start()
    Starts the WebApp @param bc the BundleContext of the WebApp host @throws BundleException
  • org.apache.muse.test.http.remote.HttpServerClient.start()
  • org.apache.myfaces.extensions.cdi.test.cargo.SimplePageInteraction.start()
  • org.apache.myfaces.trinidadinternal.image.painter.ImageLoader.start()
  • org.apache.naming.NamingService.start()
    Start the servlet container.
  • org.apache.niolex.commons.test.Performance.start()
    Start to test now.
  • org.apache.niolex.commons.test.StopWatch.start()
    Start a new time counter to count the current unit running time. This method can be called in parallel. @return a new stop object
  • org.apache.niolex.commons.util.Runme.start()
    Start this thread. Override super method @see java.lang.Thread#start()
  • org.apache.ode.il.dbutil.Database.start()
  • org.apache.onami.persist.PersistenceService.start()
    Starts the underlying persistence engine and makes onami-persist ready for use. This method must be called by your code prior to using any other onami-persist artifacts. If you are using onami-persist in a web container {@link PersistenceFilter} will call thismethod upon initialization of the web application. @throws IllegalStateException if the service is already running.
  • org.apache.oozie.BundleEngine.start()
  • org.apache.oozie.DagEngine.start()
    Start a job. @param jobId job Id. @throws DagEngineException thrown if the job could not be started.
  • org.apache.oozie.action.ActionExecutor.start()
    Start an action.

    The {@link Context#setStartData} method must be called within this method.

    If theaction has completed, the {@link Context#setExecutionData} method must be called within this method. @param context executor context. @param action the action to start. @throws ActionExecutorException thrown if the action could not start.

  • org.apache.oozie.client.OozieClient.start()
    Start a workflow job. @param jobId job Id. @throws OozieClientException thrown if the job could not be started.
  • org.apache.oozie.client.XOozieClient.start()
  • org.apache.oozie.test.EmbeddedServletContainer.start()
    Start the servlet container.

    The container starts on a free port. @throws Exception thrown if the container could not start.

  • org.apache.oozie.workflow.WorkflowInstance.start()
    Start the instance. @throws WorkflowException thrown if the instance could not be started.
  • org.apache.oozie.workflow.lite.LiteWorkflowInstance.start()
  • org.apache.openejb.Container.start()
  • org.apache.openejb.client.EJBResponse.start()
  • org.apache.openejb.config.RemoteServer.start()
  • org.apache.openejb.core.timer.EjbTimerService.start()
  • org.apache.openejb.quartz.Scheduler.start()
  • org.apache.openejb.server.ServerService.start()
  • org.apache.openejb.server.ServiceDaemon.start()
  • org.apache.openejb.server.SimpleServiceManager.start()
  • org.apache.openejb.server.axis2.ejb.EjbWsContainer.start()
  • org.apache.openejb.server.axis2.pojo.PojoWsContainer.start()
  • org.apache.openejb.server.control.StandaloneServer.start()
  • org.apache.openejb.server.cxf.ejb.EjbWsContainer.start()
  • org.apache.openejb.server.cxf.pojo.PojoWsContainer.start()
  • org.apache.openejb.server.cxf.rs.CxfRSService.start()
  • org.apache.openejb.server.discovery.MulticastDiscoveryAgent.start()
    start the discovery agent @throws Exception
  • org.apache.openejb.util.Pool.start()
  • org.apache.openjpa.datacache.CacheStatistics.start()
    Gets the time of start.
  • org.apache.openjpa.instrumentation.InstrumentationManager.start()
    Starts all instruments for all managed providers for a given level and context. @param level instrumentation level @param context instrumentation context (broker, factory, config,...)
  • org.apache.openjpa.persistence.event.common.apps.Duration.start()
  • org.apache.provisionr.core.logging.StreamLogger.start()
  • org.apache.qpid.client.AMQConnection.start()
    Start the connection, i.e. start flowing messages. Note that this method must be called only from a single thread and is not thread safe (which is legal according to the JMS specification). @throws JMSException
  • org.apache.qpid.client.AMQXAResource.start()
  • org.apache.qpid.disttest.client.Client.start()
    Register with the controller
  • org.apache.qpid.management.domain.services.QMan.start()
    Starts QMan. @throws StartupFailureException when it's not possible to proceed with startup.
  • org.apache.qpid.proton.messenger.Messenger.start()
    Transitions the Messenger to an active state. A Messenger is initially created in an inactive state. When inactive, a Messenger will not send or receive messages from its internal queues. A Messenger must be started before calling send() or recv().
  • org.apache.qpid.proton.messenger.impl.MessengerImpl.start()
  • org.apache.qpid.ra.inflow.QpidActivation.start()
    Start the activation @throws ResourceException Thrown if an error occurs
  • org.apache.qpid.server.configuration.updater.CurrentThreadTaskExecutor.start()
  • org.apache.qpid.server.management.plugin.ManagementPlugin.start()
  • org.apache.qpid.server.model.testmodel.TestConfiguredObject.start()
  • org.apache.qpid.server.txn.DistributedTransaction.start()
  • org.apache.qpid.server.virtualhost.AbstractVirtualHost.start()
  • org.apache.qpid.server.virtualhost.berkeleydb.BDBHAVirtualHostImpl.start()
  • org.apache.qpid.test.utils.Piper.start()
  • org.apache.qpid.transport.network.NetworkConnection.start()
  • org.apache.qpid.transport.network.io.IoAcceptor.start()
  • org.apache.roller.business.runnable.ContinuousWorkerThread.start()
  • org.apache.roller.weblogger.business.runnable.ContinuousWorkerThread.start()
  • org.apache.s4.fluent.FluentApp.start()
  • org.apache.sandesha.server.InvokeStrategy.start()
    Initialize the strategy.
  • org.apache.sandesha2.polling.PollingManager.start()
    Starts the PollingManager. @param configurationContext @throws SandeshaException
  • org.apache.servicemix.jbi.container.JBIContainer.start()
    start processing @throws JBIException
  • org.apache.servicemix.jbi.deployer.Component.start()
  • org.apache.servicemix.jbi.deployer.ServiceAssembly.start()
  • org.apache.servicemix.jbi.framework.ComponentMBeanImpl.start()
    Start the item. @exception javax.jbi.JBIException if the item fails to start.
  • org.apache.servicemix.jbi.framework.ServiceAssemblyLifeCycle.start()
    Start a Service Assembly and put it in the STARTED state. @return Result/Status of this operation. @throws Exception
  • org.apache.shale.dialog.DialogContext.start()

    Start the execution of this {@link DialogContext} instance,advancing until an interaction with the user is required. At that point, navigate to the appropriate view, call FacesContext.renderResopnse(), and return.

    @param context FacesContext for the current request @exception IllegalStateException if this {@link DialogContext}instance has already been started
  • org.apache.slider.client.SliderClient.start()
  • org.apache.slider.common.tools.Duration.start()
  • org.apache.slider.server.appmaster.web.AgentService.start()
  • org.apache.sling.launchpad.base.shared.Launcher.start()
    Starts the framework and returns true if successfull.
  • org.apache.solr.client.solrj.embedded.JettySolrRunner.start()
  • org.apache.solr.client.solrj.embedded.PermissiveJettySolrRunner.start()
  • org.apache.spark.streaming.api.java.JavaStreamingContext.start()
  • org.apache.sshd.SshClient.start()
  • org.apache.sshd.SshServer.start()
    Start the SSH server and accept incoming exceptions on the configured port. @throws IOException
  • org.apache.sshd.agent.AgentServer.start()
  • org.apache.sshd.agent.unix.AgentServer.start()
  • org.apache.sshd.client.channel.ForwardLocalPort.start()
  • org.apache.sshd.server.Command.start()
    Starts the shell. All streams must have been set before calling this method. The command should implement Runnable, and this method should spawn a new thread like:
     {@code Thread(this).start();}
    @param env @throws java.io.IOException
  • org.apache.stanbol.commons.testing.jarexec.JarExecutor.start()
    Start the jar if not done yet, and setup runtime hook to stop it.
  • org.apache.struts2.components.ActionComponent.start()
  • org.apache.struts2.components.Component.start()
    Callback for the start tag of this component. Should the body be evaluated? @param writer the output writer. @return true if the body should be evaluated
  • org.apache.synapse.ServerManager.start()
    Starts the system, if the system is initialized, and if not a Runtime exception of type {@link org.apache.synapse.SynapseException} will be thrown @return the state of the server after starting, for a successful start{@link org.apache.synapse.ServerState#STARTED}
  • org.apache.synapse.core.axis2.ProxyService.start()
    Start the proxy service @param synCfg the synapse configuration
  • org.apache.tajo.util.metrics.reporter.TajoMetricsScheduledReporter.start()
  • org.apache.tajo.worker.dataserver.HttpDataServer.start()
  • org.apache.tapestry5.internal.antlr.PropertyExpressionParser.start()
  • org.apache.tapestry5.test.Jetty7Runner.start()
  • org.apache.tez.client.TezClient.start()
    Start the client. This establishes a connection to the YARN cluster. In session mode, this start the App Master thats runs all the DAGs in the session. @throws TezException @throws IOException
  • org.apache.tez.client.TezSession.start()
    Start a Tez Session @throws TezException @throws IOException
  • org.apache.tez.dag.app.rm.TestTaskSchedulerHelpers.TaskSchedulerWithDrainableAppCallback.start()
  • org.apache.tez.runtime.api.LogicalInput.start()
  • org.apache.tez.runtime.api.LogicalOutput.start()
  • org.apache.tiles.request.render.PublisherRenderer.RendererListener.start()
  • org.apache.tiles.template.AddAttributeModel.start()
    Starts the operation.. @param composeStack The composing stack. @since 2.2.0
  • org.apache.tiles.template.AddListAttributeModel.start()
    Starts the operation. @param composeStack The composing stack. @param role A comma-separated list of roles. If present, the attributewill be rendered only if the current user belongs to one of the roles. @since 2.2.0
  • org.apache.tiles.template.DefinitionModel.start()
    Starts the operation. @param composeStack The compose stack, @param name The name of the definition to create. If not specified, an anonymous definition will be created. @param template The template of this definition. @param role A comma-separated list of roles. If present, the definitionwill be rendered only if the current user belongs to one of the roles. @param extendsParam The definition name that this definition extends. @param preparer The preparer to use to invoke before the definition is rendered. @since 2.2.0
  • org.apache.tiles.template.GetAsStringModel.start()
    Starts the operation. @param composeStack The compose stack, @param container The Tiles container to use. @param ignore If true, if an exception happens duringrendering, of if the attribute is null, the problem will be ignored. @param preparer The preparer to invoke before rendering the attribute. @param role A comma-separated list of roles. If present, the attributewill be rendered only if the current user belongs to one of the roles. @param defaultValue The default value of the attribute. To use only ifthe attribute was not computed. @param defaultValueRole The default comma-separated list of roles. To useonly if the attribute was not computed. @param defaultValueType The default type of the attribute. To use only ifthe attribute was not computed. @param name The name of the attribute. @param value The attribute to use immediately, if not null. @param requestItems The request objects. @since 2.2.0
  • org.apache.tiles.template.InsertAttributeModel.start()
    Starts the operation. @param composeStack The compose stack, @param container The Tiles container to use. @param ignore If true, if an exception happens duringrendering, of if the attribute is null, the problem will be ignored. @param preparer The preparer to invoke before rendering the attribute. @param role A comma-separated list of roles. If present, the attributewill be rendered only if the current user belongs to one of the roles. @param defaultValue The default value of the attribute. To use only ifthe attribute was not computed. @param defaultValueRole The default comma-separated list of roles. To useonly if the attribute was not computed. @param defaultValueType The default type of the attribute. To use only ifthe attribute was not computed. @param name The name of the attribute. @param value The attribute to use immediately, if not null. @param requestItems The request objects. @since 2.2.0
  • org.apache.tiles.template.InsertDefinitionModel.start()
    Starts the operation. @param container The Tiles container. @param requestItems The request objects. @since 2.2.0
  • org.apache.tiles.template.InsertTemplateModel.start()
    Starts the operation. @param container The Tiles container. @param requestItems The request objects. @since 2.2.0
  • org.apache.tiles.template.PutAttributeModel.start()
    Starts the operation. @param composeStack The compose stack. @since 2.2.0
  • org.apache.tiles.template.PutListAttributeModel.start()
    Starts the operation. @param composeStack The composing stack. @param role A comma-separated list of roles. If present, the attributewill be rendered only if the current user belongs to one of the roles. @param inherit If true the list contained in the in the sameattribute of the parent definition will be extended. @since 2.2.0
  • org.apache.tomcat.util.net.JIoEndpoint.Worker.start()
  • org.apache.tomcat.util.qlog.LogDaemon.start()
  • org.apache.tomee.embedded.Container.start()
  • org.apache.tools.ant.taskdefs.ExecuteStreamHandler.start()
    Start handling of the streams.
  • org.apache.tools.ant.taskdefs.ExecuteWatchdog.start()
    Watches the given process and terminates it, if it runs for too long. All information from the previous run are reset. @param process the process to monitor. It cannot be null @throws IllegalStateException if a process is still being monitored.
  • org.apache.tools.ant.taskdefs.LogStreamHandler.start()
  • org.apache.tools.ant.taskdefs.PumpStreamHandler.start()
  • org.apache.tools.ant.util.Watchdog.start()
  • org.apache.tools.ant.util.WorkerAnt.start()
  • org.apache.tuscany.binding.jsonrpc.mocks.tuscany.MockCompositeContextImpl.start()
  • org.apache.tuscany.binding.jsonrpc.mocks.tuscany.MockScopeContext.start()
  • org.apache.tuscany.core.builder.impl.AssemblyVisitorImpl.start()
    Initiate walking the object graph
  • org.apache.tuscany.core.client.TuscanyRuntime.start()
    Start the runtime and associate the module context with the calling thread.
  • org.apache.tuscany.core.component.scope.HttpSessionScopeContainer.start()
  • org.apache.tuscany.core.component.scope.ModuleScopeContainer.start()
  • org.apache.tuscany.core.component.scope.RequestScopeContainer.start()
  • org.apache.tuscany.core.component.scope.StatelessScopeContainer.start()
  • org.apache.tuscany.core.context.AtomicContext.start()
  • org.apache.tuscany.core.context.CompositeContext.start()
  • org.apache.tuscany.core.context.Context.start()
  • org.apache.tuscany.core.context.ScopeContext.start()
  • org.apache.tuscany.core.context.SystemCompositeContext.start()
  • org.apache.tuscany.core.context.impl.CompositeContextImpl.start()
  • org.apache.tuscany.core.context.scope.CompositeScopeContext.start()
  • org.apache.tuscany.core.context.scope.ModuleScopeContext.start()
  • org.apache.tuscany.core.context.scope.RequestScopeContext.start()
  • org.apache.tuscany.core.context.scope.SessionScopeContext.start()
  • org.apache.tuscany.core.context.scope.StatelessScopeContext.start()
  • org.apache.tuscany.core.implementation.composite.CompositeComponentImpl.start()
  • org.apache.tuscany.core.implementation.java.JavaAtomicComponent.start()
  • org.apache.tuscany.core.implementation.system.component.SystemAtomicComponentImpl.start()
  • org.apache.tuscany.core.runtime.RuntimeContext.start()
  • org.apache.tuscany.core.runtime.RuntimeContextImpl.start()
  • org.apache.tuscany.sca.Node.start()
    4599 10.5.2 add Deployment Composite & update Deployment Composite 4600 Adds or updates a deployment composite using a supplied composite ("composite by value" - a data 4601 structure, not an existing resource in the Domain) to the contribution identified by a supplied contribution 4602 URI. The added or updated deployment composite is given a relative URI that matches the @name 4603 attribute of the composite, with a ".composite" suffix. Since all composites run within the context of a 4604 installed contribution (any component implementations or other definitions are resolved within that 4605 contribution), this functionality makes it possible for the deployer to create a composite with final 4606 configuration and wiring decisions and add it to an installed contribution without having to modify the 4607 contents of the root contribution. 4608 Also, in some use cases, a contribution might include only implementation code (e.g. PHP scripts). It is 4609 then possible for those to be given component names by a (possibly generated) composite that is added 4610 into the installed contribution, without having to modify the packaging. * @param contributionURI the URI of the installed contribution to add the composite to @param compositeXML the composite to add to the contribution @return @throws XMLStreamException @throws ContributionReadException @throws ActivationException @throws ValidationException
  • org.apache.tuscany.sca.binding.notification.encoding.AbstractEnDeCoder.start()
  • org.apache.tuscany.sca.binding.notification.encoding.BrokerConsumerReferenceEnDeCoder.start()
  • org.apache.tuscany.sca.binding.notification.encoding.BrokerEnDeCoder.start()
  • org.apache.tuscany.sca.binding.notification.encoding.BrokerIDEnDeCoder.start()
  • org.apache.tuscany.sca.binding.notification.encoding.BrokerProducerReferenceEnDeCoder.start()
  • org.apache.tuscany.sca.binding.notification.encoding.BrokersEnDeCoder.start()
  • org.apache.tuscany.sca.binding.notification.encoding.ConnectionOverrideEnDeCoder.start()
  • org.apache.tuscany.sca.binding.notification.encoding.ConnectionOverrideResponseEnDeCoder.start()
  • org.apache.tuscany.sca.binding.notification.encoding.ConsumerReferenceEnDeCoder.start()
  • org.apache.tuscany.sca.binding.notification.encoding.EndConsumersEnDeCoder.start()
  • org.apache.tuscany.sca.binding.notification.encoding.EndProducersEnDeCoder.start()
  • org.apache.tuscany.sca.binding.notification.encoding.EndpointAddressEnDeCoder.start()
  • org.apache.tuscany.sca.binding.notification.encoding.EndpointReferenceEnDeCoder.start()
  • org.apache.tuscany.sca.binding.notification.encoding.NeighborBrokerConsumersEnDeCoder.start()
  • org.apache.tuscany.sca.binding.notification.encoding.NeighborsEnDeCoder.start()
  • org.apache.tuscany.sca.binding.notification.encoding.NewBrokerAckEnDeCoder.start()
  • org.apache.tuscany.sca.binding.notification.encoding.NewBrokerEnDeCoder.start()
  • org.apache.tuscany.sca.binding.notification.encoding.NewBrokerResponseEnDeCoder.start()
  • org.apache.tuscany.sca.binding.notification.encoding.NewConsumerEnDeCoder.start()
  • org.apache.tuscany.sca.binding.notification.encoding.NewConsumerResponseEnDeCoder.start()
  • org.apache.tuscany.sca.binding.notification.encoding.NewProducerEnDeCoder.start()
  • org.apache.tuscany.sca.binding.notification.encoding.NewProducerResponseEnDeCoder.start()
  • org.apache.tuscany.sca.binding.notification.encoding.ReferencePropertiesEnDeCoder.start()
  • org.apache.tuscany.sca.binding.notification.encoding.RemoveBrokerEnDeCoder.start()
  • org.apache.tuscany.sca.binding.notification.encoding.RemovedBrokerEnDeCoder.start()
  • org.apache.tuscany.sca.binding.notification.encoding.ReplaceBrokerConnectionEnDeCoder.start()
  • org.apache.tuscany.sca.binding.notification.encoding.SubscribeEnDeCoder.start()
  • org.apache.tuscany.sca.core.DefaultExtensionPointRegistry.start()
  • org.apache.tuscany.sca.core.ExtensionPointRegistry.start()
  • org.apache.tuscany.sca.core.assembly.CompositeActivator.start()
    Activate a component reference @param component @param ref
  • org.apache.tuscany.sca.core.context.InstanceWrapper.start()
    @throws TargetInitializationException
  • org.apache.tuscany.sca.core.factory.InstanceWrapper.start()
    @throws TargetInitializationException
  • org.apache.tuscany.sca.core.runtime.CompositeActivator.start()
    Start a composite @deprecated @param composite
  • org.apache.tuscany.sca.core.scope.ScopeContainer.start()
    Starts the Lifecycle.
  • org.apache.tuscany.sca.distributed.node.impl.EmbeddedNode.start()
  • org.apache.tuscany.sca.domain.SCADomain.start()
    Start all of the services in the domain.
  • org.apache.tuscany.sca.endpointresolver.EndpointResolver.start()
    This method will be invoked when the endpoint is activated. It gives the resolver the opportunity to do any set up ready for when it is asked to resolve the endpoint when a message arrives
  • org.apache.tuscany.sca.host.corba.jee.JEECorbaHost.start()
  • org.apache.tuscany.sca.host.corba.naming.TransientNameServer.start()
  • org.apache.tuscany.sca.host.embedded.impl.EmbeddedSCADomain.start()
  • org.apache.tuscany.sca.host.embedded.impl.ReallySmallRuntime.start()
  • org.apache.tuscany.sca.impl.NodeImpl.start()
  • org.apache.tuscany.sca.itest.conversational.Gamma.start()
  • org.apache.tuscany.sca.node.Node.start()
    Start the composite loaded in the node.
  • org.apache.tuscany.sca.node.NodeManagerService.start()
    Start the SCA node service.
  • org.apache.tuscany.sca.node.SCANode.start()
    Start all the deployed composites
  • org.apache.tuscany.sca.node.SCANode2.start()
    Start the composite loaded in the node.
  • org.apache.tuscany.sca.node.impl.NodeImpl.start()
  • org.apache.tuscany.sca.node.osgi.launcher.FelixOSGiHost.start()
  • org.apache.tuscany.sca.policy.transaction.runtime.geronimo.TransactionManagerWrapper.start()
  • org.apache.tuscany.sca.provider.ImplementationProvider.start()
    This method will be invoked when the component implementation is activated.
  • org.apache.tuscany.sca.provider.ReferenceBindingProvider.start()
    This method will be invoked when the component reference binding is activated.
  • org.apache.tuscany.sca.provider.ServiceBindingProvider.start()
    This method will be invoked when the component service binding is activated.
  • org.apache.tuscany.sca.registry.hazelcast.HazelcastDomainRegistry.start()
  • org.apache.tuscany.sca.scope.InstanceWrapper.start()
    @throws TargetInitializationException
  • org.apache.tuscany.spi.component.AtomicComponent.start()
  • org.apache.tuscany.spi.component.Component.start()
  • org.apache.tuscany.spi.component.CompositeComponent.start()
  • org.apache.tuscany.spi.component.ScopeContainer.start()
  • org.apache.tuscany.spi.component.Service.start()
  • org.apache.tuscany.spi.component.SystemAtomicComponent.start()
  • org.apache.twill.api.TwillPreparer.start()
    Starts the application. @return A {@link TwillController} for controlling the running application.
  • org.apache.twill.internal.ZKServiceDecorator.start()
  • org.apache.twill.internal.zookeeper.LeaderElection.start()
  • org.apache.uima.collection.impl.cpm.utils.ExpirationTimer.start()
  • org.apache.uima.ducc.rm.NodeStability.start()
  • org.apache.uima.internal.util.Timer.start()
    (Re)start the timer. If the timer has already been started, does nothing. @return false iff the timer is already running.
  • org.apache.uima.tools.util.gui.SwingWorker.start()
    Start the worker thread.
  • org.apache.vysper.xmpp.server.XMPPServer.start()
  • org.apache.webbeans.lifecycle.StandaloneLifeCycle.start()
  • org.apache.webbeans.spi.ContainerLifecycle.start()
    Starts container. It discovers all beans in the deployment archive.

    For Java EE artifact deployment, it scans all classes and libraries in the deployment archive. There are several types of deployment arhives;

    Container uses metadata discovery SPI for scanning archives and act accordingly. If there is an exception while starting, it must abort the deployment and provides information to the developer.

    @param startupObject any startup object. @throws Exception exception thrown by startup
  • org.apache.whirr.service.hadoop.HadoopProxy.start()
  • org.apache.wiki.rss.RSSThread.start()
  • org.apache.wiki.stress.Benchmark.start()
  • org.apache.xindice.xml.sax.SAXEventGenerator.start()
  • org.apache.xmlrpc.WebServer.start()
  • org.apache.xmlrpc.webserver.ServletWebServer.start()
  • org.apache.xmlrpc.webserver.WebServer.start()
    Spawns a new thread which binds this server to the port it's configured to accept connections on. @see #run() @throws IOException Binding the server socket failed.
  • org.apache.zookeeper.server.DatadirCleanupManager.start()
    Validates the purge configuration and schedules the purge task. Purge task keeps the most recent snapRetainCount number of snapshots and deletes the remaining for every purgeInterval hour(s).

    purgeInterval of 0 or negative integer will not schedule the purge task.

    @see PurgeTxnLog#purge(File,File,int)
  • org.apache.zookeeper.server.NIOServerCnxnFactory.start()
  • org.apache.zookeeper.server.quorum.QuorumPeer.start()
  • org.apache.zookeeper.server.quorum.QuorumPeerTestBase.MainThread.start()
  • org.archive.bdb.BdbModule.start()
  • org.archive.modules.fetcher.FetchHTTP.start()
  • org.archive.modules.writer.WARCWriterProcessor.start()
  • org.asciidoctor.maven.http.AsciidoctorHttpServer.start()
  • org.asmatron.messengine.engines.DefaultMessagingDelegate.start()
  • org.atmosphere.grizzly.AtmosphereSpadeServer.start()
    Start the {@link AtmosphereSpadeServer} @return @throws IOException
  • org.atmosphere.nettosphere.Nettosphere.start()
    Start the server
  • org.atomojo.app.WebComponent.start()
  • org.auraframework.impl.context.LoggingContextImpl.Timer.start()
  • org.axonframework.unitofwork.UnitOfWork.start()
    Starts the current unit of work, preparing it for aggregate registration. The UnitOfWork instance is registered with the CurrentUnitOfWork.
  • org.beangle.db.replication.impl.DatabaseReplicator.start()
  • org.bioinfo.ngs.qc.qualimap.gui.threads.BamAnalysisThread.start()
  • org.bioinfo.ngs.qc.qualimap.gui.threads.CountsQCAnalysisThread.start()
  • org.bioinfo.ngs.qc.qualimap.gui.threads.EpigeneticsAnalysisThread.start()
  • org.bioinfo.ngs.qc.qualimap.gui.threads.ExportHtmlThread.start()
  • org.bioinfo.ngs.qc.qualimap.gui.threads.ExportPdfThread.start()
  • org.bioinfo.ngs.qc.qualimap.gui.threads.MultisampleBamQcThread.start()
  • org.bioinfo.ngs.qc.qualimap.gui.threads.RNASeqQCAnalysisThread.start()
  • org.bitbucket.bradleysmithllc.java_cl_parser.regexp.EscapeFunctionExpression.start()
  • org.bndtools.api.IStartupParticipant.start()
  • org.boris.xlloop.util.FileSystemWatcher.start()
  • org.bric.processor.ImageProcessHandler.start()
  • org.broadinstitute.gatk.engine.walkers.Window.start()
  • org.broadinstitute.gatk.utils.SimpleTimer.start()
    Starts the timer running, and sets the elapsedTimeNano time to 0. This is equivalent to resetting the time to have no history at all. @return this object, for programming convenience
  • org.browsermob.proxy.ProxyServer.start()
  • org.browsermob.proxy.jetty.http.HttpServer.start()
  • org.burrokeet.servletEngine.Jetty.start()
  • org.burrokeet.servletEngine.Server.start()
  • org.camunda.bpm.container.impl.threading.ra.inflow.JobExecutionHandlerActivation.start()
  • org.camunda.bpm.engine.impl.jobexecutor.JobExecutor.start()
  • org.camunda.bpm.engine.impl.persistence.entity.ExecutionEntity.start()
  • org.camunda.bpm.engine.impl.pvm.PvmProcessInstance.start()
  • org.chromium.sdk.ConnectionLogger.start()
    Notifies logger that actual transmission is starting. After this {@link #handleEos()}is guaranteed to be called.
  • org.chromium.sdk.internal.transport.SocketConnection.start()
  • org.cipango.client.SipClient.start()
  • org.cipango.diameter.node.Node.start()
  • org.cipango.kaleo.location.LocationService.start()
  • org.cipango.kaleo.location.event.RegEventPackage.start()
  • org.cipango.kaleo.presence.PresenceEventPackage.start()
  • org.cipango.kaleo.presence.watcherinfo.WatcherInfoEventPackage.start()
  • org.cipango.kaleo.xcap.XcapService.start()
  • org.cipango.server.Server.start()
  • org.cipango.sipapp.SipAppContext.start()
  • org.cloudfoundry.caldecott.client.TunnelServer.start()
  • org.codehaus.activemq.ActiveMQConnectionFactory.start()
  • org.codehaus.activemq.broker.BrokerConnector.start()
  • org.codehaus.activemq.broker.BrokerContainer.start()
  • org.codehaus.activemq.broker.impl.BrokerConnectorImpl.start()
    start the Broker @throws JMSException
  • org.codehaus.activemq.broker.impl.BrokerContainerImpl.start()
    start the Container @throws JMSException
  • org.codehaus.activemq.broker.impl.DefaultBroker.start()
    Start this Service @throws JMSException
  • org.codehaus.activemq.service.MessageContainer.start()
  • org.codehaus.activemq.service.QueueMessageContainer.start()
    This container has just been loaded from disk and so it needs to be recovered, that is iterate through all the message IDs in the persistent store and add them to the in memory list of message IDs to be dispatched by consumers
  • org.codehaus.activemq.service.Service.start()
    Called to start the service @throws JMSException
  • org.codehaus.activemq.service.TopicMessageContainer.start()
  • org.codehaus.activemq.transport.NetworkConnector.start()
  • org.codehaus.activemq.transport.vm.VmTransportChannel.start()
  • org.codehaus.cargo.container.InstalledLocalContainer.start()
  • org.codehaus.plexus.DefaultPlexusContainer.start()
  • org.codehaus.plexus.PlexusContainer.start()
  • org.codehaus.plexus.compiler.util.StreamPumper.start()
  • org.codehaus.plexus.embed.ArtifactEnabledEmbedder.start()
  • org.codehaus.plexus.embed.Embedder.start()
  • org.codehaus.stomp.jms.StompConnect.start()
  • org.codehaus.wadi.servicespace.admin.AdminServiceSpace.start()
  • org.codehaus.xfire.server.http.XFireHttpServer.start()
  • org.codemap.util.StopWatch.start()
  • org.cometd.server.BayeuxServerImpl.start()
  • org.commoncrawl.async.EventLoop.start()
  • org.compass.gps.CompassGps.start()
  • org.compass.gps.impl.SingleCompassGps.start()
  • org.conserve.cache.ObjectRowMap.start()
    Start the thread purging old entries.
  • org.corrib.s3b.sscf.changelog.ChangeSender.start()
  • org.corrib.s3b.sscf.imports.BookmarksImport.start()
  • org.corrib.s3b.sscf.imports.FlickrBookmarksImport.start()
  • org.corrib.s3b.sscf.tools.IKHConnector.start()
  • org.corrib.s3b.sscf.trust.SSCFTrustEngineExecuter.start()
  • org.cybergarage.http.HTTPServerList.start()
  • org.cybergarage.upnp.Device.start()
  • org.cybergarage.upnp.control.RenewSubscriber.start()
  • org.cybergarage.upnp.device.Advertiser.start()
  • org.cybergarage.upnp.device.Disposer.start()
  • org.cybergarage.upnp.ssdp.SSDPNotifySocketList.start()
  • org.cybergarage.upnp.ssdp.SSDPSearchResponseSocketList.start()
  • org.cybergarage.upnp.ssdp.SSDPSearchSocketList.start()
  • org.cybergarage.upnp.std.av.player.MediaPlayer.start()
  • org.d_haven.event.command.CommandManager.start()
  • org.d_haven.event.command.DefaultCommandManager.start()
  • org.dbpedia2sql.stream.MergedInputStream.start()
  • org.dbwiki.data.io.XMLDocumentImportReader.start()
  • org.deftserver.io.IOLoop.start()
    Start the io loop. The thread that invokes this method will be blocked (until {@link IOLoop#stop} is invoked) and will be the io loop thread.
  • org.destecs.core.parsers.scenario.ScenarioParser.start()
  • org.destecs.core.parsers.sdp.SdpParser.start()
  • org.destecs.core.parsers.subs.SubsParser.start()
  • org.destecs.core.parsers.vdmlink.VdmLinkParser.start()
  • org.destecs.ide.core.internal.builder.SafeBuilder.start()
  • org.destecs.ide.debug.core.model.internal.AcaSimulationManager.start()
  • org.destecs.ide.debug.core.model.internal.CoSimulationThread.start()
  • org.directmemory.measures.Monitor.start()
  • org.drools.guvnor.client.moduleeditor.AssetViewerActivity.start()
  • org.drools.guvnor.client.util.Activity.start()
  • org.drools.guvnor.client.widgets.assetviewer.AssetViewerActivity.start()
  • org.drools.io.ResourceChangeScanner.start()
    Start the service, this creates a new Thread.
  • org.drools.persistence.Transaction.start()
  • org.drools.process.instance.ProcessInstance.start()
  • org.drools.ruleflow.instance.RuleFlowProcessInstance.start()
  • org.drools.ruleflow.instance.impl.RuleFlowProcessInstanceImpl.start()
  • org.drools.runtime.pipeline.Service.start()
  • org.earth3d.server.mapcreator.MapCreator.start()
  • org.easybatch.integration.quartz.EasyBatchScheduler.start()
    Start the scheduler. @throws EasyBatchSchedulerException thrown if the scheduler cannot be started
  • org.eclim.installer.step.command.Command.start()
  • org.eclim.installer.step.command.InfoCommand.start()
  • org.eclim.installer.step.command.InstallCommand.start()
  • org.eclim.installer.step.command.ListCommand.start()
  • org.eclim.installer.step.command.UninstallCommand.start()
  • org.eclim.plugin.jdt.command.debug.context.DebuggerContext.start()
  • org.eclipse.dltk.ast.references.VariableReference.start()
  • org.eclipse.egit.ui.internal.branch.BranchOperationUI.start()
    Starts the operation asynchronously
  • org.eclipse.egit.ui.internal.push.PushOperationUI.start()
    Starts the operation asynchronously showing a confirmation dialog after completion
  • org.eclipse.help.internal.browser.StreamConsumer.start()
  • org.eclipse.jetty.client.HttpClient.start()
  • org.eclipse.jetty.deploy.test.XmlConfiguredJetty.start()
  • org.eclipse.jetty.jmx.ConnectorServer.start()
  • org.eclipse.jetty.jmx.MBeanContainer.start()
  • org.eclipse.jetty.rhttp.gateway.GatewayServer.start()
  • org.eclipse.jetty.server.Connector.start()
  • org.eclipse.jetty.server.Server.start()
  • org.eclipse.jetty.server.ServerConnector.start()
  • org.eclipse.jetty.server.handler.ContextHandler.start()
  • org.eclipse.jetty.server.handler.HandlerWrapper.start()
  • org.eclipse.jetty.server.nio.SelectChannelConnector.start()
  • org.eclipse.jetty.server.session.AbstractTestServer.start()
  • org.eclipse.jetty.servlet.ServletContextHandler.start()
  • org.eclipse.jetty.servlet.ServletHolder.start()
  • org.eclipse.jetty.servlet.ServletTester.start()
  • org.eclipse.jetty.util.Scanner.start()
  • org.eclipse.jetty.util.component.LifeCycle.start()
    Starts the component. @throws Exception If the component fails to start @see #isStarted() @see #stop() @see #isFailed()
  • org.eclipse.jetty.util.ssl.SslContextFactory.start()
  • org.eclipse.jetty.util.thread.QueuedThreadPool.start()
  • org.eclipse.jetty.util.thread.ScheduledExecutorScheduler.start()
  • org.eclipse.jetty.util.thread.Scheduler.start()
  • org.eclipse.jetty.util.thread.TimerScheduler.start()
  • org.eclipse.jetty.webapp.WebAppContext.start()
  • org.eclipse.jetty.websocket.WebSocketClientFactory.start()
  • org.eclipse.jetty.websocket.client.WebSocketClient.start()
  • org.eclipse.jetty.websocket.common.WebSocketSession.start()
  • org.eclipse.jetty.websocket.common.extensions.ExtensionStack.start()
  • org.eclipse.jetty.websocket.common.io.LocalWebSocketSession.start()
  • org.eclipse.jetty.websocket.common.test.BlockheadServer.start()
  • org.eclipse.jgit.util.io.StreamCopyThread.start()
  • org.eclipse.nebula.widgets.nattable.conflation.EventConflaterChain.start()
  • org.eclipse.orion.internal.server.hosting.SiteHostingService.start()
  • org.eclipse.osgi.framework.debug.FrameworkDebugOptions.start()
  • org.eclipse.paho.client.mqttv3.internal.NetworkModule.start()
  • org.eclipse.paho.client.mqttv3.internal.TCPNetworkModule.start()
  • org.eclipse.php.internal.core.compiler.ast.nodes.Scalar.start()
  • org.eclipse.php.internal.ui.dnd.PHPViewerDropSupport.start()
  • org.eclipse.sapphire.modeling.docsys.internal.DocumentationContentParser.Start()
  • org.eclipse.sapphire.modeling.el.parser.internal.ExpressionLanguageParserImpl.Start()
  • org.eclipse.sapphire.modeling.xml.dtd.internal.DtdParserImpl.Start()
  • org.eclipse.test.performance.PerformanceMeter.start()
    Called immediately before the operation to measure. Must be followed by a call to {@link PerformanceMeter#stop()} before subsequent callsto this method or {@link PerformanceMeter#commit()}.
  • org.eclipse.wst.jsdt.debug.internal.rhino.debugger.RhinoDebuggerImpl.start()
  • org.eclipse.wst.server.core.IServer.start()
  • org.elasticsearch.common.StopWatch.start()
    Start an unnamed task. The results are undefined if {@link #stop()}or timing methods are called without invoking this method. @see #stop()
  • org.elasticsearch.discovery.zen.fd.MasterFaultDetection.start()
  • org.elasticsearch.hadoop.yarn.client.ClientRpc.start()
  • org.elasticsearch.index.engine.Engine.start()
    Starts the Engine.

    Note, after the creation and before the call to start, the store might be changed.

  • org.elasticsearch.index.engine.robin.RobinEngine.start()
  • org.elasticsearch.metrics.ElasticsearchReporter.start()
  • org.elasticsearch.node.Node.start()
    Start the node. If the node is already started, this method is no-op.
  • org.elasticsearch.node.internal.InternalNode.start()
  • org.elasticsearch.test.transport.MockTransportService.start()
  • org.emrys.webosgi.core.extension.IEarlyStarter.start()
    Start Extra process after the whole OSGi initialized, started and workspace opened.
  • org.emrys.webosgi.core.handlers.IFwkHandlerChain.start()
  • org.encog.util.Stopwatch.start()
    Start the stop watch.
  • org.enhydra.shark.api.client.wfmodel.WfProcess.start()
  • org.eurekaJ.agent.statisticReporter.StatisticReporter.start()
  • org.exist.debuggee.Debuggee.start()
  • org.exist.storage.btree.Value.start()
  • org.exist.validation.ValidationReport.start()
  • org.exolab.castor.xml.util.AnyNode2SAX.start()
  • org.exolab.jms.persistence.DatabaseService.start()
  • org.exoplatform.services.jcr.ext.backup.impl.BackupManagerImpl.start()
    {@inheritDoc}
  • org.exoplatform.services.jcr.impl.WorkspaceContainer.start()
  • org.exoplatform.services.jcr.impl.core.NamespaceDataPersister.start()
    {@inheritDoc}
  • org.exoplatform.services.jcr.impl.core.NamespaceRegistryImpl.start()
  • org.exoplatform.services.jcr.impl.core.lock.cacheable.AbstractCacheableLockManager.start()
    {@inheritDoc}
  • org.exoplatform.services.jcr.impl.core.nodetype.NodeTypeDataManagerImpl.start()
    @see org.picocontainer.Startable#start()
  • org.exoplatform.services.jcr.impl.core.nodetype.registration.JCRNodeTypeDataPersister.start()
  • org.exoplatform.services.jcr.impl.core.nodetype.registration.JcrNodeTypeDataPersister.start()
  • org.exoplatform.services.jcr.impl.core.nodetype.registration.NodeTypeDataPersister.start()
  • org.exoplatform.services.jcr.impl.dataflow.persistent.CacheableWorkspaceDataManager.start()
    @see org.picocontainer.Startable#start()
  • org.exoplatform.services.jcr.impl.dataflow.persistent.jbosscache.JBossCacheWorkspaceStorageCache.start()
    {@inheritDoc}
  • org.exoplatform.services.jcr.impl.storage.jdbc.JDBCWorkspaceDataContainer.start()
    {@inheritDoc}
  • org.exoplatform.services.jcr.load.blob.thread.CreateThread.start()
  • org.exoplatform.services.jcr.load.blob.thread.DeleteThread.start()
  • org.exoplatform.services.jcr.load.blob.thread.NtFileCreatorThread.start()
  • org.exoplatform.services.jcr.load.blob.thread.ReadThread.start()
  • org.exoplatform.services.rpc.jgv3.RPCServiceImpl.start()
  • org.fao.geonet.kernel.harvest.harvester.AbstractHarvester.start()
    Set harvester status to {@link Status#ACTIVE} and schedule the harvester to be ranat the next time according to the harvesters schedule. @return return {@link OperResult#ALREADY_ACTIVE} if the harvester is already active or {@link OperResult#OK} @throws SQLException @throws SchedulerException
  • org.fcrepo.client.SwingWorker.start()
    Start the worker thread.
  • org.fcrepo.client.messaging.JmsMessagingClient.start()
    Starts the MessagingClient. This method must be called in order to receive messages. Waits for completed connection.
  • org.fcrepo.client.messaging.MessagingClient.start()
    Starts the client, begins listening for messages
  • org.fcrepo.server.utilities.MethodInvokerThread.start()
  • org.firebirdsql.management.FBManager.start()
  • org.flexdock.dockbar.activation.ActivationQueue.start()
  • org.flexunit.ant.launcher.contexts.ExecutionContext.start()
    Starts the execution context and any work associated with the individual implementations. @throws IOException
  • org.fluentd.logger.util.MockFluentd.start()
  • org.foo.log.Activator.start()
    START LOG TEST
  • org.foray.xml.FOrayPretty.start()
    Intantiates parser and starts parsing of input. @throws IOException For I/O Errors. @throws SAXException For parsing errors. @throws ParserConfigurationException For errors configuring parser.
  • org.freeplane.main.application.SingleInstanceManager.start()
  • org.freeplane.plugin.workspace.features.AWorkspaceModeExtension.start()
  • org.fusesource.hawtdispatch.transport.TcpTransport.start()
  • org.fusesource.hawtdispatch.transport.Transport.start()
  • org.fusesource.ide.server.karaf.core.poller.PollThread.start()
  • org.fusesource.ide.server.karaf.ui.SshConnector.start()
    starts the ssh connection
  • org.g4studio.core.server.G4Server.start()
  • org.gatein.pc.test.TestPortletApplicationDeployer.start()
  • org.gdbms.engine.data.AlphanumericDataSource.start()
  • org.gdbms.engine.data.DataSource.start()
    Opens the DataSource to access the data it contains. If the data is accessed without a previous opening a ClosedDataSourceException is thrown. If this method is invoked twice then only the second call to stop will close the DataSource.
    If the DataSource was obtained with an AUTOMATIC_OPENING mode, there's no need to open the DataSource. Indeed start calls are ignored. It's possible to close the DataSource by a single call to the close method @throws DriverException if the operation fails
  • org.gdbms.engine.data.SpatialDataSource.start()
  • org.geoforge.lang.thread.GfrThr.start()
  • org.geoforge.plg3danimatedshapes.media.opengl.util.GfrFPSAnimatorPlgViewerVolShps3dAni.start()
  • org.geoserver.security.file.RoleFileWatcher.start()
  • org.geoserver.security.file.UserGroupFileWatcher.start()
  • org.gephi.partition.spi.TransformerBuilder.start()
  • org.gephi.visualization.selection.Rectangle.start()
  • org.getopt.luke.SlowThread.start()
  • org.getspout.spoutapi.io.CRCStore.URLCheck.start()
  • org.ggp.base.player.GamePlayer.start()
  • org.ggp.base.player.proxy.ProxyGamePlayer.start()
  • org.ggp.base.server.GameServer.start()
  • org.glassfish.embeddable.GlassFish.start()
    Start GlassFish. When this method is called, all the lifecycle (aka startup) services are started. Calling this method while the server is in {@link Status#STARTED} state is a no-op. @throws {@link IllegalStateException} if server is already started. @throws GlassFishException if server can't be started for some unknown reason.
  • org.glassfish.grizzly.http.server.HttpHandler.start()
    Called when the {@link HttpHandler}'s container is started by invoking {@link HttpServer#start}. By default, it does nothing.
  • org.glassfish.grizzly.http.server.HttpServer.start()

    Starts the HttpServer.

    @throws IOException if an error occurs while attempting to start theserver.
  • org.glassfish.grizzly.nio.transport.TCPNIOTransport.start()
  • org.glassfish.grizzly.threadpool.DefaultWorkerThread.start()
  • org.glassfish.grizzly.utils.DelayedExecutor.start()
  • org.glassfish.internal.embedded.Server.start()
    Starts the embedded server, opening ports, and running the startup services. @throws LifecycleException if the server cannot be started propertly
  • org.glassfish.jersey.client.oauth1.OAuth1AuthorizationFlow.start()
    Start the authorization process and return redirection URI on which the user should give a consent for our application to access resources.

    Note: the method makes a request to the Authorization Server in order to get request token.

    @return URI to which user should be redirected.
  • org.glassfish.jersey.client.oauth2.OAuth2CodeGrantFlow.start()
    Start the authorization process and return redirection URI on which the user should give a consent for our application to access resources. @return URI to which user should be redirected.
  • org.glassfish.jersey.test.spi.TestContainer.start()
    Start the container.
  • org.glassfish.tyrus.server.Server.start()
    Start the server.
  • org.glassfish.tyrus.server.TyrusServerContainer.start()
    Start container. @throws IOException when any IO related issues emerge during {@link org.glassfish.tyrus.spi.ServerContainer#start(String,int)}. @throws DeploymentException when any deployment related error is found; should contain list of all found issues.
  • org.glassfish.web.loader.WebappClassLoader.start()
    Start the class loader.
  • org.globus.workspace.service.InstanceResource.start()
  • org.gradle.api.internal.file.DirectoryWalker.start()
  • org.gradle.api.plugins.jetty.internal.Monitor.start()
  • org.gradle.foundation.ipc.basic.ProcessLauncherServer.start()
  • org.gradle.launcher.daemon.server.Daemon.start()
    Starts the daemon, receiving connections asynchronously (i.e. returns immediately). @throws IllegalStateException if this daemon is already running, or has already been stopped.
  • org.gradle.logging.LoggingManagerInternal.start()
  • org.gradle.logging.ProgressLogger.start()
    Convenience method that sets descriptions and logs started() event. @return this logger instance
  • org.gradle.process.internal.ExecHandle.start()
  • org.gradle.process.internal.WorkerProcess.start()
  • org.graphstream.ui.graphicGraph.stylesheet.parser.StyleSheetParser.start()
  • org.graylog2.restclient.lib.ApiClient.start()
  • org.gridgain.client.GridClientTestRestServer.start()
    Starts the server. @throws GridException If failed.
  • org.gridkit.coherence.util.classloader.Isolate.start()
  • org.grouplens.lenskit.util.io.LoggingStreamSlurper.start()
  • org.gudy.azureus2.core3.disk.impl.DiskManagerImpl.start()
  • org.gudy.azureus2.core3.tracker.host.TRHostTorrent.start()
  • org.gudy.azureus2.core3.util.AEThread.start()
  • org.gudy.azureus2.core3.util.AEThread2.start()
    multiple invocations of start() are possible, but discouraged if combined with other thread operations such as interrupt() or join()
  • org.gudy.azureus2.plugins.tracker.TrackerTorrent.start()
  • org.gudy.azureus2.plugins.update.UpdateCheckInstance.start()
  • org.gudy.azureus2.pluginsimpl.local.update.UpdateCheckInstanceImpl.start()
  • org.gwt.mosaic.core.client.util.regex.Matcher.start()
  • org.h2.tools.Server.start()
    Tries to start the server. @return the server if successful @throws SQLException if the server could not be started
  • org.helios.netty.examples.state.SimpleNIOServer.start()
    Starts this SimpleNIOServer instance
  • org.hibernate.cache.infinispan.InfinispanRegionFactory.start()
    {@inheritDoc}
  • org.hibernate.cache.infinispan.collection.CollectionRegionImpl.start()
  • org.hibernate.cache.infinispan.entity.EntityRegionImpl.start()
  • org.hibernate.cache.infinispan.query.QueryResultsRegionImpl.start()
  • org.hibernate.cache.infinispan.timestamp.TimestampsRegionImpl.start()
  • org.hibernate.cache.jbc.JBossCacheRegionFactory.start()
  • org.hibernate.cache.jbc2.JBossCacheRegionFactory.start()
  • org.hibernate.cache.spi.RegionFactory.start()
    Lifecycle callback to perform any necessary initialization of the underlying cache implementation(s). Called exactly once during the construction of a {@link org.hibernate.internal.SessionFactoryImpl}. @param settings The settings in effect. @param properties The defined cfg properties @throws org.hibernate.cache.CacheException Indicates problems starting the L2 cache impl;considered as a sign to stop {@link org.hibernate.SessionFactory}building.
  • org.hibernate.jmx.HibernateService.start()
  • org.hibernate.ogm.datastore.ehcache.impl.EhcacheDatastoreProvider.start()
  • org.hibernate.ogm.datastore.infinispan.impl.InfinispanDatastoreProvider.start()
  • org.hibernate.ogm.datastore.mongodb.impl.MongoDBDatastoreProvider.start()
  • org.hibernate.search.MassIndexer.start()
    Starts the indexing process in background (asynchronous). Can be called only once. @return a Future to control task canceling.get() will block until completion. cancel() is currently not implemented.
  • org.hibernate.tool.hbm2x.Exporter.start()
    Called when exporter should start generating its output
  • org.hibernate.tool.hbm2x.HibernateMappingExporter.start()
  • org.hibernate.tool.hbm2x.POJOExporter.start()
  • org.hibernate.tool.hbm2x.QueryExporter.start()
  • org.hive2hive.core.network.userprofiletask.UserProfileTask.start()
    Starts the execution of the user profile task
  • org.hive2hive.core.processes.framework.abstracts.ProcessComponent.start()
  • org.hive2hive.core.processes.framework.concretes.SequentialProcess.start()
  • org.hive2hive.core.processes.framework.decorators.AsyncComponent.start()
  • org.hive2hive.core.processes.framework.interfaces.IProcessComponent.start()
  • org.hive2hive.core.processes.implementations.common.GetMetaFileStep.start()
  • org.hive2hive.core.processes.util.FailingSequentialProcess.start()
  • org.hornetq.api.core.client.ClientSession.start()
    Starts the session. The session must be started before ClientConsumers created by the session can consume messages from the queue. @throws HornetQException if an exception occurs while starting the session
  • org.hornetq.api.core.management.AcceptorControl.start()
  • org.hornetq.api.core.management.BridgeControl.start()
  • org.hornetq.api.core.management.BroadcastGroupControl.start()
  • org.hornetq.api.core.management.ClusterConnectionControl.start()
  • org.hornetq.api.core.management.DiscoveryGroupControl.start()
  • org.hornetq.api.core.management.HornetQComponentControl.start()
    Starts this component.
  • org.hornetq.core.cluster.DiscoveryGroup.start()
  • org.hornetq.core.cluster.impl.DiscoveryGroupImpl.start()
  • org.hornetq.core.config.impl.FileConfiguration.start()
  • org.hornetq.core.deployers.impl.FileDeploymentManager.start()
  • org.hornetq.core.journal.Journal.start()
  • org.hornetq.core.journal.impl.JournalImpl.start()
  • org.hornetq.core.journal.impl.TimedBuffer.start()
  • org.hornetq.core.paging.PagingManager.start()
  • org.hornetq.core.paging.PagingStore.start()
  • org.hornetq.core.paging.impl.PagingManagerImpl.start()
  • org.hornetq.core.paging.impl.PagingStoreImpl.start()
  • org.hornetq.core.paging.impl.TestSupportPageStore.start()
  • org.hornetq.core.persistence.impl.journal.JournalStorageManager.start()
  • org.hornetq.core.remoting.impl.netty.NettyAcceptor.start()
  • org.hornetq.core.remoting.impl.netty.NettyConnector.start()
  • org.hornetq.core.replication.impl.ReplicationManagerImpl.start()
  • org.hornetq.core.server.HornetQServer.start()
  • org.hornetq.core.server.NodeManager.start()
  • org.hornetq.core.server.cluster.Bridge.start()
  • org.hornetq.core.server.cluster.BroadcastGroup.start()
  • org.hornetq.core.server.cluster.ClusterConnection.start()
  • org.hornetq.core.server.cluster.impl.BridgeImpl.start()
  • org.hornetq.core.server.cluster.impl.BroadcastGroupImpl.start()
  • org.hornetq.core.server.impl.FileLockNodeManager.start()
  • org.hornetq.core.server.impl.HornetQServerImpl.start()
  • org.hornetq.jms.bridge.impl.JMSBridgeImpl.start()
  • org.hornetq.jms.server.JMSServerManager.start()
  • org.hornetq.jms.server.embedded.EmbeddedJMS.start()
  • org.hornetq.jms.server.impl.JMSServerManagerImpl.start()
  • org.hornetq.ra.HornetQResourceAdapter.start()
    Start @param ctx The bootstrap context @throws ResourceAdapterInternalException Thrown if an error occurs
  • org.hornetq.ra.inflow.HornetQActivation.start()
    Start the activation @throws ResourceException Thrown if an error occurs
  • org.hornetq.rest.queue.push.PushConsumer.start()
  • org.hornetq.tests.integration.cluster.util.TestableServer.start()
  • org.hsqldb.Server.start()
    Starts this server synchronously.

    This method waits for current state to change from SERVER_STATE_OPENNING. In order to discover the success or failure of this operation, server state must be polled or a subclass of Server must be used that overrides the setState method to provide state change notification. @return the server state noted at entry to this method @jmx.managed-operation impact="ACTION_INFO" description="Invokes asynchronous startup sequence; returns previous state"

  • org.hsqldb.lib.StopWatch.start()
    Ensures that this object is in the running state. If this object is not running, then the call has the effect of setting the startTime attribute to the current value of System.currentTimeMillis() and setting the running attribute to true.
  • org.hsqldb.server.Server.start()
    Starts this server synchronously.

    This method waits for current state to change from SERVER_STATE_OPENNING. In order to discover the success or failure of this operation, server state must be polled or a subclass of Server must be used that overrides the setState method to provide state change notification. @return the server state noted at entry to this method @jmx.managed-operation impact="ACTION_INFO" description="Invokes asynchronous startup sequence; returns previous state"

  • org.huihoo.willow.startup.Embedded.start()
    Prepare for the beginning of active use of the public methods of this component. This method should be called after configure(), and before any of the public methods of the component are utilized. @exception LifecycleException if this component detects a fatal errorthat prevents this component from being used
  • org.huihoo.workflow.impl.monitor.EventMonitorThread.start()
  • org.huihoo.workflow.store.spi.SpiUserDatabase.start()
  • org.hyperic.sigar.CpuTimer.start()
  • org.hyperic.sigar.win32.Service.start()
  • org.identityconnectors.framework.server.ConnectorServer.start()
  • org.impalaframework.command.listener.StopCheckerListener.start()
  • org.impalaframework.interactive.command.listener.StopCheckerListener.start()
  • org.impalaframework.module.monitor.ScheduledModuleChangeMonitor.start()
    Starts the {@link ScheduledExecutorService}, settings off a task which periodically checks the monitorable resources and potentially initiates a module reload when necessary, by sending a {@link ModuleChangeEvent} to registered {@link ModuleContentChangeListener}s.
  • org.infernus.idea.checkstyle.checker.CheckFilesThread.start()
  • org.infernus.idea.checkstyle.checker.ScanFilesThread.start()
  • org.infinispan.AdvancedCache.start()
  • org.infinispan.Cache.start()
  • org.infinispan.eviction.impl.EvictionManagerImpl.start()
  • org.infinispan.loader.jdbc.connectionfactory.ConnectionFactory.start()
    Starts the connection factory. A pooled factory might be create connections here.
  • org.infinispan.loaders.CacheStore.start()
  • org.infinispan.loaders.decorators.AsyncStore.start()
  • org.infinispan.loaders.dummy.DummyInMemoryCacheStore.start()
  • org.infinispan.loaders.jdbc.TableManipulation.start()
  • org.infinispan.loaders.jdbc.binary.JdbcBinaryCacheStore.start()
  • org.infinispan.loaders.jdbc.connectionfactory.ConnectionFactory.start()
    Starts the connection factory. A pooled factory might be create connections here.
  • org.infinispan.loaders.jdbc.connectionfactory.PooledConnectionFactory.start()
  • org.infinispan.manager.CacheContainer.start()
  • org.infinispan.manager.CacheManager.start()
  • org.infinispan.manager.DefaultCacheManager.start()
  • org.infinispan.manager.EmbeddedCacheManager.start()
  • org.infinispan.marshall.VersionAwareMarshaller.start()
  • org.infinispan.marshall.core.ExternalizerTable.start()
  • org.infinispan.persistence.async.AdvancedAsyncCacheWriter.start()
  • org.infinispan.persistence.dummy.DummyInMemoryStore.start()
  • org.infinispan.persistence.jdbc.TableManipulation.start()
  • org.infinispan.persistence.jdbc.connectionfactory.ConnectionFactory.start()
    Starts the connection factory. A pooled factory might be create connections here.
  • org.infinispan.persistence.jdbc.connectionfactory.PooledConnectionFactory.start()
  • org.infinispan.persistence.spi.CacheLoader.start()
  • org.infinispan.persistence.spi.CacheWriter.start()
  • org.infinispan.remoting.ReplicationQueueImpl.start()
    Starts the asynchronous flush queue.
  • org.infinispan.server.hotrod.HotRodServer.start()
  • org.infoglue.deliver.util.CacheController.start()
  • org.infotechservice.smartcard.service.SmartCardServer.start()
    запускает сервер
  • org.infotechservice.smartcard.smartcard.NewSocialCardService.start()
  • org.infotechservice.smartcard.smartcard.OldSocialCardService.start()
  • org.intellij.erlang.parser.ErlangLexer.start()
  • org.intellij.grammar.parser.BnfLexer.start()
  • org.intellij.lang.regexp.RegExpLexer.start()
  • org.intellij.sonar.console.StreamGobbler.start()
  • org.iremake.client.network.ClientContext.start()
  • org.iremake.client.ui.UIDialog.start()
    Constructs the dialog and sets it visible. Content must be specified, otherwise nothing is done.
  • org.iremake.server.network.ServerContext.start()
  • org.italiangrid.utils.https.JettyRunThread.start()
  • org.jab.docsearch.threads.GuiThread.start()
    Start
  • org.jacorb.test.common.StreamListener.start()
  • org.jacorb.test.notification.StructuredPushReceiver.start()
  • org.jahia.services.content.JCRStoreProvider.start()
  • org.jahia.services.mail.MailService.start()
  • org.jakstab.ssl.parser.SSLParser.start()
  • org.jakstab.ssl.parser.SSLPreprocessor.start()
  • org.jamesii.core.distributed.simulationserver.SimulationClientThread.start()
  • org.jamesii.core.experiments.tasks.IComputationTask.start()
    Start the computation of the task, i.e., call the processor's run method.
  • org.jamesii.core.simulationrun.ISimulationRun.start()
  • org.jamesii.core.util.StopWatch.start()
    Calling this method corresponds with pressing the start button of this stopwatch. If the stopwatch is already running nothing happens and this method returns false. If the stopwatch is not running, then it is started and true is returned.
    You may restart the stopwatch again and again. As long as you don't reset the stop watch, the totally elapsed time increases. @return true, if start
  • org.jamesii.core.util.misc.exec.SimulationServerVMThread.start()
  • org.jamesii.gui.utils.animator.SwingAnimator.start()
  • org.jamesii.simspex.gui.PerfDBRecorder.start()
    Starts performance recorder.
  • org.jasig.portal.test.ThreadGroupRunner.start()
    Start all threads (start is in order of added runnable)
  • org.jatha.Jatha.start()
  • org.javasimon.Stopwatch.start()
    Starts this stopwatch. @return this stopwatch
  • org.javatari.atari.network.RemoteTransmitter.start()
  • org.jboss.aerogear.test.container.manager.JBossManager.start()
  • org.jboss.aesh.console.AeshConsole.start()
    Start the Console. Open stream and set the proper terminal settings.
  • org.jboss.aesh.console.Console.start()
  • org.jboss.annotation.factory.ast.AnnotationParser.Start()
  • org.jboss.aop.annotation.factory.duplicate.ast.AnnotationParser.Start()
  • org.jboss.aop.pointcut.ast.PointcutExpressionParser.Start()
  • org.jboss.aop.pointcut.ast.TypeExpressionParser.Start()
  • org.jboss.arquillian.ajocado.framework.AjaxSelenium.start()
  • org.jboss.arquillian.ajocado.framework.AjaxSeleniumImpl.start()
  • org.jboss.arquillian.container.spi.Container.start()
  • org.jboss.arquillian.core.spi.Manager.start()
  • org.jboss.arquillian.protocol.jmx.JMXConnectorServerExt.start()
  • org.jboss.arquillian.spi.DeployableContainer.start()
  • org.jboss.as.clustering.infinispan.DefaultEmbeddedCacheManager.start()
    {@inheritDoc} @see org.infinispan.lifecycle.Lifecycle#start()
  • org.jboss.as.console.client.shared.flow.TimeoutOperation.start()
    Executes a DMR operation and repeatedly calls {@code checker} until {@link #setConditionSatisfied(boolean)}was called with {@code true} or the timeout is reached. @param dispatcher the dispatcher @param operation the DMR operation which should be executed @param callback the final callback
  • org.jboss.as.console.client.shared.patching.StopServersOp.start()
  • org.jboss.as.domain.management.security.PropertiesFileLoader.start()
  • org.jboss.as.embedded.StandaloneServer.start()
  • org.jboss.as.process.protocol.ProtocolServer.start()
  • org.jboss.as.protocol.ProtocolServer.start()
  • org.jboss.as.protocol.old.ProtocolServer.start()
  • org.jboss.as.test.integration.domain.DomainTestSupport.start()
  • org.jboss.as.test.integration.domain.management.util.DomainLifecycleUtil.start()
  • org.jboss.as.test.integration.domain.mixed.util.MixedDomainTestSupport.start()
  • org.jboss.as.web.deployment.WebDeploymentService.ContextActivator.start()
  • org.jboss.as.web.host.WebDeploymentController.start()
  • org.jboss.bootstrap.NoInitServerImpl.start()
  • org.jboss.bootstrap.api.mc.server.MCServer.start()
  • org.jboss.bootstrap.spi.Server.start()
    Start the Server instance. @throws IllegalStateException Already started or not initialized. @throws Exception Failed to start.
  • org.jboss.byteman.tests.helpers.TestThread.start()
  • org.jboss.cache.Cache.start()
    Lifecycle method that starts the cache loader, starts cache replication, starts the region manager, etc., and (if configured) warms the cache using a state transfer or cache loader preload. @throws CacheException if there are startup problems
  • org.jboss.cache.CacheManagerImpl.start()
  • org.jboss.cache.CacheSPI.start()
  • org.jboss.cache.TreeCache.start()
  • org.jboss.cache.TreeCacheMBean.start()
  • org.jboss.cache.aop.PojoCache.start()
  • org.jboss.cache.factories.ComponentRegistry.start()
    This starts the components in the cache, connecting to channels, starting service threads, etc. If the cache is not in the {@link org.jboss.cache.CacheStatus#CREATED} state, {@link #create()} will be invoked first.
  • org.jboss.cache.jmx.CacheJmxWrapper.start()
  • org.jboss.cache.pojo.PojoCache.start()
    Lifecycle method to start PojoCache. @throws PojoCacheException
  • org.jboss.cache.pojo.jmx.PojoCacheJmxWrapper.start()
  • org.jboss.com.sun.net.httpserver.HttpServer.start()
    Starts this server in a new background thread. The background thread inherits the priority, thread group and context class loader of the caller.
  • org.jboss.com.sun.net.httpserver.HttpsServer.start()
  • org.jboss.dashboard.commons.misc.Chronometer.start()
    Start the timer.
  • org.jboss.deployers.spi.management.deploy.DeploymentManager.start()
    Start a previously distributed deployment. @param names the unique names of the deployments @return a DeploymentProgress used to run and track the start progress. @throws Exception for any error
  • org.jboss.deployers.vfs.spi.structure.modified.MetaDataStructureModificationChecker.start()
    Check filters.
  • org.jboss.dna.common.statistic.Stopwatch.start()
    Start the stopwatch and begin recording the statistics a new run. This method does nothing if the stopwatch is already {@link #isRunning() running} @see #isRunning()
  • org.jboss.dna.common.text.TokenStream.start()
    Begin the token stream, including (if required) the tokenization of the input content. @return this object for easy method chaining; never null @throws ParsingException if an error occurs during tokenization of the content
  • org.jboss.dna.graph.request.CompositeRequestChannel.start()
    Begins processing any requests that have been {@link #add(Request) added} to this channel. Processing is done by submittingthe channel to the supplied executor. @param executor the executor that is to do the work; may not be null @param context the execution context in which the work is to be performed; may not be null @param connectionFactory the connection factory that should be used to create connections; may not be null @throws IllegalStateException if this channel has already been started
  • org.jboss.dna.sequencer.ddl.DdlTokenStream.start()
  • org.jboss.ejb3.Ejb3Deployment.start()
  • org.jboss.ejb3.ProxyFactory.start()
  • org.jboss.ejb3.common.thread.RedirectProcessOutputToSystemOutThread.start()
  • org.jboss.ejb3.interceptors.test.ejbthree2080.StateMachineLocal.start()
  • org.jboss.ejb3.proxy.ProxyFactory.start()
    Lifecycle Start @throws Exception
  • org.jboss.ejb3.proxy.factory.RemoteProxyFactory.start()
  • org.jboss.ejb3.proxy.factory.session.SessionProxyFactory.start()
  • org.jboss.ejb3.proxy.factory.session.service.ServiceRemoteProxyFactory.start()
  • org.jboss.ejb3.proxy.factory.session.stateful.StatefulSessionProxyFactory.start()
  • org.jboss.ejb3.proxy.impl.factory.session.stateful.StatefulSessionLocalProxyFactory.start()
  • org.jboss.ejb3.proxy.impl.factory.session.stateful.StatefulSessionRemoteProxyFactory.start()
  • org.jboss.ejb3.proxy.impl.factory.session.stateless.StatelessSessionLocalProxyFactory.start()
  • org.jboss.ejb3.proxy.impl.factory.session.stateless.StatelessSessionRemoteProxyFactory.start()
  • org.jboss.ejb3.remoting.RemoteProxyFactory.start()
  • org.jboss.ejb3.test.cachepassivation.MockStatefulContainer.start()
  • org.jboss.embedded.api.server.JBossASEmbeddedServer.start()
  • org.jboss.errai.bus.server.io.websockets.WebSocketServer.start()
  • org.jboss.errai.cdi.server.gwt.JBossLauncher.start()
  • org.jboss.forge.container.addons.AddonRegistry.start()
    Start the given {@link AddonId} and all its dependencies, if possible. Return a {@link Future} which can be usedto wait while the {@link Addon} boot-up sequence is executed. Existing dependents for which this {@link AddonId}is an optional {@link AddonDependency} will be restarted.
  • org.jboss.forge.furnace.lifecycle.AddonLifecycleProvider.start()
    Start the given {@link Addon}.
  • org.jboss.fresh.events.net.EventNetRouter.start()
    This method takes the calling thread and uses it for receiving events from the client. Another thread is instanciated inside EventNetRouter that writes events from its eventlistener's buffer to output.
  • org.jboss.fresh.pool.pool.impl.PoolImpl.start()
  • org.jboss.gravia.runtime.Module.start()
    Starts this module.

    If this module's state is {@code UNINSTALLED} then an {@code IllegalStateException} is thrown.

    The following steps are required to start this module:

    1. If this module is in the process of being activated or deactivated then this method must wait for activation or deactivation to complete before continuing. If this does not occur in a reasonable time, a {@code ModuleException} is thrown to indicate this module was unable tobe started.
    2. If this module's state is {@code ACTIVE} then this method returns immediately.
    3. This module's state is set to {@code STARTING}.
    4. A module event of type {@link ModuleEvent#STARTING} is fired.
    5. The {@link ModuleActivator#start(ModuleContext)} method if one is specified, is called.If the {@code ModuleActivator} is invalid or throws an exception then:
      • This module's state is set to {@code STOPPING}.
      • A module event of type {@link ModuleEvent#STOPPING} is fired.
      • Any services registered by this module must be unregistered.
      • Any services used by this module must be released.
      • Any listeners registered by this module must be removed.
      • This module's state is set to {@code RESOLVED}.
      • A module event of type {@link ModuleEvent#STOPPED} is fired.
      • A {@code ModuleException} is then thrown.
    6. This module's state is set to {@code ACTIVE}.
    7. A module event of type {@link ModuleEvent#STARTED} is fired.
    @throws ModuleException If the module cannot be started
  • org.jboss.gravia.runtime.ModuleActivator.start()
    Called when this module is started so the Runtime can perform the module-specific activities necessary to start this module. This method can be used to register services or to allocate any resources that this module needs.

    This method must complete and return to its caller in a timely manner. @param context The execution context of the module being started. @throws Exception If this method throws an exception, this module ismarked as stopped and the Runtime will remove this module's listeners, unregister all services registered by this module, and release all services used by this module.

  • org.jboss.ha.cachemanager.CacheManager.start()
  • org.jboss.ha.core.framework.server.CoreGroupCommunicationService.start()
  • org.jboss.ha.framework.server.ClusterPartition.start()
  • org.jboss.ha.framework.server.JChannelFactory.start()
  • org.jboss.ha.framework.server.lock.SharedLocalYieldingClusterLockManager.start()
    Brings this object to a state where it is ready for normal operation. @throws Exception
  • org.jboss.identity.idm.api.Transaction.start()
    Begin new transaction
  • org.jboss.identity.idm.impl.api.session.SimpleTransactionImpl.start()
  • org.jboss.internal.soa.esb.registry.server.ESBInVMServerTransport.start()
    Start the background executor. @param numThreads The number of threads for the background executor.
  • org.jboss.jbossts.XTSService.start()
  • org.jboss.jbossts.qa.Utils.Setup.start()
  • org.jboss.jbossts.txbridge.inbound.InboundBridge.start()
  • org.jboss.jbossts.txbridge.inbound.InboundBridgeRecoveryManager.start()
  • org.jboss.jbossts.txbridge.outbound.OutboundBridge.start()
  • org.jboss.jbossts.txbridge.outbound.OutboundBridgeRecoveryManager.start()
  • org.jboss.jca.core.security.DefaultCallback.start()
    {@inheritDoc}
  • org.jboss.jca.core.security.UsersRoles.start()
    Start @exception Throwable Thrown if an error occurs
  • org.jboss.jms.client.JBossConnection.start()
  • org.jboss.jms.client.delegate.ClientConnectionDelegate.start()
  • org.jboss.jms.client.remoting.ConsolidatedRemotingConnectionListener.start()
  • org.jboss.jms.client.remoting.JMSRemotingConnection.start()
  • org.jboss.jms.delegate.ConnectionEndpoint.start()
  • org.jboss.jms.server.DestinationManager.start()
  • org.jboss.jms.server.bridge.Bridge.start()
  • org.jboss.jms.server.endpoint.ConnectionEndpoint.start()
  • org.jboss.jms.tx.MessagingXAResource.start()
  • org.jboss.marshalling.Marshaller.start()
    Begin marshalling to a stream. @param newOutput the new stream @throws IOException if an error occurs during setup, such as an error writing the header
  • org.jboss.marshalling.Unmarshaller.start()
    Begin unmarshalling from a stream. @param newInput the new stream @throws IOException if an error occurs during setup, such as an invalid header
  • org.jboss.messaging.core.contract.PostOffice.start()
  • org.jboss.messaging.core.impl.IDManager.start()
  • org.jboss.messaging.core.impl.JDBCPersistenceManager.start()
  • org.jboss.messaging.core.impl.postoffice.MessagingPostOffice.start()
  • org.jboss.messaging.core.impl.tx.TransactionRepository.start()
  • org.jboss.messaging.core.plugin.IDManager.start()
  • org.jboss.messaging.core.plugin.JDBCPersistenceManager.start()
  • org.jboss.messaging.core.plugin.contract.PersistenceManager.start()
  • org.jboss.messaging.core.plugin.postoffice.DefaultPostOffice.start()
  • org.jboss.messaging.core.plugin.postoffice.cluster.DefaultClusteredPostOffice.start()
  • org.jboss.messaging.core.tx.TransactionRepository.start()
  • org.jboss.modcluster.container.ContainerEventHandler.start()
  • org.jboss.monitor.StringThresholdMonitor.start()
  • org.jboss.monitor.ThresholdMonitor.start()
  • org.jboss.mx.remote.connector.soap.axis.AxisSOAPConnectorServer.start()
  • org.jboss.mx.remote.connector.socket.SocketConnector.start()
  • org.jboss.mx.remote.discovery.multicast.MulticastDetector.start()
  • org.jboss.mx.remote.server.CascadingAgent.start()
  • org.jboss.naming.JavaCompInitializer.start()
  • org.jboss.naming.NamingProviderURLWriter.start()
  • org.jboss.netty.util.HashedWheelTimer.start()
    Starts the background thread explicitly. The background thread will start automatically on demand even if you did not call this method. @throws IllegalStateException if this timer has been{@linkplain #stop() stopped} already
  • org.jboss.osgi.resolver.XBundle.start()
  • org.jboss.profileservice.deployment.hotdeploy.Scanner.start()
  • org.jboss.remoting.callback.CallbackPoller.start()
  • org.jboss.remoting.callback.CallbackStore.start()
    Will get the file path value (if not already set will just use the default setting) and will create the directory specified by the file path if it does not already exist. @throws Exception
  • org.jboss.remoting.detection.Detector.start()
    called by MBeanServer to start the mbean lifecycle @throws Exception
  • org.jboss.remoting.detection.jndi.JNDIDetector.start()
    Will establish the connection to the JNDI server and start detection of other servers. @throws Exception
  • org.jboss.remoting.detection.multicast.MulticastDetector.start()
    called by MBeanServer to start the mbean lifecycle @throws Exception
  • org.jboss.remoting.security.SSLServerSocketFactoryService.start()
    start the service, create is already called
  • org.jboss.remoting.security.SSLSocketFactoryService.start()
    start the service, create is already called
  • org.jboss.remoting.transport.Connector.start()
    Starts the connector. This is when configuration will be applied and server invoker created. @jmx.managed-operation description = "Start sets up the ServerInvoker we are wrapping."impact = "ACTION"
  • org.jboss.remoting.transport.socket.ServerThread.start()
  • org.jboss.resource.adapter.jms.inflow.JmsActivation.start()
    Start the activation @throws ResourceException for any error
  • org.jboss.resteasy.core.AsynchronousDispatcher.start()
  • org.jboss.resteasy.plugins.cache.server.JBossCache.start()
  • org.jboss.resteasy.plugins.server.tjws.TJWSEmbeddedJaxrsServer.start()
  • org.jboss.resteasy.spi.ResteasyDeployment.start()
  • org.jboss.seam.example.common.test.selenium.SeamSelenium.start()
  • org.jboss.security.auth.AuthenticationTimedCachePolicy.start()
  • org.jboss.security.plugins.JaasSecurityDomain.start()
  • org.jboss.services.binding.impl.PojoServiceBindingStore.start()
    Builds the runtime sets of bindings from the injected base bindings and ServiceBindingSets. @throws DuplicateServiceException @throws UnknownHostException
  • org.jboss.services.binding.managed.ServiceBindingManagementObject.start()
  • org.jboss.soa.esb.listeners.jca.EndpointFactory.start()
  • org.jboss.soa.esb.listeners.lifecycle.ManagedLifecycleController.start()
    Start the lifecyles for the managed instances.

    The managed instances will be left in the destroyed state if an error occurs. @throws ManagedLifecycleException For errors during the lifecycle start.

  • org.jboss.soa.esb.testutils.jbr.JBRServer.start()
  • org.jboss.system.Service.start()
    start the service, create is already called @throws Exception for any error
  • org.jboss.system.ServiceControllerMBean.start()
    Starts the indicated service @param serviceName Description of Parameter @throws Exception Description of Exception
  • org.jboss.system.server.profileservice.hotdeploy.HDScanner.start()
  • org.jboss.test.classinfo.support.ErrorHolderThread.start()
  • org.jboss.test.faces.FacesEnvironment.FacesRequest.start()
  • org.jboss.test.messaging.tools.container.LocalTestServer.start()
  • org.jboss.test.messaging.tools.container.Server.start()
  • org.jboss.test.messaging.tools.container.ServiceContainer.start()
  • org.jboss.test.messaging.tools.jmx.ServiceContainer.start()
    By default, starting the container DELETES ALL DATA previously existing in the database.
  • org.jboss.test.messaging.tools.jmx.rmi.Server.start()
  • org.jboss.test.thread.TestThread.start()
  • org.jboss.test.virtual.support.ps.hotdeploy.HDScanner.start()
  • org.jboss.util.CachePolicy.start()
  • org.jboss.util.TimedCachePolicy.start()
    Schedules this with the class resolutionTimer Timer object for execution every resolution seconds.
  • org.jboss.varia.property.PropertyEditorManagerService.start()
  • org.jboss.varia.scheduler.SingleScheduleProviderMBean.start()
  • org.jboss.virtual.plugins.cache.CombinedVFSCache.start()
  • org.jboss.virtual.plugins.cache.IterableTimedVFSCache.start()
  • org.jboss.virtual.plugins.cache.LRUVFSCache.start()
  • org.jboss.virtual.spi.cache.VFSCache.start()
    Start the cache. @throws Exception for any error
  • org.jboss.virtual.spi.cache.helpers.NoopVFSCache.start()
  • org.jboss.web.tomcat.service.session.JBossCacheManager.start()
    {@inheritDoc}
  • org.jboss.web.tomcat.service.session.persistent.DataSourcePersistentManager.start()
  • org.jboss.web.tomcat.service.sso.jbc.JBossCacheSSOClusterManager.start()
    Prepare for the beginning of active use of the public methods of this component. This method should be called before any of the public methods of this component are utilized. It should also send a LifecycleEvent of type START_EVENT to any registered listeners. @throws LifecycleException if this component detects a fatal errorthat prevents this component from being used
  • org.jboss.wsf.spi.WSFRuntime.start()
  • org.jboss.wsf.spi.deployment.DeploymentAspect.start()
  • org.jboss.wsf.spi.http.HttpServer.start()
    Start an instance of this HTTP server
  • org.jbox2d.testbed.framework.TestbedController.start()
  • org.jbpm.api.ProcessInstance.start()
  • org.jbpm.job.executor.JobExecutor.start()
  • org.jbpm.pvm.internal.client.ClientProcessInstance.start()
    starts this process instance
  • org.jbpm.pvm.internal.model.ExecutionImpl.start()
  • org.jbpm.ruleflow.instance.RuleFlowProcessInstance.start()
  • org.jbpm.task.service.TaskClient.start()
  • org.jbpm.taskinstance.CustomTaskInstance.start()
  • org.jbpm.taskmgmt.exe.TaskInstance.start()
    can optionally be used to indicate that the actor is starting to work on this task instance.
  • org.jbpm.ui.util.InfoPathSupport.start()
  • org.jclouds.virtualbox.functions.admin.PreseedCfgServer.start()
  • org.jdesktop.animation.timing.Animator.start()
    Starts the animation @throws IllegalStateException if animation is already running; thiscommand may only be run prior to starting the animation or after the animation has ended
  • org.jdesktop.core.animation.timing.Animator.start()
    Starts the animation. @throws IllegalStateException if animation is already running; this command may only be run prior to starting the animation or after the animation has ended.
  • org.jdesktop.wonderland.runner.RunManager.start()
    Start the given runner. @param runner the runner to start @param wait whether or not to wait for the runner to start @return the StatusWaiter that waits for this runner to start, ornull if wait is false @throws RunnerException if there is a problem starting the runner
  • org.jencks.JCAConnector.start()
  • org.jenkinsci.plugins.workflow.steps.Step.start()
    Start execution of something and report the end result back to the given callback. Arguments are passed when {@linkplain StepDescriptor#newInstance instantiating steps}. @return true if the execution of this step has synchronously completed before this method returns. It is the callee's responsibility to set the return value via {@link StepContext#onSuccess(Object)}or {@link StepContext#onFailure(Throwable)}. false if the asynchronous execution has started and that {@link StepContext}will be notified when the result comes in. (Note that the nature of asynchrony is such that it is possible for the {@link StepContext} to be already notified before this method returns.) @throws Exception if any exception is thrown, {@link Step} is assumed to have completed abnormally synchronously(as if {@link StepContext#onFailure(Throwable) is called and the method returned true.)}
  • org.jenkinsci.plugins.workflow.steps.StepExecution.start()
    Start execution of something and report the end result back to the given callback. Arguments are passed when {@linkplain StepDescriptor#newInstance(Map) instantiating steps}. @return true if the execution of this step has synchronously completed before this method returns. It is the callee's responsibility to set the return value via {@link StepContext#onSuccess(Object)}or {@link StepContext#onFailure(Throwable)}. false if the asynchronous execution has started and that {@link StepContext}will be notified when the result comes in. (Note that the nature of asynchrony is such that it is possible for the {@link StepContext} to be already notified before this method returns.) @throws Exception if any exception is thrown, {@link Step} is assumed to have completed abnormally synchronously(as if {@link StepContext#onFailure(Throwable) is called and the method returned true.)}
  • org.jetbrains.plugins.clojure.lexer.ClojureFlexLexer.start()
  • org.jetlang.fibers.Fiber.start()
  • org.jetlang.fibers.ThreadFiber.start()
  • org.jfree.layouting.LibLayoutBoot.start()
  • org.jfree.report.JFreeReportBoot.start()
  • org.jgroups.JChannelFactory.start()
  • org.jgroups.blocks.ConnectionTableNIO.start()
  • org.jgroups.blocks.PullPushAdapter.start()
  • org.jgroups.debug.Debugger.start()
  • org.jgroups.debug.ProtocolTester.start()
  • org.jgroups.protocols.DISCARD.start()
  • org.jgroups.protocols.MPING.start()
  • org.jgroups.stack.GossipRouter.start()
    Lifecycle operation. Called after create(). When this method is called, the managed attributes have already been set.
    Brings the Router into a fully functional state.
  • org.jgroups.stack.Protocol.start()
    This method is called on a {@link org.jgroups.Channel#connect(String)}. Starts work. Protocols are connected and queues are ready to receive events. Will be called from bottom to top. This call will replace the START and START_OK events. @exception Exception Thrown if protocol cannot be started successfully. This will cause the ProtocolStackto fail, so {@link org.jgroups.Channel#connect(String)} will throw an exception
  • org.jgroups.util.ReusableThread.start()
    Will always be called from synchronized method, no need to do our own synchronization
  • org.jgroups.util.Scheduler.start()
  • org.jitsi.service.neomedia.AudioMediaStream.start()
  • org.jitsi.service.neomedia.MediaStream.start()
    Starts capturing media from this stream's MediaDevice and then streaming it through the local StreamConnector toward the stream's target address and port. The method also puts the MediaStream in a listening state that would make it play all media received from the StreamConnector on the stream's MediaDevice.
  • org.jitterbit.application.ui.wizard.Wizard.start()
    Starts this wizard. This will display the first page of the wizard in the WizardDisplayer. @param appWin the ApplicationWizard from which the wizard is launched @throws IllegalStateException if this wizard does not have a displayer or a page chain
  • org.jitterbit.integration.client.database.DriverCacheRefresher.start()
  • org.jitterbit.integration.client.datalocation.connection.all.AllLocationsTester.start()
  • org.jitterbit.integration.client.deploy.DeployGate.start()
    Starts this DeployGate.
  • org.jitterbit.integration.client.ui.admin.util.AllScheduledOperationsRunner.start()
    Sends a request to the Jitterbit server to start all operations that are running on a schedule.

    This call is asynchronous - the call is made in a separate thread, and this method returns immediately.

  • org.jitterbit.integration.client.ui.interchange.entity.webservice.edit.wsdl.WsdlEditor.start()
  • org.jitterbit.integration.client.ui.project.copy.SelectiveDeepCopyUi.start()
  • org.jitterbit.integration.client.ui.structure.editor.text.SimpleStructureFileTemplateWizard.start()
  • org.jitterbit.integration.client.ui.structure.editor.xml.wizard.XmlStructureWizard.start()
  • org.jitterbit.integration.filetransfer.client.upload.FileUploader.start()
  • org.jivesoftware.smackx.bytestreams.socks5.Socks5Proxy.start()
    Starts the local SOCKS5 proxy server. If it is already running, this method does nothing.
  • org.jivesoftware.smackx.jingle.mediaimpl.jmf.AudioChannel.start()
    Starts the transmission. Returns null if transmission started ok. Otherwise it returns a string with the reason why the setup failed. Starts receive also. @return result description
  • org.jivesoftware.smackx.jingle.nat.TransportNegotiator.start()
  • org.jivesoftware.whack.ExternalComponent.start()
  • org.jledit.ConsoleEditor.start()
  • org.jmule.core.JMuleCore.start()
    Start the system
  • org.jmule.core.configmanager.ConfigurationManager.start()
  • org.jmule.core.ipfilter.IPFilter.start()
  • org.jmule.core.searchmanager.SearchManager.start()
  • org.jmule.core.servermanager.ServerManager.start()
  • org.jmule.core.sharingmanager.SharingManager.start()
  • org.jnode.driver.DeviceManager.start()
    Start a given device. The device must have been registered. This method blocks until the device has been started. @param device @throws DeviceNotFoundException The device has not been registered. @throws DriverException
  • org.jnode.plugin.Plugin.start()
    Start this plugin To invoke this method, a JNodePermission("startPlugin") is required. @throws PluginException
  • org.jnode.util.StopWatch.start()
  • org.jnp.server.Main.start()
  • org.jnp.server.NamingBeanImpl.start()
    @throws Exception
  • org.jostraca.WriterFormatParser.start()
  • org.jpacman.framework.ui.IPacmanInteraction.start()
    Start the game.
  • org.jpacman.framework.ui.MainUI.start()
    Actually start the the controllers, and show the UI.
  • org.jpedal.utils.SwingWorker.start()
    Start the worker thread.
  • org.jpos.q2.Q2.start()
  • org.jregex.MatchResult.start()
  • org.jresearch.gossip.scheduler.Scheduler.start()
    @see org.quartz.Scheduler#start()
  • org.jruby.compiler.impl.SkinnyMethodAdapter.start()
  • org.jtestserver.server.TestServer.start()
  • org.jwall.web.audit.AuditEventDispatcher.start()
  • org.jwall.web.audit.io.InputHandler.start()
  • org.jwall.web.audit.net.NetworkEventServer.start()
  • org.kapott.hbci.manager.FlickerRenderer.start()
    eigenen Code zum Rendern einbauen } public void done(int iterations) { // Nach 20 Uebertragungen hoeren wir auf. if (iterations > 20) stop(); } }; renderer.start(); renderer.waitFor(); System.out.println("Code uebertragen");
  • org.keycloak.services.managers.BruteForceProtector.start()
  • org.kie.api.builder.KieScanner.start()
  • org.kie.api.task.TaskService.start()
  • org.kiji.schema.zookeeper.TableLayoutTracker.start()
    Start this table layout tracker. Asynchronously updates the handler with the initial layout. @return this. @throws IOException on unrecoverable ZooKeeper error.
  • org.kiji.schema.zookeeper.UsersTracker.start()
    Starts the tracker. Will block until the users list is initialized. When the block is initialized all handlers will be invoked in another thread. @throws IOException on unrecoverable ZooKeeper error. @return this.
  • org.kitesdk.minicluster.MiniCluster.start()
    Starts the services in order, passing the previous service's modified Configuration object to the next. @throws IOException
  • org.knapper.core.roles.ISpGameSession.start()
  • org.kohsuke.stapler.jetty.JettyRunner.start()
  • org.latexlab.clsi.client.local.ClsiLocalEngine.start()
    Starts the Java applet component of this widget.
  • org.lealone.hbase.server.HBasePgServer.start()
  • org.lealone.hbase.server.HBaseTcpServer.start()
  • org.lestr.astenn.cxf.SOAPServer.start()
  • org.lightview.service.EscalationProvider.start()
  • org.lilypondbeans.jccparser.test.ListAll.start()
  • org.lilyproject.lilyservertestfw.LilyProxy.start()
  • org.lilyproject.runtime.LilyRuntime.start()
    Starts the Lily Runtime. This will launch all modules (i.e. their Spring containers), and set up the restservices.

    A LilyRuntime instance can only be started once, even after it has been stopped. Just create a new LilyRuntime instance with the same LilyRuntimeConfig if you want to (re)start another instance.

  • org.lilyproject.runtime.module.ModuleImpl.start()
  • org.lilyproject.solrtestfw.SolrProxy.start()
  • org.linkedin.util.concurrent.ExternalCommand.start()
    After creating the command, you have to start it... @throws IOException
  • org.littleshoot.proxy.DefaultHttpProxyServer.start()
  • org.littleshoot.proxy.HttpProxyServer.start()
  • org.locationtech.udig.project.render.ILabelPainter.start()
  • org.mcstats.Metrics.start()
  • org.milyn.smooks.camel.dataformat.SmooksDataFormat.start()
  • org.mindswap.pellet.utils.Timer.start()
    Start time timer by recording the time this function is called. If timer is running when this function is called time is not recorded and only an internal counter is updated.
  • org.mizartools.system.executable.MakeEnvironment.start()
  • org.mizartools.system.executable.Verifier.start()
  • org.mizartools.utility.ProcessManager.start()
  • org.mockserver.mockserver.MockServer.start()
    Start the instance using the ports provided @param port the http port to use @param securePort the secure https port to use
  • org.modeshape.common.statistic.Stopwatch.start()
    Start the stopwatch and begin recording the statistics a new run. This method does nothing if the stopwatch is already {@link #isRunning() running} @see #isRunning()
  • org.modeshape.common.text.TokenStream.start()
    Begin the token stream, including (if required) the tokenization of the input content. @return this object for easy method chaining; never null @throws ParsingException if an error occurs during tokenization of the content
  • org.modeshape.jcr.JcrEngine.start()
  • org.modeshape.jcr.ModeShapeEngine.start()
    Start this engine to make it available for use. This method does nothing if the engine is already running. @see #shutdown()
  • org.modeshape.sequencer.ddl.DdlTokenStream.start()
  • org.mokai.ConnectorService.start()
  • org.mokai.impl.camel.AbstractCamelConnectorService.start()
    Starts consuming messages from the queue (returned by {@link AbstractCamelConnectorService#getQueueUri()}method) and builds the Apache Camel routes to process and receive messages from the {@link Processor}. If the {@link Processor} implements {@link Serviceable}, it will call the {@link Serviceable#doStart()}method.
  • org.mokai.impl.camel.CamelRoutingEngine.start()
  • org.mom4j.messaging.MessagingServer.start()
  • org.mortbay.component.LifeCycle.start()
    Starts the component. @throws Exception If the component fails to start @see #isStarted() @see #stop() @see #isFailed()
  • org.mortbay.http.HttpContext.start()
  • org.mortbay.http.HttpListener.start()
  • org.mortbay.http.HttpServer.start()
  • org.mortbay.http.ResourceCache.start()
  • org.mortbay.jetty.AbstractBuffers.start()
  • org.mortbay.jetty.Connector.start()
  • org.mortbay.jetty.LocalConnector.start()
  • org.mortbay.jetty.Server.start()
  • org.mortbay.jetty.ant.utils.ServerProxy.start()
    Starts this server.
  • org.mortbay.jetty.client.HttpClient.start()
  • org.mortbay.jetty.deployer.WebAppDeployer.start()
  • org.mortbay.jetty.handler.ContextHandler.start()
  • org.mortbay.jetty.handler.HandlerCollection.start()
  • org.mortbay.jetty.nio.SelectChannelConnector.start()
  • org.mortbay.jetty.servlet.Context.start()
  • org.mortbay.jetty.servlet.ServletHttpContext.start()
  • org.mortbay.jetty.testing.ServletTester.start()
  • org.mortbay.jetty.webapp.WebAppContext.start()
  • org.mortbay.log.OutputStreamLogSink.start()
  • org.mortbay.management.MBeanContainer.start()
  • org.mortbay.thread.QueuedThreadPool.start()
  • org.mortbay.util.Scanner.start()
    Start the scanning action.
  • org.movsim.viewer.graphics.TrafficCanvas.start()
  • org.moyrax.reporting.TestCase.start()
    Starts the test execution and sets the reference time used to calculate how long was the execution. @param startTimestamp Start time reference. It must be greater than 0.
  • org.mt4j.util.animation.Animation.start()
    Start.
  • org.mule.MuleServer.start()
    Start the mule server @param ownThread determines if the server will run in its own daemon thread orthe current calling thread @param registerShutdownHook whether to register the default Mule Server shutdown hock. this will shut down mule cleanly ifthe JVM is shutdown. The only reason not to register this hook is to override it with a custom version
  • org.mule.api.MuleContext.start()
  • org.mule.api.component.LifecycleAdapter.start()
  • org.mule.api.context.WorkManager.start()
  • org.mule.api.schedule.Scheduler.start()
  • org.mule.api.service.Service.start()
  • org.mule.api.transport.Connector.start()
  • org.mule.api.transport.MessageDispatcher.start()
  • org.mule.api.transport.MessageReceiver.start()
  • org.mule.api.transport.MessageRequester.start()
  • org.mule.construct.AbstractFlowConstruct.start()
  • org.mule.construct.Flow.start()
  • org.mule.jbi.framework.JbiContainerImpl.start()
  • org.mule.jbi.management.AutoInstallService.start()
  • org.mule.module.management.agent.RmiRegistryAgent.start()
  • org.mule.processor.AsyncInterceptingMessageProcessor.start()
  • org.mule.registry.Assembly.start()
  • org.mule.tck.functional.AssertionMessageProcessor.start()
  • org.mule.tck.testmodels.mule.TestConnector.start()
  • org.mule.test.infrastructure.deployment.FakeMuleServer.start()
  • org.mule.transport.AbstractConnector.start()
  • org.mule.util.queue.TransactionalQueueManager.start()
  • org.mule.util.timer.EventTimerTask.start()
  • org.mule.work.MuleWorkManager.start()
  • org.nanocontainer.deployer.FolderContentPoller.start()
  • org.nasutekds.admin.ads.util.ServerLoader.start()
  • org.nasutekds.server.replication.plugin.LDAPReplicationDomain.start()
    Starts the Replication Domain.
  • org.nasutekds.server.replication.service.ReplicationBroker.start()
    Start the ReplicationBroker.
  • org.nasutekds.server.util.cli.PointAdder.start()
    Starts the PointAdder: points are added at the end of the logs periodically.
  • org.nbgit.GitProgressSupport.start()
  • org.nbgit.task.StatusTask.start()
  • org.neo4j.server.NeoServer.start()
  • org.neo4j.server.WrappingNeoServer.start()
  • org.neo4j.server.WrappingNeoServerBootstrapper.start()
  • org.neo4j.smack.Neo4jServer.start()
  • org.neo4j.smack.pipeline.database.DatabaseWorkPipeline.start()
  • org.netbeans.api.progress.ProgressHandle.start()
  • org.netbeans.jemmy.Timeout.start()
    Starts timeout measuring.
  • org.newdawn.slick.AppGameContainer.start()
    Start running the game @throws SlickException Indicates a failure to initialise the system
  • org.newdawn.slick.CanvasGameContainer.start()
    Start the game container rendering @throws SlickException Indicates a failure during game execution
  • org.noos.xing.mydoggy.examples.mydoggyset.ui.MonitorPanel.start()
  • org.noos.xing.mydoggy.mydoggyset.MyDoggySet.start()
  • org.noos.xing.mydoggy.mydoggyset.ui.MonitorPanel.start()
  • org.nustaq.net.TCPObjectServer.start()
  • org.nutz.lang.Stopwatch.start()
  • org.nutz.repo.gif.AnimatedGifEncoder.start()
    Initiates GIF file creation on the given stream. The stream is not closed automatically. @param os OutputStream on which GIF images are written. @return false if initial write failed.
  • org.objectweb.joram.client.connector.JoramAdapter.start()
    Initializes the adapter; starts, if needed, a collocated JORAM server, and if needed again, administers it. @exception ResourceAdapterInternalException If the adapter could not beinitialized.
  • org.objectweb.joram.client.connector.OutboundConnection.start()
    Delegates the call to the wrapped JMS connection. @exception javax.jms.IllegalStateException If the handle is invalid. @exception javax.jms.JMSException Generic exception.
  • org.ofbiz.base.concurrent.DependencyPool.start()
  • org.ofbiz.base.util.DateRange.start()
    Returns the starting date of this range. @return Range starting date
  • org.olat.ims.qti.container.ItemContext.start()
    Method start.
  • org.olat.ims.qti.container.SectionContext.start()
    Start duration counters.
  • org.one.stone.soup.server.http.HttpServer.start()
  • org.onebusaway.container.stop.StopButtonService.start()
  • org.ontoware.jrest.RestServer.start()
  • org.openengsb.core.common.internal.Activator.start()
  • org.openengsb.itests.remoteclient.SecureSampleConnector.start()
  • org.openhab.binding.insteonhub.internal.hardware.InsteonHubProxy.start()
    Connect and start any internal threads
  • org.openhab.binding.insteonplm.internal.device.ModemDBBuilder.start()
  • org.openhab.core.scriptengine.ScriptExecutionThread.start()
  • org.openide.compiler.CompilerJob.start()
  • org.openinvoice.ubl4j.ui.console.UBL4JConsole.start()
  • org.openntf.domino.thread.DominoThread.start()
  • org.openoffice.gdocs.util.Downloader.start()
  • org.openpnp.spi.JobProcessor.start()
    Start the Job. The Job must be in the Stopped state.
  • org.openqa.grid.web.Hub.start()
  • org.openqa.jetty.http.HttpContext.start()
  • org.openqa.jetty.http.HttpHandler.start()
  • org.openqa.jetty.http.HttpListener.start()
  • org.openqa.jetty.http.HttpServer.start()
  • org.openqa.jetty.jetty.Server.start()
  • org.openqa.selenium.chrome.ChromeDriverService.start()
  • org.openqa.selenium.server.SeleniumServer.start()
    Starts the Jetty server @throws Exception on error.
  • org.openqa.selenium.testworker.TrackableThread.start()
  • org.openquark.util.ui.SwingWorker.start()
    Start the worker thread.
  • org.openstreetmap.josm.tools.XmlObjectParser.start()
  • org.openstreetmap.osmosis.core.pipeline.common.TaskRunner.start()
  • org.openstreetmap.osmosis.replicationhttp.v0_6.impl.SequenceServer.start()
    Starts the server. @param initialSequenceNumber The initial sequence number.
  • org.opoo.press.support.Preview.start()
  • org.ops4j.pax.exam.TestContainer.start()
    Starts the test container. @return this for fluent api @throws TimeoutException - if timeout occured and the test container cannot be started
  • org.ops4j.pax.exam.nat.internal.NativeTestContainer.start()
  • org.ops4j.pax.swissbox.framework.RemoteFramework.start()
  • org.osgi.framework.Bundle.start()
    Starts this bundle.

    If this bundle's state is UNINSTALLED then an IllegalStateException is thrown.

    If the Framework implements the optional Start Level service and the current start level is less than this bundle's start level:

    When the Framework's current start level becomes equal to or more than this bundle's start level, this bundle will be started.

    Otherwise, the following steps are required to start this bundle:

    1. If this bundle is in the process of being activated or deactivated then this method must wait for activation or deactivation to complete before continuing. If this does not occur in a reasonable time, a BundleException is thrown to indicate this bundle was unable to be started.
    2. If this bundle's state is ACTIVE then this method returns immediately.
    3. If the {@link #START_TRANSIENT} option is not set then set thisbundle's autostart setting to Started with declared activation if the {@link #START_ACTIVATION_POLICY} option is set orStarted with eager activation if not set. When the Framework is restarted and this bundle's autostart setting is not Stopped, this bundle must be automatically started.
    4. If this bundle's state is not RESOLVED, an attempt is made to resolve this bundle. If the Framework cannot resolve this bundle, a BundleException is thrown.
    5. If the {@link #START_ACTIVATION_POLICY} option is set and thisbundle's declared activation policy is {@link Constants#ACTIVATION_LAZY lazy} then:
      • If this bundle's state is STARTING then this method returns immediately.
      • This bundle's state is set to STARTING.
      • A bundle event of type {@link BundleEvent#LAZY_ACTIVATION} is fired.
      • This method returns immediately and the remaining steps will be followed when this bundle's activation is later triggered.
    6. This bundle's state is set to STARTING.
    7. A bundle event of type {@link BundleEvent#STARTING} is fired.
    8. The {@link BundleActivator#start} method of this bundle'sBundleActivator, if one is specified, is called. If the BundleActivator is invalid or throws an exception then:
      • This bundle's state is set to STOPPING.
      • A bundle event of type {@link BundleEvent#STOPPING} is fired.
      • Any services registered by this bundle must be unregistered.
      • Any services used by this bundle must be released.
      • Any listeners registered by this bundle must be removed.
      • This bundle's state is set to RESOLVED.
      • A bundle event of type {@link BundleEvent#STOPPED} is fired.
      • A BundleException is then thrown.
    9. If this bundle's state is UNINSTALLED, because this bundle was uninstalled while the BundleActivator.start method was running, a BundleException is thrown.
    10. This bundle's state is set to ACTIVE.
    11. A bundle event of type {@link BundleEvent#STARTED} is fired.
    Preconditions Postconditions, no exceptions thrown Postconditions, when an exception is thrown @param options The options for starting this bundle. See{@link #START_TRANSIENT} and {@link #START_ACTIVATION_POLICY}. The Framework must ignore unrecognized options. @throws BundleException If this bundle could not be started. This couldbe because a code dependency could not be resolved or the specified BundleActivator could not be loaded or threw an exception or this bundle is a fragment. @throws IllegalStateException If this bundle has been uninstalled or thisbundle tries to change its own state. @throws SecurityException If the caller does not have the appropriateAdminPermission[this,EXECUTE], and the Java Runtime Environment supports permissions. @since 1.4
  • org.osgi.framework.BundleActivator.start()
    Starts a bundle
  • org.osgi.framework.launch.Framework.start()
    Start this Framework.

    The following steps are taken to start this Framework:

    1. If this Framework is not in the {@link #STARTING} state,{@link #init() initialize} this Framework.
    2. All installed bundles must be started in accordance with each bundle's persistent autostart setting. This means some bundles will not be started, some will be started with eager activation and some will be started with their declared activation policy. The start level of this Framework is moved to the start level specified by the {@link Constants#FRAMEWORK_BEGINNING_STARTLEVEL beginning startlevel} framework property, as described in the Start LevelSpecification. If this framework property is not specified, then the start level of this Framework is moved to start level one (1). Any exceptions that occur during bundle starting must be wrapped in a {@link BundleException} and then published as a framework event of type{@link FrameworkEvent#ERROR}
    3. This Framework's state is set to {@link #ACTIVE}.
    4. A framework event of type {@link FrameworkEvent#STARTED} is fired
    @throws BundleException If this Framework could not be started. @throws SecurityException If the caller does not have the appropriate{@code AdminPermission[this,EXECUTE]}, and the Java Runtime Environment supports permissions. @see "Start Level Specification"
  • org.osgi.service.framework.CompositeBundle.start()
  • org.osoa.sca.SCA.start()
    Start the SCA implementation. If this method completes successfully then a module context will be associated with the current thread.
  • org.ow2.easybeans.api.EZBContainer.start()
    Start method.
    This method is called after the init method. @throws EZBComponentException if the start has failed.
  • org.ow2.easybeans.component.api.EZBComponent.start()
    Start method.
    This method is called after the init method. @throws EZBComponentException if the start has failed.
  • org.ow2.easybeans.mavenplugin.server.EasyBeansPluginServer.start()
    Launch the server. @param persistenceListener The listener which is called before the deployment, or null
  • org.ow2.util.event.api.IEventDispatcher.start()
    Start method.
    This method is called after the init method. @throws EZBComponentException if the start has failed.
  • org.owasp.jbrofuzz.ui.AbstractPanel.start()

    Method describing what action a particular panel can start.

    @author subere@uncon.org @version 1.3 @since 1.2
  • org.owasp.webscarab.util.swing.SwingWorker.start()
    Start the worker thread.
  • org.papoose.core.Papoose.start()
  • org.papoose.event.EventAdminImpl.start()
  • org.papoose.http.HttpServer.start()
  • org.papoose.http.HttpServiceImpl.start()
  • org.papoose.log.LogServiceImpl.start()
    Start this logging service.
  • org.pentaho.di.job.Job.start()
  • org.pentaho.platform.api.scheduler2.IScheduler.start()
    Allows the scheduler to process scheduled jobs. Note that the "paused" state of individual jobs is not changed by this call.
  • org.pentaho.platform.engine.core.system.boot.PentahoSystemBoot.start()
    Starts the Pentaho platform, making it ready to process requests. @throws PlatformInitializationException if there was a problem initializing the platform
  • org.pentaho.platform.plugin.boot.PentahoBoot.start()
  • org.pentaho.platform.web.hsqldb.HsqlDatabaseStarterBean.start()
    Starts hsqldb databases. @return true if the server was started properly.
  • org.pentaho.reporting.libraries.base.boot.AbstractBoot.start()
    Starts the boot process. The boot process is synchronized and will block if parallel booting is not finished yet. Any failure in booting will set the bootFailed property to true. If booting is finished, the bootDone property is set to true.
  • org.pentaho.reporting.libraries.base.util.PerformanceLoggingStopWatch.start()
  • org.pentaho.reporting.libraries.base.util.StopWatch.start()
  • org.pentaho.test.platform.engine.core.MicroPlatform.start()
  • org.pentaho.ui.xul.XulRunner.start()
  • org.pentaho.ui.xul.swing.SwingXulRunner.start()
  • org.perf4j.StopWatch.start()
    Starts this StopWatch, which sets its startTime property to the current time and resets the elapsedTime property. For single-use StopWatch instance you should not need to call this method as a StopWatch is automatically started when it is created. Note any existing tag and message are not changed.
  • org.picketlink.identity.federation.bindings.tomcat.idp.IDPWebBrowserSSOValve.start()
    Prepare for the beginning of active use of the public methods of this component. This method should be called after configure(), and before any of the public methods of the component are utilized. @exception LifecycleException if this component detects a fatal error that prevents this component from being used
  • org.picketlink.idm.api.Transaction.start()
  • org.picocontainer.DefaultPicoContainer.start()
    Start the components of this PicoContainer and all its logical child containers. The starting of the child container is only attempted if the parent container start successfully. The child container for which start is attempted is tracked so that upon stop, only those need to be stopped. The lifecycle operation is delegated to the component adapter, if it is an instance of {@link Behavior lifecycle manager}. The actual {@link LifecycleStrategy lifecycle strategy} supporteddepends on the concrete implementation of the adapter. @see Behavior @see LifecycleStrategy @see #makeChildContainer() @see #addChildContainer(PicoContainer) @see #removeChildContainer(PicoContainer)
  • org.picocontainer.MutablePicoContainer.start()
  • org.picocontainer.PicoContainer.start()
  • org.picocontainer.Startable.start()
    Start this component. Called initially at the begin of the lifecycle. It can be called again after a stop.
  • org.picocontainer.defaults.DefaultPicoContainer.start()
    Start the components of this PicoContainer and all its logical child containers. Any component implementing the lifecycle interface {@link org.picocontainer.Startable} will be started. @see #makeChildContainer() @see #addChildContainer(PicoContainer) @see #removeChildContainer(PicoContainer)
  • org.pluginbuilder.autotestsuite.junit3.SystemOutputCapture.start()
  • org.pokenet.server.battle.impl.NpcBattleLauncher.start()
    Starts the battle launcher
  • org.projectodd.stilts.stomp.client.SubscriptionBuilder.start()
  • org.python.indexer.Def.start()
  • org.python.indexer.ast.NName.start()
  • org.qi4j.api.metrics.MetricsTimer.start()
    Start the Timer Metrics.
  • org.qi4j.library.scheduler.schedule.cron.CronSchedule.start()
  • org.qi4j.library.scheduler.schedule.once.OnceSchedule.start()
  • org.quartz.Scheduler.start()

    Starts the Scheduler's threads that fire {@link Trigger}s. When a scheduler is first created it is in "stand-by" mode, and will not fire triggers. The scheduler can also be put into stand-by mode by calling the standby() method.

    The misfire/recovery process will be started, if it is the initial call to this method on this scheduler instance.

    @throws SchedulerException if shutdown() has been called, or there is an error within the Scheduler. @see #startDelayed(int) @see #standby() @see #shutdown()
  • org.quartz.spi.SchedulerPlugin.start()

    Called when the associated Scheduler is started, in order to let the plug-in know it can now make calls into the scheduler if it needs to.

  • org.qzerver.model.agent.action.providers.executor.http.threads.HttpOutputThread.start()
  • org.qzerver.model.agent.action.providers.executor.http.threads.HttpTimeoutThread.start()
  • org.qzerver.model.agent.action.providers.executor.localcommand.threads.ProcessExecutionThread.start()
  • org.qzerver.model.agent.action.providers.executor.localcommand.threads.ProcessOutputThread.start()
  • org.qzerver.model.agent.action.providers.executor.localcommand.threads.ProcessTimeoutThread.start()
  • org.radargun.sysmonitor.Monitors.start()
  • org.radargun.traits.Lifecycle.start()
    Start the service.
  • org.rascalmpl.library.util.Eval.EvalTimer.start()
  • org.red5.server.WebScope.start()
    Starts scope. Scope can be both application or room level. @param scope Scope object @return true if scope can be started, falseotherwise. See {@link AbstractScopeAdapter#start(IScope)} fordetails.
  • org.red5.server.adapter.MultiThreadedApplicationAdapter.start()
    Starts scope. Scope can be both application or room level. @param scope Scope object @return true if scope can be started, falseotherwise. See {@link AbstractScopeAdapter#start(IScope)} fordetails.
  • org.red5.server.api.stream.IClientBroadcastStream.start()
    Starts scope. Scope can be both application or room level. @param scope Scope object @return true if scope can be started, falseotherwise. See {@link AbstractScopeAdapter#start(IScope)} fordetails.
  • org.red5.server.api.stream.IClientStream.start()
    Starts scope. Scope can be both application or room level. @param scope Scope object @return true if scope can be started, falseotherwise. See {@link AbstractScopeAdapter#start(IScope)} fordetails.
  • org.red5.server.scope.WebScope.start()
    Starts scope. Scope can be both application or room level. @param scope Scope object @return true if scope can be started, falseotherwise. See {@link AbstractScopeAdapter#start(IScope)} fordetails.
  • org.red5.server.stream.StreamingProxy.start()
    Starts scope. Scope can be both application or room level. @param scope Scope object @return true if scope can be started, falseotherwise. See {@link AbstractScopeAdapter#start(IScope)} fordetails.
  • org.redline_rpm.ReadableChannelWrapper.start()
  • org.reficio.ws.it.util.SslTunnel.start()
  • org.reficio.ws.server.core.SoapServer.start()
    Starts the SOAP server
  • org.restlet.Application.start()
    Starts the application, all the enabled associated services then the inbound and outbound roots.
  • org.restlet.Client.start()
  • org.restlet.Component.start()
    Starts the component. First it starts all the connectors (clients then servers), the routers, the services, the realms and then the component's internal helper. Finally it calls the start method of the super class. @see #startClients() @see #startServers() @see #startRouters() @see #startServices() @see #startRealms() @see #startHelper()
  • org.restlet.Server.start()
  • org.restlet.routing.Filter.start()
    Starts the filter and the next Restlet if attached.
  • org.rhq.bundle.ant.type.DeploymentUnitType.start()
  • org.rhq.core.pluginapi.inventory.ResourceComponent.start()
    Initializes the resource component, possibly connecting to the managed resource itself. The implementation can be custom to the plugin or resource, but the idea is that a resource component can create a single connection to their resource here, and maintain that connection throughout the life of the component (i.e. until the time when {@link #stop()} is called).

    This method typically examines the plugin configuration from {@link ResourceContext#getPluginConfiguration()}and uses that information to connect to the managed resource. If this method finds that the plugin configuration is invalid which causes the connection to the managed resource to fail, then this method should throw {@link InvalidPluginConfigurationException}. This exception typically should not be thrown if the connection failed for some reason other than an invalid plugin configuration (e.g. in the case the managed resource is simply not running now) because usually those conditions can be tracked as part of the resource's {@link AvailabilityFacet#getAvailability() availability} data.

    Note that this method does not imply that the actual managed resource should be started; this only starts the plugin's resource component. To start the actual resource, plugins must utilize the {@link OperationFacet} facet to provide an operation to start it.

    @param context the context for this resource which includes information about the resource @throws InvalidPluginConfigurationException if the resource component failed to start because it could notconnect to the resource due to a bad plugin configuration @throws Exception any other exception that causes the component to fail to start
  • org.rhq.enterprise.agent.AgentShutdownHook.start()
  • org.rhq.enterprise.communications.ServiceContainer.start()
    This initializes the container with the given set of configuration preferences and starts the communications services. The configuration preferences are used to configure the internal services. Note that if {@link ServiceContainerConfigurationConstants#DISABLE_COMMUNICATIONS} is true, this method doesnothing - all communications services will not be started.

    The client_configuration is used in case any of the server-side services need to act as a client and send commands out to another external server (as is the case when input streams are being remoted).

    @param configuration set of configuration preferences used to configure the internal server-side services @param client_configuration set of configuration preferences used to configure the internal client-side services @throws Exception if failed to initialize all of the services successfully @see #start(Preferences,ClientCommandSenderConfiguration,MBeanServer)
  • org.rhq.modules.plugins.jbossas7.BaseComponent.start()
    Start the resource connection @see org.rhq.core.pluginapi.inventory.ResourceComponent#start(org.rhq.core.pluginapi.inventory.ResourceContext)
  • org.rhq.plugins.jbossas5.script.ScriptComponent.start()
  • org.richfaces.resource.optimizer.Faces.start()
  • org.richfaces.resource.optimizer.faces.FacesImpl.start()
  • org.rioproject.impl.system.measurable.cpu.CPU.start()
  • org.rioproject.impl.system.measurable.disk.DiskSpace.start()
    Override PeriodicWatch.start() to get an initial reading prior to scheduling
  • org.rioproject.impl.system.measurable.memory.Memory.start()
    Override PeriodicWatch.start() to get an initial reading prior to scheduling
  • org.rioproject.impl.watch.PeriodicWatch.start()
    @see PeriodicWatchMBean#start
  • org.rioproject.servicebean.ServiceBean.start()
    The start method provides the capability for a dynamic service to initialize itself and make it ready to accept inbound communications, returning an Object which can be used to communicate with the service. It is the responsibility of the service to initiate appropriate startup logic. If the service has started itself, subsequent invocations of this method will not re-start the service, but return the Object created during the initial start @param context The ServiceBeanContext containing serviceinitialization attributes @return An Object that can be used to communicate to the service @throws Exception If any errors or unexpected conditions occur
  • org.rioproject.tools.ui.util.SwingWorker.start()
    Start the worker thread.
  • org.rsbot.bot.Bot.start()
  • org.rzo.yajsw.controller.jvm.JVMController.start()
    Start.
  • org.rzo.yajsw.os.Process.start()
    Start. @return true, if successful
  • org.rzo.yajsw.srvmgr.client.AsyncServiceManagerServer.start()
  • org.rzo.yajsw.wrapper.AbstractWrappedProcessMBean.start()
    Start.
  • org.rzo.yajsw.wrapper.WrappedService.start()
  • org.safehaus.asyncweb.container.ServiceContainer.start()
  • org.seleniumhq.selenium.fluent.Monitor.start()
  • org.servicemix.jbi.container.JBIContainer.start()
    start processing @throws JBIException
  • org.servicemix.jbi.framework.ComponentMBeanImpl.start()
    Start the item. @exception javax.jbi.JBIException if the item fails to start.
  • org.sf.bee.commons.asyncjobs.AsyncStarter.start()
  • org.sf.bee.profiler.components.TimeWatcher.start()

    Start the stopwatch.

    This method starts a new timing session, clearing any previous values.

    @throws IllegalStateException if the StopWatch is already running.
  • org.sf.mustru.crawl.BuildIndex.start()
  • org.sf.mustru.utils.IndexTools.start()
  • org.sgx.yuigwt.editors.impl.EditorFramework1.start()
  • org.simpleframework.http.core.Transfer.start()
    This starts the transfer with no specific content length set. This is typically used when dynamic data is emitted ans will require chunked encoding for HTTP/1.1 and connection close for HTTP/1.0. Once invoked the HTTP headers are committed.
  • org.sleuthkit.autopsy.coreutils.StopWatch.start()
  • org.slf4j.profiler.Profiler.start()
    Starts a child stop watch and stops any previously started time instruments.
  • org.snova.framework.Snova.start()
  • org.snu.ids.ha.util.Timer.start()
  • org.socialmusicdiscovery.server.api.plugin.Plugin.start()
    Will be called when the plugin should be activated, if you want to do any initialization you should do it inside this {@link #start} method @return true if the plugin is going to continue to run after the method returns, false if the plugin has already done its work after the method returns and can be considered to be stopped.. @throws PluginException If an error occurs that results in that the plugin failed to start
  • org.socialmusicdiscovery.server.business.logic.injections.database.DatabaseProvider.start()
    Called initially before the first connection is established with the provider
  • org.sodbeans.matching.parser.QuorumParser.start()
  • org.sodbeans.phonemic.daemon.PhonemicDaemon.start()
  • org.sonatype.ldaptestsuite.LdapServer.start()
  • org.sonatype.security.SecuritySystem.start()
    Starts the SecuritySystem. Before this method is called the state is unknown.
  • org.sonatype.tests.http.server.fluent.Server.start()
  • org.speakright.core.SRInstance.start()
    Start the application. @param flow the application flow object. @return whether app was started successfully.
  • org.spout.vanilla.protocol.LANThread.start()
  • org.spoutcraft.api.animation.PropertyAnimation.start()
  • org.spoutcraft.client.ScheduledTextFieldUpdate.start()
  • org.springframework.amqp.rabbit.listener.BlockingQueueConsumer.start()
  • org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer.start()
  • org.springframework.batch.core.job.flow.Flow.start()
    @throws FlowExecutionException
  • org.springframework.context.ConfigurableApplicationContext.start()
  • org.springframework.context.Lifecycle.start()
    Start this component. Should not throw an exception if the component is already running.

    In the case of a container, this will propagate the start signal to all components that apply.

  • org.springframework.context.support.AbstractApplicationContext.start()
  • org.springframework.context.support.AbstractXmlApplicationContext.start()
  • org.springframework.context.support.ClassPathXmlApplicationContext.start()
  • org.springframework.context.support.FileSystemXmlApplicationContext.start()
  • org.springframework.context.support.GenericApplicationContext.start()
  • org.springframework.context.support.GenericXmlApplicationContext.start()
  • org.springframework.context.support.StaticApplicationContext.start()
  • org.springframework.data.hadoop.jetty.BatchAdminServer.start()
  • org.springframework.data.hadoop.store.output.TextFileWriter.start()
  • org.springframework.data.hadoop.test.context.HadoopCluster.start()
    Starts the cluster. @throws Exception if cluster failed to start
  • org.springframework.ide.eclipse.beans.core.internal.model.BeansModel.start()
  • org.springframework.integration.endpoint.SourcePollingChannelAdapter.start()
  • org.springframework.jms.listener.AbstractJmsListeningContainer.start()
    Start this container. @throws JmsException if starting failed @see #doStart
  • org.springframework.jms.listener.AbstractMessageListenerContainer.start()
  • org.springframework.jms.listener.DefaultMessageListenerContainer.start()
    Overridden to reset the stop callback, if any.
  • org.springframework.retry.backoff.BackOffPolicy.start()
    Start a new block of back off operations. Implementations can choose to pause when this method is called, but normally it returns immediately. @param context the current retry context, which might contain informationthat we can use to decide how to proceed. @return the implementation-specific {@link BackOffContext} or 'null'.
  • org.springframework.richclient.application.Application.start()
    Starts this application.
  • org.springframework.roo.shell.eclipse.Bootstrap.start()
  • org.springframework.scheduling.quartz.SchedulerFactoryBean.start()
  • org.springframework.shell.core.JLineShellComponent.start()
  • org.springframework.util.StopWatch.start()
    Start an unnamed task. The results are undefined if {@link #stop()}or timing methods are called without invoking this method. @see #stop()
  • org.springframework.util.backoff.BackOff.start()
    Start a new back off execution. @return a fresh {@link BackOffExecution} ready to be used
  • org.springframework.util.backoff.ExponentialBackOff.start()
  • org.springframework.util.backoff.FixedBackOff.start()
  • org.springframework.web.context.support.AnnotationConfigWebApplicationContext.start()
  • org.springframework.web.context.support.XmlWebApplicationContext.start()
  • org.springframework.web.socket.client.WebSocketConnectionManager.start()
  • org.springframework.webflow.engine.impl.FlowExecutionImpl.start()
  • org.springframework.webflow.execution.FlowExecution.start()
    Start this flow execution. This method should only be called once.

    When this method returns, execution status is either "paused" or "ended". If ended, the flow execution cannot be used again. If "paused", the flow execution may be {@link #resume(ExternalContext) resumed}. @param input flow execution input @param context the external context representing the calling environment @throws FlowExecutionException if an exception was thrown within a state of the flow execution during requestprocessing

  • org.springframework.xd.dirt.integration.bus.Binding.start()
  • org.springframework.xd.dirt.zookeeper.EmbeddedZooKeeper.start()
    Start the ZooKeeper server in a background thread.

    Register an error handler via {@link #setErrorHandler} in order to handleany exceptions thrown during startup or execution.

  • org.springframework.xd.dirt.zookeeper.ZooKeeperConnection.start()
    Starts the underlying {@link CuratorFramework} instance.
  • org.springframework.xd.module.core.Module.start()
  • org.springframework.yarn.test.context.YarnCluster.start()
    Starts the cluster. @throws Exception if cluster failed to start
  • org.springside.modules.metrics.reporter.ReportScheduler.start()
  • org.springside.modules.nosql.redis.service.elector.MasterElector.start()
    启动抢注线程, 自行创建scheduler线程池.
  • org.springside.modules.nosql.redis.service.scheduler.JobDispatcher.start()
    启动分发线程, 自行创建scheduler线程池.
  • org.squirrelframework.foundation.fsm.UntypedStateMachine.start()
  • org.stringtree.util.spec.SpecProcessor.start()
  • org.subethamail.smtp.server.SMTPServer.start()
    Call this method to get things rolling after instantiating the SMTPServer.
  • org.subethamail.wiser.Wiser.start()
    Starts the SMTP Server
  • org.sunflow.system.Timer.start()
  • org.swingml.RenderingThread.start()
  • org.swingml.SubmittingThread.start()
  • org.switchyard.component.bean.ServiceProxyHandler.start()
  • org.switchyard.component.bpm.exchange.BPMExchangeHandler.start()
  • org.switchyard.component.rules.exchange.RulesExchangeHandler.start()
  • org.switchyard.deploy.ServiceHandler.start()
  • org.switchyard.deploy.internal.Deployment.start()
    Starts the deployment. All services are registered and the appropriate activators are triggered.
  • org.switchyard.standalone.SwitchYard.start()
    Start the SwitchYard application.
  • org.syncany.operations.daemon.WatchServer.start()
  • org.syncany.operations.watch.DefaultRecursiveWatcher.start()
  • org.syncany.operations.watch.NotificationListener.start()
  • org.talend.esb.job.controller.GenericOperation.start()
    Start this operation. After being started the operation is ready to get invoked. @param arguments pass these arguments to the backing {@link TalendESBJob job}
  • org.teavm.chromerdp.ChromeRDPServer.start()
  • org.teiid.client.DQP.start()
  • org.teiid.dqp.internal.datamgr.ConnectorManager.start()
    initialize this ConnectorManager. @throws TranslatorException
  • org.teiid.services.BufferServiceImpl.start()
  • org.teiid.translator.ExecutionFactory.start()
    Initialize the connector with supplied configuration
  • org.terasology.launcher.log.LogViewAppender.start()
  • org.terasology.logic.behavior.tree.Interpreter.start()
  • org.tinyradius.util.RadiusServer.start()
    Starts the Radius server. @param listenAuth open auth port? @param listenAcct open acct port?
  • org.tmatesoft.hg.internal.BatchRangeHelper.start()
  • org.tmatesoft.hg.internal.Lifecycle.start()
    @param count approximate number of iterations. @param callback callback to communicate with RevlogStream (now to stop iteration only) @param token identifier of the process
  • org.tmatesoft.hg.util.ProgressSupport.start()
  • org.tmatesoft.svn.core.internal.util.SVNStreamGobbler.start()
  • org.trifort.rootbeer.runtime.util.Stopwatch.start()
  • org.uengine.telnet.TelnetNormalModule.start()
  • org.uengine.util.FileCopy.start()
  • org.uiautomation.ios.IOSServer.start()
  • org.uiautomation.ios.ServerSideSession.start()
  • org.uiautomation.ios.utils.Command.start()
    Starts the command. Doesn't wait for it to finish. Doesn't wait for stdout and stderr either.
  • org.vertx.java.core.streams.Pump.start()
    Start the Pump. The Pump can be started and stopped multiple times.
  • org.vertx.java.platform.Verticle.start()
    Vert.x calls the start method when the verticle is deployed
  • org.voltcore.messaging.HostMessenger.start()
    Start the host messenger and connect to the leader, or become the leader if necessary.
  • org.voltdb.ServerThread.start()
  • org.webbitserver.WebServer.start()
    Start web server in background.
  • org.wicketstuff.progressbar.ProgressBar.start()
    Start the progress bar. This must happen in an AJAX request. @param target
  • org.wikipediacleaner.gui.swing.basic.BasicWorker.start()
  • org.wikipediacleaner.gui.swing.basic.ProgressPanel.start()
    Start progress panel.
  • org.wikipediacleaner.gui.swing.worker.AutomaticFixingWorker.start()
  • org.wikipediacleaner.gui.swing.worker.CheckWikiProjectWorker.start()
  • org.wikipediacleaner.gui.swing.worker.DisambiguationAnalysisWorker.start()
  • org.wikipediacleaner.gui.swing.worker.FullAnalysisWorker.start()
  • org.wikipediacleaner.gui.swing.worker.LoginWorker.start()
  • org.wikipediacleaner.gui.swing.worker.RetrieveContentWorker.start()
  • org.wikipediacleaner.gui.swing.worker.SendWorker.start()
  • org.wikipediacleaner.gui.swing.worker.TranslateWorker.start()
  • org.wikipediacleaner.gui.swing.worker.UpdateDabWarningWorker.start()
  • org.wikipediacleaner.gui.swing.worker.UpdateISBNWarningWorker.start()
  • org.wikipediacleaner.gui.swing.worker.UpdateInfoWorker.start()
  • org.wso2.carbon.deployment.synchronizer.DeploymentSynchronizer.start()
    Start this DeploymentSynchronizer instance. If the autoCommit and autoCheckout modes are not enabled, this method will do nothing. If such additional features are enabled, this method will schedule the necessary periodic tasks and get the auto-sync tasks up and running.
  • org.wso2.carbon.event.client.broker.SimpleMessageReceiver.start()
  • org.wso2.carbon.multiple.instance.endpoint.mgt.EndPointManager.start()
  • org.wso2.carbon.tomcat.BetterTomcat.start()
    Start the server. @throws LifecycleException If an irrecoverable error occurs while starting
  • org.wso2.esb.integration.http.SimpleHttpServer.start()
  • org.xlightweb.WebContainer.start()
  • org.xlightweb.server.HttpServer.start()
  • org.xlightweb.server.IHttpServer.start()
  • org.xsocket.connection.IServer.start()
  • org.xsocket.connection.Server.start()
  • org.xvr.xvrengine.process.ProcessExitHandler.start()
  • org.xwiki.test.integration.XWikiExecutor.start()
  • org.zeromq.ZLoop.start()
  • org.zkoss.io.FileWatchdog.start()
  • org.zper.base.ZLog.SegmentInfo.start()
  • org.zper.server.ZPReader.start()
  • org.zper.server.ZPWriter.start()
  • parquet.hadoop.ParquetFileWriter.start()
    start the file @throws IOException
  • pdp.scrabble.ihm.MainFrame_old.start()
    Start main frame.
  • penny.util.StopWatch.start()
  • perestrojka.backend.Converter.start()
  • pivot.wtk.effects.FadeTransition.start()
  • pku.cbi.abcgrid.worker.update.UpdateThread.start()
  • play_downloader.RunAfterDownloadThread.start()
  • pluginreceiver.model.XPlaneUDPReceiver.start()
  • practica1.ui.simulacion.ThreadSimulacion.start()
  • prefuse.util.io.XMLWriter.start()
    Print a start tag with attributes. The tag will be followed by a newline, and the indentation level will be increased. @param tag the tag name @param names the names of the attributes @param values the values of the attributes @param nattr the number of attributes
  • processing.core.PApplet.start()
  • proj.zoie.impl.indexing.ZoieSystem.start()
  • proj.zoie.perf.indexing.LinedFileDataProvider.start()
  • pt.opensoft.resource.Resource.start()
  • pt.opensoft.util.Timer.start()
    Reinicia o timer (no caso de ja estar activo), e come�a a correr.
  • ptolemy.distributed.client.ClientThread.start()
  • ptolemy.gui.JTextAreaExec.start()
    Start running the commands.
  • pubsub.PublisherEventHandler.start()
  • pubsub.SubscriberEventHandler.start()
  • pushy.RemoteProcessBuilder.start()
  • py4j.GatewayServer.start()
  • qat.agent.ExecProcess.start()
    This method should not be called directly, but rather via ObjectName.start() to ensure the thread is started correctly.
  • qat.plugins.chorus.ExecProcess.start()
  • r.nodes.exec.Selector.start()
  • rabbit.tracking.internal.TrackingPlugin.start()
  • railo.runtime.thread.ChildThreadImpl.start()
  • railo.runtime.timer.Stopwatch.start()
    start the watch
  • randomevents.telephone.TelephoneCenter.start()
  • rationals.Transition.start()
  • ratpack.server.RatpackServer.start()
    Starts the server, returning as soon as the server is up and ready to receive requests.

    This will create new threads that are not daemonized. @throws Exception if the server could not be started

  • remote.motecontrol.client.SimpleMoteManager.start()
  • restx.server.WebServer.start()
  • restx.server.simple.simple.SimpleWebServer.start()
  • riffle.process.scheduler.ProcessChain.start()
  • ro.isdc.wro.util.StopWatch.start()
    Start an unnamed task. The results are undefined if {@link #stop()} or timing methods are called without invokingthis method. @see #stop()
  • rocket.generator.rebind.visitor.AllMethodsVisitor.start()
    Starts the visiting process starting at the most derived type towards java.lang.Object. @param derivedType
  • rocket.generator.rebind.visitor.ConcreteTypesImplementingInterfaceVisitor.start()
  • rocket.generator.rebind.visitor.ConstructorParameterVisitor.start()
  • rocket.generator.rebind.visitor.MethodParameterVisitor.start()
  • rocket.generator.rebind.visitor.ReachableTypesVisitor.start()
    Starts the visiting process. @param type
  • rocket.generator.rebind.visitor.SubTypesVisitor.start()
  • rocket.generator.rebind.visitor.TypeConstructorsVisitor.start()
  • rocket.generator.rebind.visitor.VirtualMethodVisitor.start()
    Starts the visiting process starting at the most derived type towards java.lang.Object. @param derivedType
  • rpc.connection.StreamedRPC.start()
  • ru.vassaev.core.thread.Process.start()
  • scalaExec.scalaLab.StreamGobbler.start()
  • schema2template.example.odf.OdfHelper.start()
  • scotlandyard.engine.impl.Game.start()
    start the game, change game status to running, initialise players and tokens @param player @throws Exception
  • se.llbit.chunky.renderer.BenchmarkManager.start()
  • se.llbit.chunky.renderer.RenderManager.start()
  • se.llbit.chunky.renderer.cl.CLRenderManager.start()
  • se.llbit.chunky.renderer.test.TestRenderer.start()
  • se.llbit.chunky.world.DeleteChunksJob.start()
  • se.sics.mspsim.platform.GenericNode.start()
  • se.sics.mspsim.util.ServiceComponent.start()
  • se.sperber.cryson.CrysonServer.start()
  • search.searchtechniques.Search.start()
  • sensor.VoltageSensor.start()
  • sensor.spot.SpotADC.start()
  • server.sprite.MovableSprite.start()
  • server.sprite.Sprite.start()
  • shag.progress.ModalProgress.start()
  • shared.dialog.JWaitDialog.start()
  • sizzle.aggregators.Table.start()
  • smartrics.rest.test.fitnesse.fixture.HttpServer.start()
  • smilehouse.opensyncro.system.PipeExecutionThread.start()
  • sos.spooler.Subprocess.start()
  • speculoos.jndi.JNDISource.start()
  • speculoos.jndi.pool.JNDIPooledSource.start()
  • st.gravel.support.compiler.ast.SourcePosition.start()
  • stanfordlogic.network.ConnectionManager.start()
  • streamer.debug.MockServer.start()
  • stress.Benchmark.start()
  • sun.audio.AudioPlayer.start()
    Start playing a stream. The stream will continue to play until the stream runs out of data, or it is stopped. @see AudioPlayer#stop
  • syam.BookEditor.Util.Metrics.start()
    Start measuring statistics. This will immediately create an async repeating task as the plugin and send the initial data to the metrics backend, and then after that it will post in increments of PING_INTERVAL * 1200 ticks. @return True if statistics measuring is running, otherwise false.
  • synalp.generation.server.GeneratorServer.start()
  • tangowidget.device.DeviceStateButton.start()
  • tcg.common.util.ProcessExecution.start()
  • tcg.common.util.StreamGobbler.start()
  • tcg.scada.sim.iecsim.scripter.Scripter.start()
    Start the script (running on its own thread)
  • test.plugin.TestPluginLifeCycle.start()
  • tetrisexample.util.AgentThread.start()
  • tetrisexample.util.EnvThread.start()
  • tetrisexample.util.RLGlueThread.start()
  • tetrisexample.util.VizThread.start()
  • threads.Generator.start()
  • threads.Integrator.start()
  • threads.PushThread.start()
  • threads.SMSThread.start()
  • tool.process.ProcessExitDetector.start()
  • tzar.mafiabot.engine.Parser.start()
  • uk.co.brunella.osgi.bdt.framework.BundleWrapper.start()
  • uk.co.caprica.vlcj.player.MediaPlayer.start()
    Begin play-back and wait for the media to start playing or for an error to occur.

    If called when the play-back is paused, the play-back will resume from the current position.

    This call will block until the media starts or errors. @return true if the media started playing, false if the media failed to start because of an error

  • uk.co.caprica.vlcj.player.embedded.EmbeddedMediaPlayer.start()
  • uk.co.caprica.vlcj.player.headless.HeadlessMediaPlayer.start()
  • uk.gov.nationalarchives.droid.gui.action.CloseProfileAction.start()
    Starts the action.
  • uk.gov.nationalarchives.droid.gui.action.ExitAction.start()
    Executes the exit action, which may involve saving unsaved profiles.
  • uk.gov.nationalarchives.droid.gui.action.SaveProfileWorker.start()
    Starts the save operation. @param saveAs if true, forces a save dialog box to open. @return true if the operation was not cancelled.
  • uk.gov.nationalarchives.droid.gui.signature.CheckSignatureUpdateAction.start()
    Starts the task. @param parentFrame the parent of this task
  • uk.gov.nationalarchives.droid.gui.signature.UpdateSignatureAction.start()
    Starts the action. @param parentFrame the parent frame
  • uk.gov.nationalarchives.droid.profile.ProfileInstanceManager.start()
    Starts a profile, which will complete in the future. @return a future object for controlling the job. @throws IOException file replay failed.
  • uk.org.taverna.server.client.Run.start()
  • unlekker.util.UProgressInfo.start()
    Called at the start of task that should be tracked.
  • us.codecraft.webmagic.Spider.start()
  • util.Downloader.start()
  • util.StopWatch.start()
  • utils.Timer.start()
    Starts the timer. Separate method provided so that user can specify exactly when to start the timer instead of just having it start when it is constructed.
  • vavi.sound.mobile.AudioEngine.start()
    Start adpcm playing. @param streamNumber packet id
  • viewer.common.SwingWorker.start()
    Start the worker thread.
  • vista.VistaConsola.start()
  • voldemort.server.AbstractSocketService.start()
  • voldemort.server.VoldemortServer.start()
  • voldemort.server.http.HttpService.start()
  • vs.server.Dispatcher.start()
  • vs.server.TimeoutDispatcher.start()
  • water.fvec.Chunk.start()
  • weblech.spider.Spider.start()
  • whitening.opengl.s.nehe.commons.GLDisplay.start()
  • xbird.server.Server.start()
    @param srvNames if none specified, register all services in the 'service.list'.
  • xdoclet.template.TemplateParser.start()
    A utility method used for generating the dest_file based on template_file template file. @exception TemplateException Description of Exception
  • xlockFrame.start()
  • xnap.plugin.nap.net.AltDirectBrowseUpload.start()
  • y.module.LayoutModule.start()

  • Examples of net.wimpi.modbus.net.ModbusTCPListener.start()

          //3. create a listener with 3 threads in pool
          if (Modbus.debug) System.out.println("Listening...");
          listener = new ModbusTCPListener(3);
          listener.setPort(port);
          listener.start();

        } catch (Exception ex) {
          ex.printStackTrace();
        }
      }//main
    View Full Code Here

    Examples of net.wimpi.modbus.net.ModbusUDPListener.start()

          ModbusCoupler.getReference().setUnitID(15);

          //2. Setup and start listener
          listener = new ModbusUDPListener();
          listener.setPort(port);
          listener.start();

        } catch (Exception ex) {
          ex.printStackTrace();
        }
    View Full Code Here

    Examples of net.wimpi.modbusme.net.ModbusTCPListener.start()

          //3. create a listener with 3 threads in pool
          if (Modbus.debug) System.out.println("Listening...");
          listener = new ModbusTCPListener(3);
          listener.setPort(port);
          listener.start();

        } catch (Exception ex) {
          ex.printStackTrace();
        }
      }//main
    View Full Code Here

    Examples of net.wimpi.modbusme.net.ModbusUDPListener.start()

          ModbusCoupler.getReference().setUnitID(15);

          //2. Setup and start listener
          listener = new ModbusUDPListener();
          listener.setPort(port);
          listener.start();

        } catch (Exception ex) {
          ex.printStackTrace();
        }
    View Full Code Here

    Examples of net.wimpi.telnetd.TelnetD.start()

                props.load(is);

                TelnetD daemon = TelnetD.createTelnetD(props);

                // 2.start serving/accepting connections
                daemon.start();
            } catch (Exception ex) {
                ex.printStackTrace();
                System.exit(1);
            }
        }
    View Full Code Here

    Examples of net.wimpi.telnetd.net.PortListener.start()

        //
        this.listeners = listeners;

        // Start listeners
        for (PortListener listener : this.listeners) {
          listener.start();
          map.put(listener.getConnectionManager(), this);
        }
      }

      @Override
    View Full Code Here

    Examples of net.xoetrope.xui.helper.SwingWorker.start()

                    DeviceLoader.receipt.printReceipt(currentTrans, true);

                    return null;
                }
            };
            worker.start();

            // save the TX Log
            txLog.set("statusId", "POSTX_SOLD");
            txLog.set("orderId", orderId);
            txLog.set("itemCount", new Long(cart.size()));
    View Full Code Here

    Examples of net.yacy.cora.protocol.Scanner.start()

                    final Scanner scanner = new Scanner(ia, CONCURRENT_RUNNER, timeout);
                    if (post.get("scanftp", "").equals("on")) scanner.addFTP(bigrange);
                    if (post.get("scanhttp", "").equals("on")) scanner.addHTTP(bigrange);
                    if (post.get("scanhttps", "").equals("on")) scanner.addHTTPS(bigrange);
                    if (post.get("scansmb", "").equals("on")) scanner.addSMB(bigrange);
                    scanner.start();
                    scanner.terminate();
                    if ("on".equals(post.get("accumulatescancache", "")) && !"scheduler".equals(post.get("rescan", ""))) {
                        Scanner.scancacheExtend(scanner, validTime);
                    } else {
                        Scanner.scancacheReplace(scanner, validTime);
    View Full Code Here

    Examples of net.yacy.cora.services.federated.opensearch.SRURSSConnector.start()

         * @param global
         */
        public static void addSRURSSServices(final SearchHub search, final String[] rssServices, final int count, final CacheStrategy verify, final boolean global, final String userAgent) {
            for (final String service: rssServices) {
                final SRURSSConnector accumulator = new SRURSSConnector(search, service, count, verify, global, userAgent);
                accumulator.start();
                search.addAccumulator(accumulator);
            }
        }

        public static void main(final String[] args) {
    View Full Code Here

    Examples of net.yacy.document.importer.OAIPMHImporter.start()

                    sb.tables.recordAPICall(post, "IndexImportOAIPMH_p.html", WorkTables.TABLE_API_TYPE_CRAWLER, "OAI-PMH import for " + oaipmhurl);
                    DigestURI url = null;
                    try {
                        url = new DigestURI(oaipmhurl);
                        OAIPMHImporter job = new OAIPMHImporter(sb.loader, url);
                        job.start();
                        prop.put("status", 1);
                        prop.put("optiongetlist", 1);
                        prop.put("iframetype", 1);
                    } catch (MalformedURLException e) {
                        Log.logException(e);
    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.