-
ae.sun.awt.image.ImageRepresentation.abort()
-
co.cask.tephra.TransactionContext.abort()
-
co.cask.tephra.TransactionManager.abort()
-
co.paralleluniverse.galaxy.quasar.Store.abort()
Ends a transaction after a failure.
This method must be called only after {@link #rollback(co.paralleluniverse.galaxy.StoreTransaction) rollback()}has been called, or a manual rollback has been done.
@param txn The current transaction, which we wish to complete after failure.
-
com.adito.vfs.VFSOutputStream.abort()
Abort any data written to the temporary file and delete it.
-
com.alibaba.otter.node.etl.common.io.download.DataRetriever.abort()
Aborts the current retrieving.
-
com.alibaba.otter.node.etl.common.io.download.impl.aria2c.Aria2cRetriever.abort()
-
com.alibaba.wasp.fserver.FServer.abort()
@see FServer#abort(String,Throwable)
-
com.alibaba.wasp.master.FMaster.abort()
-
com.amazonaws.services.s3.model.S3ObjectInputStream.abort()
Aborts the underlying http request without reading any more data and closes the stream.
By default Apache {@link HttpClient} tries to reuse http connections byreading to the end of an attached input stream on {@link InputStream#close()}. This is efficient from a socket pool management perspective, but for objects with large payloads can incur significant overhead while bytes are read from s3 and discarded. It's up to clients to decide when to take the performance hit implicit in not reusing an http connection in order to not read unnecessary information from S3.
@see EofSensorInputStream
-
com.arjuna.ats.arjuna.AtomicAction.abort()
Abort (rollback) the transaction. If the transaction has already terminated, or has not been begun, then an appropriate error code will be returned.
@return ActionStatus
indicating outcome.
-
com.asakusafw.runtime.directio.hadoop.DirectIoTransactionEditor.abort()
Aborts Direct I/O transaction for an execution.
@param executionId target execution ID
@return {@code true} if successfully aborted, or {@code false} if nothing to do
@throws IOException if failed to abort by I/O error
@throws InterruptedException if interrupted
@throws IllegalArgumentException if some parameters were {@code null}
-
com.asakusafw.windgate.core.resource.ResourceProvider.abort()
Aborts the specified session corresponding to this resouce. The default implementation does nothing.
@param sessionId the target session ID
@throws IOException if failed to abort the resource
-
com.asakusafw.windgate.core.session.SessionMirror.abort()
Aborts and releases this session. This session will not be reopened later.
@throws IOException if failed to detach from the specified session
-
com.dotcms.repackage.org.apache.commons.httpclient.HttpMethodBase.abort()
-
com.facebook.presto.jdbc.internal.jetty.client.api.Request.abort()
Attempts to abort the send of this request.
@param cause the abort cause, must not be null
@return whether the abort succeeded
-
com.google.gwt.xhr.client.XMLHttpRequest.abort()
org/TR/XMLHttpRequest/#abort
-
com.googlecode.richrest.client.Abortable.abort()
中止传输
@throws IOException 中止失败时抛出
-
com.googlecode.richrest.client.Transfer.abort()
中止传输
-
com.googlecode.richrest.client.work.Work.abort()
-
com.hp.hpl.jena.graph.TransactionHandler.abort()
If transactions are supported and there is a tranaction in progress, abort it. If transactions are not supported, or there is no transaction in progress, throw an UnsupportedOperationException.
-
com.hp.hpl.jena.query.Dataset.abort()
Abort a transaction - finish the transaction and undo any changes (if a "write" transaction)
-
com.hp.hpl.jena.query.QueryExecution.abort()
Stop in mid execution. This method can be called in parallel with other methods on the QueryExecution object. There is no guarantee that the concrete implementation actual will stop or that it will do so immediately. No operations on the query execution or any associated result set are permitted after this call and may cause exceptions to be thrown.
-
com.hp.hpl.jena.rdf.model.Model.abort()
Abort the current transaction and abandon any changes in progress.
@return this model to enable cascading.
-
com.hp.hpl.jena.tdb.transaction.DatasetGraphTxn.abort()
-
com.hp.mwtests.performance.products.TxWrapper.abort()
-
com.jada.order.payment.PaymentEngine.abort()
-
com.persistit.TransactionStatus.abort()
-
com.qspin.qtaste.testsuite.TestScript.TaskThread.abort()
-
com.rabbitmq.client.Channel.abort()
Abort this channel with the {@link com.rabbitmq.client.AMQP#REPLY_SUCCESS} close codeand message 'OK'. Forces the channel to close and waits for the close operation to complete. Any encountered exceptions in the close operation are silently discarded.
-
com.rabbitmq.client.Connection.abort()
Abort this connection and all its channels with the {@link com.rabbitmq.client.AMQP#REPLY_SUCCESS} close codeand message 'OK'. Forces the connection to close. Any encountered exceptions in the close operations are silently discarded.
-
com.rabbitmq.client.impl.recovery.AutorecoveringConnection.abort()
@see com.rabbitmq.client.Connection#abort()
-
com.sleepycat.db.Transaction.abort()
Cause an abnormal termination of the transaction.
The log is played backward, and any necessary undo operations are done. Before Transaction.abort returns, any locks held by the transaction will have been released.
In the case of nested transactions, aborting a parent transaction causes all children (unresolved or not) of the parent transaction to be aborted.
All cursors opened within the transaction must be closed before the transaction is aborted.
After Transaction.abort has been called, regardless of its return, the {@link com.sleepycat.db.Transaction Transaction} handle may not be accessed again.
@throws DatabaseException if a failure occurs.
-
com.sleepycat.je.Transaction.abort()
Cause an abnormal termination of the transaction.
The log is played backward, and any necessary undo operations are done. Before Transaction.abort returns, any locks held by the transaction will have been released.
In the case of nested transactions, aborting a parent transaction causes all children (unresolved or not) of the parent transaction to be aborted.
All cursors opened within the transaction must be closed before the transaction is aborted.
After this method has been called, regardless of its return, the {@link Transaction} handle may not be accessed again, with oneexception: the {@code abort} method itself may be called any number oftimes to simplify error handling.
@throws EnvironmentFailureException if an unexpected, internal orenvironment-wide failure occurs.
@throws IllegalStateException if the environment has been closed, orcursors associated with the transaction are still open.
-
com.sleepycat.je.rep.txn.ReplayTxn.abort()
-
com.sleepycat.je.txn.Txn.abort()
-
com.subgraph.vega.api.http.requests.IHttpRequestTask.abort()
Abort the request.
@throws UnsupportedOperationException
-
com.sun.sgs.service.Transaction.abort()
Aborts the transaction, specifying the cause. This notifies all participants that the transaction has aborted, and invalidates all future use of this transaction. The caller should always follow a call to
abort
by throwing an exception that details why the transaction was aborted. If the exception could be caught by application code, then the exception thrown should be a {@link TransactionAbortedException}, created by wrapping the original cause if needed. Throwing an exception is needed not only to communicate the cause of the abort and whether to retry the exception, but also because the application code associated with this transaction will continue to execute normally unless an exception is raised. Supplying the cause to this method allows future calls to the transaction to include the cause to explain why the transaction is no longer active.
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.
@param cause the exception that caused the abort
@throws TransactionNotActiveException if the transaction has beenaborted
@throws IllegalStateException if all transaction participants have beenprepared and {@link #abort abort} has notbeen called, or if called from a thread that is not the thread that created this transaction
-
com.sun.sgs.service.TransactionParticipant.abort()
Tells the participant to abort its involvement with the given transaction.
@param txn the Transaction
object
@throws IllegalStateException if this participant has already beenaborted or committed, or if this participant is not participating in the given transaction
-
com.sun.sgs.service.store.db.DbTransaction.abort()
Aborts the transaction. This method should not be called if any cursors associated with this transaction are still open. No methods should be called on this transaction after this method is called.
@throws DbDatabaseException if an unexpected database problem occurs
-
com.sun.sgs.test.util.DummyTransaction.abort()
-
com.vmware.vim.binding.vim.HttpNfcLease.abort()
-
com.yahoo.omid.client.TransactionManager.abort()
Aborts a transaction and automatically rollbacks the changes.
@param transactionState Object identifying the transaction to be committed.
@throws TransactionException
-
de.danet.an.workflow.api.Process.abort()
-
de.danet.an.workflow.internalapi.ExtProcessLocal.abort()
-
de.danet.an.workflow.localapi.ActivityLocal.abort()
-
de.danet.an.workflow.localcoreapi.WfProcessLocal.abort()
-
de.danet.an.workflow.omgcore.WfActivity.abort()
-
de.danet.an.workflow.omgcore.WfProcess.abort()
-
de.zib.scalaris.Transaction.abort()
Cancels the current transaction.
For a transaction to be cancelled, only the {@link #transLog} needs to bereset. Nothing else needs to be done since the data was not modified until the transaction was committed.
@see #commit()
-
edu.brown.hstore.estimators.TransactionEstimator.abort()
The transaction with provided txn_id has aborted
@param txn_id
-
entagged.listing.gui.ListingProgressDialog.abort()
(overridden)
@see entagged.listing.gui.ListingProgressListener#abort()
-
freenet.io.xfer.PartiallyReceivedBlock.abort()
Abort the transfer.
@param reason
@param description
@param cancelledLocally If true, the transfer was deliberately aborted by *this node*,not as the result of a timeout.
@return Null if the PRB is aborted now. The data if it is not.
-
freenet.node.NewPacketFormatKeyContext.AddedAcks.abort()
-
freenet.support.io.PrependLengthOutputStream.abort()
Abort the stream. Will write a length of 0 when close()'ed.
@return False if the stream has already been closed.
-
helma.objectmodel.db.Transactor.abort()
Abort the current transaction, rolling back all changes made.
-
hudson.BulkChange.abort()
Exits the scope of {@link BulkChange} without saving the changes.
This can be used when a bulk change fails in the middle. Note that unlike a real transaction, this will not roll back the state of the object.
The abort method can be called after the commit method, in which case this method does nothing. This is so that {@link BulkChange} can be used naturally in the try/finally block.
-
hudson.util.AtomicFileWriter.abort()
When the write operation failed, call this method to leave the original file intact and remove the temporary file. This method can be safely invoked from the "finally" block, even after the {@link #commit()} is called, to simplify coding.
-
javax.security.auth.spi.LoginModule.abort()
Method to abort the authentication process (phase 2).
This method is called if the LoginContext's overall authentication failed. (the relevant REQUIRED, REQUISITE, SUFFICIENT and OPTIONAL LoginModules did not succeed).
If this LoginModule's own authentication attempt succeeded (checked by retrieving the private state saved by the {@code login} method), then this method cleans up any statethat was originally saved.
@exception LoginException if the abort fails
@return true if this method succeeded, or false if this{@code LoginModule} should be ignored.
-
net.jini.core.transaction.Transaction.abort()
Abort the transaction. This can be called at any time by any object holding a reference to the transaction. Abort asks the transaction manager to abort the transaction and to notify each participant of the decision, resulting in them rolling back any state changes made as part of the transaction. Returns as soon as the transaction manager records the abort decision, without waiting for the transaction manager to notify all participants of the decision.
@throws UnknownTransactionException if the transaction is unknown to the manager. This may be because the transaction ID was incorrect, or because the transaction has proceeded to cleanup due to an earlier commit or abort, and has been forgotten.
@throws CannotAbortException if the transaction is known to have previously reached the COMMITTED state due to an earlier commit.
@throws RemoteException if a communication error occurs.
-
net.jini.core.transaction.server.TransactionParticipant.abort()
Requests that the participant roll back any changes for the specified transaction and unlock any resources locked by the transaction. All state associated with the transaction can then be discarded by the participant.
@param mgr the manager of the transaction
@param id the transaction ID
@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 RemoteException if there is a communication error
-
net.jini.jeri.InboundRequest.abort()
Terminates this request, freeing all associated resources.
This method may be invoked at any stage of the processing of the request.
After this method has been invoked, I/O operations on the streams returned by the getRequestInputStream
and getResponseOutputStream
methods will fail with an IOException
, except some operations that may succeed because they only affect data in local I/O buffers.
If this method is invoked before the close
method has been invoked on the stream returned by getResponseOutputStream
, there is no guarantee that any or none of the data written to the stream so far will be delivered; the implication of such an invocation of this method is that the user is no longer interested in the successful delivery of the response.
-
net.jini.jeri.OutboundRequest.abort()
Terminates this request, freeing all associated resources.
This method may be invoked at any stage of the processing of the request.
After this method has been invoked, I/O operations on the streams returned by the getRequestOutputStream
and getResponseInputStream
methods will fail with an IOException
, except some operations that may succeed because they only affect data in local I/O buffers.
If this method is invoked before the close
method has been invoked on the stream returned by getRequestOutputStream
, there is no guarantee that any or none of the data written to the stream so far will be delivered; the implication of such an invocation of this method is that the user is no longer interested in the successful delivery of the request.
-
net.sourceforge.processdash.util.RobustFileOutputStream.abort()
-
net.sourceforge.processdash.util.RobustFileWriter.abort()
-
org.apache.cassandra.io.sstable.SSTableRewriter.abort()
-
org.apache.cassandra.io.sstable.SSTableWriter.abort()
After failure, attempt to close the index writer and data file before deleting all temp components for the sstable
-
org.apache.cassandra.io.sstable.format.SSTableWriter.abort()
After failure, attempt to close the index writer and data file before deleting all temp components for the sstable
-
org.apache.commons.httpclient.HttpMethod.abort()
Aborts the execution of the HTTP method.
@see #execute(HttpState,HttpConnection)
@since 3.0
-
org.apache.commons.httpclient.HttpMethodBase.abort()
Aborts the execution of this method.
@since 3.0
-
org.apache.commons.httpclient.methods.EntityEnclosingMethod.abort()
-
org.apache.commons.httpclient.methods.GetMethod.abort()
-
org.apache.commons.net.ftp.FTPClient.abort()
Abort a transfer in progress.
@return True if successfully completed, false if not.
@exception FTPConnectionClosedException If the FTP server prematurely closes the connection as a result of the client being idle or some other reason causing the server to send FTP reply code 421. This exception may be caught either as an IOException or independently as itself.
@exception IOException If an I/O error occurs while either sending acommand to the server or receiving a reply from the server.
-
org.apache.cxf.interceptor.InterceptorChain.abort()
-
org.apache.derby.iapi.store.access.TransactionController.abort()
Abort all changes made by this transaction since the last commit, abort or the point the transaction was started, whichever is the most recent. All savepoints within this transaction are released, and all resources are released (held or non-held).
@exception StandardException Only exceptions with severities greater thanExceptionSeverity.TRANSACTION_SEVERITY will be thrown.
-
org.apache.derby.iapi.store.raw.Transaction.abort()
Abort all changes made by this transaction since the last commit, abort or the point the transaction was started, whichever is the most recent. All savepoints within this transaction are released.
@exception StandardException Only exceptions with severities greater than ExceptionSeverity.TRANSACTION_SEVERITY will be thrown.
-
org.apache.derby.iapi.store.raw.xact.RawTransaction.abort()
-
org.apache.excalibur.event.PreparedEnqueue.abort()
Abort a previously prepared provisional enqueue operation (from the prepareEnqueue
method). Causes the queue to discard the provisionally enqueued elements.
-
org.apache.hadoop.hbase.HTable.abort()
Abort a row mutation
@param lockid lock id returned from startUpdate
-
org.apache.hadoop.hbase.ipc.TransactionalRegionInterface.abort()
Abort the transaction.
@param regionName
@param transactionId
@throws IOException
-
org.apache.hadoop.hbase.master.HMaster.abort()
-
org.apache.hadoop.hbase.monitoring.MonitoredTask.abort()
-
org.apache.hadoop.hbase.regionserver.HRegionServer.abort()
Cause the server to exit without closing the regions it is serving, the log it is using and without notifying the master. Used unit testing and on catastrophic events such as HDFS is yanked out from under hbase or we OOME.
@param reason the reason we are aborting
@param cause the exception that caused the abort, or null
-
org.apache.hadoop.hbase.regionserver.RegionServerServices.abort()
-
org.apache.hadoop.hdfs.server.namenode.EditLogOutputStream.abort()
Close the stream without necessarily flushing any pending data. This may be called after a previous write or close threw an exception.
-
org.apache.hadoop.hdfs.util.AtomicFileOutputStream.abort()
Close the atomic file, but do not "commit" the temporary file on top of the destination. This should be used if there is a failure in writing.
-
org.apache.harmony.auth.module.JndiLoginModule.abort()
-
org.apache.harmony.auth.module.KeyStoreLoginModule.abort()
-
org.apache.harmony.auth.module.LdapLoginModule.abort()
-
org.apache.hcatalog.data.transfer.HCatWriter.abort()
This method should be called at master node. Primary purpose of this is to do cleanups in case of failures.
@throws {@link HCatException}
-
org.apache.hive.hcatalog.data.transfer.HCatWriter.abort()
This method should be called at master node. Primary purpose of this is to do cleanups in case of failures.
@throws {@link HCatException}
-
org.apache.http.client.methods.AbortableHttpRequest.abort()
Aborts this http request. Any active execution of this method should return immediately. If the request has not started, it will abort after the next execution. Aborting this request will cause all subsequent executions with this request to fail.
@see HttpClient#execute(HttpUriRequest)
@see HttpClient#execute(org.apache.http.HttpHost,org.apache.http.HttpRequest)
@see HttpClient#execute(HttpUriRequest,org.apache.http.protocol.HttpContext)
@see HttpClient#execute(org.apache.http.HttpHost,org.apache.http.HttpRequest,org.apache.http.protocol.HttpContext)
-
org.apache.http.client.methods.HttpDelete.abort()
-
org.apache.http.client.methods.HttpEntityEnclosingRequestBase.abort()
-
org.apache.http.client.methods.HttpGet.abort()
-
org.apache.http.client.methods.HttpHead.abort()
-
org.apache.http.client.methods.HttpPost.abort()
-
org.apache.http.client.methods.HttpPut.abort()
-
org.apache.http.client.methods.HttpRequestBase.abort()
-
org.apache.http.client.methods.HttpUriRequest.abort()
Aborts execution of the request.
@throws UnsupportedOperationException if the abort operation is not supported / cannot be implemented.
-
org.apache.http.mockup.RequestCount.abort()
-
org.apache.lucene.index.IndexWriter.abort()
@deprecated Please use {@link #rollback} instead.
-
org.apache.tapestry5.hibernate.HibernateSessionManager.abort()
Aborts the current transaction, and starts a new transaction to replace it.
-
org.apache.tez.mapreduce.output.MROutput.abort()
MROutput expects that a Processor call abort in case of any error ( including an error during commit ) prior to the Processor's completion
@throws IOException
-
org.apache.tomcat.lite.http.HttpChannel.abort()
Close the connection, return to pool. Called if a framing error happens, or if we want to force the connection to close, without waiting for all data to be sent/received.
@param t
@throws IOException
-
org.apache.zookeeper.common.AtomicFileOutputStream.abort()
Close the atomic file, but do not "commit" the temporary file on top of the destination. This should be used if there is a failure in writing.
-
org.cometd.client.BayeuxClient.abort()
Interrupts abruptly the communication with the Bayeux server.
This method may be useful to simulate network failures.
@see #disconnect()
-
org.dspace.core.Context.abort()
Close the context, without committing any of the changes performed using this context. The database connection is freed. No exception is thrown if there is an error freeing the database connection, since this method may be called as part of an error-handling routine where an SQLException has already been thrown.
-
org.eclipse.jetty.client.HttpDestination.abort()
Aborts all the {@link HttpExchange}s queued in this destination.
@param cause the abort cause
-
org.eclipse.jetty.client.api.Request.abort()
Attempts to abort the send of this request.
@param cause the abort cause, must not be null
@return whether the abort succeeded
-
org.eclipse.jetty.client.api.Response.abort()
Attempts to abort the receive of this response.
@param cause the abort cause, must not be null
@return whether the abort succeeded
-
org.eclipse.osgi.storagemanager.ManagedOutputStream.abort()
Instructs this output stream to be closed and the contents discarded. If this managed output stream is part of a set returned by {@link StorageManager#getOutputStreamSet(String[])} then the new content of all managed output streams in the set will be discarded.
-
org.elasticsearch.index.snapshots.IndexShardSnapshotStatus.abort()
Marks snapshot as aborted
-
org.exist.storage.txn.TransactionManager.abort()
-
org.fireflow.engine.IProcessInstance.abort()
强行中止流程实例,不管是否达到终态。
@throws RuntimeException
-
org.ggp.base.server.GameServer.abort()
-
org.jboss.security.authorization.AuthorizationModule.abort()
Abort the Authorization Process
@return true - abort passed, false-otherwise
-
org.locationtech.geogig.api.GeogigTransaction.abort()
-
org.nasutekds.server.replication.server.DraftCNDB.DraftCNDBCursor.abort()
-
org.nasutekds.server.replication.server.ReplicationDB.ReplServerDBCursor.abort()
-
org.odmg.Transaction.abort()
Abort and close the transaction. Calling abort abandons all persistent object modifications and releases the associated locks. Aborting a transaction does not restore the state of modified transient objects
-
org.ofbiz.workflow.WfActivity.abort()
-
org.ofbiz.workflow.WfProcess.abort()
-
org.photovault.dbhelper.ODMGXAWrapper.abort()
-
org.tmatesoft.svn.core.internal.io.fs.FSDeltaConsumer.abort()
-
org.vfny.geoserver.Response.abort()
Called when things go horriably wrong.
Used try and restore application state when things go wrong. This is called by AbstractAction to try and recover when sending out a ServiceException.
Allows a Response a chance to clean up after its self when AbstractionAction is error handling.
-
se.unlogic.standardutils.dao.TransactionHandler.abort()
-
sun.awt.image.ImageRepresentation.abort()