-
ae.sun.font.LayoutPathImpl.SegmentPathBuilder.complete()
-
cascading.cascade.Cascade.complete()
Method complete begins the current Cascade process if method {@link #start()} was not previously called. This methodblocks until the process completes.
@throws RuntimeException wrapping any exception thrown internally.
-
cascading.flow.Flow.complete()
Method complete starts the current Flow instance if it has not be previously started, then block until completion.
-
com.aelitis.azureus.core.devices.TranscodeProviderAdapter.complete()
-
com.aesthete.swingobjects.fw.common.util.CsmartFormBuilder.complete()
-
com.amazonaws.services.simpleworkflow.flow.core.ExternalTaskCompletionHandle.complete()
-
com.arjuna.mw.wst.UserBusinessActivity.complete()
If participants have registered for the BusinessAgreementWithComplete protocol then they will be expecting the application to inform them when all work intended for them has been sent (and responded to). The complete method is used for this purpose.
-
com.arjuna.mw.wst11.UserBusinessActivity.complete()
If participants have registered for the BusinessAgreementWithComplete protocol then they will be expecting the application to inform them when all work intended for them has been sent (and responded to). The complete method is used for this purpose.
-
com.arjuna.webservices.wsba.CoordinatorCompletionParticipantInboundEvents.complete()
Handle the complete event.
@param complete The complete notification.
@param addressingContext The addressing context.
@param arjunaContext The arjuna context.
-
com.arjuna.webservices11.wsba.CoordinatorCompletionParticipantInboundEvents.complete()
Handle the complete event.
@param complete The complete notification.
@param addressingProperties The addressing context.
@param arjunaContext The arjuna context.
-
com.arjuna.wst.BusinessActivityTerminator.complete()
-
com.arjuna.wst.stub.BusinessActivityTerminatorStub.complete()
-
com.arjuna.wst11.BusinessActivityTerminator.complete()
Handle the complete event.
@param complete The complete notification.
@param addressingProperties The addressing context.
@param arjunaContext The arjuna context.Active -> Completing Canceling -> Canceling Completing -> Completing 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 Fail)
-
com.arjuna.wst11.stub.BusinessActivityTerminatorStub.complete()
-
com.asakusafw.windgate.core.session.SessionMirror.complete()
Completes and releases this session. This session will not be reopened later.
@throws IOException if failed to detach from the specified session
-
com.caucho.network.listen.AsyncController.complete()
-
com.cloudera.iterativereduce.yarn.avro.generated.IterativeReduceService.complete()
-
com.dianping.cat.message.Event.complete()
-
com.dianping.cat.message.Heartbeat.complete()
-
com.dianping.cat.message.Metric.complete()
-
com.dianping.cat.message.Trace.complete()
-
com.dianping.cat.message.Transaction.complete()
-
com.dianping.cat.message.internal.DefaultEvent.complete()
-
com.dianping.cat.message.internal.DefaultTransaction.complete()
-
com.flaptor.indextank.api.IndexEngineApi.complete()
-
com.google.api.client.extensions.auth.helpers.ThreeLeggedFlow.complete()
After the user has authorized the request, the token or code obtained should be passed to this complete function to allow us to exchange the code with the authentication server for a {@link Credential}.
@param authorizationCode Code or token obtained after the user grants permission
@return {@link Credential} object that is obtained from token server
@throws IOException When an error occurs when communicating with the token server
-
com.google.api.explorer.client.history.EmbeddedHistoryItemView.complete()
Complete the partially filled history item with the response data.
@param response Response data.
@param timeMillis Time that execution took in milliseconds.
@param linkFactory Link factory that is used to generate hyperlink and menu links in theresponse view.
-
com.lowagie.text.Table.complete()
Will fill empty cells with valid blank Cell
s
-
com.ning.compress.Uncompressor.complete()
Method called to indicate that all data to uncompress has already been fed. This typically results in last block of data being uncompressed, and results being sent to listener(s); but may also throw an exception if incomplete block was passed.
-
com.persistit.TransactionStatus.complete()
-
com.sun.tools.javac.code.Symbol.complete()
Complete the elaboration of this symbol's definition.
-
com.sun.tools.javac.code.Symbol.ClassSymbol.complete()
-
com.sun.tools.javac.code.Symbol.PackageSymbol.complete()
-
com.sun.tools.javac.code.Type.complete()
Complete loading all classes in this type.
-
com.vmware.vim.binding.vim.HttpNfcLease.complete()
-
com.volantis.devrep.repository.impl.devices.policy.types.DefaultSelectionPolicyType.complete()
Mark the selection as having had it's initialisation completed.
Note: This method must be called after {@link #addKeyword} and before {@link #getKeywords}.
-
com.volantis.devrep.repository.impl.devices.policy.types.DefaultStructurePolicyType.complete()
Mark the structure as having had it's initialisation completed.
Note: This method must be called after {@link #addFieldType} and before {@link #getFieldTypes}.
-
com.volantis.mcs.context.ListenerEventRegistry.complete()
Mark this registry as completed.
At this point if the registry has unreferenced listeners, an exception will be thrown, as the page is invalid in this case.
-
crosby.binary.osmosis.OsmosisSerializer.complete()
-
de.danet.an.workflow.api.Activity.complete()
-
de.danet.an.workflow.localapi.ActivityLocal.complete()
-
de.danet.an.workflow.omgcore.WfActivity.complete()
This method is used by an application to signal the completion of an activity. Note that this does not necessarily imply that the activity's state changes to
closed.completed
.
XPDL allows an activity to be implemented by several tools that are executed in sequence. Only if complete
is called after the last tool has been started will the workflow engine change the activity's state to closed.completed
. Else the activity will remain in the open.running
state and the next tool will be started. If complete
is called while the activity's state has been set to open.not_running.suspended
the next tool will not be started until the activity is resumed.
The {@link de.danet.an.workflow.api.Activity extended API}provides methods for finding out which tool is currently being executed.
@throws RemoteException if a system-level error occurs.
@throws CannotCompleteException if the activity cannot be completed yet.
-
eas.startSetup.ParCollection.complete()
ergänzt fehlende Werte durch die Konstanten oder sonstige Standardwerte.
-
flex2.compiler.io.ResourceFile.complete()
-
henplus.Command.complete()
Returns a list of strings that are possible at this stage. Used for the readline-completion in interactive mode. Based on the partial command and the lastWord you have to determine the words that are available at this stage. Return 'null', if you don't know a possible completion.
@param disp the CommandDispatcher - you might want to access other values through it.
@param partialCommand The command typed so far
@param lastWord the last word returned by readline.
-
java.util.concurrent.CompletableFuture.complete()
If not already completed, sets the value returned by {@link #get()} and related methods to the given value.
@param value the result value
@return {@code true} if this invocation caused this CompletableFutureto transition to a completed state, else {@code false}
-
javax.servlet.AsyncContext.complete()
Completes the asynchronous operation that was started on the request that was used to initialze this AsyncContext, closing the response that was used to initialize this AsyncContext.
Any listeners of type {@link AsyncListener} that were registeredwith the ServletRequest for which this AsyncContext was created will be invoked at their {@link AsyncListener#onComplete(AsyncEvent) onComplete} method.
It is legal to call this method any time after a call to {@link ServletRequest#startAsync()} or{@link ServletRequest#startAsync(ServletRequest,ServletResponse)}, and before a call to one of the dispatch methods of this class. If this method is called before the container-initiated dispatch that called startAsync has returned to the container, then the call will not take effect (and any invocations of {@link AsyncListener#onComplete(AsyncEvent)} will be delayed) untilafter the container-initiated dispatch has returned to the container.
-
jline.ArgumentCompletor.complete()
-
jline.Completor.complete()
Populates candidates with a list of possible completions for the buffer. The candidates list will not be sorted before being displayed to the user: thus, the complete method should sort the {@link List} before returning.
@param buffer the buffer
@param candidates the {@link List} of candidates to populate
@return the index of the buffer for whichthe completion will be relative
-
jline.console.completer.ArgumentCompleter.complete()
-
jline.console.completer.Completer.complete()
Populates candidates with a list of possible completions for the buffer. The candidates list will not be sorted before being displayed to the user: thus, the complete method should sort the {@link List} before returning.
@param buffer The buffer
@param cursor The current position of the cursor in the buffer
@param candidates The {@link List} of candidates to populate
@return The index of the buffer for which the completion will be relative
-
jline.console.completer.StringsCompleter.complete()
-
models.gtfs.GtfsSnapshotMerge.complete()
-
net.azib.ipscan.core.state.StateMachine.complete()
Transitions back to the idle state
-
net.bnubot.util.task.Task.complete()
-
net.sf.jabref.autocompleter.AbstractAutoCompleter.complete()
Returns one or more possible completions for a given String. The returned completion depends on which informations were stored while adding BibtexEntries by the used implementation of {@link AbstractAutoCompleter}.
@see AbstractAutoCompleter#addBibtexEntry(BibtexEntry)
-
net.spy.memcached.ops.OperationCallback.complete()
Called whenever an operation completes.
-
nexj.core.rpc.InstanceFactory.complete()
Completes the second and the third instantiation passes.
-
nexj.core.runtime.InvocationContext.complete()
Completes all the units of work.
@param bCommit True to commit, false to rollback.
-
nexj.core.scripting.object.ClassObject.complete()
Completes the class object change.
-
orestes.bloomfilter.FilterBuilder.complete()
Checks if all necessary parameters were set and tries to infer optimal parameters (e.g. size and hashes from given expectedElements and falsePositiveProbability). This is done automatically.
-
org.activiti.engine.TaskService.complete()
Called when the task is successfully executed.
@param taskId the id of the task to complete, cannot be null.
@throws ActivitiObjectNotFoundException when no task exists with the given id.
@throws ActivitiException when this task is {@link DelegationState#PENDING} delegation.
-
org.adoptopenjdk.jitwatch.core.AssemblyProcessor.complete()
-
org.apache.abdera.model.Feed.complete()
-
org.apache.axiom.mime.MultipartWriter.complete()
Complete writing of the MIME multipart package. This method does not close the underlying stream.
@throws IOException if an I/O error occurs when writing to the underlying stream
-
org.apache.axiom.om.impl.OMMultipartWriter.complete()
Complete writing of the MIME multipart package. This method delegates to {@link MultipartWriter#complete()}.
@throws IOException if an I/O error occurs when writing to the underlying stream
-
org.apache.axiom.util.base64.Base64EncodingStringBufferOutputStream.complete()
Write out any pending data, including padding if necessary.
@throws IOException if an I/O error occurs
-
org.apache.axiom.util.base64.Base64EncodingWriterOutputStream.complete()
Write out any pending data, including padding if necessary.
@throws IOException if an I/O error occurs
-
org.apache.axis2.client.OperationClient.complete()
To close the transport if necessary , can call this method. The main usage of this method is when client uses two tarnsports for sending and receiving , and we need to remove entries for waiting calls in the transport listener queue. Note : DO NOT call this method if you are not using two transports to send and receive
@param msgCtxt : MessageContext# which has all the transport information
@throws AxisFault : throws AxisFault if something goes wrong
-
org.apache.axis2.om.OMOutput.complete()
-
org.apache.batik.util.ParsedURL.complete()
Returns true if the URL looks well formed and complete. This does not garuntee that the stream can be opened but is a good indication that things aren't totally messed up.
-
org.apache.catalina.core.AsyncContextImpl.complete()
-
org.apache.cocoon.bean.helpers.OutputStreamListener.complete()
-
org.apache.cxf.continuations.ContinuationProvider.complete()
Let the provider know that the exchange is complete
-
org.apache.cxf.endpoint.ConduitSelector.complete()
Called on completion of the MEP for which the Conduit was required. This is the point at which a one-shot strategy would dispose of the Conduit.
@param exchange represents the completed MEP
-
org.apache.derby.iapi.services.compiler.MethodBuilder.complete()
Indicate the method is complete. Once this call has been made the caller must discard the reference to this object.
-
org.apache.derbyTesting.junit.SpawnedProcess.complete()
Waits for the process to terminate.
This call will block until one of the following conditions are met:
- the process terminates on its own
- the hung-process watchdog mechanism forcibly terminates the process (see {@linkplain #scheduleKill})
@return The process exit code.
@throws IOException if printing diagnostics fails
-
org.apache.felix.karaf.shell.console.Completer.complete()
-
org.apache.felix.karaf.shell.console.completer.StringsCompleter.complete()
-
org.apache.flex.forks.batik.util.ParsedURL.complete()
Returns true if the URL looks well formed and complete. This does not garuntee that the stream can be opened but is a good indication that things aren't totally messed up.
-
org.apache.geronimo.gshell.console.completer.StringsCompleter.complete()
-
org.apache.isis.applib.services.command.spi.CommandService.complete()
"Complete" the command, typically meaning to indicate that the command is completed, and to persist it if its {@link Command#getPersistence()} and {@link Command#isPersistHint() persistence hint} indicate that it should be.
However, not every implementation necessarily {@link #persistIfPossible(Command) supports persistence}.
-
org.apache.jetspeed.aggregator.PortletContent.complete()
Notify that this content is completed.
-
org.apache.karaf.shell.console.Completer.complete()
-
org.apache.karaf.shell.console.completer.StringsCompleter.complete()
-
org.apache.karaf.shell.support.completers.StringsCompleter.complete()
-
org.apache.mina.session.DefaultWriteFuture.complete()
complete this future
-
org.apache.mina.transport.ConnectFuture.complete()
session connected
-
org.apache.ode.bpel.iapi.MyRoleMessageExchange.complete()
Complete the message, exchange: indicates that the client has receive the response (if any).
-
org.apache.ode.bpel.rtrep.common.extension.ExtensionContext.complete()
Marks the currently executed activity as successfully completed.
-
org.apache.ode.bpel.runtime.extension.ExtensionContext.complete()
Marks the currently executed activity as successfully completed.
@param cid id
-
org.apache.tools.ant.taskdefs.Redirector.complete()
Complete redirection. This operation will close any streams and create any specified property values.
@throws IOException if the output properties cannot be read from theiroutput streams.
-
org.apache.uima.ducc.transport.event.common.DuccWorkReservation.complete()
-
org.apache.xmlbeans.unmarshal.UnmarshalContext.complete()
-
org.aspectj.org.eclipse.jdt.internal.codeassist.CompletionEngine.complete()
-
org.camunda.bpm.engine.TaskService.complete()
Marks a task as done and continues process execution. This method is typically called by a task list user interface after a task form has been submitted by the {@link Task#getAssignee() assignee}.
@param taskId the id of the task to complete, cannot be null.
@throws ProcessEngineException when no task exists with the given id or when this task is {@link DelegationState#PENDING} delegation.
-
org.camunda.bpm.engine.impl.cmmn.execution.CmmnActivityExecution.complete()
Transition to {@link CaseExecutionState#COMPLETED} state.
This
case execution must be in {@link CaseExecutionState#ACTIVE}state to be able to do this transition.
It is only possible to complete a case execution which is associated with a {@link Stage} or {@link Task}.
If this
case execution has a parent case execution, that parent case execution will be notified that this
case execution has been completed. This can lead to a completion of the parent case execution, for more details when the parent case execution can be completed see {@link #complete()}.
In case of a {@link Stage} the completion can only be performed when the followingcriteria are fulfilled:
- there are no children in the state {@link CaseExecutionState#ACTIVE} or {@link CaseExecutionState#NEW}
- if the property
autoComplete
of the associated {@link Stage} is set to true
: - all required (
requiredRule
evaluates to true
) children are in state - {@link CaseExecutionState#DISABLED}
- {@link CaseExecutionState#COMPLETED}
- {@link CaseExecutionState#TERMINATED}
- {@link CaseExecutionState#FAILED}
- if the property
autoComplete
of the associated {@link Stage} is set to false
: - all children are in
- {@link CaseExecutionState#DISABLED}
- {@link CaseExecutionState#COMPLETED}
- {@link CaseExecutionState#TERMINATED}
- {@link CaseExecutionState#FAILED}
For a {@link Task} instance, this means its purpose has been accomplished:
- {@link HumanTask} have been completed by human.
- {@link CaseTask} have launched a new {@link CaseInstance} and if output parametersare required and/or the property
isBlocking
is set to true
, then the launched {@link CaseInstance} has completed and returned theoutput parameters. - {@link ProcessTask} have launched a new {@link ProcessInstance} and if output parametersare required and/or the property
isBlocking
is set to true
, then the launched {@link ProcessInstance} has completed and returned theoutput parameters.
@throws CaseIllegalStateTransitionException will be thrown, if
this
case executionis not {@link CaseExecutionState#ACTIVE} or when the case execution cannot becompleted.
@throws ProcessEngineException when an internal exception happens during the executionof the command.
-
org.camunda.bpm.engine.impl.cmmn.execution.CmmnCaseInstance.complete()
-
org.camunda.bpm.engine.impl.cmmn.execution.CmmnExecution.complete()
-
org.camunda.bpm.engine.impl.persistence.entity.TaskEntity.complete()
-
org.camunda.bpm.engine.runtime.CaseExecutionCommandBuilder.complete()
Additionally to {@link #execute()} the associated case execution willbe completed. Therefore there happens a transition from the state ACTIVE
to state COMPLETED
.
It is only possible to complete a case execution which is associated with a {@link Stage} or {@link Task}.
In case of a {@link Stage} the completion can only be performed when the followingcriteria are fulfilled:
- there are no children in the state
ACTIVE
For a {@link Task} instance, this means its purpose has been accomplished:
- {@link HumanTask} has been completed by human.
If the given case execution has a parent case execution, that parent case execution will be notified that the given case execution has been completed. This can lead to a completion of the parent case execution if the completion criteria are fulfilled.
@throws NotValidException when the given case execution id is null
@throws NotFoundException when no case execution is found for thegiven case execution id
@throws NotAllowedException when the transition is not allowed to be done
@throws ProcessEngineException when an internal exception happens during the executionof the command.
-
org.cometd.server.Transport.complete()
-
org.crsh.cli.spi.Completer.complete()
Query the completer for a set of completions for the given prefix. The returned {@link Completion} objectprovides the possible completion matching the prefix argument.
@param parameter the completed parameter
@param prefix the prefix to complete
@return the possible suffix map
@throws Exception any exception that would prevent completion to perform correctly
-
org.cyclopsgroup.jcli.jline.CliCompletor.complete()
-
org.dspace.app.xmlui.utils.DSpaceValidity.complete()
Complete this validity object. After the completion no more objects may be added to the validity object and the object will return as valid.
-
org.dspace.core.Context.complete()
Close the context object after all of the operations performed in the context have completed succesfully. Any transaction with the database is committed.
@exception SQLException if there was an error completing the database transaction or closing the connection
-
org.eclipse.jdt.internal.codeassist.CompletionEngine.complete()
-
org.eclipse.jetty.continuation.Continuation.complete()
Complete a suspended request.
This method can be called by any thread that has been passed a reference to a suspended request. When a request is completed, the associated response object committed and flushed. The request is not redispatched.
If complete 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 complete 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.
Typically resume() is used after a call to {@link #suspend(ServletResponse)} witha possibly wrapped response. The async handler should use the response provided by {@link #getServletResponse()} to write the response beforecalling {@link #complete()}. If the request was suspended with a call to {@link #suspend()} then no response object will be available via{@link #getServletResponse()}.
Once complete has been called and any thread calling the filter chain and/or servlet chain has returned to the container, the request lifecycle is complete. The container is able to recycle request objects, so it is not valid hold a request or continuation reference after the end of the life cycle.
@see #suspend()
@exception IllegalStateException if the request is not suspended.
-
org.encog.util.http.FormUtility.complete()
Complete the building of the form.
-
org.fireflow.engine.IWorkItem.complete()
结束当前WorkItem;并由工作流引擎根据流程定义决定下一步操作。引擎的执行规则如下
1、工作流引擎首先判断该WorkItem对应的TaskInstance是否可以结束。 如果TaskInstance的assignment策略为ANY,或者,assignment策略为ALL且它所有的WorkItem都已经完成 则结束当前TaskInstance
2、判断TaskInstance对应的ActivityInstance是否可以结束。如果ActivityInstance的complete strategy 为ANY,或者,complete strategy为ALL且他的所有的TaskInstance都已经结束,则结束当前ActivityInstance
3、根据流程定义,启动下一个Activity,并创建相关的TaskInstance和WorkItem
@throws org.fireflow.engine.EngineException
@throws org.fireflow.kenel.KenelException
-
org.fireflow.engine.impl.ProcessInstance.complete()
正常结束工作流 1、首先检查有无活动的token,如果有则直接返回,如果没有则结束当前流程 2、执行结束流程的操作,将state的值设置为结束状态 3、然后检查parentTaskInstanceId是否为null,如果不为null则,调用父taskinstance的complete操作。
-
org.fireflow.kernel.IActivityInstance.complete()
结束活动
@param token
@param targetActivityInstance
@throws KernelException
-
org.geotools.util.DefaultProgressListener.complete()
-
org.geotools.util.ProgressListener.complete()
Notifies this listener that the operation has finished. The progress indicator will shows 100% or disaspears, at implementor choice. If warning messages were pending, they will be displayed now.
-
org.glassfish.api.admin.ProgressStatus.complete()
Indicates the command is complete and no further progress status will be delivered. Subsequent invocations of progress() will be ignored. This method also invokes {@code complete()} on all child ProgressStatus objects.If this method is not invoked prior to the command completing the CLI framework will implicitly invoke {@code complete()} for the ProgressStatus associated with the command.
@param message to be displayed to the user.
-
org.gradle.api.internal.artifacts.ivyservice.resolveengine.result.ResolutionResultBuilder.complete()
-
org.gradle.api.internal.artifacts.ivyservice.resolveengine.result.StreamingResolutionResultBuilder.complete()
-
org.gradle.api.reporting.components.internal.ComponentReportRenderer.complete()
-
org.gradle.api.tasks.diagnostics.internal.ReportRenderer.complete()
Completes this report. This method must be called last on this renderer.
-
org.gudy.azureus2.plugins.update.Update.complete()
mark the update as complete and inform any listeners
-
org.hyperic.sigar.util.GetlineCompleter.complete()
-
org.impalaframework.module.spi.TransitionResultSet.complete()
-
org.infinispan.cli.commands.Command.complete()
-
org.intalio.tempo.workflow.tms.ITaskManagementService.complete()
-
org.intalio.tempo.workflow.tms.client.TempoClient.complete()
Generate a complete request. This also adds some output to the task.
-
org.jboss.as.cli.CommandLineCompleter.complete()
-
org.jboss.as.cli.handlers.FilenameTabCompleter.complete()
-
org.jboss.forge.shell.completer.CommandCompleter.complete()
-
org.jboss.gwt.circuit.StoreCallback.complete()
After a successful vote, the dispatcher hands the action to the store for completion. It's the stores responsibility to acknowledge the action.
-
org.jboss.jandex.Indexer.complete()
-
org.jboss.ws.extensions.security.SecurityDecoder.complete()
-
org.jbpm.pvm.internal.task.TaskImpl.complete()
-
org.jbpm.task.service.TaskClient.complete()
-
org.jitterbit.integration.client.ui.interchange.entity.transformation.tree.NodePathCompleter.complete()
-
org.jitterbit.integration.data.entity.operation.pipeline.PipelineAutoCompleter.complete()
-
org.jitterbit.integration.data.entity.operation.pipeline.transformation.TransformationAutoCompleter.complete()
-
org.jitterbit.integration.data.entity.operation.pipeline.ws.WebServiceAutoCompleter.complete()
-
org.jitterbit.integration.data.project.path.ProjectPathCompleter.complete()
-
org.jitterbit.ui.text.contentassist.CompletionToken.complete()
Auto-completes this token in the specified document.
-
org.jnode.shell.ArgumentCompleter.complete()
-
org.jnode.shell.CommandLine.complete()
-
org.jnode.shell.Completable.complete()
Add valid completions to the supplied 'completions' object. Each completion should be a complete (acceptable) token or a prefix for one or more acceptable tokens. The method should not add too many completions.
@param completions
@param shell
@throws CompletionException
-
org.jnode.shell.syntax.ArgumentBundle.complete()
-
org.jostraca.process.TemplateHandler.complete()
-
org.kie.api.task.TaskService.complete()
-
org.locationtech.geogig.api.ProgressListener.complete()
Notifies this listener that the operation has finished.
-
org.mindswap.pellet.tableau.completion.CompletionStrategy.complete()
apply all the tableau rules to the designated ABox
-
org.mindswap.pellet.tableau.completion.SROIQIncStrategy.complete()
-
org.mortbay.cometd.Transport.complete()
-
org.mortbay.jetty.HttpGenerator.complete()
Complete the message.
@throws IOException
-
org.mortbay.jetty.Response.complete()
-
org.ofbiz.shipment.packing.PackingSession.complete()
-
org.ofbiz.workflow.WfAssignment.complete()
Mark this assignment as complete.
@throws WfException
-
org.onesocialweb.gwt.client.task.DefaultTaskInfo.complete()
-
org.opengis.util.ProgressListener.complete()
Notifies this listener that the operation has finished. The progress indicator will shows 100% or disappears, at implementor choice. If warning messages were pending, they will be displayed now.
-
org.openstreetmap.osmosis.core.container.v0_6.DatasetContext.complete()
-
org.openstreetmap.osmosis.xml.v0_6.XmlChangeWriter.complete()
close the changeset on the server.
-
org.openstreetmap.osmosis.xml.v0_6.XmlWriter.complete()
close the changeset on the server.
-
org.qi4j.api.unitofwork.UnitOfWork.complete()
Complete this UnitOfWork. This will send all the changes down to the underlying EntityStore's.
@throws UnitOfWorkCompletionException if the UnitOfWork could not be completed
@throws ConcurrentEntityModificationException if entities have been modified by others
-
org.serviceconnector.scmp.SCMPCompositeReceiver.complete()
Complete.
-
org.sonatype.nexus.obr.metadata.ObrResourceWriter.complete()
Appends the OBR metadata footer and marks the stream as complete.
-
org.springframework.http.server.ServerHttpAsyncRequestControl.complete()
Mark asynchronous request processing as completed.
-
org.teavm.common.FiniteExecutor.complete()
-
org.teavm.common.SimpleFiniteExecutor.complete()
-
org.vertx.java.core.impl.DefaultFutureResult.complete()
Has it completed?
-
org.zkoss.zk.ui.event.EventThreadCleanup.complete()
Called in the serlvet thread to clean up. It is called after {@link #cleanup} is called.
Note: {@link #cleanup} is called first in the event processing thread,and then {@link #complete} is called in the servlet thread.
-
riffle.process.scheduler.ProcessChain.complete()
-
sun.font.LayoutPathImpl.SegmentPathBuilder.complete()
-
tv.floe.metronome.classification.neuralnetworks.iterativereduce.MasterNode.complete()