-
abstrasy.InterpreterSemaphore.resume()
Réveille l'acteur thread... Depuis REV6251(31/01/2011): Ne fragmente plus le verrouillage du semaphore. resume n'est pas bloquant. Il peut donc être utilisé dans une section critique.
@param thread
@throws Exception
-
avrora.sim.Simulation.resume()
The resume()
method resumes the simulation after it has been paused.
-
bitronix.tm.BitronixTransactionManager.resume()
-
bitronix.tm.internal.XAResourceManager.resume()
Resume all enlisted resources in the current transaction context.
@throws XAException if the resource threw an exception during resume.
-
com.arjuna.ats.internal.jta.transaction.arjunacore.TransactionManagerImple.resume()
Unlike the OTS, if we are already associated with a transaction then we cannot call resume.
-
com.arjuna.ats.internal.jts.orbspecific.CurrentImple.resume()
To support checked transactions we can only resume if the action is local or we received it implicitly. If the control refers to a nested transaction then we must recreate the entire hierarchy, i.e., the effect of a suspend/resume on the same control should be the same as never calling suspend in the first place. If the control is for a local transaction then it is simple to recreate the hierarchy. Otherwise we rely upon the PropagationContext to recreate it. If this control is a "proxy" then create a new proxy instance, so we can delete proxies whenever suspend is called. Should check if "new" transaction is not actually the current one anyway. If so, just return. The spec. doesn't mention what to do in this case, so for now we go to the overhead of the work regardless.
-
com.arjuna.mw.wsas.UserActivity.resume()
Given a token representing a context, associate it with the current thread of control. This will implicitly disassociate the thread from any activities that it may already be associated with. If the parameter is null then the thread is associated with no activity.
@param tx The activity to associate with this thread. Thismay be null in which case the current thread becomes associated with no activity.
@exception InvalidActivityException Thrown if the activity handleis invalid in this context.
@exception SystemException Thrown if any other error occurs.
-
com.arjuna.mw.wscf.model.twophase.api.CoordinatorManager.resume()
-
com.arjuna.mw.wscf.model.twophase.api.UserCoordinator.resume()
Given a token representing a context, associate it with the current thread of control. This will implicitly disassociate the thread from any activities that it may already be associated with. If the parameter is null then the thread is associated with no activity.
@param tx The activity to associate with this thread. Thismay be null in which case the current thread becomes associated with no activity.
@exception InvalidActivityException Thrown if the activity handleis invalid in this context.
@exception SystemException Thrown if any other error occurs.
-
com.arjuna.mw.wst.BusinessActivityManager.resume()
The resume method can be used to (re-)associate a thread with a transaction(s) via its TxContext. Prior to association, the thread is disassociated with any transaction(s) with which it may be currently associated. If the TxContext is null, then the thread is associated with no transaction. The UnknownTransactionException exception is thrown if the transaction that the TxContext refers to is invalid in the scope of the invoking thread.
-
com.arjuna.mw.wst.TransactionManager.resume()
The resume method can be used to (re-)associate a thread with a transaction(s) via its TxContext. Prior to association, the thread is disassociated with any transaction(s) with which it may be currently associated. If the TxContext is null, then the thread is associated with no transaction. The UnknownTransactionException exception is thrown if the transaction that the TxContext refers to is invalid in the scope of the invoking thread.
-
com.arjuna.mw.wst11.TransactionManager.resume()
The resume method can be used to (re-)associate a thread with a transaction(s) via its TxContext. Prior to association, the thread is disassociated with any transaction(s) with which it may be currently associated. If the TxContext is null, then the thread is associated with no transaction. The UnknownTransactionException exception is thrown if the transaction that the TxContext refers to is invalid in the scope of the invoking thread.
-
com.atomikos.datasource.xa.XAResourceTransaction.resume()
@see ResourceTransaction.
-
com.atomikos.icatch.CompositeTransactionManager.resume()
Re-maps the calling thread to the given transaction.
@param compositeTransaction
@exception IllegalStateException If this thread has a transaction context already.
@exception SysException
-
com.caucho.transaction.TransactionManagerImpl.resume()
Resume the transaction.
-
com.founder.fix.fixflow.core.impl.runtime.ProcessInstanceEntity.resume()
-
com.founder.fix.fixflow.core.impl.runtime.TokenEntity.resume()
-
com.founder.fix.fixflow.core.task.TaskInstance.resume()
恢复任务
-
com.founder.fix.fixflow.core.task.TaskMgmtInstance.resume()
恢复这个令牌下的所有任务实例
-
com.google.enterprise.connector.util.diffing.CheckpointAndChangeQueue.resume()
Returns an {@link Iterator} for currently available{@link CheckpointAndChange} objects that occur after the passed incheckpoint. The {@link String} form of a {@link DiffingConnectorCheckpoint}passed in is produced by calling {@link DiffingConnectorCheckpoint#toString()}. As a side effect, Objects up to and including the object with the passed in checkpoint are removed from this queue.
@param checkpointString null means return all {@link CheckpointAndChange}objects and a non null value means to return {@link CheckpointAndChange} objects with checkpoints after thepassed in value.
@throws IOException if error occurs while manipulating recovery state
-
com.lightcrafts.utils.directory.DirectoryMonitor.resume()
Resume monitoring of and notification about directories (but only if the call to resume()
has balanced all previous calls to {@link #suspend()}.
@param force If true
, force resumption and monitoring andnotification.
-
com.linkedin.databus.client.pub.DatabusV3Registration.resume()
Resume traffic consumption. This is an asynchronous call to the component which pulls events from the relay. This can be called when the consumption is paused/suspended.
@throws IllegalStateException If the registration is not paused or suspended.
-
com.linkedin.databus.core.util.RateMonitor.resume()
-
com.lowagie.text.pdf.PdfWriter.resume()
-
com.lowagie.text.rtf.RtfWriter2.resume()
-
com.netflix.logging.messaging.MessageBatcher.resume()
Resume the collector. The collector resumes picking up messages from the queue and calling the processors.
-
com.opengamma.engine.view.client.ViewClient.resume()
Resumes the flow of results exposed through this client.
-
com.sun.grid.jgrid.Job.resume()
Notifies this job that it should resume execution. This method calls Computable.resume() and sets the state to RUNNING.
-
com.sun.jdi.ThreadReference.resume()
Resumes this thread. If this thread was not previously suspended through {@link #suspend} or through {@link VirtualMachine#suspend}, or because of a SUSPEND_ALL or SUSPEND_EVENT_THREAD event, then invoking this method has no effect. Otherwise, the count of pending suspends on this thread is decremented. If it is decremented to 0, the thread will continue to execute. Note: the normal way to resume from an event related suspension is via {@link com.sun.jdi.event.EventSet#resume}.
@throws VMCannotBeModifiedException if the VirtualMachine is read-only - see {@link VirtualMachine#canBeModified()}.
-
com.sun.jdi.VirtualMachine.resume()
Continues the execution of the application running in this virtual machine. All threads are resumed as documented in {@link ThreadReference#resume}.
@throws VMCannotBeModifiedException if the VirtualMachine is read-only - see {@link VirtualMachine#canBeModified()}.
@see #suspend
-
com.sun.jdi.event.EventSet.resume()
Resumes threads suspended by this event set. If the {@link #suspendPolicy}is {@link com.sun.jdi.request.EventRequest#SUSPEND_ALL}, a call to this method is equivalent to {@link com.sun.jdi.VirtualMachine#resume}. If the suspend policy is {@link com.sun.jdi.request.EventRequest#SUSPEND_EVENT_THREAD}, a call to this method is equivalent to {@link com.sun.jdi.ThreadReference#resume} for the event thread.Otherwise, a call to this method is a no-op.
-
com.sun.messaging.jmq.jmsserver.core.Consumer.resume()
-
com.sun.messaging.jmq.jmsserver.core.Session.resume()
-
com.sun.messaging.jmq.jmsserver.core.Subscription.resume()
-
com.sun.messaging.jmq.jmsserver.service.imq.IMQConnection.resume()
-
com.sun.scenario.animation.Clip.resume()
-
com.sun.xml.ws.api.pipe.Fiber.resume()
Wakes up a suspended fiber.
If a fiber was suspended without specifying the next {@link Tube}, then the execution will be resumed in the response processing direction, by calling the {@link Tube#processResponse(Packet)} method on the next/first {@link Tube} in the {@link Fiber}'s processing stack with the specified resume packet as the parameter.
If a fiber was suspended with specifying the next {@link Tube}, then the execution will be resumed in the request processing direction, by calling the next tube's {@link Tube#processRequest(Packet)} method with the specified resume packet as the parameter.
This method is implemented in a race-free way. Another thread can invoke this method even before this fiber goes into the suspension mode. So the caller need not worry about synchronizing {@link NextAction#suspend()} and this method.
@param resumePacket packet used in the resumed processing
-
com.teamjmonkey.controls.MoveRandomControl.resume()
-
com.uwyn.drone.core.Bot.resume()
-
de.danet.an.workflow.api.Activity.resume()
-
de.danet.an.workflow.localcoreapi.WfProcessLocal.resume()
-
de.danet.an.workflow.omgcore.WfActivity.resume()
-
de.danet.an.workflow.omgcore.WfProcess.resume()
-
de.scoopgmbh.copper.tranzient.TransientProcessorPool.resume()
-
edu.uci.ics.jung.algorithms.layout.util.Relaxer.resume()
Make the relaxer thread resume.
-
io.vertx.core.net.NetSocket.resume()
-
io.vertx.core.net.NetSocketStream.resume()
-
it.sauronsoftware.cron4j.TaskExecutor.resume()
Resumes the execution after it has been paused.
-
javax.speech.synthesis.Synthesizer.resume()
-
javax.transaction.TransactionManager.resume()
-
javax.ws.rs.container.AsyncResponse.resume()
Resume the suspended request processing using the provided response data.
The provided response data can be of any Java type that can be returned from a {@link javax.ws.rs.HttpMethod JAX-RS resource method}. The processing of the data by JAX-RS framework follows the same path as it would for the response data returned synchronously by a JAX-RS resource method. The asynchronous response must be still in a {@link #isSuspended() suspended} statefor this method to succeed.
@param response data to be sent back in response to the suspended request.
@return {@code true} if the request processing has been resumed, returns {@code false} in casethe request processing is not {@link #isSuspended() suspended} and could not be resumed.
@see #resume(Throwable)
-
juzu.impl.request.ContextLifeCycle.resume()
Resume the current context life cycle.
-
kilim.Task.resume()
Add itself to scheduler if it is neither already running nor done.
@return True if it scheduled itself.
-
mage.game.Game.resume()
-
mage.utils.timer.PriorityTimer.resume()
-
net.cakenet.jsaton.script.Script.resume()
-
net.jodah.concurrentunit.Waiter.resume()
Resumes the waiter when the expected number of {@link #resume()} calls have occurred.
@throws IllegalStateException if the waiter is not expecting resume to be called
-
net.rim.device.api.io.messaging.Destination.resume()
-
nginx.clojure.Coroutine.resume()
Runs the Coroutine until it is finished or suspended. This method must only be called when the Coroutine is in the states NEW or SUSPENDED. It is not multi threading safe.
@throws java.lang.IllegalStateException if the Coroutine is currently running or already finished.
-
open.dolphin.infomodel.DiagnosisLiteModel.resume()
-
org.apache.avalon.excalibur.testcase.FullLifecycleComponent.resume()
-
org.apache.axis2.engine.AxisEngine.resume()
Resume processing of a message.
@param msgctx
@return An InvocationResponse allowing the invoker to perhaps determinewhether or not the message processing will ever succeed.
@throws AxisFault
-
org.apache.camel.CamelContext.resume()
-
org.apache.camel.SuspendableService.resume()
Resumes the service.
-
org.apache.camel.component.http.HttpConsumer.resume()
-
org.apache.camel.impl.DefaultCamelContext.resume()
-
org.apache.cxf.continuations.Continuation.resume()
Resume a suspended request
-
org.apache.cxf.interceptor.InterceptorChain.resume()
-
org.apache.cxf.phase.PhaseInterceptorChain.resume()
-
org.apache.falcon.client.FalconClient.resume()
-
org.apache.ftpserver.FtpServer.resume()
Resume the server handler
-
org.apache.geronimo.transaction.UnspecifiedTransactionContext.resume()
-
org.apache.geronimo.transaction.context.UnspecifiedTransactionContext.resume()
-
org.apache.ivory.client.IvoryClient.resume()
-
org.apache.jmeter.protocol.jms.client.OnMessageSubscriber.resume()
resume will call Connection.start() to begin receiving inbound messages.
-
org.apache.myfaces.trinidad.context.ComponentContextManager.resume()
Resume a set of suspended changes.
@param facesContext the faces context
@param suspendedChanges a set of changes that have been previously suspended
@return Iterator of changes that were resumedduring the call (iterates in the earliest to most recent order).
-
org.apache.ode.bpel.engine.DebuggerSupport.resume()
-
org.apache.oodt.cas.workflow.engine.IterativeWorkflowProcessorThread.resume()
-
org.apache.oozie.BundleEngine.resume()
-
org.apache.oozie.CoordinatorEngine.resume()
-
org.apache.oozie.DagEngine.resume()
Resume a job.
@param jobId job Id.
@throws DagEngineException thrown if the job could not be resumed.
-
org.apache.oozie.client.OozieClient.resume()
Resume a workflow job.
@param jobId job Id.
@throws OozieClientException thrown if the job could not be resume.
-
org.apache.oozie.client.XOozieClient.resume()
-
org.apache.servicemix.wsn.client.Subscription.resume()
-
org.apache.sling.event.jobs.Queue.resume()
Resume a suspended queue. {@link #suspend()}. If the queue is not suspended, calling this method has no effect. Depending on the queue implementation, if a job failed a job queue might sleep for a configured time, before a new job is processed. By calling this method, the job queue can be woken up and force an immediate reprocessing. This feature is only supported by ordered queues at the moment. If a queue does not support this feature, calling this method has only an effect if the queue is really suspended.
-
org.apache.ws.notification.base.Subscription.resume()
Resumes the delivery of notification messages for this subscription.
@throws Exception if unable to resume message delivery
-
org.atmosphere.cpr.AtmosphereResource.resume()
Complete the {@link HttpServletResponse} and finish/commit it. If the{@link HttpServletResponse} is in the process of being resumed, invokingthat method has no effect.
-
org.atmosphere.cpr.AtmosphereResourceImpl.resume()
{@inheritDoc}
-
org.atmosphere.cpr.Meteor.resume()
Resume the underlying {@link HttpServletResponse}
@return {@link Meteor}
-
org.codehaus.plexus.component.manager.ComponentManager.resume()
-
org.eclim.plugin.jdt.command.debug.context.DebuggerContext.resume()
Resumes execution from the current breakpoint.
-
org.eclim.plugin.jdt.command.debug.context.ThreadContext.resume()
Resumes execution of the given thread.
-
org.eclipse.core.runtime.jobs.IJobManager.resume()
Resumes execution of jobs after a previous
suspend
. All jobs that were sleeping or waiting prior to the suspension, or that were scheduled while the job manager was suspended, will now be eligible for execution.
Calling this method on a rule that is not suspended has no effect. If another thread also owns the rule at the time this method is called, then the rule will not be resumed until all threads have released the rule.
@deprecated This method is not safe and should not be used.Suspending a scheduling rule violates the thread safety of clients that use scheduling rules as a mutual exclusion mechanism, and can result in concurrency problems in all clients that use the suspended rule.
@see #suspend(ISchedulingRule,IProgressMonitor)
-
org.eclipse.debug.core.model.IDebugTarget.resume()
-
org.eclipse.debug.core.model.IThread.resume()
-
org.eclipse.jdt.debug.core.IJavaThread.resume()
-
org.eclipse.jetty.continuation.Continuation.resume()
Resume a suspended request.
This method can be called by any thread that has been passed a reference to a continuation. When called the request is redispatched to the normal filter chain and servlet processing with {@link #isInitial()} false.
If resume is called before a suspended request is returned to the container (ie the thread that called {@link #suspend()} is stillwithin the filter chain and/or servlet service method), then the resume does not take effect until the call to the filter chain and/or servlet returns to the container. In this case both {@link #isSuspended()} and{@link #isResumed()} return true. Multiple calls to resume are ignored.
Typically resume() is used after a call to {@link #suspend()} withno arguments. The dispatch after a resume call will use the original request and response objects, even if {@link #suspend(ServletResponse)} had been passed a wrapped response.
@see #suspend()
@exception IllegalStateException if the request is not suspended.
-
org.encog.neural.networks.training.propagation.back.Backpropagation.resume()
Resume training.
@param state The training state to return to.
-
org.encog.neural.networks.training.propagation.resilient.ResilientPropagation.resume()
Resume training.
@param state The training state to return to.
-
org.glassfish.grizzly.filterchain.FilterChainContext.resume()
Resume processing of the current task
-
org.glassfish.jersey.server.internal.process.AsyncContext.resume()
-
org.graylog2.restclient.models.Node.resume()
-
org.gudy.azureus2.core3.download.DownloadManager.resume()
-
org.hornetq.api.core.management.QueueControl.resume()
Resumes the queue. Messages are again delivered to its consumers.
-
org.hornetq.api.jms.management.JMSQueueControl.resume()
Resumes the queue. Messages are again delivered to its consumers.
-
org.hornetq.core.server.Queue.resume()
Resumes the delivery of message for the queue. If a queue is resumed, resuming it again will only throw a warning. To check if a queue is resumed, invoke isPaused()
-
org.hornetq.core.server.impl.QueueImpl.resume()
-
org.hornetq.core.transaction.Transaction.resume()
-
org.hornetq.jms.bridge.JMSBridge.resume()
-
org.hyperic.sigar.win32.Service.resume()
-
org.infinispan.transaction.tm.DummyTransactionManager.resume()
-
org.jboss.cache.transaction.DummyTransactionManager.resume()
-
org.jboss.resteasy.spi.ResteasyAsynchronousResponse.resume()
-
org.jbpm.graph.exe.ProcessInstance.resume()
resumes a suspended execution. All timers that have been suspended might fire if the duedate has been passed. If an admin resumes a process instance, the option should be offered to update, remove and create the timers and messages related to this process instance.
@see #suspend()
-
org.jbpm.pvm.internal.repository.DeploymentImpl.resume()
-
org.jbpm.task.service.TaskClient.resume()
-
org.jbpm.taskmgmt.exe.TaskMgmtInstance.resume()
resumes all task instances for this process instance.
-
org.libvirt.Domain.resume()
-
org.luaj.vm2.LuaThread.resume()
Start or resume this thread
@param args The arguments to send as return values to {@link #yield(Varargs)}
@return {@link Varargs} provided as arguments to {@link #yield(Varargs)}
-
org.mortbay.jetty.nio.SelectChannelConnector.RetryContinuation.resume()
-
org.mortbay.util.ajax.Continuation.resume()
Resume the request. Resume a suspended request. The passed event will be returned in the getObject method.
-
org.mule.api.service.Service.resume()
Resumes a single Mule Service that has been paused. If the service is not paused nothing is executed.
-
org.mule.api.transaction.Transaction.resume()
Resume the XA transaction
@throws TransactionException if any error
-
org.ofbiz.workflow.WfActivity.resume()
-
org.ofbiz.workflow.client.WorkflowClient.resume()
Resume an activity
@param workEffortId The WorkEffort entity key for the activity object
@throws WfException
-
org.omg.CosTransactions.Current.resume()
-
org.red5.server.api.stream.ISubscriberStream.resume()
Resume from a position for current playing item.
@param position Position for resume in millisecond.
-
org.richfaces.application.push.Request.resume()
Resume the underlying response object
-
org.speakright.core.SRInstance.resume()
Resume (after pausing). Only used by async transactions (IFlow.onComplete).
-
org.springframework.batch.core.job.flow.Flow.resume()
@param stateName the name of the state to resume on
@param executor the context to be passed into each state executed
@return a {@link FlowExecution} containing the exit status of the flow
@throws FlowExecutionException
-
org.springframework.transaction.support.TransactionSynchronization.resume()
Resume this synchronization. Supposed to rebind resources to TransactionSynchronizationManager if managing any.
@see TransactionSynchronizationManager#bindResource
-
org.springframework.webflow.engine.Flow.resume()
Resume a paused session for this flow in its current view state.
@param context the flow execution control context
@throws FlowExecutionException when an exception occurs during the resume operation
-
org.springframework.webflow.execution.FlowExecution.resume()
Resume this flow execution. May be called when the flow execution is paused. 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 resumed again.
@param context the external context, representing the calling environment, where something happened this flowexecution should respond to
@throws FlowExecutionException if an exception was thrown within a state of the resumed flow execution duringevent processing
-
ptolemy.actor.Manager.resume()
If the model is paused, resume execution. This method must be called from a different thread than that controlling the execution, since the thread controlling the execution is suspended.
-
sounds.Sound.resume()
-
sounds.WavSound.resume()