-
akka.actor.Cancellable.cancel()
-
artofillusion.util.ThreadManager.cancel()
Cancel a run which is in progress. Calling this method does not interrupt any tasks that are currently executing, but it prevents any more from being started until the next time run() is called.
-
au.edu.qut.yawl.engine.YNetRunner.cancel()
-
azkaban.flow.ExecutableFlow.cancel()
Cancels a running flow
@return Whether the flow was canceled
-
ch.ethz.inf.vs.californium.coap.Request.cancel()
-
ch.ethz.inf.vs.californium.observe.ObserveRelation.cancel()
Cancel this observe relation. This methods invokes the cancel methods of the resource and the endpoint.
-
ch.njol.skript.util.Task.cancel()
Cancels this task.
-
ch.tatool.element.Executable.cancel()
Cancels the execution. This method allows the system to gracefully cancel an execution. The Executable should try to finish any ongoing work and return execute as soon as possible.
-
code.satyagraha.gfm.viewer.bots.PreferencesBot.cancel()
-
com.aelitis.azureus.core.networkmanager.impl.tcp.VirtualChannelSelectorImpl.cancel()
-
com.alibaba.druid.proxy.jdbc.CallableStatementProxyImpl.cancel()
-
com.alibaba.dubbo.remoting.exchange.support.DefaultFuture.cancel()
-
com.arjuna.mw.wscf.model.twophase.api.CoordinatorManager.cancel()
-
com.arjuna.mw.wscf.model.twophase.api.UserCoordinator.cancel()
Cancel the activity.
@exception InvalidActivityException Thrown if the current activity isinvalid in the execution environment.
@exception WrongStateException Thrown if the current activity is not in astate that allows it to be completed, or is incompatible with the completion status provided.
@exception ProtocolViolationException Thrown if the a violation of theactivity service or HLS protocol occurs.
@exception NoPermissionException Thrown if the invoking thread doesnot have permission to terminate the transaction.
@exception SystemException Thrown if some other error occurred.
@see com.arjuna.mw.wsas.activity.Outcome
-
com.arjuna.mw.wst.UserBusinessActivity.cancel()
If the BA must undo its work then the cancel method is used. Any participants that can compensate are forced to do so.
-
com.arjuna.mw.wst11.UserBusinessActivity.cancel()
If the BA must undo its work then the cancel method is used. Any participants that can compensate are forced to do so.
-
com.arjuna.webservices.wsba.CoordinatorCompletionParticipantInboundEvents.cancel()
Handle the cancel event.
@param cancel The cancel notification.
@param addressingContext The addressing context.
@param arjunaContext The arjuna context.
-
com.arjuna.webservices.wsba.ParticipantCompletionParticipantInboundEvents.cancel()
Handle the cancel event.
@param cancel The cancel notification.
@param addressingContext The addressing context.
@param arjunaContext The arjuna context.
-
com.arjuna.webservices11.wsba.CoordinatorCompletionParticipantInboundEvents.cancel()
Handle the cancel event.
@param cancel The cancel notification.
@param addressingProperties The addressing context.
@param arjunaContext The arjuna context.
-
com.arjuna.webservices11.wsba.ParticipantCompletionParticipantInboundEvents.cancel()
Handle the cancel event.
@param cancel The cancel notification.
@param addressingProperties The addressing context.
@param arjunaContext The arjuna context.
-
com.arjuna.wst.BusinessActivityTerminator.cancel()
-
com.arjuna.wst.stub.BusinessActivityTerminatorStub.cancel()
-
com.arjuna.wst11.BusinessActivityTerminator.cancel()
Handle the cancel event.
@param cancel The cancel notification.
@param addressingProperties The addressing context.
@param arjunaContext The arjuna context.Active -> Canceling Canceling -> Canceling Completing -> Canceling Completed -> Completed (resend Completed) Closing -> Closing Compensating -> Compensating Failing-Active -> Failing-Active (resend Fail) Failing-Canceling -> Failing-Canceling (resend Fail) Failing-Completing -> Failing-Completing (resend Fail) Failing-Compensating -> Failing-Compensating NotCompleting -> NotCompleting (resend CannotComplete) Exiting -> Exiting (resend Exit) Ended -> Ended (send Canceled)
-
com.arjuna.wst11.stub.BusinessActivityTerminatorStub.cancel()
-
com.atlauncher.workers.InstanceInstaller.cancel()
-
com.cisco.server.ServerService.cancel()
Stops the server
@throws IllegalStateException if the server is already stopped
-
com.cloudhopper.commons.util.windowing.WindowFuture.cancel()
Completes (as a cancel) a request. This method will set the done timestamp to System.currentTimeMillis().
-
com.couchbase.client.http.AsyncConnectionRequest.cancel()
-
com.couchbase.client.http.RequestHandle.cancel()
-
com.datastax.driver.core.ResultSetFuture.cancel()
re any resource used by this query driver // side is released immediately ... handle timeout ... }
@param mayInterruptIfRunning the value of this parameter is currentlyignored.
@return {@code false} if the future could not be cancelled (it has alreadycompleted normally); {@code true} otherwise.
-
com.dbxml.db.core.transaction.Transaction.cancel()
commit ends a transaction by rolling back all data. This method, in turn, should call the cancel methods of all participating Collections' Transaction Logs.
-
com.ericsson.ssa.sip.timer.ServletTimerImpl.cancel()
-
com.eviware.soapui.impl.wsdl.testcase.WsdlTestCaseRunner.cancel()
-
com.eviware.soapui.model.testsuite.TestStep.cancel()
-
com.facebook.presto.importer.JobStateFactory.JobState.cancel()
-
com.github.couchapptakeout.events.utils.FileDownloader.cancel()
-
com.globant.google.mendoza.malbec.Order.cancel()
Cancels the order. If the order has been charged, you must refund it before you can cancel it. Possible invalid state errors for cancel-order: the order is not in a financial order state that can be cancelled.
@param reason The reason the order was cancelled. Cannot be null.
@param comment An optional comment. Note that this comment will be visibleto the buyer in the order history. It can be null.
-
com.google.common.jimfs.AbstractWatchService.Key.cancel()
-
com.google.common.util.concurrent.ListenableFuture.cancel()
-
com.google.enterprise.connector.pusher.Pusher.cancel()
Cancels a feed. Discard any accumulated feed data.
-
com.google.gwt.animation.client.Animation.cancel()
Immediately cancel this animation. If the animation is running or is scheduled to run, {@link #onCancel()} will be called.
-
com.google.gwt.animation.client.AnimationScheduler.AnimationHandle.cancel()
-
com.google.gwt.http.client.Request.cancel()
Cancels a pending request. If the request has already been canceled or if it has timed out no action is taken.
-
com.google.gwt.user.client.Event.NativePreviewEvent.cancel()
-
com.google.gwt.user.client.Timer.cancel()
Cancels this timer. If the timer is not running, this is a no-op.
-
com.google.gwt.user.client.rpc.impl.FailedRequest.cancel()
-
com.hazelcast.executor.impl.DistributedExecutorService.cancel()
-
com.hazelcast.mapreduce.impl.task.JobSupervisor.cancel()
-
com.hazelcast.util.scheduler.EntryTaskScheduler.cancel()
-
com.hp.hpl.jena.sparql.engine.iterator.QueryIterConcat.cancel()
-
com.intellij.openapi.progress.ProgressIndicator.cancel()
-
com.intellij.openapi.ui.popup.JBPopup.cancel()
Cancels the popup (as if Esc was pressed).
-
com.jboss.transaction.txinterop.webservices.bainterop.generated.ParticipantPortType.cancel()
-
com.l2jfrozen.gameserver.model.quest.QuestTimer.cancel()
-
com.linkedin.parseq.Cancellable.cancel()
Attempts to cancel the object with the given reason. Check the return value to determine if cancellation was successful. Subsequent calls to cancel will always return {@code false}.
@param reason an Exception indicating why this object was cancelled
@return {@code true} iff the object was successfully cancelled as a resultof this invocation.
-
com.linkedin.r2.util.Cancellable.cancel()
Attempts to cancel the action represented by this Cancellable.
@return true if the action was cancelled; false the action could not be cancelled,either because it has already occurred or for some other reason.
-
com.opengamma.util.async.Cancelable.cancel()
Attempts to cancel the operation.
@param mayInterruptIfRunning true if the thread can be interrupted, false if tasks should be allowed to complete naturally
@return true if the operation was canceled
-
com.ourlinc.helloworld.model.Activity.cancel()
取消活动
-
com.puppetlabs.geppetto.forge.v3.ProgressMonitor.cancel()
Marks this monitor as cancelled
-
com.sleepycat.je.rep.utilint.ServiceDispatcher.cancel()
Cancels the registration of a service. Subsequent attempts to access the service will be ignored and the channel will be closed and will not be queued.
@param serviceName the name of the service being cancelled
-
com.stripe.model.Transfer.cancel()
-
com.sun.grid.jgrid.Job.cancel()
Notifies this job that it should cancel execution. This method calls Computable.cancel() and sets the state to STOPPED.
@throws NotInterruptableException Thrown if the Computable does not implement interruption for cancelation.
-
com.sun.jini.thread.RetryTask.cancel()
Cancel the retrying of the task. This ensures that there will be no further attempts to invoke tryOnce
. It will not interfere with any ongoing invocation of tryOnce
unless a subclass overrides this to do so. Any override of this method should invoke super.cancel()
.
-
com.sun.sgs.app.PeriodicTaskHandle.cancel()
Cancels attempts to run the associated task in future periods. Calling this method has no effect on runs of the task for the current period if an attempt to run the task for that period has already begun. Cancelling a periodic task may involve removing an associated managed object maintained internally by the TaskManager
. The system will make an effort to flag subsequent references to the removed object by throwing {@link ObjectNotFoundException} when this method iscalled, although that behavior is not guaranteed.
@throws ObjectNotFoundException if the task has already been cancelledand removed
@throws TransactionException if the operation failed because of aproblem with the current transaction
-
com.sun.sgs.kernel.RecurringTaskHandle.cancel()
Cancels the associated recurring task. A recurring task may be cancelled before it is started.
@throws IllegalStateException if the task has already been cancelled
-
com.sun.sgs.kernel.TaskReservation.cancel()
Cancels this reservation, releaseing the reserved space in the scheduler for the associated task or tasks.
@throws IllegalStateException if the reservation has already beenused or cancelled
-
com.sun.star.util.XCancellable.cancel()
-
com.sun.xml.ws.security.secconv.WSSCContract.cancel()
Cancel a SecurityContextToken
-
com.taobao.zeus.jobs.Job.cancel()
-
com.xeiam.xchange.coinsetter.service.polling.CoinsetterOrderServiceRaw.cancel()
-
commonj.timers.Timer.cancel()
-
de.sciss.app.AbstractCompoundEdit.cancel()
Cancels the compound edit and undos all sub edits made so far.
@synchronization waitExclusive on the given LockManager and doors.however, the caller must block all addEdit
and the end
or cancel
call into a sync block itself to prevent confusion by intermitting calls to the locked objects.
-
de.sciss.eisenkraut.edit.BasicCompoundEdit.cancel()
-
de.sciss.meloncillo.edit.BasicCompoundEdit.cancel()
-
de.sciss.meloncillo.edit.CompoundSessionObjEdit.cancel()
-
de.willuhn.jameica.hbci.synchronize.SynchronizeSession.cancel()
Bricht die Synchronisierung ab.
-
desmoj.core.simulator.ExternalEvent.cancel()
-
edu.emory.mathcs.backport.java.util.concurrent.Future.cancel()
Attempts to cancel execution of this task. This attempt will fail if the task has already completed, already been cancelled, or could not be cancelled for some other reason. If successful, and this task has not started when cancel is called, this task should never run. If the task has already started, then the mayInterruptIfRunning parameter determines whether the thread executing this task should be interrupted in an attempt to stop the task.
@param mayInterruptIfRunning true if the thread executing thistask should be interrupted; otherwise, in-progress tasks are allowed to complete
@return false if the task could not be cancelled,typically because it has already completed normally; true otherwise
-
edu.emory.mathcs.backport.java.util.concurrent.ScheduledFuture.cancel()
-
elemental.util.Timer.cancel()
Cancels this timer.
-
er.ajax.AjaxProgress.cancel()
Cancels this procedure.
-
eu.stratosphere.nephele.template.AbstractInvokable.cancel()
This method is called when a task is canceled either as a result of a user abort or an execution failure. It can be overwritten to respond to shut down the user code properly.
@throws Exception thrown if any exception occurs during the execution of the user code
-
freenet.client.async.ClientGetter.cancel()
Cancel the request. This must result in onFailure() being called in order to send the client a cancel FetchException, and to removeFrom() the state.
-
freenet.client.async.ClientRequester.cancel()
Cancel the request. Subclasses must implement to actually tell the ClientGetState's or ClientPutState's to cancel.
@param context The ClientContext object including essential but non-persistent objects such as the schedulers.
-
freenet.clients.fcp.ClientRequest.cancel()
-
freenet.node.updater.UpdateOverMandatoryManager.UOMDependencyFetcher.cancel()
-
games.stendhal.client.gui.ProgressBar.cancel()
Exits quickly.
-
henplus.view.util.CancelWriter.cancel()
cancel out the written string and wipe it with spaces.
-
hudson.model.Queue.cancel()
Cancels the item in the queue. If the item is scheduled more than once, cancels the first occurrence.
@return true if the project was indeed in the queue and was removed.false if this was no-op.
-
io.apigee.trireme.core.ScriptFuture.cancel()
-
io.netty.channel.ChannelFuture.cancel()
Cancels the I/O operation associated with this future and notifies all listeners if canceled successfully.
@return {@code true} if and only if the operation has been canceled.{@code false} if the operation can't be canceled or is alreadycompleted.
-
io.netty.util.Timeout.cancel()
Cancels the {@link TimerTask} associated with this handle. It thetask has been executed or cancelled already, it will return with no side effect.
-
io.undertow.websockets.core.WebSocketChannel.cancel()
-
io.vertx.core.TimeoutStream.cancel()
Cancels the timeout. Note this has the same effect as calling {@link #handler(Handler)} with a nullargument.
-
java.nio.channels.SelectionKey.cancel()
Cancels this key.
-
java.nio.file.WatchKey.cancel()
Cancels the registration with the watch service. Upon return the watch key will be invalid. If the watch key is enqueued, waiting to be retrieved from the watch service, then it will remain in the queue until it is removed. Pending events, if any, remain pending and may be retrieved by invoking the {@link #pollEvents pollEvents} method after the key iscancelled.
If this watch key has already been cancelled then invoking this method has no effect. Once cancelled, a watch key remains forever invalid.
-
java.sql.CallableStatement.cancel()
-
java.sql.PreparedStatement.cancel()
-
java.sql.Statement.cancel()
Cancels this Statement execution if both the database and the JDBC driver support aborting an SQL statement in flight. This method can be used by one thread to stop a Statement that is being executed on another thread.
@throws SQLException if an error occurs accessing the database
-
java.util.Timer.cancel()
Terminates this timer, discarding any currently scheduled tasks. Does not interfere with a currently executing task (if it exists). Once a timer has been terminated, its execution thread terminates gracefully, and no more tasks may be scheduled on it.
Note that calling this method from within the run method of a timer task that was invoked by this timer absolutely guarantees that the ongoing task execution is the last task execution that will ever be performed by this timer.
This method may be called repeatedly; the second and subsequent calls have no effect.
-
java.util.TimerTask.cancel()
Cancels this timer task. If the task has been scheduled for one-time execution and has not yet run, or has not yet been scheduled, it will never run. If the task has been scheduled for repeated execution, it will never run again. (If the task is running when this call occurs, the task will run to completion, but will never run again.)
Note that calling this method from within the run method of a repeating timer task absolutely guarantees that the timer task will not run again.
This method may be called repeatedly; the second and subsequent calls have no effect.
@return true if this task is scheduled for one-time execution and hasnot yet run, or this task is scheduled for repeated execution. Returns false if the task was scheduled for one-time execution and has already run, or if the task was never scheduled, or if the task was already cancelled. (Loosely speaking, this method returns true if it prevents one or more scheduled executions from taking place.)
-
java.util.concurrent.Future.cancel()
Attempts to cancel execution of this task. This attempt will fail if the task has already completed, has already been cancelled, or could not be cancelled for some other reason. If successful, and this task has not started when {@code cancel} is called,this task should never run. If the task has already started, then the {@code mayInterruptIfRunning} parameter determineswhether the thread executing this task should be interrupted in an attempt to stop the task.
After this method returns, subsequent calls to {@link #isDone} willalways return {@code true}. Subsequent calls to {@link #isCancelled}will always return {@code true} if this method returned {@code true}.
@param mayInterruptIfRunning {@code true} if the thread executing thistask should be interrupted; otherwise, in-progress tasks are allowed to complete
@return {@code false} if the task could not be cancelled,typically because it has already completed normally; {@code true} otherwise
-
java.util.concurrent.FutureTask.cancel()
-
java.util.concurrent.ScheduledFuture.cancel()
-
javax.ejb.Timer.cancel()
-
javax.enterprise.deploy.spi.status.ProgressObject.cancel()
(optional) A cancel request on an in-process operation stops all further processing of the operation and returns the environment to it original state before the operation was executed. An operation that has run to completion cannot be cancelled.
@throws OperationUnsupportedException occurs when this optional commandis not supported by this implementation.
-
javax.jdo.Query.cancel()
Method to cancel an executing query in the specified thread. If the underlying datastore doesn't support cancellation of queries this will throw JDOUnsupportedOptionException. If the cancellation fails (e.g in the underlying datastore) then this will throw a JDOException.
@since 2.3
-
javax.tv.service.SIRequest.cancel()
-
javax.ws.rs.container.AsyncResponse.cancel()
Cancel the suspended request processing.
When a request processing is cancelled using this method, the JAX-RS implementation MUST indicate to the client that the request processing has been cancelled by sending back a {@link javax.ws.rs.core.Response.Status#SERVICE_UNAVAILABLE HTTP 503 (Service unavailable)}error response.
Invoking a {@code cancel(...)} method multiple times to cancel request processing has the sameeffect as canceling the request processing only once. Invoking a {@code cancel(...)} method onan asynchronous response instance that has already been resumed has no effect and the method call is ignored while returning {@code true}.
@return {@code true} if the request processing has been cancelled, returns {@code false} in casethe request processing is not {@link #isSuspended() suspended} and could not be cancelledand is not {@link #isCancelled() cancelled} already.
@see #cancel(int)
@see #cancel(java.util.Date)
-
jsky.util.IApplyCancel.cancel()
-
l2p.gameserver.model.base.Transaction.cancel()
Заканчивает транзакцию и очищает соответствующее поле у участников.
-
l2p.gameserver.model.quest.QuestTimer.cancel()
-
lineage2.gameserver.model.Request.cancel()
Method cancel.
-
net.bnubot.bot.commands.Vote.cancel()
-
net.citizensnpcs.healers.HealerTask.cancel()
-
net.citizensnpcs.wizards.WizardTask.cancel()
-
net.ftb.download.workers.AssetDownloader.cancel()
-
net.jini.core.lease.Lease.cancel()
Used by the lease holder to indicate that it is no longer interested in the resource or information held by the lease. If the leased information or resource could cause a callback to the lease holder (or some other object on behalf of the lease holder), the lease grantor should not issue such a callback after the lease has been cancelled. The overall effect of a cancel call is the same as lease expiration, but instead of happening at the end of a pre-agreed duration it happens immediately.
@throws UnknownLeaseException the lease being cancelled is unknownto the lease grantor
@throws RemoteException
-
net.pterodactylus.sone.core.FreenetInterface.InsertToken.cancel()
-
net.rim.blackberry.api.bbm.platform.io.BBMPlatformOutgoingJoinRequest.cancel()
-
net.rubyeye.xmemcached.command.Command.cancel()
-
net.sf.jabref.export.SaveSession.cancel()
-
net.sf.jml.impl.MsnFileTransferImpl.cancel()
-
net.sf.mzmine.taskcontrol.Task.cancel()
Cancel a running task by user request.
-
net.spy.memcached.internal.GetFuture.cancel()
-
net.spy.memcached.ops.Operation.cancel()
Cancel this operation.
-
net.tomp2p.futures.BaseFuture.cancel()
-
net.tomp2p.futures.FutureResponse.cancel()
-
net.tomp2p.relay.PeerMapUpdateTask.cancel()
-
nexj.core.runtime.InvocationContext.cancel()
Cancels any blocked processes.
@see Cancellable#cancel()
-
nexj.core.util.Cancellable.cancel()
-
org.apache.archiva.redback.components.taskqueue.BuildProjectTask.cancel()
-
org.apache.aries.samples.ariestrader.api.persistence.OrderDataBean.cancel()
-
org.apache.aries.samples.ariestrader.entities.OrderDataBeanImpl.cancel()
-
org.apache.commons.scxml.invoke.Invoker.cancel()
Cancel this invocation.
@throws InvokerException In case there is a fatal problem withcanceling this invoke.
-
org.apache.directory.ldap.client.api.future.ResponseFuture.cancel()
{@inheritDoc}
-
org.apache.directory.ldap.client.api.future.SearchFuture.cancel()
-
org.apache.drill.exec.work.FragmentRunner.cancel()
-
org.apache.drill.exec.work.foreman.Foreman.cancel()
-
org.apache.drill.exec.work.fragment.FragmentExecutor.cancel()
-
org.apache.drill.exec.work.fragment.FragmentManager.cancel()
-
org.apache.drill.exec.work.fragment.IncomingFragmentHandler.cancel()
-
org.apache.excalibur.source.ModifiableSource.cancel()
Cancel the data sent to an
OutputStream
returned by {@link #getOutputStream()}.
After cancelling, the stream should no longer be used.
-
org.apache.felix.deploymentadmin.spi.DeploymentSessionImpl.cancel()
Cancels the session if it is in progress.
@return true if a session was in progress and now canceled, falseotherwise.
-
org.apache.flink.client.CliFrontend.cancel()
Executes the cancel action.
@param args Command line arguments for the cancel action.
-
org.apache.flink.runtime.executiongraph.ExecutionGraph.cancel()
-
org.apache.flink.runtime.instance.AllocatedSlot.cancel()
-
org.apache.hadoop.hdfs.util.Canceler.cancel()
Requests that the current operation be canceled if it is still running. This does not block until the cancellation is successful.
@param reason the reason why cancellation is requested
-
org.apache.hadoop.io.ReadaheadPool.ReadaheadRequest.cancel()
-
org.apache.http.concurrent.Cancellable.cancel()
-
org.apache.http.conn.ConnectionRequest.cancel()
-
org.apache.jackrabbit.core.state.SessionItemStateManager.cancel()
{@inheritDoc}
-
org.apache.jackrabbit.core.state.UpdatableItemStateManager.cancel()
Cancel an update operation. This will undo all changes made to objects inside this item state manager.
@throws IllegalStateException if the manager is not in edit mode.
-
org.apache.jena.atlas.lib.AlarmClock.cancel()
Cancel a task
-
org.apache.juddi.subscription.SubscriptionNotifier.cancel()
-
org.apache.karaf.eik.ui.internal.KarafRemoteShellConnectJob.cancel()
-
org.apache.mina.core.future.ConnectFuture.cancel()
Cancels the connection attempt and notifies all threads waiting for this future.
-
org.apache.ode.bpel.runtime.channels.ActivityRecovery.cancel()
Cancel the activity (unsuccessful completion).
-
org.apache.ode.bpel.runtime.channels.ActivityRecoveryChannel.cancel()
-
org.apache.qpid.qmf2.agent.Subscription.cancel()
Cancel the Subscription, tidying references up and cancelling the TimerTask.
-
org.apache.servicemix.nmr.api.internal.InternalExchange.cancel()
-
org.apache.servicemix.timers.Timer.cancel()
-
org.apache.sshd.client.future.ConnectFuture.cancel()
Cancels the connection attempt and notifies all threads waiting for this future.
-
org.apache.sshd.client.future.DefaultConnectFuture.cancel()
-
org.apache.sshd.common.io.IoConnectFuture.cancel()
Cancels the connection attempt and notifies all threads waiting for this future.
-
org.apache.twill.common.Cancellable.cancel()
Attempts to cancel execution of this task.
-
org.archfirst.bfexch.domain.trading.order.Order.cancel()
Cancels the order if the status change is valid
-
org.atmosphere.cpr.AtmosphereResourceImpl.cancel()
-
org.broad.igv.tools.FeatureSearcher.cancel()
Signal the searcher to stop. Note that stopping may not be instantaneous
-
org.bukkit.scheduler.BukkitTask.cancel()
Will attempt to cancel this task.
-
org.cometd.server.AbstractServerTransport.Scheduler.cancel()
-
org.crsh.shell.ShellProcess.cancel()
Signals the process it should be cancelled. This method cannot be be called before the process has started, it can be called multiple times after the process has started. The cancellation of the process is asynchronous, the cancellation of the process will terminate the current context lifecycle by calling the {@link org.crsh.shell.ShellProcessContext#end(ShellResponse)} method.
@throws IllegalStateException if the execution has not yet started
-
org.drools.beliefsystem.BeliefSet.cancel()
This will remove all entries and do clean up, like retract FHs.
@param propagationContext
-
org.drools.common.AgendaItem.cancel()
-
org.drools.core.beliefsystem.BeliefSet.cancel()
This will remove all entries and do clean up, like retract FHs.
@param propagationContext
-
org.drools.core.common.AgendaItem.cancel()
-
org.drools.guvnor.client.messages.Constants.Cancel()
-
org.drools.ruleflow.instance.RuleFlowNodeInstance.cancel()
-
org.eclipse.core.runtime.jobs.IJobManager.cancel()
Cancels all jobs in the given job family. Jobs in the family that are currently waiting will be removed from the queue. Sleeping jobs will be discarded without having a chance to wake up. Currently executing jobs will be asked to cancel but there is no guarantee that they will do so.
@param family the job family to cancel, or null
to cancel all jobs
@see Job#belongsTo(Object)
-
org.eclipse.core.runtime.jobs.Job.cancel()
Stops the job. If the job is currently waiting, it will be removed from the queue. If the job is sleeping, it will be discarded without having a chance to resume and its sleeping state will be cleared. If the job is currently executing, it will be asked to stop but there is no guarantee that it will do so.
@return false
if the job is currently running (and thus may notrespond to cancelation), and true
in all other cases.
-
org.eclipse.egit.ui.common.CommitDialogTester.cancel()
-
org.eclipse.egit.ui.common.RepoRemoteBranchesPage.cancel()
-
org.eclipse.egit.ui.internal.push.PushTagsWizardTester.cancel()
-
org.fenixedu.academic.domain.QueueJob.cancel()
-
org.fenixedu.academic.domain.accounting.events.dfa.DFACandidacyEvent.cancel()
-
org.fenixedu.academic.domain.accounting.paymentCodes.AccountingEventPaymentCode.cancel()
-
org.fenixedu.academic.domain.accounting.report.events.EventReportQueueJob.cancel()
-
org.fenixedu.academic.domain.candidacyProcess.erasmus.reports.ErasmusCandidacyProcessReport.cancel()
-
org.fenixedu.academic.domain.serviceRequests.AcademicServiceRequest.cancel()
-
org.fenixedu.academic.domain.serviceRequests.RegistrationAcademicServiceRequest.cancel()
-
org.fest.swing.fixture.JFileChooserFixture.cancel()
Simulates a user pressing the "Cancel" button in this fixture's {@code JFileChooser}.
@throws ComponentLookupException if the "Cancel" button cannot be found.
@throws IllegalStateException if the "Cancel" button is disabled.
@throws IllegalStateException if the "Cancel" button is not showing on the screen.
-
org.fusesource.ide.server.karaf.core.poller.PollThread.cancel()
-
org.geoserver.importer.FeatureTypeImporter.cancel()
-
org.gephi.utils.longtask.spi.LongTask.cancel()
Cancel the task. Returns true
if the task has been sucessfully cancelled, false
otherwise.
@return true
if the task has been sucessfully cancelled, false
otherwise
-
org.glassfish.hk2.runlevel.RunLevelFuture.cancel()
The cancel method attempts to cancel the current running job (if the job is not already completed or already cancelled). The meaning of cancel is different depending on whether or not the system was going up to a level or coming down to a level.
If the system was going up to a level then calling cancel will cause the system to stop going up, and instead proceed back down to the last completed level. For example, suppose there were three services at level ten and the system was going up to level ten. As the system was proceeding up to level ten the first of the three services had already been started and the second service was in progress and the third service had not been started. The system will wait for the second service to complete coming up and then will shut it down along with the first service. Since the last completed level was nine, the system will remain at level nine and this job will be complete.
If the system was going down to a level then calling cancel will cause the system to continue going down, but it will stop going down at the next level. For example, suppose there were three services at level ten and the current proposed level is five. Suppose one of those three services had already been shutdown and one was in the process of being shutdown and the other had not yet been shutdown when the cancel arrives. The system will continue to shutdown the one in progress and then will shutdown the remaining service at level ten to reach level nine. However, the job will no longer attempt to go down to level five, but will instead be finished at level nine.
@param mayInterruptIfRunning is currently ignored
-
org.glite.ce.commonj.utils.TimerTask.cancel()
-
org.globus.gram.GramJob.cancel()
-
org.gradle.gradleplugin.foundation.request.Request.cancel()
Cancels this request.
@return true if you can cancel or it or if it has already ran. This return code is mainly meant to prevent you from
-
org.gudy.azureus2.core3.torrentdownloader.TorrentDownloader.cancel()
Cancels the download.
-
org.gudy.azureus2.core3.util.TimerEvent.cancel()
-
org.gudy.azureus2.plugins.peers.PeerReadRequest.cancel()
-
org.gudy.azureus2.plugins.update.UpdateCheckInstance.cancel()
-
org.gudy.azureus2.pluginsimpl.local.update.UpdateCheckInstanceImpl.cancel()
-
org.h2.command.Command.cancel()
-
org.h2.command.CommandInterface.cancel()
Cancel the statement if it is still processing.
-
org.hive2hive.core.processes.framework.abstracts.ProcessComponent.cancel()
-
org.hive2hive.core.processes.implementations.userprofiletask.TestPutUserProfileTaskStep.cancel()
-
org.hornetq.core.client.impl.LargeMessageBufferImpl.cancel()
-
org.hornetq.core.client.impl.LargeMessageControllerImpl.cancel()
-
org.hornetq.core.server.Queue.cancel()
-
org.itsnat.core.event.ItsNatTimerHandle.cancel()
Cancels this timer task. If the task has been scheduled for one-time execution and has not yet run, or has not yet been scheduled, it will never run. If the task has been scheduled for repeated execution, it will never run again. (If the task is running when this call occurs, the task will run to completion, but will never run again.)
Note that calling this method from within the EventListener.handleEvent(Event)
method of a repeating timer task absolutely guarantees that the timer task will not run again.
This method may be called repeatedly; the second and subsequent calls have no effect.
Note: documentation copied (and slightly modified) from java.util.TimerTask.cancel()
.
@return true if this task is scheduled for one-time execution and hasnot yet run, or this task is scheduled for repeated execution. Returns false if the task was scheduled for one-time execution and has already run, or if the task was never scheduled, or if the task was already cancelled. (Loosely speaking, this method returns
true if it prevents one or more scheduled executions from taking place.)
-
org.itsnat.impl.core.listener.domext.ItsNatTimerEventListenerWrapperImpl.cancel()
-
org.japura.task.Task.cancel()
-
org.jboss.as.controller.Cancellable.cancel()
Attempt to cancel this operation.
@return false if the task could not be cancelled;true otherwise
-
org.jboss.as.ejb3.timerservice.TimerImpl.cancel()
{@inheritDoc}
-
org.jboss.dna.graph.request.CompositeRequest.cancel()
-
org.jboss.dna.graph.request.ReadNodeRequest.cancel()
{@inheritDoc}
@see org.jboss.dna.graph.request.Request#cancel()
-
org.jboss.errai.bus.client.api.AsyncTask.cancel()
-
org.jboss.errai.bus.server.async.TimedTask.cancel()
-
org.jboss.errai.common.client.api.tasks.AsyncTask.cancel()
Prevents this task from being scheduled again, optionally interrupting the task if it is currently running.
@param interrupt if true, and this task is presently being executed, {@link Thread#interrupt()} will be called on the thread currentlyexecuting this task.
-
org.jboss.forge.addon.resource.monitor.ResourceMonitor.cancel()
Cancels this monitor. All registered listeners are automatically discarded.
-
org.jboss.identity.federation.api.wstrust.WSTrustRequestHandler.cancel()
Cancels the security token as specified in the request message.
@param request the request message that contains the token to be canceled.
@param callerPrincipal the {@code Principal} of the ws-trust token requester.
@return a {@code RequestSecurityTokenResponse} indicating whether the token has been canceled or not.
@throws WSTrustException if an error occurs while handling the cancellation process.
-
org.jboss.identity.federation.core.wstrust.WSTrustRequestHandler.cancel()
Cancels the security token as specified in the request message.
@param request the request message that contains the token to be canceled.
@param callerPrincipal the {@code Principal} of the ws-trust token requester.
@return a {@code RequestSecurityTokenResponse} indicating whether the token has been canceled or not.
@throws WSTrustException if an error occurs while handling the cancellation process.
-
org.jboss.messaging.core.Delivery.cancel()
-
org.jboss.messaging.core.contract.Delivery.cancel()
-
org.jboss.messaging.core.impl.SimpleDelivery.cancel()
-
org.jboss.netty.channel.ChannelFuture.cancel()
Cancels the I/O operation associated with this future and notifies all listeners if canceled successfully.
@return {@code true} if and only if the operation has been canceled.{@code false} if the operation can't be canceled or is alreadycompleted.
-
org.jboss.netty.util.Timeout.cancel()
-
org.jboss.remoting.ConnectionValidator.cancel()
-
org.jboss.remoting3.jmx.protocol.CancellableDataOutputStream.cancel()
-
org.jboss.remotingjmx.protocol.CancellableDataOutputStream.cancel()
-
org.jboss.seam.async.QuartzTriggerHandle.cancel()
-
org.jboss.seam.example.hibernate.BookingListAction.cancel()
-
org.jboss.util.timeout.Timeout.cancel()
Cancel this timeout. It is guaranteed that on return from this method this timer is no longer active. This means that either it has been cancelled and the timeout will not happen, or (in case of late cancel) the timeout has happened and the timeout callback function has returned. On return from this method this instance should no longer be used. The reason for this is that an implementation may reuse cancelled timeouts, and at return the instance may already be in use for another timeout.
-
org.jboss.util.timeout.TimeoutFactory.cancel()
Cancels all submitted tasks, stops the worker thread and clean-ups everything except for the thread pool. Scheduling new timeouts after cancel is called results in a IllegalStateException.
-
org.jbpm.pvm.internal.session.TimerSession.cancel()
Cancels a timer.
If a transaction is in progress, the cancellation will be effective at the end of the transaction. If the timer has been created in the same transaction or if there is no transaction, the cancellation is immediately effective.
If the timer is executing when the cancellation becomes effective, the execution in progress will not be stopped.
@param timerImpl the timer to be cancelled.
-
org.jbpm.taskmgmt.exe.TaskInstance.cancel()
cancels this task. This task intance will be marked as cancelled and as ended. But cancellation doesn't influence singalling and continuation of process execution.
-
org.jdesktop.core.animation.timing.Animator.cancel()
This method is like the {@link #stop} method, only this one will not resultin a calls to the {@link TimingTarget#end(Animator)} method of all theregistered timing targets of this animation; it simply stops the animation immediately and returns. If the animation is not running, or is stopping, then this method returns {@code false}.
The animation may take some period of time to actually stop, it waits for all calls to registered {@link TimingTarget}s to complete. Invoking {@link #await()} after this method will wait until the animation stops.This means that the code snippet " {@code a.cancel(); a.start();}" could fail throwing an {@link IllegalStateException} at the call to{@link #start()} because the animation may not have stopped right away.This can be fixed by inserting a call to {@link #await()} or using thesnippet " {@code a.cancelAndAwait(); a.start();}" instead.
@return {@code true} if the animation was running and was successfullystopped, {@code false} if the animation was not running or was inthe process of stopping and didn't need to be stopped.
@see #await()
@see #cancelAndAwait()
@see #stop()
-
org.jdesktop.swingworker.SwingWorker.cancel()
{@inheritDoc}
-
org.jetbrains.jps.api.RequestFuture.cancel()
-
org.jivesoftware.smack.PacketCollector.cancel()
Explicitly cancels the packet collector so that no more results are queued up. Once a packet collector has been cancelled, it cannot be re-enabled. Instead, a new packet collector must be created.
-
org.jivesoftware.xmpp.workgroup.request.Request.cancel()
Send a Cancel notice to the queue when a user has left.
@param type the type of Cancel. The type will be used to explain the reason of the departure.
@see CancelType
-
org.jivesoftware.xmpp.workgroup.request.UserRequest.cancel()
-
org.jsynthlib.core.GuiHandler.ISearchHandler.cancel()
-
org.knowhowlab.osgi.monitoradmin.job.AbstractMonitoringJob.cancel()
Cancel job internaly
-
org.lealone.command.Command.cancel()
-
org.lealone.command.CommandInterface.cancel()
Cancel the statement if it is still processing.
-
org.lightview.service.EscalationProvider.cancel()
-
org.locationtech.udig.catalog.tests.ui.workflow.DialogDriver.cancel()
-
org.modeshape.jcr.query.QueryContext.cancel()
Cancel the query if it is currently running. Note that this method does not block until the query is cancelled; it merely marks the query as being cancelled, and the query will terminate at its next available opportunity.
@return true if the query was executing and will be cancelled, or false if the query was no longer running (because it hadfinished successfully or had already been cancelled) and could not be cancelled.
-
org.nasutekds.server.protocols.internal.InternalSearchOperation.cancel()
-
org.olap4j.OlapStatement.cancel()
-
org.opennebula.client.vm.VirtualMachine.cancel()
Cancels the running VM.
@return If an error occurs the error message contains the reason.
@deprecated Replaced by hard shutdown {@link #shutdown(boolean)}
-
org.opentripplanner.routing.trippattern.TripTimes.cancel()
Cancel this entire trip
-
org.pushingpixels.trident.Timeline.cancel()
-
org.qi4j.spi.entitystore.StateCommitter.cancel()
-
org.rascalmpl.library.util.Eval.EvalTimer.cancel()
-
org.reactivestreams.Subscription.cancel()
Request the {@link Publisher} to stop sending data and clean up resources.
Data may still be sent to meet previously signalled demand after calling cancel as this request is asynchronous.
-
org.saiku.olap.query.IQuery.cancel()
-
org.snmp4j.agent.mo.snmp4j.example.Snmp4jHeartbeatMib.HeartbeatTask.cancel()
-
org.springframework.cassandra.core.Cancellable.cancel()
Cancels the query operation that this cancellable came from.
-
org.strecks.action.BasicSubmitAction.cancel()
Executed form is submitted using the button generated via the html:cancel tag
-
org.strecks.action.NavigableSubmitAction.cancel()
Executed form is submitted using the button generated via the html:cancel tag
-
org.strecks.action.basic.impl.NavigableLookupDispatchAction.cancel()
-
org.strecks.action.basic.impl.SimpleLookupDispatchAction.cancel()
-
org.strecks.action.navigable.impl.NavigableFormSubmitBean.cancel()
-
org.teiid.translator.Execution.cancel()
Cancels the execution abnormally. This will happen via a different thread from the one performing the execution, so should be expected to happen in a multi-threaded scenario.
-
org.voltcore.utils.DeferredSerialization.cancel()
A deferred serialization might not be able to take place if a stream is closed so a method for canceling the serialization and freeing associated resources must be provided.
-
org.voltdb.utils.DeferredSerialization.cancel()
A deferred serialization might not be able to take place if a stream is closed so a method for canceling the serialization and freeing associated resources must be provided.
-
org.wicketstuff.progressbar.spring.Task.cancel()
-
org.xwiki.tag.test.po.AddTagsPane.cancel()
-
org.xwiki.test.ui.framework.elements.DeletePage.cancel()
-
org.xwiki.test.ui.tag.elements.AddTagsPane.cancel()
Click on the cancel button to close the panel.
-
org.zanata.async.handle.CopyVersionTaskHandle.cancel()
-
pdp.scrabble.game.Board.cancel()
Cancel all operations from the current player turn (give letters back to the player and remove then from the board).
@param player player which placed letters.
-
prefuse.Visualization.cancel()
Cancel the Action with the given name, if it has been scheduled.
@param action the name of the Action to cancel
@return the canceled Action
-
prefuse.action.Action.cancel()
-
ptolemy.gui.JTextAreaExec.cancel()
Cancel any running commands.
-
rcm.util.Timer.cancel()
-
reactor.timer.HashWheelTimer.cancel()
Cancel current Timer
-
reactor.timer.Timer.cancel()
Cancel this timer by interrupting the task thread. No more tasks can be submitted to this timer after cancellation.
-
spark.api.Command.cancel()
Cancel execution of this command.
-
test.shell.base.BaseProcessContext.cancel()
-
tripleplay.util.Timer.Handle.cancel()
-
winterwell.utils.TimeOut.cancel()
@see TimerTask#cancel()