-
ai.domain.bool.Bool.join()
-
ai.domain.boxes.IntegerBoxes.join()
-
anvil.script.Context.join()
-
avrora.sim.Simulation.join()
The join()
method waits for the simulation to terminate before returning. After this method returns, the nodes are all guaranteed to be have terminated.
@throws InterruptedException
-
avrora.sim.SimulatorThread.join()
-
ca.carleton.gcrc.couch.date.impl.DateRobotThread.join()
-
ca.carleton.gcrc.couch.submission.impl.SubmissionRobotThread.join()
-
cartago.CartagoWorkspace.join()
Get a context to work inside the workspace
@param aid Agent identifier
@return
-
chunmap.model.coord.CoordSeqEditor.join()
和另一条线连接在一起
@param l2
@return
-
co.paralleluniverse.fibers.Fiber.join()
-
co.paralleluniverse.strands.Strand.join()
Awaits the termination of this strand. This method blocks until this strand terminates.
@throws ExecutionException if this strand has terminated as a result of an uncaught exception(which will be the {@link Throwable#getCause() cause} of the thrown {@code ExecutionException}.
@throws InterruptedException
-
com.alibaba.jstorm.utils.SmartThread.join()
-
com.alipay.bluewhale.core.utils.SmartThread.join()
-
com.anzsoft.client.XMPP.mandioca.rooms.XmppRoom.join()
p.org/extensions/xep-0045.html#enter
-
com.asakusafw.bulkloader.common.StreamRedirectThread.join()
-
com.asakusafw.compiler.flow.processor.operator.MasterJoinFlowFactory.join()
結合する。
@param ex1 マスタ
@param ex2 トラン
@return 生成した演算子オブジェクト
-
com.atlassian.localtunnel.util.SocketJoiner.join()
-
com.axemblr.provisionr.core.logging.StreamLogger.join()
-
com.clarkparsia.pellet.rules.rete.BetaNode.join()
-
com.cloudera.flume.core.connector.DirectDriver.join()
-
com.cloudera.sqoop.util.AsyncSink.join()
-
com.espertech.esper.epl.join.util.QueryPlanIndexHook.join()
-
com.facebook.testing.LoopThread.join()
-
com.github.searls.jasmine.server.ServerManager.join()
-
com.google.api.client.util.Joiner.join()
-
com.google.common.base.Joiner.join()
Returns a string containing the string representation of each of {@code parts}, using the previously configured separator between each.
-
com.google.common.base.Joiner.MapJoiner.join()
-
com.google.gxp.compiler.fs.FileRef.join()
Joins a path suffix onto this FileRef creating a new FileRef which is effectively 'suffix' relative to 'this'. eg: new FileRef("/a/b").join("/x/y") is new FileRef("/a/b/x/y")
-
com.google.sitebricks.acceptance.util.JettyAcceptanceTest.join()
-
com.google_voltpatches.common.base.Joiner.join()
Returns a string containing the string representation of each of {@code parts}, using the previously configured separator between each.
-
com.googlecode.flaxcrawler.CrawlerController.join()
Joins crawler workers threads and waits for them to finish their work
-
com.hp.mwtests.ts.arjuna.resources.BasicThreadedObject.join()
-
com.hp.mwtests.ts.txoj.common.resources.BasicThreadedObject.join()
-
com.hp.mwtests.ts.txoj.common.resources.HammerThreadedObject.join()
-
com.impetus.labs.korus.addons.constructs.pipeline.Pipeline.join()
This method is used to join two Pipelined Tasks. It means, the order of the pipelined tasks is decided using this method. The First argument is the first pipelined tasks executed before the second argument or the following pipeline Task.
@param pipelineTaskProd The producer pipelined Task
@param pipelineTaskCon The consumer pipelined Task
-
com.linkedin.d2.discovery.event.PropertyEventThread.join()
-
com.linkedin.databus.client.pub.DatabusClientGroupMember.join()
-
com.linkedin.databus.core.util.UncaughtExceptionTrackingThread.join()
-
com.lucidera.luciddb.test.udr.SQLRunner.join()
-
com.metamx.common.lifecycle.Lifecycle.join()
-
com.mysema.query.jpa.hibernate.HibernateQuery.join()
-
com.onpositive.gae.tools.core.CheckLaunchJob.join()
-
com.opengamma.engine.view.worker.SingleThreadViewProcessWorker.BorrowedThread.join()
-
com.opengamma.engine.view.worker.ViewProcessWorker.join()
Wait for completion of any threads working directly or indirectly on this job. After this call completes, the job should not make any more callbacks to its owning process.
@throws InterruptedException if the thread was interrupted before it could complete the operation
-
com.packtpub.java7.concurrency.chapter5.recipe03.task.FolderProcessor.join()
-
com.packtpub.java7.concurrency.chapter5.recipe04.task.Task.join()
-
com.packtpub.java7.concurrency.chapter7.recipe06.task.MyRecursiveTask.join()
-
com.pardot.rhombus.cobject.async.StatementIteratorConsumer.join()
-
com.pinterest.secor.consumer.Consumer.join()
-
com.planet_ink.coffee_web.util.CWThread.join()
-
com.shop.cache.api.server.SCServer.join()
Must be called from a dedicated thread to start the server. Will not return until the server has been shutdown
@throws InterruptedException if the thread is interrupted
-
com.sleepycat.je.Database.join()
Creates a specialized join cursor for use in performing equality or natural joins on secondary indices.
Each cursor in the cursors
array must have been initialized to refer to the key on which the underlying database should be joined. Typically, this initialization is done by calling {@link Cursor#getSearchKey Cursor.getSearchKey}.
Once the cursors have been passed to this method, they should not be accessed or modified until the newly created join cursor has been closed, or else inconsistent results may be returned. However, the position of the cursors will not be changed by this method or by the methods of the join cursor.
@param cursors an array of cursors associated with this primarydatabase. In a replicated environment, an explicit transaction must be specified when opening each cursor, unless read-uncommitted isolation is isolation is specified via the {@link CursorConfig} or {@link LockMode}parameter.
@param config The join attributes. If null, default attributes areused.
@return a specialized cursor that returns the results of the equalityjoin operation.
@throws OperationFailureException if one of the
Read Operation Failures occurs.
@throws EnvironmentFailureException if an unexpected, internal orenvironment-wide failure occurs.
@throws IllegalStateException if the database has been closed.
@throws IllegalArgumentException if an invalid parameter is specified,for example, an invalid {@code JoinConfig} parameter.
@see JoinCursor
-
com.sleepycat.je.SecondaryDatabase.join()
This operation is not allowed on a secondary database. {@link UnsupportedOperationException} will always be thrown by this method.The corresponding method on the primary database should be used instead.
-
com.sleepycat.je.junit.JUnitThread.join()
-
com.sun.enterprise.ee.cms.core.GroupManagementService.join()
-
com.sun.sgs.app.Channel.join()
Adds a client session to this channel. If the specified session is already joined to this channel, then no action is taken. If the client session does not support a protocol that satisfies the minimum requirements of the channel's delivery guarantee, then {@code DeliveryNotSupportedException} will bethrown.
@param session a client session
@return this channel
@throws IllegalStateException if this channel is closed
@throws DeliveryNotSupportedException if the session does not supportthe minimum requirements of this channel's delivery guarantee
@throws ResourceUnavailableException if there are not enough resourcesto join the channel
@throws TransactionException if the operation failed because ofa problem with the current transaction
-
com.sun.sgs.service.Transaction.join()
Tells the
Transaction
that the given
TransactionParticipant
is participating in the transaction. A
TransactionParticipant
is allowed to join a
Transaction
more than once, but will only be registered as a single participant.
If the transaction has been aborted, then the exception thrown will have as its cause the value provided in the first call to {@link #abort abort}, if any. If the cause implements {@link ExceptionRetryStatus}, then the exception thrown will, too, and its {@link ExceptionRetryStatus#shouldRetry shouldRetry} method will return thevalue returned by calling that method on the cause. If no cause was supplied, then the exception will either not implement {@code ExceptionRetryStatus} or its {@code shouldRetry} method will return{@code false}.
@param participant the TransactionParticipant
joiningthe transaction
@throws TransactionNotActiveException if the transaction has beenaborted
@throws IllegalStateException if {@link TransactionParticipant#prepare prepare} has been called on anytransaction participant and the transaction has not been aborted, or if called from a thread that is not the thread that created this transaction
@throws UnsupportedOperationException if participant
doesnot implement {@link NonDurableTransactionParticipant} and theimplementation cannot support an additional durable transaction participant
-
de.anomic.search.MetadataRepository.Export.join()
-
edu.cmu.cs.crystal.analysis.constant.BooleanConstantLatticeOps.join()
-
edu.mit.csail.sdg.alloy4compiler.ast.ExprHasName.join()
-
edu.mit.csail.sdg.alloy4compiler.ast.Sig.PrimSig.join()
-
edu.stanford.genetics.treeview.SwingWorker.join()
Join the worker thread
@throws InterruptedException
-
elemental.util.ArrayOfBoolean.join()
Convert each element of the array to a String and join them with a comma separator. The value returned from this method may vary between browsers based on how JavaScript values are converted into strings.
-
elemental.util.ArrayOfInt.join()
Convert each element of the array to a String and join them with a comma separator. The value returned from this method may vary between browsers based on how JavaScript values are converted into strings.
-
elemental.util.ArrayOfNumber.join()
Convert each element of the array to a String and join them with a comma separator. The value returned from this method may vary between browsers based on how JavaScript values are converted into strings.
-
elemental.util.ArrayOfString.join()
Convert each element of the array to a String and join them with a comma separator. The value returned from this method may vary between browsers based on how JavaScript values are converted into strings.
-
eu.stratosphere.client.web.WebInterfaceServer.join()
Lets the calling thread wait until the server terminates its operation.
@throws InterruptedException Thrown, if the calling thread is interrupted.
-
eu.stratosphere.pact.runtime.test.util.TaskCancelThread.join()
-
fork.lib.bio.anno.genomic.region.GenomicRegionsBuilder.join()
-
hitune.analysis.mapreduce.processor.AnalysisProcessorManager.join()
-
hudson.Launcher.ProcStarter.join()
-
hudson.Proc.join()
Waits for the completion of the process. Unless the caller opts to pump the streams via {@link #getStdout()} etc.,this method also blocks until we finish reading everything that the process has produced to stdout/stderr.
If the thread is interrupted while waiting for the completion of the process, this method terminates the process and exits with a non-zero exit code.
@throws IOException if there's an error launching/joining a process and a stack trace could help the trouble-shooting.
-
hudson.plugins.perforce.QuickCleaner.PerforceCall.join()
-
hudson.remoting.Channel.join()
Waits for this {@link Channel} to be closed down.
The close-down of a {@link Channel} might be initiated locally or remotely.
@throws InterruptedException If the current thread is interrupted while waiting for the completion.
-
hudson.remoting.Engine.join()
-
hudson.remoting.VirtualChannel.join()
Waits for this {@link Channel} to be closed down.The close-down of a {@link Channel} might be initiated locally or remotely.
@throws InterruptedException If the current thread is interrupted while waiting for the completion.
@since 1.300
-
hudson.util.StreamCopyThread.join()
-
info.walnutstreet.vs.ps04.p2p.ring.Node.join()
-
java.lang.Thread.join()
Waits at most millis
milliseconds for this thread to die. A timeout of 0
means to wait forever.
@param millis the time to wait in milliseconds.
@exception InterruptedException if any thread has interruptedthe current thread. The interrupted status of the current thread is cleared when this exception is thrown.
-
java.nio.channels.DatagramChannel.join()
-
javax.jms.MessageProducer.join()
-
javax.persistence.criteria.From.join()
Join to the specified single-valued attribute using an inner join.
@param attribute target of the join
@return the resulting join
-
javax.persistence.criteria.Join.join()
-
jcomicdownloader.module.Run.join()
-
kodkod.ast.Expression.join()
Returns the join of this and the specified expression. The effect of this method is the same as calling this.compose(JOIN, expr).
@return this.compose(JOIN, expr)
-
kodkod.ast.Variable.join()
-
lcmc.cluster.service.ssh.ExecCommandThread.join()
-
lipstone.joshua.parser.backend.StepSolveThread.join()
-
lupos.datastructures.sort.helper.InitialRunGenerator.join()
-
marytts.util.data.audio.AudioPlayer.join()
-
mikera.arrayz.INDArray.join()
Joins an array with another array along a specified dimension
-
mikera.matrixx.Matrix.join()
-
mikera.vectorz.AVector.join()
Returns a new vector that refers to this vector joined to a second vector. Optimises the type of the returned vector to be as efficient as possible.
@param second
@return
-
mikera.vectorz.impl.Vector0.join()
-
net.datacrow.console.windows.drivemanager.DriveManagerSingleItemMatcher.join()
-
net.fenyo.gnetwatch.GUI.join()
-
net.jcores.jre.cores.CoreString.join()
Joins all string with an empty ("") joiner.
Examples:
$("a", "b", "c").join()
- Returns "abc"
.
Single-threaded.
@return The joined string, or "" if there was nothing to do.
-
net.jini.core.transaction.server.ServerTransaction.join()
Join the transaction. The crashCount
marks the state of the storage used by the participant for transactions. If the participant attempts to join a transaction more than once, the crash counts must be the same. Each system crash or other event that destroys the state of the participant's unprepared transaction storage must cause the crash count to increase by at least one.
@param part the participant joining the transaction
@param crashCount the participant's current crash count
@throws UnknownTransactionException if the transaction is unknown to the transaction manager, either because the transaction ID is incorrect or because the transaction is complete and its state has been discarded by the manager.
@throws CannotJoinException if the transaction is known to the manager but is no longer active.
@throws CrashCountException if the crash count provided for the participant differs from the crash count in a previous invocation of the same pairing of participant and transaction
@throws RemoteException if there is a communication error
-
net.jxta.membership.MembershipService.join()
-
net.pms.io.ProcessWrapperImpl.join()
-
net.schmizz.sshj.connection.channel.direct.Session.Command.join()
-
net.sf.jabref.collab.ChangeScanner.join()
-
net.sf.jmp3renamer.plugins.Replaygain.gui.ReplaygainPanel.ReplaygainThread.join()
-
net.yacy.search.index.MetadataRepository.Export.join()
-
nl.justobjects.pushlet.client.PushletClient.join()
Join server, starts session.
-
oracle.olapi.data.source.NumberSource.join()
-
oracle.olapi.data.source.Source.join()
-
oracle.olapi.data.source.StringSource.join()
-
org.apache.accumulo.core.util.Daemon.join()
-
org.apache.activemq.util.ConsumerThread.join()
-
org.apache.activemq.util.ProducerThread.join()
-
org.apache.airavata.core.gfac.provider.utils.InputStreamToFileWriter.join()
-
org.apache.airavata.gfac.local.utils.InputStreamToFileWriter.join()
-
org.apache.airavata.gfac.utils.InputStreamToFileWriter.join()
-
org.apache.avro.ipc.HttpServer.join()
-
org.apache.bookkeeper.proto.BookieServer.join()
-
org.apache.clerezza.triaxrs.testutils.BodyCheckerThread.join()
-
org.apache.derbyTesting.system.nstest.utils.MemCheck.join()
-
org.apache.derbyTesting.system.nstest.utils.SequenceReader.join()
-
org.apache.derbyTesting.system.sttest.tools.MemCheck.join()
-
org.apache.directory.studio.connection.core.jobs.StudioConnectionJob.join()
-
org.apache.empire.db.DBCommand.join()
Adds a join to the list of join expressions.
@param join the join expression
-
org.apache.felix.cm.integration.helper.ConfigureThread.join()
-
org.apache.felix.cm.integration.helper.ManagedServiceFactoryThread.join()
-
org.apache.felix.cm.integration.helper.ManagedServiceThread.join()
-
org.apache.flink.client.web.WebInterfaceServer.join()
Lets the calling thread wait until the server terminates its operation.
@throws InterruptedException Thrown, if the calling thread is interrupted.
-
org.apache.flink.runtime.operators.testutils.TaskCancelThread.join()
-
org.apache.geronimo.concurrent.thread.ManagedThread.join()
-
org.apache.geronimo.datastore.impl.remote.messaging.Node.join()
Joins the node uniquely identified on the network by aNodeInfo.
@param aNodeInfo NodeInfo of a remote node to join.
@throws IOException Indicates that an I/O error has occured.
@throws CommunicationException Indicates that the node can not beregistered by the remote node identified by aNodeInfo.
-
org.apache.hadoop.chukwa.inputtools.mdl.ErStreamHandler.join()
-
org.apache.hadoop.hbase.MiniHBaseCluster.join()
Wait for Mini HBase Cluster to shut down.
-
org.apache.hadoop.hbase.ipc.TestDelayedRpc.TestThread.join()
-
org.apache.hadoop.hbase.master.cleaner.HFileCleaner.join()
-
org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceManager.join()
Terminate the replication on this region server
-
org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceManager.NodeFailoverWorker.join()
-
org.apache.hadoop.hbase.util.JVMClusterUtil.MasterThread.join()
-
org.apache.hadoop.hdfs.notifier.server.ServerCore.join()
-
org.apache.hadoop.hdfs.server.datanode.DataStorage.RollbackThread.join()
-
org.apache.hadoop.hdfs.server.datanode.DataStorage.UpgradeThread.join()
-
org.apache.hadoop.hdfs.server.namenode.NameNode.join()
Wait for service to finish. (Normally, it runs forever.)
-
org.apache.hadoop.hive.ql.exec.Utilities.StreamPrinter.join()
-
org.apache.hadoop.mapred.ControlledMapReduceJob.ControlledMapReduceJobRunner.join()
-
org.apache.hadoop.mapred.JvmManager.JvmManagerForType.JvmRunner.join()
-
org.apache.hadoop.util.Daemon.join()
-
org.apache.hive.common.util.StreamPrinter.join()
-
org.apache.ivy.core.IvyThread.join()
-
org.apache.jackrabbit.commons.query.qom.JoinType.join()
-
org.apache.jackrabbit.spi.commons.query.qom.JoinType.join()
-
org.apache.karaf.eik.ui.features.FeaturesResolverJob.join()
-
org.apache.karaf.eik.ui.internal.PopulateObrFileJob.join()
-
org.apache.mina.common.CloseFuture.join()
-
org.apache.mina.common.ConnectFuture.join()
-
org.apache.mina.common.WriteFuture.join()
-
org.apache.mina.core.future.ConnectFuture.join()
-
org.apache.openjpa.jdbc.schema.ForeignKey.join()
Join a local column to a primary key column of another table.
-
org.apache.openjpa.jdbc.sql.Joins.join()
Join the columns of the given foreign key.
-
org.apache.provisionr.core.logging.StreamLogger.join()
-
org.apache.qpid.test.utils.Piper.join()
-
org.apache.sqoop.util.AsyncSink.join()
Wait until the stream has been processed.
@return a status code indicating success or failure. 0 is typical forsuccess.
-
org.apache.wicket.util.string.StringList.join()
-
org.apache.wink.json4j.JSONArray.join()
Method to mimic the behavior of the JavaScript array join function
@param str The string delimiter to place between joined array elements in the output string.
@return A string of all the elements joined together.
-
org.apache.wink.json4j.compat.JSONArray.join()
-
org.apache.ws.jaxme.sqls.SelectTableReference.join()
Indicates that the referenced table shall be joined with the given table pTable
and returns a reference to that table.
-
org.apache.zookeeper.server.NIOServerCnxnFactory.join()
-
org.apache.zookeeper.server.quorum.QuorumPeer.join()
-
org.cipango.server.Server.join()
-
org.codehaus.plexus.compiler.util.StreamPumper.join()
-
org.codehaus.spice.threadpool.ThreadControl.join()
-
org.codehaus.stomp.jms.StompConnect.join()
Joins with the background thread until the transport is stopped
-
org.darkhelm.dragonchess.client.channel.Channel.join()
Join the channel
-
org.eclim.installer.step.command.Command.join()
-
org.eclim.installer.step.command.InfoCommand.join()
-
org.eclim.installer.step.command.InstallCommand.join()
-
org.eclim.installer.step.command.ListCommand.join()
-
org.eclim.installer.step.command.UninstallCommand.join()
-
org.eclipse.core.runtime.jobs.IJobManager.join()
Waits until all jobs of the given family are finished. This method will block the calling thread until all such jobs have finished executing, or until this thread is interrupted. If there are no jobs in the family that are currently waiting, running, or sleeping, this method returns immediately. Feedback on how the join is progressing is provided to a progress monitor.
If this method is called while the job manager is suspended, only jobs that are currently running will be joined; Once there are no jobs in the family in the {@link Job#RUNNING} state, this method returns.
Note that there is a deadlock risk when using join. If the calling thread owns a lock or object monitor that the joined thread is waiting for, deadlock will occur. This method can also result in starvation of the current thread if another thread continues to add jobs of the given family, or if a job in the given family reschedules itself in an infinite loop.
@param family the job family to join, or
null
to join all jobs.
@param monitor Progress monitor for reporting progress on how thewait is progressing, or
null
if no progress monitoring is required.
@exception InterruptedException if this thread is interrupted while waiting
@exception OperationCanceledException if the progress monitor is canceled while waiting
@see Job#belongsTo(Object)
@see #suspend()
-
org.eclipse.core.runtime.jobs.Job.join()
Waits until this job is finished. This method will block the calling thread until the job has finished executing, or until this thread has been interrupted. If the job has not been scheduled, this method returns immediately. A job must not be joined from within the scope of its run method.
If this method is called on a job that reschedules itself from within the run method, the join will return at the end of the first execution. In other words, join will return the first time this job exits the {@link #RUNNING} state, or as soon as this job enters the {@link #NONE} state.
If this method is called while the job manager is suspended, this job will only be joined if it is already running; if this job is waiting or sleeping, this method returns immediately.
Note that there is a deadlock risk when using join. If the calling thread owns a lock or object monitor that the joined thread is waiting for, deadlock will occur.
@exception InterruptedException if this thread is interrupted while waiting
@see ILock
@see IJobManager#suspend()
-
org.eclipse.egit.ui.test.JobJoiner.join()
Join the job. If the job is either not yet scheduled within the timeout or not yet done, an {@link AssertionError} is thrown.
-
org.eclipse.jetty.server.Server.join()
-
org.eclipse.jgit.util.io.StreamCopyThread.join()
-
org.elasticsearch.common.base.Joiner.join()
-
org.evolizer.famix.importer.jobs.FamixParserJob.join()
-
org.evolizer.famix.importer.jobs.FamixStoreModelJob.join()
-
org.exoplatform.services.jcr.load.blob.thread.CreateThread.join()
-
org.exoplatform.services.jcr.load.blob.thread.DeleteThread.join()
-
org.ggp.base.server.GameServer.join()
-
org.hibernate.engine.transaction.spi.TransactionImplementor.join()
Perform a join to the underlying transaction
-
org.hive2hive.core.processes.implementations.files.download.dht.DownloadTaskDHT.join()
-
org.hive2hive.core.processes.implementations.files.download.direct.DownloadTaskDirect.join()
-
org.huihoo.workflow.impl.monitor.EventMonitorThread.join()
-
org.infernus.idea.checkstyle.checker.ScanFilesThread.join()
-
org.jacorb.test.notification.StructuredPushReceiver.join()
-
org.jasig.portal.test.ThreadGroupRunner.join()
Join on all threads (join is in order of added runnable)
-
org.jboss.arquillian.graphene.spi.javascript.JavaScript.join()
Joins this JavaScript object with another JavaScript object to single JavaScript.
@param javaScriptToJoin the JavaScript object we want to join with
@return the joined JavaScript object
-
org.jboss.byteman.tests.helpers.TestThread.join()
-
org.jboss.test.classinfo.support.ErrorHolderThread.join()
-
org.jfree.report.flow.layoutprocessor.LayoutController.join()
Joins with a delegated process flow. This is generally called from a child flow and should *not* (I mean it!) be called from outside. If you do, you'll suffer.
@param flowController the flow controller of the parent.
@return the joined layout controller that incorperates all changes fromthe delegate.
-
org.jivesoftware.smackx.muc.MultiUserChat.join()
Joins the chat room using the specified nickname. If already joined using another nickname, this method will first leave the room and then re-join using the new nickname. The default timeout of Smack for a reply from the group chat server that the join succeeded will be used. After joining the room, the room will decide the amount of history to send.
@param nickname the nickname to use.
@throws XMPPException if an error occurs joining the room. In particular, a401 error can occur if no password was provided and one is required; or a 403 error can occur if the user is banned; or a 404 error can occur if the room does not exist or is locked; or a 407 error can occur if user is not on the member list; or a 409 error can occur if someone is already in the group chat with the same nickname.
-
org.jpox.store.mapped.expression.ClassExpression.join()
Method to add a join expression for this class.
@param expr Expression to join to
@return This expression
-
org.jruby.RubyArray.join()
rb_ary_join
-
org.mctourney.autoreferee.AutoRefTeam.join()
Adds a player to this team. Players may not be added to teams if the match is already in progress.
@return true if player was successfully added, otherwise false
-
org.mobicents.mscontrol.MsLink.join()
-
org.modeshape.jcr.api.query.qom.QueryObjectModelFactory.join()
-
org.mortbay.jetty.Server.join()
-
org.netbeans.server.uihandler.statistics.NetBeansModules.join()
-
org.openrdf.sail.rdbms.evaluation.SqlJoinBuilder.join()
-
org.openstreetmap.osmosis.core.pipeline.common.TaskRunner.join()
-
org.qzerver.model.agent.action.providers.executor.http.threads.HttpOutputThread.join()
-
org.qzerver.model.agent.action.providers.executor.localcommand.threads.ProcessExecutionThread.join()
-
org.sf.mustru.utils.IndexTools.join()
-
org.snmp4j.util.WorkerTask.join()
Waits until this task has been finished.
-
org.syrup.helpers.Writer.join()
-
org.terasology.network.NetworkSystem.join()
-
org.terasology.network.internal.NetworkSystemImpl.join()
-
org.tuba.integration.IntegrationJob.join()
-
org.voltdb.ServerThread.join()
-
org.webmacro.broker.ResourceBroker.join()
-
org.wicketstuff.progressbar.spring.AsynchronousExecutor.join()
-
railo.runtime.thread.ChildThread.join()
-
se.llbit.chunky.renderer.BenchmarkManager.join()
-
smartrics.rest.test.fitnesse.fixture.HttpServer.join()
-
smilehouse.opensyncro.system.PipeExecutionThread.join()
-
solver.thread.ThreadSolver.join()
-
stanfordlogic.network.ConnectionManager.join()
-
storm.trident.TridentTopology.join()
-
tachyon.TachyonURI.join()
Append additional path elements to the end of a TachyonURI.
@param suffix the suffix to add
@return the new TachyonURI
-
thread.concurrencyCookbook.chapter5.recipe03.FolderProcessor.join()
-
xnap.plugin.nap.util.PrivateChannel.join()