-
EDU.oswego.cs.dl.util.concurrent.Executor.execute()
Execute the given command. This method is guaranteed only to arrange for execution, that may actually occur sometime later; for example in a new thread. However, in fully generic use, callers should be prepared for execution to occur in any fashion at all, including immediate direct execution.
The method is defined not to throw any checked exceptions during execution of the command. Generally, any problems encountered will be asynchronous and so must be dealt with via callbacks or error handler objects. If necessary, any context-dependent catastrophic errors encountered during actions that arrange for execution could be accompanied by throwing context-dependent unchecked exceptions.
However, the method does throw InterruptedException: It will fail to arrange for execution if the current thread is currently interrupted. Further, the general contract of the method is to avoid, suppress, or abort execution if interruption is detected in any controllable context surrounding execution.
-
EDU.oswego.cs.dl.util.concurrent.PooledExecutor.execute()
Arrange for the given command to be executed by a thread in this pool. The method normally returns when the command has been handed off for (possibly later) execution.
-
EDU.oswego.cs.dl.util.concurrent.ThreadedExecutor.execute()
Execute the given command in a new thread.
-
ProcessExecuting.ProcessExecutor.execute()
@throws ProcessRunningException
@throws ProcessCanNotBeRunException
-
ProgramTesting.ProgramTester.execute()
Выполняет и тестирует программу на всех тестах до первого проваленного. TODO memory
@param program программа, не должна быть null
@throws UnsuccessException в одном из тестов был получен неверный ответ (вывод)
@throws TestingInternalServerErrorException ошибка на сервере (не найдены тесты и т.д.)
@throws TestingTimeLimitExceededException программа превысила лимит времени
@throws RunTimeErrorException ошибка времени выполнения
-
abstrasy.Interpreter.execute()
-
actions.Action.execute()
-
algo.FlightDijkstra.execute()
-
android.database.sqlite.SQLiteStatement.execute()
-
anvil.script.CompilableFunction.execute()
-
anvil.script.Function.execute()
-
ar.com.AmberSoft.iEvenTask.backend.entities.Relation.execute()
-
ar.com.AmberSoft.iEvenTask.services.CreateTaskService.execute()
-
ar.com.AmberSoft.iEvenTask.services.GetEventService.execute()
-
ar.com.AmberSoft.iEvenTask.services.GetTaskService.execute()
-
ar.com.AmberSoft.iEvenTask.services.ListEventService.execute()
-
ar.com.AmberSoft.iEvenTask.services.ListProfileService.execute()
-
ar.com.AmberSoft.iEvenTask.services.Service.execute()
-
ar.com.AmberSoft.iEvenTask.services.UpdateEntityService.execute()
-
at.bestsolution.efxclipse.tooling.rrobot.model.task.BooleanExpression.execute()
@model
@generated
-
at.fhj.itm.util.PDFUtil.execute()
-
au.net.ocean.maven.plugin.annotation.Mojo.execute()
-
azkaban.flow.ExecutableFlow.execute()
Executes the flow. This call should not block. Instead, when execution is complete, it should call the callback() method on the callback. Execute can be called multiple times and, upon completion, should call all callbacks that were passed into an execute() call. If the job is already completed when an execute() call is made, the callback should still be called.
@param parentProperties properties that should be used as parent properties by the execution.
@param callback the callback to be run upon completion.
-
backtype.storm.LocalDRPC.execute()
-
backtype.storm.utils.DRPCClient.execute()
-
barrysoft.web.ExtractionJob.execute()
-
br.com.gmartins.simbler.compiler.analyzers.LexAnalyzerWorker.execute()
-
br.com.gmartins.simbler.importer.EniacCodeConverter.execute()
-
br.com.ingenieux.launchify.spi.LaunchifySPI.execute()
-
br.com.ingenieux.mojo.beanstalk.cmd.env.create.CreateEnvironmentCommand.execute()
-
br.com.ingenieux.mojo.beanstalk.cmd.env.swap.SwapCNamesCommand.execute()
-
br.com.ingenieux.mojo.beanstalk.cmd.env.terminate.TerminateEnvironmentCommand.execute()
-
br.com.ingenieux.mojo.beanstalk.cmd.env.update.UpdateEnvironmentCommand.execute()
-
br.com.ingenieux.mojo.beanstalk.cmd.env.waitfor.WaitForEnvironmentCommand.execute()
-
br.com.mystudies.ds.service.Service.execute()
-
br.com.objectos.way.cli.Cli.execute()
-
br.com.objectos.way.ssh.WaySSH.execute()
-
br.com.visualmidia.system.GDSystem.execute()
-
brooklyn.entity.basic.lifecycle.ScriptHelper.execute()
-
by.bsuir.hypermarket.command.Command.execute()
Method processes request and returns corresponding page path
@param request
@return path to the requested page
@throws ServletException
@throws IOException
-
ca.simplegames.micro.controllers.ControllerManager.execute()
-
cascading.lingual.catalog.ddl.DDLParser.execute()
-
cascading.lingual.shell.Shell.execute()
-
cc.concurrent.mango.runtime.operator.Operator.execute()
-
ceylon.modules.spi.Executable.execute()
Execute process with configuration.
@param conf the configuration
@throws Exception for any error
-
ch.epfl.labos.iu.orm.queryll2.symbolic.FrameWithHelpers.execute()
-
ch.fusun.baron.client.rmi.ClientService.execute()
@param command The command to execute
-
ch.fusun.baron.core.command.GameCommand.execute()
Executes the command
-
ch.hortis.sonar.core.service.Executor.execute()
-
ch.hortis.sonar.mvn.reports.ReportHandler.execute()
-
ch.mtSystems.gcjStubber.model.CommandExecutor.execute()
Executes the command and blocks until it is finished. If an exception occured while reading the output, it is thrown (I think this is not possible).
-
ch.njol.skript.lang.Trigger.execute()
@param e
@return false iff an exception occurred
-
ch.qos.logback.core.contention.MultiThreadedHarness.execute()
-
ch.qos.logback.core.contention.ThreadedThroughputCalculator.execute()
-
ch.rolandschaer.ascrblr.HttpRequest.execute()
Executes the current HTTP request and handles the response. If a read or connection timeout has been defined these values will be set before the request. After a successful request a internal flag executed
will be set to true
.
@throws IOException
@throws ServiceException
-
civquest.city.gameChange.ConstructCity.execute()
-
civquest.city.gameChange.RemoveCity.execute()
-
civquest.group.gameChange.AddGroup.execute()
-
civquest.group.gameChange.MarkField.execute()
-
civquest.group.gameChange.MarkUnit.execute()
-
civquest.group.gameChange.UnmarkAll.execute()
-
civquest.group.gameChange.UnmarkAllFields.execute()
-
civquest.group.gameChange.UnmarkAllUnits.execute()
-
civquest.group.gameChange.UnmarkField.execute()
-
civquest.group.gameChange.UnmarkUnit.execute()
-
civquest.map.combat.gameChange.UnitShot.execute()
-
civquest.map.gameChange.SetFieldRuledByCity.execute()
-
civquest.map.gameChange.SetPopulation.execute()
-
civquest.map.gameChange.VegetationChange.execute()
Executes and promotes the change.
-
civquest.map.resource.gameChange.SetDistributionConsumer.execute()
-
civquest.map.resource.gameChange.SetResourceEdgeAmount.execute()
-
civquest.nation.gameChange.AddNation.execute()
-
civquest.swing.gameChange.SetWorkingField.execute()
-
civquest.swing.gameChange.ToggleUnitBlinkOn.execute()
-
civquest.units.gameChange.ConstructUnit.execute()
-
civquest.units.gameChange.RemoveUnit.execute()
-
civquest.visibility.blackWhite.gameChange.MakeCompleteVisible.execute()
-
civquest.visibility.blackWhite.gameChange.MakeInvisible.execute()
-
civquest.visibility.blackWhite.gameChange.MakeTerrainVisible.execute()
-
cn.bran.japid.compiler.TranslateTemplateTask.execute()
-
cn.com.wapps.wrapper.MVCDataWrapper.execute()
-
cn.com.wrapper.DataWrapper.execute()
-
cn.dreampie.common.plugin.lesscss.compiler.LessCssCompiler.execute()
Execute the MOJO.
@throws cn.dreampie.common.plugin.lesscss.compiler.LessCssException if something unexpected occurs.
-
cn.dreampie.lesscss.compiler.LessCssCompiler.execute()
Execute the MOJO.
@throws cn.dreampie.lesscss.compiler.LessCssException if something unexpected occurs.
-
cn.org.rapid_framework.generator.provider.java.model.JavaMethod.JavaMethodInvokeSequencesParser.execute()
-
cn.wensiqun.asmsupport.Executeable.execute()
执行
@return
-
co.cask.tephra.DefaultTransactionExecutor.execute()
-
co.cask.tephra.TransactionExecutor.execute()
Execute a function under transactional semantics. A transaction is started and all datasets are initialized with the transaction. Then the passed function is executed, the transaction is committed, and the function return value is returned as the return value of this method. If any exception is caught, the transaction is aborted and the original exception is rethrown, wrapped into a TransactionFailureException. If the transaction fails due to a write conflict, a TransactionConflictException is thrown.
@param function the function to execute
@param input the input parameter for the function
@param < I> the input type of the function
@param < O> the result type of the function
@return the function's return value
@throws TransactionConflictException if there is a write conflict with another transaction.
@throws TransactionFailureException if any exception is caught, be it from the function or from the datasets.
-
co.nubetech.crux.server.HBaseFacade.execute()
-
com.adito.jdbc.JDBCPreparedStatement.execute()
-
com.adm.biz.Service.execute()
-
com.aerospike.client.command.DeleteCommand.execute()
-
com.aerospike.client.command.ExecuteCommand.execute()
-
com.aerospike.client.command.ExistsCommand.execute()
-
com.aerospike.client.command.OperateCommand.execute()
-
com.aerospike.client.command.ReadCommand.execute()
-
com.aerospike.client.command.ReadHeaderCommand.execute()
-
com.aerospike.client.command.ScanCommand.execute()
-
com.aerospike.client.command.TouchCommand.execute()
-
com.aerospike.client.command.WriteCommand.execute()
-
com.aerospike.client.query.QueryAggregateExecutor.execute()
-
com.aerospike.client.query.QueryRecordExecutor.execute()
-
com.aerospike.client.query.ServerExecutor.execute()
-
com.alexnevsky.hotel.commands.ICommand.execute()
Processes user request and returns path to the page with results.
@param request User request that contains necessary parameters for processing.
@param response Response to send back to the user.
@return Path to the page with results of action performing.
-
com.alibaba.citrus.service.moduleloader.Module.execute()
执行模块。
-
com.alibaba.citrus.service.moduleloader.impl.adapter.ActionEventAdapter.execute()
执行一个module。
-
com.alibaba.citrus.service.moduleloader.impl.adapter.DataBindingAdapter.execute()
-
com.alibaba.druid.pool.DruidPooledCallableStatement.execute()
-
com.alibaba.druid.pool.DruidPooledPreparedStatement.execute()
-
com.alibaba.jstorm.callback.Callback.execute()
-
com.alibaba.jstorm.callback.ClusterStateCallback.execute()
-
com.alipay.bluewhale.core.callback.Callback.execute()
-
com.almworks.sqlite4java.SQLiteQueue.execute()
Places a job in the queue for asynchronous execution in database thread.
The added job's {@link SQLiteJob#job} method will be called from the database thread with an instance of{@link SQLiteConnection}. Job may provide a return value, which will be treated as the job result.
The queue must be started in order for jobs to start executing. Jobs may be added to the queue before or after the queue is started. However, if the queue is already stopped, the job will be immediately cancelled. (It will receive {@link SQLiteJob#jobCancelled} and {@link SQLiteJob#jobFinished} callbacks before this method finishes.)
Because this method returns the argument, you can chain this method with other methods in SQLiteJob or in its subclass:
MyResult r = myQueue.execute(new SQLiteJob<MyResult>() { ... }).complete();
@param job the job to be executed on this queue's database connection, must not be null
@param < T> class of the job's result; use Object or Void if no result is needed
@param < J> job class
@return job
@see SQLiteJob
-
com.amazonaws.services.simpleworkflow.flow.generic.ActivityImplementation.execute()
Execute external activity or initiate its execution if {@link #isManualActivityCompletion()} is true
.
@param task information about activity to be executed. Use {@link ActivityTask#getInput()} to get activity inputarguments.
@return result of activity execution if {@link #isManualActivityCompletion()} is setto false. Use {@link ActivityWorker#respondActivityTaskCompleted(String,Map)}to return result in asynchronous case.
-
com.amazonaws.services.simpleworkflow.flow.interceptors.AsyncExecutor.execute()
-
com.amazonaws.services.simpleworkflow.flow.interceptors.AsyncRetryingExecutor.execute()
-
com.amazonaws.services.simpleworkflow.flow.interceptors.AsyncScheduledExecutor.execute()
-
com.amazonaws.services.simpleworkflow.flow.interceptors.RetryInterceptor.execute()
-
com.aneeshpu.dpdeppop.query.Query.execute()
-
com.aptana.interactive_console.console.IXmlRpcClient.execute()
@param command the command to be executed in the server
@param args the arguments passed to the command
@return the result from executing the command
@throws XmlRpcException
-
com.aptana.interactive_console.console.ScriptXmlRpcClient.execute()
Executes a command in the server. Within this method, we should be careful about being able to return if the server dies. If we wanted to have a timeout, this would be the place to add it.
@return the result from executing the given command in the server.
-
com.aptana.interactive_console.console.ui.internal.actions.HandleDeletePreviousWord.execute()
-
com.aragost.javahg.commands.CommitCommand.execute()
@param files the files to commit.
@return the changeset created by the commit, or null if nothingwas committed.
-
com.aragost.javahg.commands.ResolveCommand.execute()
@param files the files to re-merge
@return the command output
-
com.aragost.javahg.commands.VersionCommand.execute()
Retrieve the Mercurial version number.
@return the Mercurial version of the command server. This is astring since it can include extra information such as the exact changeset ID used to build Mercurial.
-
com.aragost.javahg.internals.ExtraLogCommand.execute()
-
com.aragost.javahg.internals.GenericCommand.execute()
-
com.aragost.javahg.internals.PhaseLogCommand.execute()
-
com.art.anette.client.database.ClientDB.execute()
-
com.art.anette.server.database.ServerDB.execute()
-
com.artemis.Weaver.execute()
-
com.asakusafw.testdriver.JobExecutor.execute()
Executes a Hadoop job.
@param job the job descriptor
@param environmentVariables recommended environment variables
@throws IOException if failed to execute the job
-
com.asakusafw.windgate.core.AbortTask.execute()
Executes WindGate process.
@throws IOException if failed
@throws InterruptedException if interrupted
-
com.asakusafw.windgate.core.GateTask.execute()
Executes WindGate process.
@throws IOException if failed
@throws InterruptedException if interrupted
-
com.asakusafw.windgate.core.process.ProcessProvider.execute()
Execute a gate process for the specified process script.
@param < T> the type of data model object to be processed
@param drivers provides drivers for the execution
@param script target script
@throws IOException if failed to execute gate process
@throws IllegalArgumentException if any parameter is {@code null}
-
com.asakusafw.yaess.core.CommandScriptHandler.execute()
-
com.asakusafw.yaess.core.HadoopScriptHandler.execute()
-
com.asakusafw.yaess.core.JobScheduler.execute()
Executes a series of jobs.
@param monitor the progress monitor of the execution
@param context current execution context
@param jobs jobs to be executed
@param errorHandler handles errors during each job execution
@throws InterruptedException if the execution was interrupted
@throws IOException if failed to execute the jobs
-
com.atlassian.clover.ant.tasks.CloverLogTask.execute()
-
com.atlassian.clover.ant.tasks.CloverMergeTask.execute()
-
com.atlassian.clover.ant.tasks.CloverPassTask.execute()
-
com.atlassian.sal.api.net.Request.execute()
-
com.atlauncher.workers.InstanceInstaller.execute()
-
com.avaje.ebean.EbeanServer.execute()
Execute a SQL Update Delete or Insert statement using the current transaction. This returns the number of rows that where updated, deleted or inserted.
Refer to Ebean.execute(UpdateSql) for full documentation.
@see Ebean#execute(SqlUpdate)
-
com.avaje.ebean.SqlUpdate.execute()
Execute the update returning the number of rows modified.
After you have executed the SqlUpdate you can bind new variables using {@link #setParameter(String,Object)} etc and then execute the SqlUpdateagain.
For JDBC batch processing refer to {@link Transaction#setBatchMode(boolean)} and{@link Transaction#setBatchSize(int)}.
@see com.avaje.ebean.Ebean#execute(SqlUpdate)
-
com.avaje.ebeaninternal.server.core.DefaultBackgroundExecutor.execute()
Execute a Runnable using a background thread.
-
com.azaptree.services.command.http.WebRequestCommand.execute()
-
com.basho.riak.client.api.RiakClient.execute()
Execute a command against Riak
@param command The command
@param < T> The command's return type
@return a response from Riak
@throws ExecutionException
@throws InterruptedException
-
com.basho.riak.client.core.RiakCluster.execute()
-
com.basho.riak.client.operations.DeleteObject.execute()
Uses the specified {@link Retrier} to call the specified{@link RawClient}'s delete with bucket
, key
and (if specified) the rest of the delete operation parameters. If fetchBeforeDelete
is true, then a fetch is performed first to get a vclock.
@return null, always null.
-
com.basho.riak.client.query.BucketKeyMapReduce.execute()
-
com.basho.riak.client.query.IndexMapReduce.execute()
-
com.basho.riak.client.query.MapReduce.execute()
Run the Map/Reduce job against the {@link RawClient} the operation wasconstructed with.
@return a {@link MapReduceResult} containing the results of the query.
@throws RiakException
@throws InvalidMapReduceException
-
com.bbn.openmap.util.SwingWorker.execute()
For compatibility with old versions of SwingWorker, calls start().
-
com.bergerkiller.bukkit.tc.CollisionMode.execute()
-
com.bleujin.dbfs.common.QueryObj.execute()
-
com.bleujin.framework.db.rowset.CachedRowSet.execute()
-
com.bleujin.framework.db.rowset.WebRowSet.execute()
-
com.blogger.tcuri.appserver.interceptor.InterceptorChain.execute()
フィルター処理または、Actionクラスの処理を実行する
@return Resolution
@throws Exception
-
com.blogger.tcuri.appserver.resolution.Resolution.execute()
HTTPレスポンスの処理を実行する
@param context ActionContextオブジェクト
@throws Exception
-
com.box.boxjavalibv2.filetransfer.BoxFileDownload.execute()
Execute a download.
@param auth auth
@param outputStreams OutputStream's the file is going to be downloaded into.
@param objectMapper ObjectMapper
@param requestObject request object
@throws BoxRestException exception
@throws IOException exception
@throws BoxServerException exception
@throws InterruptedException exception
@throws AuthFatalFailureException exception indicating authentication totally failed
-
com.box.boxjavalibv2.filetransfer.BoxFileUpload.execute()
Execute the upload task.
@param manager BoxFilesManager
@param requestObject request objecct
@return the uploaded BoxFile
@throws BoxServerException exception
@throws BoxRestException exception
@throws AuthFatalFailureException exception indicating authentication totally failed
@throws InterruptedException interrupted exception.
-
com.buschmais.cdo.api.Query.execute()
Execute the query.
@return The {@link Query.Result} of the query.
-
com.buschmais.cdo.impl.query.CdoQueryImpl.execute()
-
com.buschmais.jqassistant.core.analysis.api.Analyzer.execute()
Executes the given rule set.
@param ruleSet The rule set.
@throws ReportWriterException If the report cannot be written.
-
com.buschmais.jqassistant.core.analysis.impl.AnalyzerImpl.execute()
-
com.canoo.webtest.steps.Step.execute()
Ant calls this method to invoke this task's functionality. We expand and verify the steps parameters then call doExecute() as well as handle lifecycle notifications.
-
com.carbonfive.db.jdbc.ScriptRunner.execute()
-
com.carmanconsulting.cassidy.pojo.assembly.AssemblyStep.execute()
-
com.caucho.quercus.env.Env.execute()
Evaluates the top-level code and prepend and append code.
-
com.caucho.quercus.program.QuercusProgram.execute()
Execute the program
@param env the calling environment
@return null if there is no return value
-
com.cburch.logisim.circuit.CircuitMutation.execute()
-
com.cedarsoft.exec.Executer.execute()
-
com.cedarsoft.exec.Executor.execute()
execute
@return a int.
@throws IOException if any.
@throws InterruptedException if any.
-
com.cedarsoft.execution.Executer.execute()
-
com.cedarsoft.execution.Executor.execute()
execute
@return a int.
@throws IOException if any.
@throws InterruptedException if any.
-
com.cenqua.clover.tasks.CloverLogTask.execute()
-
com.cenqua.clover.tasks.CloverMergeTask.execute()
-
com.cenqua.clover.tasks.CloverPassTask.execute()
-
com.cenqua.clover.tasks.CloverSnapshotTask.execute()
-
com.cenqua.clover.tasks.CloverTestCheckpointTask.execute()
-
com.cenqua.clover.tasks.HistoryPointTask.execute()
-
com.changestuffs.server.actionhandlers.ArticlesAddActionHandler.execute()
-
com.cloud.bridge.service.controller.s3.ServletAction.execute()
-
com.cloud.utils.script.Script.execute()
-
com.cloud.utils.script.Script2.execute()
-
com.cloudcontrolled.cctrl.maven.plugin.deploy.CloudcontrolledDeploy.execute()
{@inheritDoc}
-
com.cloudcontrolled.cctrl.maven.plugin.push.CloudcontrolledPush.execute()
{@inheritDoc}
-
com.cloudera.hoop.fs.FSOpen.execute()
Executes the filesystem operation.
@param fs filesystem instance to use.
@return The inputstream of the file.
@throws IOException thrown if an IO error occured.
-
com.cloudera.lib.service.Hadoop.execute()
-
com.cloudloop.adapter.HTTPRequest.execute()
-
com.codicesoftware.plastic.commands.CreateWorkspaceCommand.Execute()
-
com.codicesoftware.plastic.commands.GetConfigCommand.execute()
-
com.codicesoftware.plastic.commands.GetWorkspaceFromPathCommand.execute()
-
com.codicesoftware.plastic.commands.SetWorkspaceSelectorCommand.execute()
-
com.complexible.common.web.Request.execute()
-
com.complexible.stardog.api.BooleanQuery.execute()
-
com.complexible.stardog.api.GraphQuery.execute()
-
com.complexible.stardog.api.SelectQuery.execute()
-
com.complexible.stardog.api.UpdateQuery.execute()
-
com.consol.citrus.TestAction.execute()
Main execution method doing all work
@param context
-
com.consol.citrus.TestCase.execute()
-
com.consol.citrus.container.SequenceAfterSuite.execute()
-
com.consol.citrus.container.SequenceAfterTest.execute()
-
com.consol.citrus.container.SequenceBeforeSuite.execute()
-
com.consol.citrus.container.SequenceBeforeTest.execute()
-
com.consol.citrus.dsl.CitrusTestBuilder.execute()
Build an execute test case with new test context generated from Spring bean application context. If no Spring bean application context is set an exception is raised. Users may want to create proper test context instance themselves in case Spring application context is not present. Otherwise set application context before execution properly.
-
com.consol.citrus.dsl.definition.MockBuilder.execute()
-
com.cordys.cpc.bsf.soap.SOAPRequestObject.execute()
-
com.cosmo.data.DataAgent.execute()
Ejecuta una sent�ncia SQL de la que no se espera ning�n resultado (p. ej. INSERT, UPDATE, DELETE).
@param sql Una cadena que contiene la sent�ncia SQL a ejecutar.
@return {@code True} si la ejecuci�n ha tenido �xito o {@code false} en cualquier otro caso.
@throws DataException
-
com.cosmo.data.DataQuery.execute()
Ejecuta la consulta.
@param workspace Una instancia de {@link Workspace} que representa el workspace actual.
@return Una instancia de {@link ResultSet} que contiene los datos devueltos por la consulta.
@throws DataException
-
com.creativewidgetworks.goldparser.engine.Reduction.execute()
This method is called when the parsed program tree is executed. Rule handler classes override this method as necessary to implement code generation or execution strategies
@throws ParserException
-
com.ctp.cdi.query.builder.QueryBuilder.execute()
-
com.cxy.redisclient.integration.hash.AddHash.execute()
-
com.cxy.redisclient.integration.hash.DelField.execute()
-
com.cxy.redisclient.integration.hash.IsFieldExist.execute()
-
com.cxy.redisclient.integration.hash.ReadHash.execute()
-
com.cxy.redisclient.integration.hash.SetField.execute()
-
com.cxy.redisclient.integration.key.DeleteKey.execute()
-
com.cxy.redisclient.integration.key.DumpKey.execute()
-
com.cxy.redisclient.integration.key.Expire.execute()
-
com.cxy.redisclient.integration.key.FindContainerKeys.execute()
-
com.cxy.redisclient.integration.key.GetSize.execute()
-
com.cxy.redisclient.integration.key.IsKeyExist.execute()
-
com.cxy.redisclient.integration.key.ListContainerKeys.execute()
-
com.cxy.redisclient.integration.key.ListContainers.execute()
-
com.cxy.redisclient.integration.key.ListKeys.execute()
-
com.cxy.redisclient.integration.key.RenameKey.execute()
-
com.cxy.redisclient.integration.key.RestoreKey.execute()
-
com.cxy.redisclient.integration.key.TTLs.execute()
-
com.cxy.redisclient.integration.list.AddList.execute()
-
com.cxy.redisclient.integration.list.InsertList.execute()
-
com.cxy.redisclient.integration.list.ListList.execute()
-
com.cxy.redisclient.integration.list.ListListPage.execute()
-
com.cxy.redisclient.integration.list.RemoveValue.execute()
-
com.cxy.redisclient.integration.list.SetValue.execute()
-
com.cxy.redisclient.integration.list.UpdateList.execute()
-
com.cxy.redisclient.integration.protocol.RedisSession.execute()
-
com.cxy.redisclient.integration.pubsub.Publish.execute()
-
com.cxy.redisclient.integration.pubsub.Subscribe.execute()
-
com.cxy.redisclient.integration.server.QueryDBAmount.execute()
-
com.cxy.redisclient.integration.server.QueryServerProperties.execute()
-
com.cxy.redisclient.integration.server.QueryServerVersion.execute()
-
com.cxy.redisclient.integration.set.AddSet.execute()
-
com.cxy.redisclient.integration.set.ListSet.execute()
-
com.cxy.redisclient.integration.set.ListSetPage.execute()
-
com.cxy.redisclient.integration.set.RemoveSet.execute()
-
com.cxy.redisclient.integration.string.AddString.execute()
-
com.cxy.redisclient.integration.string.ReadString.execute()
-
com.cxy.redisclient.integration.string.UpdateString.execute()
-
com.cxy.redisclient.integration.zset.AddZSet.execute()
-
com.cxy.redisclient.integration.zset.ListZSet.execute()
-
com.cxy.redisclient.integration.zset.ListZSetPage.execute()
-
com.cxy.redisclient.integration.zset.RemoveMembers.execute()
-
com.datastax.driver.core.Session.execute()
Executes the provided query. This is a convenience method for {@code execute(new SimpleStatement(query))}.
@param query the CQL query to execute.
@return the result of the query. That result will never be null but canbe empty (and will be for any non SELECT query).
@throws NoHostAvailableException if no host in the cluster can becontacted successfully to execute this query.
@throws QueryExecutionException if the query triggered an executionexception, i.e. an exception thrown by Cassandra when it cannot execute the query with the requested consistency level successfully.
@throws QueryValidationException if the query if invalid (syntax error,unauthorized or any other validation problem).
-
com.db4o.query.Query.execute()
executes the {@link Query}.
@return {@link ObjectSet} - the result of the {@link Query}.
-
com.dbxml.xmlrpc.XmlRpcClient.execute()
-
com.dci.intellij.dbn.connection.transaction.DatabaseTransactionManager.execute()
-
com.dci.intellij.dbn.database.common.execution.MethodExecutionProcessor.execute()
-
com.dci.intellij.dbn.execution.method.MethodExecutionManager.execute()
-
com.dci.intellij.dbn.execution.statement.processor.StatementExecutionCursorProcessor.execute()
-
com.developmentsprint.spring.breaker.CircuitManager.execute()
-
com.director.core.ExecutorAdapter.execute()
-
com.documentum.fc.client.DfQuery.execute()
-
com.dooapp.gaedo.finders.dynamic.Mode.execute()
-
com.dotcms.repackage.com.caucho.quercus.program.QuercusProgram.execute()
-
com.dotcms.repackage.org.elasticsearch.action.admin.indices.create.CreateIndexRequestBuilder.execute()
-
com.dotcms.repackage.org.elasticsearch.action.admin.indices.settings.UpdateSettingsRequestBuilder.execute()
-
com.dotcms.repackage.org.elasticsearch.action.bulk.BulkRequestBuilder.execute()
-
com.dotcms.repackage.org.elasticsearch.action.count.CountRequestBuilder.execute()
-
com.dotcms.repackage.org.elasticsearch.action.search.SearchRequestBuilder.execute()
-
com.dotmarketing.business.query.SQLQueryFactory.execute()
-
com.dotmarketing.fixtask.FixTasksExecutor.execute()
-
com.dowdandassociates.gentoo.bootstrap.Bootstrapper.execute()
-
com.dragome.compiler.DragomeJsCompiler.execute()
-
com.dtolabs.launcher.Setup.execute()
Validates the install, generates preference data and then invokes the adminCmd.xml
@param args Command line args
@throws SetupException thrown if error
-
com.dtolabs.rundeck.core.tasks.net.ExtSSHExec.execute()
Execute the command on the remote host.
@exception BuildException Most likely a network error or bad parameter.
-
com.dtrules.interpreter.IRObject.execute()
This method defines the executable behavior of a object within the Rules Interpreter.
@param state The Rules Engine State
@throws RulesException
-
com.dtrules.session.IRSession.execute()
Execute the given postfix string
@param s
@throws RulesException
@Deprecated
-
com.ebay.sdk.call.AddItemCall.execute()
-
com.ebay.sdk.call.AddOrderCall.execute()
-
com.ebay.sdk.call.AddSellingManagerInventoryFolderCall.execute()
-
com.ebay.sdk.call.AddSellingManagerProductCall.execute()
-
com.ebay.sdk.call.DeleteSellingManagerTemplateCall.execute()
-
com.ebay.sdk.call.GetCategoriesCall.execute()
-
com.ebay.sdk.call.GetCategoryFeaturesCall.execute()
-
com.ebay.sdk.call.GetDescriptionTemplatesCall.execute()
-
com.ebay.sdk.call.GetOrdersCall.execute()
-
com.ebay.sdk.call.GetSellingManagerInventoryCall.execute()
-
com.ebay.sdk.call.GetSellingManagerInventoryFolderCall.execute()
-
com.ebay.sdk.call.GetStoreCall.execute()
-
com.ebay.sdk.call.GetStoreOptionsCall.execute()
-
com.ebay.sdk.call.ReviseSellingManagerProductCall.execute()
-
com.ebay.sdk.call.SetStoreCall.execute()
-
com.ebay.sdk.call.VerifyAddItemCall.execute()
-
com.eclipsesource.tabris.ui.Action.execute()
Will be called by the Tabris UI when a User presses the visual representation of this action.
@param context the context to control the application flow and share data.
-
com.ecyrd.jspwiki.dav.methods.DavMethod.execute()
-
com.ecyrd.jspwiki.dav.methods.GetMethod.execute()
-
com.ecyrd.jspwiki.dav.methods.PropFindMethod.execute()
-
com.ecyrd.jspwiki.plugin.PluginManager.execute()
Executes a plugin class in the given context.
Used to be private, but is public since 1.9.21.
@param context The current WikiContext.
@param classname The name of the class. Can also be ashortened version without the package name, since the class name is searched from the package search path.
@param params A parsed map of key-value pairs.
@return Whatever the plugin returns.
@throws PluginException If the plugin execution failed forsome reason.
@since 2.0
-
com.ee.tayra.domain.operation.Operation.execute()
-
com.espertech.esper.core.start.EPPreparedExecuteMethod.execute()
Executes the prepared query.
@return query results
-
com.esri.core.geometry.OperatorBoundary.execute()
Calculates the boundary geometry. \param geoms The input geometry cursor. \param progress_tracker The progress tracker, that allows to cancel the lengthy operation. \return Returns a cursor over boundries for each geometry.
-
com.esri.core.geometry.OperatorBuffer.execute()
Creates a buffer around the input geometries
@param inputGeometries The geometries to buffer.
@param sr The SpatialReference of the Geometries.
@param distances The buffer distances for the Geometries. If the size of the distances array is less than the number of geometries in the inputGeometries, the last distance value is used for the rest of geometries.
@param bUnion If True, the buffered geometries will be unioned, otherwise they wont be unioned.
-
com.esri.core.geometry.OperatorExportToGeoJson.execute()
-
com.esri.core.geometry.OperatorExportToWkb.execute()
Performs the ExportToWKB operation.
@param exportFlags Use the {@link WkbExportFlags} interface.
@param geometry The Geometry being exported.
@return Returns a ByteBuffer object containing the Geometry in WKB format
-
com.esri.core.geometry.OperatorImportFromESRIShape.execute()
Performs the ImportFromESRIShape operation on a stream of shape buffers
@return Returns a GeometryCursor.
-
com.esri.core.geometry.OperatorSimplify.execute()
Performs the Simplify operation on the geometry set.
@return Returns a GeometryCursor of simplified geometries.
-
com.esri.core.geometry.OperatorUnion.execute()
Performs the Topological Union operation on the geometry set.
@param inputGeometries is the set of Geometry instances to be unioned.
-
com.esri.gpt.catalog.arcims.ExtendedQueryRequest.execute()
Executes query.
@throws ImsServiceException if error executing query
-
com.esri.gpt.catalog.discovery.DiscoveryQueryAdapter.execute()
Executes a query for metadata documents.
@param context the active request context
@param discoveryQuery the query to execute
@throws DiscoveryException if an exception occurs
-
com.esri.gpt.catalog.harvest.history.HeDeleteRequest.execute()
Executes request.
@throws SQLException if error accessing database.
-
com.esri.gpt.catalog.harvest.history.HeSelectOneRequest.execute()
Executes request.
@throws java.sql.SQLException if accessing database fails
-
com.esri.gpt.catalog.harvest.history.HeSelectRequest.execute()
Executes request.
@throws java.sql.SQLException if request execution fails
-
com.esri.gpt.catalog.harvest.history.HeTransformReportRequest.execute()
Executes request.
@param template template to use for transformation
@param writer writer
@param mapParams transformation parameters
@throws Exception exceptions is transformation fails
-
com.esri.gpt.catalog.harvest.history.HeUpdateReportRequest.execute()
Executes request.
@param report input stream with the report
@throws SQLException if writing report fails
-
com.esri.gpt.catalog.harvest.history.HeUpdateRequest.execute()
Executes event.
@throws java.sql.SQLException if accessing database failed
-
com.esri.gpt.catalog.harvest.jobs.HjCancelRequest.execute()
Executes request.
@return true
if records has been found and deleted
@throws SQLException if deleting jobs fails
-
com.esri.gpt.catalog.harvest.jobs.HjCompleteRequest.execute()
Executes request.
@return true
if the record has been updated
@throws java.sql.SQLException if error accesing database occured
-
com.esri.gpt.catalog.harvest.jobs.HjCreateRequest.execute()
Inserts a new jobs into the database. If there is any job for the particular repository, no record will be inserted.
@return true
if any record has been inserted
-
com.esri.gpt.catalog.harvest.jobs.HjGetNextRequest.execute()
Executes request.
@throws SQLException if accessing database failed
-
com.esri.gpt.catalog.harvest.jobs.HjLoadAllRequest.execute()
Executes request.
@throws SQLException if accessing database fails
-
com.esri.gpt.catalog.harvest.jobs.HjResetRunningRequest.execute()
Executes request.
@throws SQLException if accessing database failed
-
com.esri.gpt.catalog.harvest.jobs.HjWithdrawRequest.execute()
Executes request.
@return true
if records has been found and deleted
@throws SQLException if deleting jobs fails
-
com.esri.gpt.catalog.harvest.repository.HrCompleteUpdateRequest.execute()
Executes request.
@throws Exception if any error occurred
-
com.esri.gpt.catalog.harvest.repository.HrDeleteRequest.execute()
Executes request.
@throws java.sql.SQLException if request execution fails
-
com.esri.gpt.catalog.harvest.repository.HrHarvestRequest.execute()
Executes request.
@throws java.sql.SQLException if request execution fails
-
com.esri.gpt.catalog.harvest.repository.HrSelectRequest.execute()
Executes request.
@throws java.sql.SQLException if request execution fails
-
com.esri.gpt.catalog.harvest.repository.HrUpdateLastSyncDate.execute()
Executes request.
@throws SQLException if accessing database fails
-
com.esri.gpt.catalog.lucene.LuceneQueryAdapter.execute()
Executes a query for metadata documents.
@param context the active request context
@param discoveryQuery the query to execute
@throws DiscoveryException if an exception occurs
-
com.esri.gpt.catalog.management.MmdActionRequest.execute()
Executes the action request.
@throws ImsServiceException in an exception occurs while communicationwith the ArcIMS metadata publishing service
@throws Exception if an exception occurs
-
com.esri.gpt.catalog.management.MmdQueryRequest.execute()
Executes the query request.
@throws SQLException if a database exception occurs
@throws IOException
@throws SAXException
@throws ParserConfigurationException
-
com.esri.gpt.catalog.publication.CollectSourceUrisRequest.execute()
Executes request.
@throws SQLException if accessing database fails
@throws IOException if accessing index fails
-
com.esri.gpt.catalog.publication.DeleteSourceUrisRequest.execute()
-
com.esri.gpt.control.georss.dcatcache.DcatCacheUpdateRequest.execute()
Executes update request.
@throws IOException if request fails
-
com.esri.gpt.framework.http.HttpClientRequest.execute()
Executes the HTTP request.
@throws IOException if an Exception occurs
-
com.esri.gpt.framework.resource.query.Query.execute()
Executes query.
-
com.esri.sde.sdk.client.SeInsert.execute()
-
com.esri.sde.sdk.client.SeQuery.execute()
-
com.esri.sde.sdk.client.SeUpdate.execute()
-
com.eviware.soapui.model.mock.MockResponse.execute()
-
com.exigen.ie.constrainer.Constrainer.execute()
Executes the goal without state restoration.
@return true if success
@param goal com.exigen.ie.constrainer.Goal
-
com.exigen.ie.constrainer.Constraint.execute()
-
com.exigen.ie.constrainer.Goal.execute()
An implementation of the execution algorithm of this goal. Returns subgoal of this goal if there are any, null otherwise.
-
com.extendedencryption.action.executer.BaseExecuter.execute()
-
com.facebook.presto.testing.LocalQueryRunner.execute()
-
com.facebook.presto.util.LocalQueryRunner.execute()
-
com.flipkart.phantom.task.impl.TaskHandlerExecutor.execute()
-
com.founder.fix.fixflow.core.action.ActionHandler.execute()
动作执行方法
@param executionContext
@throws Exception
-
com.founder.fix.fixflow.core.action.ConnectorHandler.execute()
连接器执行方法
@param executionContext 上下文环境变量
@throws Exception
-
com.founder.fix.fixflow.core.impl.connector.ConnectorInstanceBehavior.execute()
-
com.founder.fix.fixflow.core.impl.db.SqlCommand.execute()
执行查询
@param sql
@throws DAOException
-
com.founder.fix.fixflow.core.impl.interceptor.CommandExecutor.execute()
-
com.founder.fix.fixflow.core.scriptlanguage.BusinessRulesScript.execute()
执行业务规则
@param parameter 参数
@return
-
com.founder.fix.fixflow.core.scriptlanguage.DeleteRulesScript.execute()
执行删除规则
@param parameter 参数
@return
-
com.founder.fix.fixflow.core.scriptlanguage.InsertRulesScript.execute()
执行插入规则
@param parameter 参数
@return
-
com.founder.fix.fixflow.core.scriptlanguage.SelectRulesScript.execute()
执行查询规则
@param parameter 参数
@return
-
com.founder.fix.fixflow.core.scriptlanguage.UpdateRulesScript.execute()
执行更新规则
@param parameter 参数
@return
-
com.fray.evo.action.EcAction.execute()
-
com.fray.evo.util.EcAutoUpdate.execute()
-
com.garbagemule.MobArena.waves.ability.Ability.execute()
Execute the boss ability. The ability should be concise and not start any unnecessary threading, or schedule any unnecessary tasks. The MABoss object can be used to get the LivingEntity that is the boss, and to damage, heal or just set the boss health directly.
@param arena the Arena of the boss
@param boss the MABoss object
-
com.gargoylesoftware.htmlunit.javascript.JavaScriptEngine.execute()
Executes the specified JavaScript code in the context of a given HTML page.
@param htmlPage the page that the code will execute within
@param sourceCode the JavaScript code to execute
@param sourceName the name that will be displayed on error conditions
@param startLine the line at which the script source starts
@return the result of executing the specified code
-
com.gargoylesoftware.htmlunit.javascript.PostponedAction.execute()
Execute the action.
@throws Exception if it fails
-
com.gemstone.gemfire.cache.execute.Execution.execute()
-
com.gemstone.gemfire.cache.query.Query.execute()
-
com.github.kristofa.test.http.client.ApacheHttpClientImpl.execute()
{@inheritDoc}
-
com.github.kristofa.test.http.client.HttpClient.execute()
Executes a HTTP request and returns response.
@param request HTTP request.
@return Response.
@throws HttpRequestException In case request failed.
-
com.github.marook.eclipse_remote_control.run.runner.ICommandRunner.execute()
-
com.github.maven_nar.cpptasks.CCTask.execute()
Executes the task. Compiles the given files.
@throws BuildException if someting goes wrong with the build
-
com.github.maven_nar.cpptasks.ide.ProjectDef.execute()
Executes the task. Compiles the given files.
@param task cc task
@param sources source files (includes headers)
@param targets compilation targets
@param linkTarget link target
-
com.github.mustachejava.Mustache.execute()
Execute the mustache object with a given writer and a single scope context.
@param writer
@param scope
@return
-
com.github.tomakehurst.wiremock.admin.AdminTask.execute()
-
com.globant.google.mendoza.command.MendozaAddCouponCommand.execute()
Executes the mendoza server add coupon command.
-
com.globant.google.mendoza.command.MendozaAddGiftCommand.execute()
Executes the mendoza server add gift certificate command.
-
com.globant.google.mendoza.command.MendozaAssertCartCommand.execute()
Executes the schema validation of the shopping cart.
-
com.globant.google.mendoza.command.MendozaAssertSignatureCommand.execute()
Executes the validation of the shopping cart signature.
-
com.globant.google.mendoza.command.MendozaCancelOrderCommand.execute()
Executes the mendoza server cancel order command.
-
com.globant.google.mendoza.command.MendozaChangeMerchantCommand.execute()
Executes the mendoza server change merchant command.
-
com.globant.google.mendoza.command.MendozaChargeOrderCommand.execute()
Executes the mendoza server charge order command.
-
com.globant.google.mendoza.command.MendozaCheckoutCommand.execute()
Executes the mendoza server post cart command.
-
com.globant.google.mendoza.command.MendozaCheckoutEncodedCommand.execute()
Executes the mendoza server post encoded cart command.
-
com.globant.google.mendoza.command.MendozaHelpCommand.execute()
Executes the mendoza server reset command.
-
com.globant.google.mendoza.command.MendozaLoginCommand.execute()
Executes the mendoza server login command.
-
com.globant.google.mendoza.command.MendozaPlaceOrderCommand.execute()
Executes the mendoza server place order command.
-
com.globant.google.mendoza.command.MendozaRefundOrderCommand.execute()
Executes the mendoza server refund order command.
-
com.globant.google.mendoza.command.MendozaResetCommand.execute()
Executes the mendoza server reset command.
-
com.globant.google.mendoza.command.MendozaStatusCommand.execute()
Executes the mendoza server login command.
-
com.google.api.client.auth.oauth2.TokenRequest.execute()
Executes request for an access token, and returns the parsed access token response.
To execute but parse the response in an alternate way, use {@link #executeUnparsed()}.
Default implementation calls {@link #executeUnparsed()} and then parses using{@link TokenResponse}. Subclasses may override to change the return type, but must still call {@link #executeUnparsed()}.
@return parsed successful access token response
@throws TokenResponseException for an error response
-
com.google.api.client.googleapis.auth.oauth2.GoogleAuthorizationCodeTokenRequest.execute()
-
com.google.api.client.googleapis.auth.oauth2.GoogleRefreshTokenRequest.execute()
-
com.google.api.client.googleapis.auth.oauth2.draft10.GoogleAccessTokenRequest.GoogleAuthorizationCodeGrant.execute()
-
com.google.api.client.googleapis.batch.BatchRequest.execute()
Executes all queued HTTP requests in a single call, parses the responses and invokes callbacks.
Calling {@link #execute()} executes and clears the queued requests. This means that the{@link BatchRequest} object can be reused to {@link #queue} and {@link #execute()} requestsagain.
-
com.google.api.client.googleapis.services.AbstractGoogleClientRequest.execute()
-
com.google.api.client.http.HttpRequest.execute()
ess the HTTP response object } finally { response.disconnect(); }
@return HTTP response for an HTTP success response (or HTTP error response if{@link #getThrowExceptionOnExecuteError()} is {@code false})
@throws HttpResponseException for an HTTP error response (only if{@link #getThrowExceptionOnExecuteError()} is {@code true})
@see HttpResponse#isSuccessStatusCode()
-
com.google.api.services.androidpublisher.AndroidPublisher.Edits.Apks.Upload.execute()
-
com.google.api.services.androidpublisher.AndroidPublisher.Edits.Commit.execute()
-
com.google.api.services.androidpublisher.AndroidPublisher.Edits.Insert.execute()
-
com.google.api.services.androidpublisher.AndroidPublisher.Edits.Listings.Update.execute()
-
com.google.api.services.androidpublisher.AndroidPublisher.Edits.Tracks.Update.execute()
-
com.google.api.services.bigquery.Bigquery.Jobs.Get.execute()
-
com.google.api.services.bigquery.Bigquery.Jobs.Insert.execute()
-
com.google.api.services.drive.Drive.Files.Insert.execute()
-
com.google.api.services.drive.Drive.Files.Update.execute()
-
com.google.api.services.youtube.YouTube.Thumbnails.Set.execute()
-
com.google.api.translate.TranslateV2.execute()
-
com.google.appengine.datanucleus.mapping.DependentDeleteRequest.execute()
Perform the work of the delete request. Calls preDelete on related fields, and nulls other relations as required to allow the deletion of the owner.
@return Dependent objects that need deleting after the delete of the owner
-
com.google.appengine.tck.event.ExecutionLifecycleEvent.execute()
Do we execute wrt current execution context.
@return true if yes, false if no, null if undetermined
-
com.google.appengine.tools.enhancer.EnhancerTask.execute()
Execution method
@throws BuildException Thrown when an error occurs when processing the task
-
com.google.code.http4j.RequestExecutor.execute()
-
com.google.code.mojo.license.LicenseCheckMojo.execute()
-
com.google.code.mojo.license.LicenseFormatMojo.execute()
-
com.google.code.mojo.license.LicenseRemoveMojo.execute()
-
com.google.common.util.concurrent.ExecutionList.execute()
Runs this execution list, executing all existing pairs in the order they were added. However, note that listeners added after this point may be executed before those previously added, and note that the execution order of all listeners is ultimately chosen by the implementations of the supplied executors.
This method is idempotent. Calling it several times in parallel is semantically equivalent to calling it exactly once.
@since Guava release 10 (present in release 01 as {@code run})
-
com.google.enterprise.connector.dctm.dfcwrap.IQuery.execute()
-
com.google.enterprise.connector.filenet4.filewrap.ISearch.execute()
-
com.google.feedserver.tools.FeedClient.execute()
-
com.google.gdata.client.Service.GDataRequest.execute()
-
com.google.gerrit.sshd.commands.QueryShell.execute()
-
com.google.gwt.animation.client.AnimationScheduler.AnimationCallback.execute()
-
com.google.gwt.core.client.Scheduler.RepeatingCommand.execute()
-
com.google.gwt.core.client.Scheduler.ScheduledCommand.execute()
-
com.google.gwt.search.client.LocalSearch.execute()
-
com.google.gwt.search.client.SearchControl.execute()
Programmatically execute a query. This allows the control to be seeded with an initial query and search results. Using this method is equivalent to typing a query into the SearchControl and pressing return.
@param query A search query
-
com.google.gwt.user.client.Command.execute()
Causes the Command to perform its encapsulated behavior.
-
com.google.gwtorm.jdbc.JdbcExecutor.execute()
-
com.google.wave.api.WaveService.HttpFetcher.execute()
-
com.google.wave.extensions.tweety.controller.FetchController.execute()
Performs a fetch, triggered by user's interaction with the control form, and return a list of {@link Tweet} based on that input.
@return A list of {@link Tweet}.
@throws IOException If there is a problem connecting to Twitter.
@throws JSONException If there is a problem parsing the JSON response.
@throws ParseException If there is a problem parsing the date in the JSONresponse.
@throws CacheException If there is a problem fetching data from GoogleApp Engine Memcache.
-
com.google.ytd.command.Command.execute()
-
com.google.ytd.command.GetVideoSubmissions.execute()
-
com.googlecode.aviator.Expression.execute()
Execute expression with environment
@param env Binding variable environment
@return
-
com.googlecode.batchfb.util.RequestBuilder.execute()
-
com.googlecode.goclipse.ui.actions.GocodeClient.execute()
-
com.googlecode.prolog_cafe.lang.BufferingPrologControl.execute()
-
com.graphaware.tx.executor.batch.BatchTransactionExecutor.execute()
Execute work in batches.
-
com.graphaware.tx.executor.batch.NoInputBatchTransactionExecutor.execute()
-
com.groupon.odo.bmp.http.BrowserMobHttpRequest.execute()
-
com.hazelcast.client.spi.ClientExecutionService.execute()
-
com.hazelcast.core.IExecutorService.execute()
Executes task on a randomly selected member
@param command task
@param memberSelector memberSelector
@throws {@link java.util.concurrent.RejectedExecutionException } if no member is selected
-
com.hazelcast.executor.impl.DistributedExecutorService.execute()
-
com.hazelcast.spi.impl.InternalOperationService.execute()
Executes a Runnable on a thread that is responsible for a given partition. This method is typically used by the {@link com.hazelcast.client.ClientEngine} when it has received a Packet containinga request that needs to be processed. The advantage of this method is that the request can immediately be handed over to a thread that can take care of it; either execute it directly or send it to the remote machine.
@param task the task to execute
@param partitionId the partition id. A partition of smaller than 0, means that the task is going to be executed inthe generic operation-threads and not on a partition specific operation-thread.
-
com.hazelcast.test.WatchedOperationExecutor.execute()
-
com.hazelcast.util.executor.ManagedExecutorService.execute()
-
com.hazelcast.util.executor.StripedExecutor.execute()
-
com.heroku.api.connection.Connection.execute()
Synchronously execute the given request, using a different apiKey than the one associated with this connection
@param request the request to execute
@param < T> the response type
@param apiKey the apiKey of the user to make the request on behalf of
@return the response as parsed by the request object
-
com.heroku.api.connection.HttpClientConnection.execute()
-
com.hp.hpl.jena.shared.Command.execute()
Perform some action and return some result.
-
com.hp.hpl.jena.sparql.engine.main.StageGenerator.execute()
-
com.hp.hpl.jena.sparql.modify.UpdateProcessRemoteBase.execute()
-
com.hp.hpl.jena.update.UpdateProcessor.execute()
Execute
-
com.hp.hpl.squirrelrdf.ldap.LdapSparqlMap.execute()
Execute the query. Essentially just analyses the query then plumbs the iterators together.
@param results
@return
-
com.hp.hpl.squirrelrdf.ldap.LdapSubQuery.execute()
-
com.icegreen.greenmail.pop3.commands.Pop3Command.execute()
-
com.icegreen.greenmail.smtp.commands.SmtpCommand.execute()
-
com.iisigroup.cap.hg.service.IHGService.execute()
execute connect
@throws Exception
-
com.iisigroup.cap.operation.Operation.execute()
-
com.iisigroup.cap.operation.OperationStep.execute()
-
com.iisigroup.cap.plugin.HandlerPlugin.execute()
execute
@param params Client 參數
@return String
-
com.impetus.labs.korus.addons.constructs.pipeline.Pipeline.execute()
Starts the execution of the pipeline after the initialization and joining of the tasks are done.
-
com.inadco.hbl.client.AggregateQuery.execute()
Execute the query
@return result set . It is expected to be closed by the user!
@throws HblException
-
com.inadco.hbl.client.PreparedAggregateQuery.execute()
-
com.inadco.hbl.client.impl.PreparedAggregateQueryImpl.execute()
-
com.innavace.ds.config.Configuration.execute()
-
com.intellij.execution.runners.ProgramRunner.execute()
-
com.intellij.openapi.command.WriteCommandAction.execute()
-
com.intellij.openapi.editor.actionSystem.EditorActionHandler.execute()
Executes the action.
@param editor the editor in which the action is invoked.
@param dataContext the data context for the action.
-
com.intellij.plugins.haxe.runner.NMERunningState.execute()
-
com.intellij.plugins.haxe.runner.OpenFLRunningState.execute()
-
com.intersys.objects.CacheQuery.execute()
-
com.ipc.oce.objects.reports.OCDataCompositionTemplateComposer.execute()
Созданный макет компоновки.
@param schema - Схема, для которой требуется построить макет.
@param settings - Настройки, для которых необходимо создать макет.
@param details - Содержит переменную, в которую будут помещены данные расшифровки. Если параметр не указан, расшифровка заполняться не будет.
@return
@throws JIException
-
com.ipc.oce.query.OCQuery.execute()
Выполняет запрос к базе данных. В случае, если запросу установлен пакетный запрос, метод последовательно выполнит все запросы из пакета и вернет результат последнего запроса пакета, который не создает и не уничтожает временную таблицу. Если такого запроса нет, то будет возвращен результат исполнения последнего запроса
@return
@throws JIException
-
com.ipeirotis.gal.engine.Engine.execute()
-
com.izforge.izpack.ant.IzPackTask.execute()
-
com.jbidwatcher.search.Searcher.execute()
-
com.jpetrak.gate.stringannotation.extendedgazetteer2.ExtendedGazetteer2.execute()
-
com.lgx8.common.payment.util.httpClient.HttpProtocolHandler.execute()
执行Http请求
@param request
@return
-
com.linkedin.helix.josql.ZNRecordQueryProcessor.execute()
-
com.lowagie.geoforge.toolbox.GfrPdfPhotoAlbumFromAbs.execute()
-
com.lowagie.geoforge.toolbox.GfrPdfPhotoAlbumFromFiles.execute()
-
com.lowagie.geoforge.toolbox.GfrPdfPhotoAlbumFromFolder.execute()
-
com.lowagie.tools.AbstractTool.execute()
Executes the tool (in most cases this generates a PDF file).
-
com.mangofactory.swagger.core.CommandExecutor.execute()
-
com.mathieucarbou.mojo.license.LicenseCheckMojo.execute()
-
com.mathieucarbou.mojo.license.LicenseFormatMojo.execute()
-
com.mathieucarbou.mojo.license.LicenseRemoveMojo.execute()
-
com.maverick.http.HttpClient.execute()
-
com.microsoft.sqlserver.jdbc.SQLServerCallableStatement.execute()
-
com.mks.api.CmdRunner.execute()
-
com.mobixess.jodb.soda.api.Query.execute()
executes the {@link Query}.
@return {@link ObjectSet} - the result of the {@link Query}.
@throws IOException
@throws IllegalClassTypeException
-
com.mockey.ClientExecuteProxy.execute()
@param twistInfo
@param proxyServer
@param realServiceUrl
@param httpMethod
@param request
@return
@throws ClientExecuteProxyException
-
com.mockey.model.Service.execute()
The core method to execute the request as either a Proxy, Dynamic, or Static Scenario.
-
com.mongodb.BulkWriteOperation.execute()
Execute the bulk write operation with the default write concern of the collection from which this came. Note that the continueOnError property of the write concern is ignored.
@return the result of the bulk write operation.
@throws com.mongodb.BulkWriteException
@throws com.mongodb.MongoException
-
com.mongodb.hadoop.testutils.MapReduceJob.execute()
-
com.mossle.auth.support.Exporter.execute()
-
com.mossle.auth.support.Importer.execute()
-
com.mxgraph.layout.hierarchical.stage.mxCoordinateAssignment.execute()
A basic horizontal coordinate assignment algorithm
-
com.mxgraph.layout.hierarchical.stage.mxHierarchicalLayoutStage.execute()
Takes the graph detail and configuration information within the facade and creates the resulting laid out graph within that facade for further use.
-
com.mxgraph.layout.hierarchical.stage.mxMedianHybridCrossingReduction.execute()
Performs a vertex ordering within ranks as described by Gansner et al 1993
-
com.mxgraph.layout.hierarchical.stage.mxMinimumCycleRemover.execute()
Produces the layer assignmment using the graph information specified
-
com.mxgraph.layout.mxCircleLayout.execute()
-
com.mxgraph.layout.mxCompactTreeLayout.execute()
-
com.mxgraph.layout.mxIGraphLayout.execute()
Executes the layout for the children of the specified parent.
@param parent Parent cell that contains the children to be layed out.
-
com.mxgraph.layout.mxOrganicLayout.execute()
Implements .
-
com.mxgraph.layout.mxParallelEdgeLayout.execute()
-
com.mxgraph.model.mxIGraphModel.mxAtomicGraphModelChange.execute()
-
com.mysema.query.jpa.codegen.HibernateDomainExporter.execute()
-
com.mysema.query.jpa.codegen.JPADomainExporter.execute()
-
com.mysema.query.sql.dml.SQLDeleteClause.execute()
-
com.mysema.query.sql.dml.SQLInsertClause.execute()
-
com.mysema.query.sql.dml.SQLMergeClause.execute()
-
com.mysema.query.sql.dml.SQLUpdateClause.execute()
-
com.mysql.cluster.ndbj.NdbTransaction.execute()
-
com.mysql.clusterj.jdbc.SQLExecutor.Executor.execute()
-
com.mysql.jdbc.Statement.execute()
Execute a SQL statement that may return multiple results. We don't have to worry about this since we do not support multiple ResultSets. You can use getResultSet or getUpdateCount to retrieve the result.
@param sql any SQL statement
@return true if the next result is a ResulSet, false if it is an updatecount or there are no more results
@exception SQLException if a database access error occurs
-
com.mysql.management.util.QueryUtil.execute()
-
com.netflix.astyanax.MutationBatch.execute()
-
com.netflix.astyanax.cql.schema.CqlKeyspaceDefinitionImpl.execute()
-
com.netflix.astyanax.query.RowSliceQuery.execute()
-
com.netflix.niws.client.http.RestClient.execute()
-
com.netflix.priam.agent.tasks.AgentTask.execute()
-
com.netflix.priam.agent.tasks.ProcessTask.execute()
-
com.netflix.priam.backup.IncrementalBackup.execute()
-
com.netflix.priam.backup.SnapshotBackup.execute()
-
com.netflix.zeno.util.SimultaneousExecutor.execute()
-
com.ning.http.client.AsyncHttpClient.BoundRequestBuilder.execute()
-
com.nykredit.kundeservice.data.sql.SqlQuery.execute()
-
com.openbravo.data.loader.Transaction.execute()
-
com.opengamma.engine.exec.DependencyGraphExecutor.execute()
Evaluates a dependency graph.
@param graph a full graph or a subgraph. A subgraph may have some nodes whose child nodes are NOT part of that graph. The assumption is that such nodes have already been evaluated and theirvalues can already be found in the shared computation cache.
@return An object you can call get() on to wait for completion
-
com.opengamma.engine.function.FunctionInvoker.execute()
Execute on the specified target, producing the values desired. Exceptions thrown will result in a failure of this node.
@param executionContext The execution-time configuration for this invocation.
@param inputs All required inputs pre-packaged for this function invocation.
@param target The target on which calculation should be performed.
@param desiredValues The only values that should be computed by this invocation.
@return All values that were computed by this invocation.
-
com.opengamma.integration.tool.portfolio.PortfolioLoader.execute()
Execute the portfolio load(s) with the configured options.
-
com.opengamma.util.db.tool.DbCreateOperation.execute()
-
com.opengamma.util.db.tool.DbTool.execute()
-
com.opengamma.util.db.tool.DbUpgradeOperation.execute()
-
com.opensymphony.xwork.ActionProxy.execute()
-
com.opensymphony.xwork.Result.execute()
-
com.opensymphony.xwork2.ActionProxy.execute()
Execute this ActionProxy. This will set the ActionContext from the ActionInvocation into the ActionContext ThreadLocal before invoking the ActionInvocation, then set the old ActionContext back into the ThreadLocal.
@return the result code returned from executing the ActionInvocation
@throws Exception can be thrown.
@see ActionInvocation
-
com.opensymphony.xwork2.Result.execute()
Represents a generic interface for all action execution results. Whether that be displaying a webpage, generating an email, sending a JMS message, etc.
@param invocation the invocation context.
@throws Exception can be thrown.
-
com.orientechnologies.orient.core.command.OCommandExecutor.execute()
Execute the requested command parsed previously.
@param iArgs Optional variable arguments to pass to the command.
@see #parse(OCommandRequestInternal)
@return
-
com.orientechnologies.orient.core.command.OCommandRequest.execute()
-
com.orientechnologies.orient.core.command.OCommandRequestText.execute()
-
com.orientechnologies.orient.core.command.script.OCommandExecutorScript.execute()
-
com.orientechnologies.orient.core.command.script.OCommandScript.execute()
-
com.orientechnologies.orient.core.sql.functions.OSQLFunctionRuntime.execute()
Execute a function.
@param iRecord Current record
@return
-
com.orientechnologies.orient.core.sql.methods.OSQLMethodRuntime.execute()
Execute a method.
@param iCurrentRecord Current record
@param iCurrentResult TODO
@param iContext
@return
-
com.orientechnologies.orient.graph.migration.OGraphMigration.execute()
-
com.orientechnologies.orient.server.distributed.task.OAbstractRemoteTask.execute()
-
com.orientechnologies.orient.server.network.protocol.http.command.OServerCommand.execute()
Executes the command requested.
@return boolean value that indicates if this command is part of a chain
-
com.pcmsolutions.system.callback.CallbackTask.execute()
-
com.planet_ink.coffee_web.util.CWThreadExecutor.execute()
-
com.ponysdk.sample.command.pony.CreatePonyCommand.execute()
-
com.ponysdk.sample.command.pony.FindPonyChildsCommand.execute()
-
com.ponysdk.sample.command.pony.FindPonysCommand.execute()
-
com.ponysdk.sample.trading.command.trading.FindCurrenciesCommand.execute()
-
com.ponysdk.ui.server.basic.PPusher.execute()
-
com.projity.algorithm.Query.execute()
-
com.projity.dialog.OpenProjectDialog.execute()
-
com.projity.pm.graphic.spreadsheet.common.CommonSpreadSheetAction.execute()
-
com.proofpoint.http.client.HttpClient.execute()
-
com.proofpoint.http.client.jetty.JettyHttpClient.execute()
-
com.pugh.sockso.commands.CommandExecuter.execute()
Executes a command and returns the results
@param command
@return
-
com.pv.mf.db.IUpdateOrmBuilder.execute()
-
com.pv.mf.db.mock.impl.UpdateBuilder.execute()
-
com.qspin.qtaste.kernel.campaign.CampaignManager.execute()
Executes a campaign
@param campaign the campaign to execute.
-
com.qspin.qtaste.testsuite.impl.JythonTestScript.execute()
-
com.restfb.DefaultLegacyFacebookClient.execute()
@see com.restfb.LegacyFacebookClient#execute(java.lang.String,com.restfb.Parameter[])
-
com.restfb.LegacyFacebookClient.execute()
Executes a Facebook API method with the given {@code parameters}, ignoring the response.
@param method The Facebook API method to call, e.g. {@code fql.query}.
@param parameters Parameters to include in the API call.
@throws FacebookException If an error occurs while performing the API call.
-
com.salas.bb.utils.swingworker.SwingWorker.execute()
Schedules this {@code SwingWorker} for execution on a
worker thread. There are a number of
workerthreads available. In the event all
worker threads are busy handling other {@code SwingWorkers} this{@code SwingWorker} is placed in a waiting queue.
Note: {@code SwingWorker} is only designed to be executed once. Executing a {@code SwingWorker} more than oncewill not result in invoking the {@code doInBackground} method twice.
-
com.salesforce.dataloader.action.IAction.execute()
This is the main method. Call this method to execute the action
@throws DataAccessObjectException
-
com.salesforce.ide.ui.actions.ShowInBrowserAction.execute()
-
com.salesforce.phoenix.compile.MutationPlan.execute()
-
com.samskivert.mustache.Mustache.Lambda.execute()
-
com.samskivert.mustache.Template.execute()
Executes this template with the given context, returning the results as a string.
@throws MustacheException if an error occurs while executing or writing the template.
-
com.scooterframework.orm.sqldataexpress.processor.DataProcessor.execute()
execute
-
com.scratchdisk.script.Script.execute()
-
com.serotonin.m2m2.rt.script.ScriptExecutor.execute()
-
com.simoncat.net.HttpClient.execute()
-
com.sk89q.skmcl.util.HttpRequest.execute()
Execute the request. After execution, {@link #close()} should be called.
@return this object
@throws IOException on I/O error
-
com.skyline.energy.executor.DataAccessExecutor.execute()
-
com.sleepycat.dbxml.XmlQueryExpression.execute()
-
com.sleepycat.je.rep.NetworkRestore.execute()
Restores the log files from one of the members of the replication group.
If config.getLogProviders()
returns null, or an empty list, it uses the member that is least busy as the provider of the log files. Otherwise it selects a member from the list, choosing the first member that's available, to provide the log files. If the members in this list are not present in logException.getLogProviders()
, it will result in an IllegalArgumentException
being thrown. Exceptions handlers for InsufficientLogException
will typically use {@link InsufficientLogException#getLogProviders()} as thestarting point to compute an appropriate list, with which to set up the config
argument.
Log files that are currently at the node will be retained if they are part of a consistent set of log files. Obsolete log files are either deleted, or are renamed based on the the configuration of config.getRetainLogFiles()
.
@param logException the exception thrown by {@code ReplicatedEnvironment()} that necessitated this log refresh operation
@param config configures the execution of the network restore operation
@throws EnvironmentFailureException if an unexpected, internal orenvironment-wide failure occurs.
@throws IllegalArgumentException if the config
is invalid
@see NetworkRestoreConfig
-
com.sleepycat.je.rep.stream.FeederReplicaHandshake.execute()
Executes the feeder side of the handshake.
@throws ProtocolException
@throws ExitException
-
com.sleepycat.je.rep.stream.FeederReplicaSyncup.execute()
The feeder's side of the protocol. Find out where to start the replication stream.
@return the VLSN to start the replication stream
@throws InterruptedException
@throws NetworkRestoreException
@throws ChecksumException
-
com.sleepycat.je.rep.stream.ReplicaFeederHandshake.execute()
Executes the replica side of the handshake.
@throws ProtocolException
-
com.sleepycat.je.rep.stream.ReplicaFeederSyncup.execute()
The replica's side of the protocol.
@throws InterruptedException
@throws InsufficientLogException
@throws HardRecoveryElectionException
-
com.socialnetworkshirts.twittershirts.dataaccess.spreadshirt.http.HttpCallCommand.execute()
-
com.sos.DataExchange.SOSDataExchangeEngine.Execute()
-
com.splunk.shuttl.server.distributed.RequestOnSearchPeers.execute()
@return JSONObjects as response from each distributed peer.
-
com.springsource.insight.plugin.jdbc.helpers.AbstractStatement.execute()
-
com.starflow.wf.engine.ExecutorService.execute()
执行任务,可以按照同步异步方式执行
@param tasker 执行任务
@param invokePattern 执行模式(同步和异步)
@return
@throws Exception
-
com.starflow.wf.engine.core.expression.IExpressionHandler.execute()
-
com.starflow.wf.engine.transaction.TransactionTemplate.execute()
-
com.starflow.wf.service.spi.IActivateRuleAction.execute()
@param processInstance 流程实例
@param activityInst 环节实例
@return Boolean 是否直接运行
-
com.starflow.wf.service.spi.IApplicationExecptionAction.execute()
@param exception
@param processInstance 流程实例
@param activityInst 环节实例
-
com.starflow.wf.service.spi.IToolAppAction.execute()
@param processInstance 流程实例
@param activityInst 环节实例
@return Object
-
com.sun.enterprise.admin.cli.CLICommand.execute()
Execute this command with the given arguemnts. The implementation in this class saves the passed arguments in the argv field and calls the initializePasswords method. Then it calls the prepare, parse, and validate methods, finally returning the result of calling the executeCommand method. Note that argv[0] is the command name.
@throws CommandException if execution of the command fails
@throws CommandValidationException if there's something wrongwith the options or arguments
-
com.sun.enterprise.admin.cli.CLIProcessExecutor.execute()
This method invokes the runtime exec
@param cmd the command to execute
@param wait if true, wait for process to end.
@exception Exception
-
com.sun.enterprise.admin.cli.remote.RemoteCLICommand.execute()
-
com.sun.enterprise.admin.cli.remote.RemoteCommand.execute()
-
com.sun.enterprise.ee.synchronization.TimestampRemoveCommand.execute()
Removes the synchronization timestamp file as specified (in the meta xml file).
@throws SynchronizationException if an error while processing the zip
-
com.sun.enterprise.universal.process.ProcessManager.execute()
-
com.sun.enterprise.util.ProcessExecutor.execute()
-
com.sun.enterprise.v3.admin.RestartDomainCommand.execute()
Restart of the application server : All running services are stopped. LookupManager is flushed. Client code that started us should notice the return value of 10 and restart us.
-
com.sun.enterprise.web.connector.grizzly.AsyncTask.execute()
-
com.sun.enterprise.web.connector.grizzly.ReadTask.execute()
-
com.sun.faban.common.Command.execute()
Called from the command agent allowing the agent to ensure the command will work in the agent environment.
@param checker The command checker
@param extMap The extended command map for the service/tool, if any
@return A handle to the executing command
@throws IOException Error dealing with the stdin, stdout, or stderr
@throws InterruptedException The execute thread got interrupted.
-
com.sun.faban.harness.agent.CmdAgentImpl.execute()
Executes a command from the remote command agent.
@param c The command to be executed
@param svcPath The service location, if any
@return A handle to the command
@throws IOException Error communicating with resulting process
@throws InterruptedException Thread got interrupted waiting
-
com.sun.faces.lifecycle.ApplyRequestValuesPhase.execute()
-
com.sun.faces.lifecycle.Phase.execute()
Perform all state transitions required by the current phase of the request processing {@link Lifecycle} for a particular request.Return one of the standard state change values (GOTO_EXIT
, GOTO_NEXT
, or GOTO_RENDER
) to indicate what the request processing lifecycle should do next.
@param context FacesContext for the current request being processed
@throws FacesException if a processing error occurred whileexecuting this phase
-
com.sun.faces.lifecycle.ProcessValidationsPhase.execute()
-
com.sun.faces.lifecycle.RenderResponsePhase.execute()
-
com.sun.grid.installer.util.cmd.CopyExecutableCommand.execute()
-
com.sun.grid.installer.util.cmd.FsTypeCommand.execute()
-
com.sun.grid.installer.util.cmd.GetArchCommand.execute()
-
com.sun.grid.installer.util.cmd.GetJvmLibCommand.execute()
-
com.sun.grid.installer.util.cmd.RemoteComponentScriptCommand.execute()
-
com.sun.grid.installer.util.cmd.ResolveHostCommand.execute()
-
com.sun.grid.installer.util.cmd.SimpleLocalCommand.execute()
-
com.sun.grizzly.Context.execute()
-
com.sun.jini.thread.Executor.execute()
Executes the given Runnable action asynchronously in some thread. The implementation may create a new thread to execute the action, or it may execute the action in an existing thread. The execution of a given action must not be delayed indefinitely in order to complete execution of a different action passed to a different invocation of this method. In other words, the implementation must assume that there may be arbitrary dependencies between actions passed to this method, so it needs to be careful to avoid potential deadlock by delaying execution of one action indefinitely until another completes. Also, this method itself must not block, because it may be invoked by code that is serially processing data to produce multiple such arbitrarily-dependent actions that need to be executed.
@param runnable the Runnable action to execute
@param name string to include in the name of the thread usedto execute the action
-
com.sun.org.apache.xpath.internal.Expression.execute()
Execute an expression in the XPath runtime context, and return the result of the expression.
@param xctxt The XPath runtime context.
@param currentNode The currentNode.
@return The result of the expression in the form of a XObject
.
@throws javax.xml.transform.TransformerException if a runtime exceptionoccurs.
-
com.sun.org.apache.xpath.internal.XPath.execute()
Given an expression and a context, evaluate the XPath and return the result.
@param xctxt The execution context.
@param contextNode The node that "." expresses.
@param namespaceContext The context in which namespaces in theXPath are supposed to be expanded.
@return The result of the XPath or null if callbacks are used.
@throws TransformerException thrown ifthe error condition is severe enough to halt processing.
@throws javax.xml.transform.TransformerException
@xsl.usage experimental
-
com.sun.org.apache.xpath.internal.objects.XObject.execute()
For support of literal objects in xpaths.
@param xctxt The XPath execution context.
@return This object.
@throws javax.xml.transform.TransformerException
-
com.sun.rowset.JdbcRowSetImpl.execute()
Creates the internal
ResultSet
object for which this
JdbcRowSet
object is a wrapper, effectively making the result set a JavaBeans component.
Certain properties must have been set before this method is called so that it can establish a connection to a database and execute the query that will create the result set. If a DataSource
object will be used to create the connection, properties for the data source name, user name, and password must be set. If the DriverManager
will be used, the properties for the URL, user name, and password must be set. In either case, the property for the command must be set. If the command has placeholder parameters, those must also be set. This method throws an exception if the required properties are not set.
Other properties have default values that may optionally be set to new values. The execute
method will use the value for the command property to create a PreparedStatement
object and set its properties (escape processing, maximum field size, maximum number of rows, and query timeout limit) to be those of this rowset.
@throws SQLException if (1) a database access error occurs,(2) any required JDBC properties are not set, or (3) if an invalid connection exists.
-
com.sun.star.awt.XDialog.execute()
-
com.sun.star.awt.XMessageBox.execute()
-
com.sun.star.form.runtime.XFormOperations.execute()
-
com.sun.star.lib.TestBed.execute()
-
com.sun.star.report.ReportJob.execute()
Although we might want to run the job as soon as it has been created, sometimes it is wiser to let the user add some listeners first. If we execute at once, the user either has to deal with threading code or wont receive any progress information in single threaded environments.
-
com.sun.star.sdbc.XPreparedStatement.execute()
-
com.sun.star.sdbc.XRowSet.execute()
-
com.sun.star.sdbc.XStatement.execute()
-
com.sun.star.system.XSystemShellExecute.execute()
-
com.sun.star.task.XJob.execute()
-
com.sun.star.ucb.XCommandProcessor.execute()
-
com.sun.star.ui.dialogs.XExecutableDialog.execute()
-
com.tangosol.net.InvocationService.execute()
-
com.taobao.zeus.socket.worker.reqresp.WorkerBeCancel.execute()
-
com.taobao.zeus.socket.worker.reqresp.WorkerBeExecute.execute()
-
com.taobao.zeus.socket.worker.reqresp.WorkerHeartBeat.execute()
-
com.test.FormProcessingAction.execute()
-
com.thenetcircle.comsumerdispatcher.distribution.watcher.CountChangedWatcher.execute()
-
com.tinkerpop.furnace.algorithms.vertexcentric.computers.SerialGraphComputer.execute()
-
com.tinkerpop.gremlin.process.computer.VertexProgram.execute()
This method denotes the main body of the computation and is executed on each vertex in the graph. This method is logically executed in parallel on all vertices in the graph. When the {@link Memory} is read, it is according to the aggregated state yielded in the previous iteration.When the {@link Memory} is written, the data will be aggregated at the end of the iteration for reading in the next iteration.
@param vertex the {@link Vertex} to execute the {@link VertexProgram} on
@param messenger the messenger that moves data between vertices
@param memory the shared state between all vertices in the computation
-
com.tinkerpop.rexster.client.RexsterClient.execute()
Sends a RexProMessage, and returns the received RexProMessage response. This method is for low-level operations with RexPro only.
@param rawMessage message to send.
-
com.tll.client.data.rpc.ForgotPasswordCommand.execute()
-
com.twitter.common.application.ShutdownRegistry.ShutdownRegistryImpl.execute()
-
com.twitter.common.base.Command.execute()
-
com.vaadin.ui.JavaScript.execute()
Executes the given JavaScript code in the browser.
@param script The JavaScript code to run.
-
com.vladium.emma.emmaTask.execute()
-
com.volantis.map.agent.ResponseCallback.execute()
This method will be called when the Media Conversion Program has the requested information and the caller has entered the {@link MediaAgent#waitForComplete()} method.
@param params the parameters asked for. This MAY contain more parametersthen where requested. It will always contain a value for the generated short URL. The key for this value is {@link MediaAgent.OUTPUT_URL_PARAMETER_NAME}.
@throws Exception if any problem is encountered.
-
com.volantis.map.ics.imageprocessor.impl.ICSOperation.execute()
-
com.volantis.map.operation.Operation.execute()
This method should return {@link Result#SUCCESS} if the operation wassuccessfull, {@link Result#UNSUPPORTED} if the plugin cannot performthe specified operation.
@param descriptor
@param request
@param response
@return Result#SUCCESS if the operation succeeded, Result#UNSUPPORTED ifthe operation is not supported.
@throws Exception if an error occurs when attempting to perform theoperation
-
com.volantis.mcs.expression.functions.diselect.DIAspectRatioFunction.execute()
-
com.volantis.mcs.expression.functions.diselect.DIColorFunction.execute()
-
com.volantis.mcs.expression.functions.diselect.DIColorIndexFunction.execute()
-
com.volantis.mcs.expression.functions.diselect.DIGridFunction.execute()
-
com.volantis.mcs.expression.functions.diselect.DIMonochromeFunction.execute()
-
com.volantis.mcs.expression.functions.diselect.DIResolutionFunction.execute()
-
com.volantis.mcs.expression.functions.diselect.DIScanFunction.execute()
-
com.volantis.mcs.interaction.impl.operation.SetModelObjectOperation.execute()
-
com.volantis.shared.net.http.HttpGetMethod.execute()
Execute the method.
@return The status code.
@throws IOException If there was a problem.
-
com.volantis.xml.pipeline.sax.drivers.web.HTTPRequestExecutor.execute()
Executes the HTTP request
@return a HTTPResponseAccessor
instance that allowsthe response to be accessed.
@throws HTTPException if an error occurs
-
com.workplacesystems.utilsj.threadpool.WorkerThread.execute()
-
com.xebialabs.overthere.OverthereConnection.execute()
Executes a command with its arguments.
@param handler the handler that will be invoked when the executed command generated output.
@param commandLine the command line to execute.
@return the exit value of the executed command. Usually 0 on successful execution.
@deprecated use {@link #execute(OverthereExecutionOutputHandler,OverthereExecutionOutputHandler,CmdLine)}
-
com.yahoo.ycsb.client.MasterClient.execute()
-
com.yahoo.ycsb.rmi.SlaveRMIInterface.execute()
-
com.yammer.tenacity.tests.TenacityFailingCommand.execute()
-
com.youtube.vitess.vtgate.VtGate.execute()
-
com.zeroturnaround.liverebel.api.update.ConfigurableUpdate.execute()
-
connectivity.tools.RowSet.execute()
-
controller.commands.Attack.execute()
-
controller.commands.Command.execute()
-
controller.commands.Heal.execute()
-
controller.commands.Move.execute()
-
controller.commands.Trade.execute()
-
core.operation.CreateNewTestOperation.execute()
Execute the operation.
-
cuke4duke.ant.CucumberTask.execute()
-
cuke4duke.ant.GemTask.execute()
-
de.akquinet.innovation.play.maven.utils.CopyDependenciesEmbeddedMojo.execute()
-
de.danielkullmann.hackvm.HackVM.execute()
-
de.desy.tine.client.TLink.execute()
Executes a synchronous link using the data sets supplied at link creation. Synchronous. This method executes the link using the data sets and parameters provided at instantiation. The call will block for 1000 msec or until the call completes. \note The TLink object created will remain resident until a call to the cancel() method is made. Thus repeated calls to execute() can be made without invoking separate calls to TLink().
@return 0 if successful, otherwise a tine return code which can beinterpreted using getError() or getLastError(). \b Example: \include eg_execute1.java
@see de.desy.tine.client.TLink#TLink
@see de.desy.tine.client.TLink#attach
-
de.iritgo.aktera.clients.KeelStarter.execute()
-
de.iritgo.aktera.clients.webapp.WebappClientConnector.execute()
Run the business model, using a request/response pair The description sounds curious since the method doesn't take a request as an argument! This is because although most webapps use the HttpServletRequest/HttpServletResponse pair, some, particularly Cocoon, do not and use their own abstraction. So, the method preferred here, is that the WebappClientConnector implementation will pass in the the appropriate request/response and other paramters in the constructor and use those during the execution of this method. See de.iritgo.aktera.struts.StrutsClientConnector and de.iritgo.aktera.clients.cocoon.CocoocClientConnector for examples.
@return The Keel response
@throws ClientException
@throws ModelException
-
de.iritgo.aktera.model.Command.execute()
Convenience method, equivilant to execute(req, res, false, false)
-
de.iritgo.aktera.model.Model.execute()
-
de.iritgo.aktera.model.ModelRequest.execute()
Actually execute the requested model object's logic, returning the ModelResponse it creates
-
de.iritgo.aktera.scheduler.action.ScheduleActionHandler.execute()
@param action TODO
-
de.iritgo.aktera.ui.UIController.execute()
Execute the controller.
@param request The ui request
@param response The ui response
@throws UIControllerException In case of an error
-
de.iritgo.simplelife.process.Procedure2.execute()
-
de.matrixweb.smaller.pipeline.Pipeline.execute()
@param version
@param vfs
@param resolver
@param manifest
@param targetDir
@throws IOException
-
de.matrixweb.smaller.resource.Processor.execute()
@param vfs The file system to operate in
@param resource
@param options A {@link Map} of options for processing
@return Returns the transformed source
@throws IOException
-
de.mhus.lib.bpm.BpmActionHandler.execute()
-
de.mhus.lib.bpm.BpmActivity.execute()
-
de.mhus.lib.bpm.BpmInstance.execute()
-
de.mhus.lib.cao.CaoAction.execute()
Executes a defined action. Is the action need to execute an operation it will return the operation object to be executed by the caller.
@param list
@param configuration
@return
@throws CaoException
-
de.mhus.lib.parser.CompiledString.execute()
Return the new, compiled string.
@param attributes
@return
-
de.mhus.lib.sql.DbStatement.execute()
Executes the given SQL statement, which may return multiple results. In this statement InputStream as attribute values are allowed.
@See Statement.execute
@param attributes
@return
@throws Exception
-
de.mnl.srcpd4cu.srcp.Command.execute()
Execeute the command with the given arguments for the given session.
@param session the session
@param arguments the arguments
@return the result
-
de.netseeker.ejoe.EJClient.execute()
Main entry point for client tier implementations. Handles all remote server calls... This method is threadsafe, ensuring that only one request is processed at a time.
@param obj input objects for the EJOE Server
@return the object(s) returned by the EJOE server
-
de.novanic.eventservice.client.command.RemoteListenCommand.execute()
When the RemoteListenCommand is executed, the listen method of the EventService is called.
@param anEventService EventService ({@link de.novanic.eventservice.client.event.service.EventService})
@see de.novanic.eventservice.client.event.service.EventService#listen()
-
de.novanic.eventservice.client.event.command.InitEventServiceCommand.execute()
Initializes the server/service connection.
-
de.saumya.mojo.ruby.script.Script.execute()
-
de.spinscale.elasticsearch.client.action.suggest.SuggestRefreshRequestBuilder.execute()
-
de.spinscale.elasticsearch.client.action.suggest.SuggestRequestBuilder.execute()
-
de.spinscale.elasticsearch.client.action.suggest.SuggestStatisticsRequestBuilder.execute()
-
de.sub.goobi.helper.GoobiScript.execute()
Starten des Scripts ================================================================
-
de.sub.goobi.helper.tasks.ProcessSwapInTask.execute()
-
de.sub.goobi.helper.tasks.ProcessSwapOutTask.execute()
-
de.timefinder.core.ui.command.TimeFinderCommand.MySwingWorker.execute()
-
de.willuhn.jameica.hbci.rmi.HBCIDBService.execute()
-
de.willuhn.jameica.hbci.synchronize.SynchronizeBackend.execute()
Fuehrt die uebergebenen Jobs auf dem Backend aus.
@param jobs die auszufuehrenden Jobs.
@return die neue Session.
@throws ApplicationException bei einem Anwendungsfehler.
@throws OperationCanceledException wenn der User die Synchronisierung abgebrochen hat.
-
de.willuhn.sql.version.Updater.execute()
-
driftingdroids.model.Solver.execute()
-
driftingdroids.model.SolverBFS.execute()
-
driftingdroids.model.SolverIDDFS.execute()
-
eas.math.gnuplot2.JGnuplot.execute()
flags:
JG_InNewThread
JG_DeleteTempFile: use ~JG_DeleteTempFile flag to keep the temp file. This is useful when doing multi-thread plotting. The temp files shold be deleted at the end all together (delAllTempFiles()) to guarantee all figures can be plotted before temp files are deleted.
JG_Pause
JG_Log
JG_Default = JG_DeleteTempFile | JG_Pause | JG_Log
JG_All
@param plot
@param code
@param flags
@return
-
eas.simulation.spatial.standardBrains.mdle.plan.MDL2ePlan.execute()
-
easyJ.database.dao.command.DeleteCommand.execute()
-
easyJ.database.dao.command.InsertCommand.execute()
-
easyJ.database.dao.command.SelectCommand.execute()
-
easyJ.database.dao.command.UpdateCommand.execute()
-
ecar.sinalizacao.CalculoSinalizacao.execute()
-
edsdk.api.CanonCamera.execute()
-
edu.emory.mathcs.backport.java.util.concurrent.Executor.execute()
Executes the given command at some time in the future. The command may execute in a new thread, in a pooled thread, or in the calling thread, at the discretion of the Executor implementation.
@param command the runnable task
@throws RejectedExecutionException if this task cannot beaccepted for execution.
@throws NullPointerException if command is null
-
edu.emory.mathcs.backport.java.util.concurrent.ThreadPoolExecutor.execute()
Executes the given task sometime in the future. The task may execute in a new thread or in an existing pooled thread. If the task cannot be submitted for execution, either because this executor has been shutdown or because its capacity has been reached, the task is handled by the current RejectedExecutionHandler.
@param command the task to execute
@throws RejectedExecutionException at discretion ofRejectedExecutionHandler, if task cannot be accepted for execution
@throws NullPointerException if command is null
-
edu.indiana.extreme.xbaya.jython.gui.JythonRunnerWindow.execute()
-
edu.internet2.middleware.grouperClient.api.GcAddMember.execute()
-
edu.internet2.middleware.grouperClient.api.GcFindGroups.execute()
-
edu.internet2.middleware.grouperClient.api.GcGetGroups.execute()
-
edu.internet2.middleware.grouperClient.api.GcGetMembers.execute()
-
edu.internet2.middleware.grouperClient.api.GcHasMember.execute()
-
edu.isi.karma.cleaning.InterpreterType.execute()
-
edu.isi.karma.kr2rml.planning.TriplesMapPlanExecutor.execute()
-
edu.stanford.bmir.protege.web.client.rpc.RenderingServiceManager.execute()
-
edu.ucla.sspace.hadoop.WordCooccurrenceCountingJob.execute()
Exceutes the word co-occurrence counting job on the corpus files in the input directory using the current Hadoop instance, returning an iterator over all the occurrences frequences found in the corpus.
@param inputDirs a list of directories on the Hadoop distributed filesystem containing all the corpus files that will be processed
@return an iterator over the unique {@link WordCooccurrence} counts foundin the corpus. Note that if two words co-occur the same distance apart multiple times, only one {@code WordCooccurrence} isreturned, where the number of co-occurrences is reflected by the the {@link WordCooccurrence#getCount() getCount()} method.
@throws Exception if Hadoop throws an {@code Exception} during itsexecution or if the resulting output files cannot be read.
-
edu.ucla.sspace.ri.HadoopRandomIndexing.execute()
Computes the co-occurrences present in the documents in the input directory and writes the {@link SemanticSpace} to the provided writer.
@param inputDirs one or more a directories in the Hadoop file system thatcontain all the documents to process
@param writer a writer to which the output {@link SemanticSpace} will bewritten upon completion of the map-reduce analysis.
@throws Exception if any exception occurs during the Hadoop processing orwhen writing the {@link SemanticSpace}
-
edu.umd.cs.findbugs.DiscoverSourceDirectories.execute()
Execute the search for source directories.
@throws edu.umd.cs.findbugs.classfile.CheckedAnalysisException
@throws java.io.IOException
@throws java.lang.InterruptedException
-
edu.umd.cs.findbugs.IFindBugsEngine.execute()
Execute FindBugs on the Project. All bugs found are reported to the BugReporter object which was set when this object was constructed.
@throws java.io.IOException if an I/O exception occurs analyzing one of the files
@throws InterruptedException if the thread is interrupted while conducting the analysis
-
edu.umd.cs.findbugs.SelfCalls.execute()
Find the self calls.
-
edu.umd.cs.findbugs.ba.BlockTypeDataflow.execute()
-
edu.umd.cs.findbugs.ba.LiveLocalStoreDataflow.execute()
-
edu.umd.cs.findbugs.ba.LockChecker.execute()
Execute dataflow analyses (only if required).
@throws CheckedAnalysisException
-
edu.umd.cs.findbugs.ba.LockDataflow.execute()
-
edu.umd.cs.findbugs.ba.PruneInfeasibleExceptionEdges.execute()
Prune infeasible exception edges from the CFG. If the method returns normally, then the operation was successful, and the CFG should no longer contain infeasible exception edges. If ClassNotFoundException or DataflowAnalysisException are thrown, then the operation was unsuccessful, but the CFG is still valid because it was not modified. If a runtime exception is thrown, then the CFG may be partially modified and should be considered invalid.
-
edu.umd.cs.findbugs.ba.PruneUnconditionalExceptionThrowerEdges.execute()
-
edu.umd.cs.findbugs.ba.ReturnPathDataflow.execute()
-
edu.umd.cs.findbugs.ba.bcp.PatternMatcher.execute()
Search for examples of the ByteCodePattern.
@return this object
@throws DataflowAnalysisException if the ValueNumberAnalysis did not produce useful values for the method
-
edu.umd.cs.findbugs.ba.ca.CallListDataflow.execute()
-
edu.umd.cs.findbugs.ba.constant.ConstantDataflow.execute()
-
edu.umd.cs.findbugs.ba.deref.UnconditionalValueDerefDataflow.execute()
-
edu.umd.cs.findbugs.ba.heap.LoadDataflow.execute()
-
edu.umd.cs.findbugs.ba.heap.StoreDataflow.execute()
-
edu.umd.cs.findbugs.ba.npe.IsNullValueDataflow.execute()
-
edu.umd.cs.findbugs.ba.npe.NullDerefAndRedundantComparisonFinder.execute()
-
edu.umd.cs.findbugs.ba.npe.ReturnPathTypeDataflow.execute()
-
edu.umd.cs.findbugs.ba.obl.ObligationDataflow.execute()
-
edu.umd.cs.findbugs.ba.type.TypeDataflow.execute()
-
edu.umd.cs.findbugs.ba.vna.ValueNumberDataflow.execute()
-
es.upm.dit.ScrappyExecutor.execute()
-
eu.admire.example.Client.execute()
-
eu.irmosproject.ascd.transformation.MOFScriptExecutor.execute()
@param path
-
eu.planets_project.ifr.core.wee.api.workflow.WorkflowInstance.execute()
-
eu.planets_project.tb.impl.services.mockups.workflow.WorkflowDroidXCDLExtractorComparator.execute()
Returns an EvaluationExecutable containing the XCDLs, etc.
@param f1
@param f2
@return
@throws Exception
-
eu.scape_project.planning.services.taverna.executor.SSHTavernaExecutor.execute()
-
eu.stratosphere.api.java.ExecutionEnvironment.execute()
Triggers the program execution. The environment will execute all parts of the program that have resulted in a "sink" operation. Sink operations are for example printing results ( {@link DataSet#print()}, writing results (e.g. {@link DataSet#writeAsText(String)}, {@link DataSet#write(eu.stratosphere.api.common.io.FileOutputFormat,String)}, or other generic data sinks created with {@link DataSet#output(eu.stratosphere.api.common.io.OutputFormat)}.
The program execution will be logged and displayed with a generated default name.
@return The result of the job execution, containing elapsed time and accumulators.
@throws Exception Thrown, if the program executions fails.
-
evolaris.framework.smsservices.business.commands.MacroCommand.execute()
-
fitnesse.slim.instructions.Instruction.execute()
-
flagthis.pubsubhubbub.Publisher.execute()
-
fmpp.setting.Settings.execute()
-
fr.eolya.simplepipeline.connector.Connector.execute()
Run this Connector.
-
fr.pingtimeout.jtail.gui.controller.FileIndexerWorker.execute()
-
fr.soleil.comete.dao.tangodao.command.StringArrayCommandDAO.execute()
-
fr.soleil.tango.clientapi.TangoCommand.execute()
-
freenet.support.compress.DecompressorThreadManager.execute()
Creates and executes a new thread for each decompressor, chaining the output of the previous to the next.
@return An InputStream from which uncompressed data may be read from
-
games.stendhal.client.events.AttackEvent.execute()
-
gluebooster.maven.preprocessor.javasources.JavaSourcePreprocessor.execute()
-
gov.nasa.arc.mct.evaluator.enums.MultiEvaluator.MultiExpression.execute()
-
gov.nasa.arc.mct.policy.Policy.execute()
Implements the policy execution on a given PolicyContext
. The ExecutionResult
should include a boolean status indicating if a policy passed or failed on a PolicyContext
. A text message should be included if the policy failed, since this message will be used in the log and dialog windows triggered by a user action.
@param context the policy context
@return the result of the policy execution
-
gov.nasa.arc.mct.services.component.PolicyManager.execute()
Executes all policies in the specified category and returns the aggregate result. The result is true only if all policies return true results, and false otherwise.
@param categoryKey the name of the category to execute
@param context the policy context to use when executing the policies
@return true, if the aggregate result of executing the policy category is true
-
gov.nysenate.openleg.api.AbstractApiRequest.execute()
-
gpinterpreter.vector.VecInterpreter.execute()
-
grails.plugins.gwt.client.GwtActionServiceAsync.execute()
-
gri.ssh.Shell.execute()
-
gri.tasks.Task.execute()
-
gri.tasks.java.SimpleMethodTask.execute()
Executes the given method
-
gridool.Grid.execute()
-
groovyx.gaelyk.query.QueryBuilder.execute()
-
gui.commands.Command.execute()
-
healthwatcher.view.command.Command.execute()
-
heart.xtt.Rule.execute()
Method that fires the decision part of the rule. It does not evaluate the rule conditions. For that, refer to {@link #evaluate()}.
@param wm a working memory object that contains information about attributes values
@return true, if the rule was correctly executed, false if there are some errors
@throws UnsupportedOperationException
@throws NotInTheDomainException
-
helloworld.behavioral.command.Command.execute()
-
helloworld.behavioral.command.HelloWorldPrintCommand.execute()
-
helma.xmlrpc.XmlRpcClient.execute()
-
hirondelle.predict.main.logoff.LogoffAction.execute()
Perform all operations related to ending a session.
Expire the session cookie, end the session, and redirect to the log off page. A redirect is used to avoid problems with browser reloads. The response includes a header which instructs the browser to explicitly delete its JSESSIONID cookie.
-
hirondelle.web4j.action.Action.execute()
Execute desired operation.
Typical operations include :
- validate user input
- interact with the database
- place required objects in the appropriate scope
- set the appropriate {@link ResponsePage}.
Returns an identifier for the resource (for example a JSP) which will display the end result of this Action (using either a forward or a redirect).
-
hudson.cli.CLI.execute()
-
hudson.model.queue.MappingWorksheet.Mapping.execute()
-
in.partake.controller.ActionProxy.execute()
-
info.archinnov.achilles.query.cql.NativeQuery.execute()
Execute statement without returning result. Useful for INSERT/UPDATE/DELETE and DDL statements
-
info.bliki.extensions.scribunto.interfaces.MwCommon.execute()
-
info.magnolia.cms.core.search.Query.execute()
-
info.walnutstreet.vs.ps02.member.protocol.ChatCommand.execute()
-
io.airlift.http.client.jetty.JettyHttpClient.execute()
-
io.apigee.trireme.core.NodeScript.execute()
Run the script and return a Future denoting its status. The script is treated exactly as any other Node.js program -- that is, it runs in a separate thread, and the returned future may be used to track its status or completion.
When the script has run to completion -- which means that has left no timers or "nextTick" jobs in its queue, and the "http" and "net" modules are no longer listening for incoming network connections, then it will exit with a status code. Cancelling the future will make the script exit more quickly and throw CancellationException. It is also OK to interrupt the script.
-
io.crate.action.sql.TransportSQLAction.execute()
-
io.crate.executor.Executor.execute()
-
io.druid.server.coordinator.LoadPeonCallback.execute()
-
io.fabric8.process.fabric.support.ProcessManagerJmxTemplate.execute()
-
io.fabric8.process.manager.support.command.Command.execute()
-
io.fabric8.service.ContainerTemplate.execute()
-
io.fabric8.tooling.archetype.generator.ArchetypeHelper.execute()
Main method which extracts given Maven Archetype in destination directory
-
io.fathom.cloud.ssh.SshConfig.execute()
-
io.hawt.jsonschema.maven.plugin.JsonSchemaGeneratorMojo.execute()
-
io.netty.channel.EventLoop.execute()
-
io.netty.util.concurrent.EventExecutor.execute()
-
io.remotecontrol.server.Receiver.execute()
-
io.undertow.testutils.TestHttpClient.execute()
-
it.eng.spago.dbaccess.sql.SQLCommand.execute()
-
it.eng.spagobi.engines.InternalEngineIFace.execute()
Executes the document and populates the response.
@param requestContainer The RequestContainer
object (the session can be retrieved from this object)
@param obj The BIObject
representing the document to be executed
@param response The response SourceBean
to be populated
@throws EMFUserError the EMF user error
-
it.eng.spagobi.engines.kpi.SpagoBIKpiInternalEngine.execute()
-
it.eng.spagobi.tools.scheduler.utils.JavaClassDestination.execute()
-
it.geosolutions.unredd.stats.impl.RasterClassifiedStatistics.execute()
-
it.itc.irst.nusmv.cli.ExecuteNuSMV.execute()
Execute NuSMV with the given SMV input. Return a list of all output.
@param smv input for NuSMV
@return a list of output strings
@throws IOException
@throws NuSMVException if Crocopat wrote something to stderr
-
java.beans.Expression.execute()
{@inheritDoc}
If the invoked method completes normally, the value it returns is copied in the {@code value} property.Note that the {@code value} property is set to {@code null}, if the return type of the underlying method is {@code void}.
@throws NullPointerException if the value of the {@code target} or{@code methodName} property is {@code null}
@throws NoSuchMethodException if a matching method is not found
@throws SecurityException if a security manager exists andit denies the method invocation
@throws Exception that is thrown by the invoked method
@see java.lang.reflect.Method
@since 1.7
-
java.beans.Statement.execute()
The execute method finds a method whose name is the same as the methodName property, and invokes the method on the target. When the target's class defines many methods with the given name the implementation should choose the most specific method using the algorithm specified in the Java Language Specification (15.11). The dynamic class of the target and arguments are used in place of the compile-time type information and, like the
java.lang.reflect.Method
class itself, conversion between primitive values and their associated wrapper classes is handled internally.
The following method types are handled as special cases:
- Static methods may be called by using a class object as the target.
- The reserved method name "new" may be used to call a class's constructor as if all classes defined static "new" methods. Constructor invocations are typically considered
Expression
s rather than Statement
s as they return a value. - The method names "get" and "set" defined in the
java.util.List
interface may also be applied to array instances, mapping to the static methods of the same name in the Array
class.
-
java.sql.CallableStatement.execute()
-
java.sql.PreparedStatement.execute()
Executes the SQL statement in this PreparedStatement.
A PreparedStatement may return multiple results. The execute method returns a flag indicating the kind of result produced by PreparedStatement. The methods getResultSet
or getUpdateCount
are used to retrieve the first result, while getMoreResults
must be used to retrieve the second and subsequent results.
@return true if the result of the execution is a ResultSet, false ifthere is no result or if the result is an update count.
@throws SQLException if a database error happens
-
java.sql.Statement.execute()
Executes a supplied SQL statement. This may return multiple ResultSets.
Use the getResultSet
or getUpdateCount
methods to get the first result and getMoreResults
to get any subsequent results.
@param sql the SQL statement to execute
@return true if the first result is a ResultSet, false if the firstresult is an update count or if there is no result
@throws SQLException if an error occurs accessing the database
-
java.util.concurrent.Executor.execute()
Executes the given command at some time in the future. The command may execute in a new thread, in a pooled thread, or in the calling thread, at the discretion of the {@code Executor} implementation.
@param command the runnable task
@throws RejectedExecutionException if this task cannot beaccepted for execution
@throws NullPointerException if command is null
-
java.util.concurrent.ExecutorService.execute()
-
java.util.concurrent.ForkJoinPool.execute()
Arranges for (asynchronous) execution of the given task.
@param task the task
@throws NullPointerException if the task is null
@throws RejectedExecutionException if the task cannot bescheduled for execution
-
java.util.concurrent.ScheduledExecutorService.execute()
-
java.util.concurrent.ScheduledThreadPoolExecutor.execute()
Executes {@code command} with zero required delay.This has effect equivalent to {@link #schedule(Runnable,long,TimeUnit) schedule(command, 0, anyUnit)}. Note that inspections of the queue and of the list returned by {@code shutdownNow} will access the zero-delayed{@link ScheduledFuture}, not the {@code command} itself.
A consequence of the use of {@code ScheduledFuture} objects isthat {@link ThreadPoolExecutor#afterExecute afterExecute} is alwayscalled with a null second {@code Throwable} argument, even if the{@code command} terminated abruptly. Instead, the {@code Throwable}thrown by such a task can be obtained via {@link Future#get}.
@throws RejectedExecutionException at discretion of{@code RejectedExecutionHandler}, if the task cannot be accepted for execution because the executor has been shut down
@throws NullPointerException {@inheritDoc}
-
java.util.concurrent.ThreadPoolExecutor.execute()
Executes the given task sometime in the future. The task may execute in a new thread or in an existing pooled thread. If the task cannot be submitted for execution, either because this executor has been shutdown or because its capacity has been reached, the task is handled by the current RejectedExecutionHandler.
@param command the task to execute
@throws RejectedExecutionException at discretion ofRejectedExecutionHandler, if task cannot be accepted for execution
@throws NullPointerException if command is null
-
javarepl.client.JavaREPLClient.execute()
-
javarepl.console.rest.RestConsole.execute()
-
javax.faces.lifecycle.Lifecycle.execute()
-
javax.jcr.SimpleCredentials.execute()
-
javax.jcr.query.Query.execute()
-
javax.jcr.query.qom.QueryObjectModel.execute()
-
javax.jdo.Query.execute()
Execute the query and return the filtered Collection.
@return the filtered Collection
.
@see #executeWithArray(Object[] parameters)
-
javax.persistence.StoredProcedureQuery.execute()
Return true if the first result corresponds to a result set, and false if it is an update count or if there are no results other than through INOUT and OUT parameters, if any.
@return true if first result corresponds to result set
@throws QueryTimeoutException if the query execution exceedsthe query timeout value set and only the statement is rolled back
@throws PersistenceException if the query execution exceedsthe query timeout value set and the transaction is rolled back
-
javax.resource.cci.Interaction.execute()
-
javax.sql.rowset.CachedRowSet.execute()
Populates this
CachedRowSet
object with data, using the given connection to produce the result set from which the data will be read. This method should close any database connections that it creates to ensure that this
CachedRowSet
object is disconnected except when it is reading data from its data source or writing data to its data source.
The reader for this CachedRowSet
object will use conn to establish a connection to the data source so that it can execute the rowset's command and read data from the the resulting ResultSet
object into this CachedRowSet
object. This method also closes conn after it has populated this CachedRowSet
object.
If this method is called when an implementation has already been populated, the contents and the metadata are (re)set. Also, if this method is called before the method acceptChanges
has been called to commit outstanding updates, those updates are lost.
@param conn a standard JDBC Connection
object with validproperties
@throws SQLException if an invalid Connection
object is suppliedor an error occurs in establishing the connection to the data source
@see #populate
@see java.sql.Connection
-
javax.sql.rowset.FilteredRowSet.execute()
-
javax.sql.rowset.JdbcRowSet.execute()
-
javax.sql.rowset.spi.SyncResolver.execute()
-
javax.swing.SwingWorker.execute()
Schedules this {@code SwingWorker} for execution on a
workerthread. There are a number of
worker threads available. In the event all
worker threads are busy handling other {@code SwingWorkers} this {@code SwingWorker} is placed in a waitingqueue.
Note: {@code SwingWorker} is only designed to be executed once. Executing a{@code SwingWorker} more than once will not result in invoking the{@code doInBackground} method twice.
-
javolution.context.ConcurrentContext.execute()
Executes the specified logic by a concurrent thread if one available; otherwise the logic is executed by the current thread. Any exception or error occurring during concurrent executions is propagated to the current thread upon {@link #exit} of the concurrent context.
@param logic the logic to execute concurrently if possible.
@throws ClassCastException if the current context is not a{@link ConcurrentContext}.
-
jetbrains.communicator.commands.SendCodePointerCommand.execute()
-
jetbrains.communicator.commands.SendMessageCommand.execute()
-
jetbrains.communicator.commands.ShowDiffCommand.execute()
-
jetbrains.communicator.core.commands.UserCommand.execute()
-
jnode.robot.IRobot.execute()
-
jodd.db.DbQuery.execute()
-
joshua.corpus.suffix_array.Compile.execute()
-
joshua.prefix_tree.ExtractRules.execute()
-
jp.ac.kobe_u.cs.prolog.lang.PrologControl.execute()
Returns true
if the system succeeds to find a first solution of the given goal, false
otherwise.
This method is useful to find only one solution.
This method first initilizes the Prolog engine by invoking engine.init()
, allocates a new Thread
object, and start the execution of the given goal. And then it stops the thread and returns true
if the goal succeeds, false
otherwise.
@see #run
-
jp.vmi.selenium.selenese.Runner.execute()
Execute test-suite / test-case.
@param selenese test-suite or test-case.
@return result.
-
jp.vmi.selenium.selenese.TestCase.execute()
-
jsr166y.ForkJoinPool.execute()
Arranges for (asynchronous) execution of the given task.
@param task the task
@throws NullPointerException if the task is null
@throws RejectedExecutionException if the task cannot bescheduled for execution
-
jug.client.command.api.AbstractCommand.execute()
-
junit.framework.TestSuite.execute()
-
kafka.deploy.utils.RemoteOperation.execute()
Executes the specific remote operation which can span multiple remote hosts.
@throws RemoteOperationException Thrown if an error occurred performingthe remote operation
-
kafka.deploy.utils.RsyncDeployer.execute()
-
kafka.deploy.utils.SshBrokerStarter.execute()
-
kafka.deploy.utils.SshBrokerStopper.execute()
-
kafka.deploy.utils.SshRunner.execute()
-
kafka.deploy.utils.SshZkStarter.execute()
-
kafka.deploy.utils.SshZkStopper.execute()
-
l2p.common.ParallelExecutor.execute()
-
l2p.database.FiltredPreparedStatement.execute()
-
liquibase.changelog.ChangeSet.execute()
-
liquibase.command.DiffCommand.execute()
-
liquibase.command.DiffToChangeLogCommand.execute()
-
liquibase.command.ExecuteSqlCommand.execute()
-
liquibase.command.GenerateChangeLogCommand.execute()
-
liquibase.command.LiquibaseCommand.execute()
-
liquibase.command.SnapshotCommand.execute()
-
liquibase.executor.Executor.execute()
Write methods
-
lombok.val.execute()
-
lpa.command.CompoundCommand.execute()
-
lupos.event.action.Action.execute()
-
lv.odylab.evemanage.client.rpc.action.ActionRunner.execute()
-
marauroa.server.db.DBTransaction.execute()
executes an SQL statement with parameter substitution
@param query SQL statement
@param params parameter values
@return number of affected rows
@throws SQLException in case of an database error
-
match.api.Event.execute()
-
mate00.parafia.net.MinistrantWorker.execute()
-
me.prettyprint.hector.api.mutation.Mutator.execute()
Batch executes all mutations scheduled to this Mutator instance by addInsertion, addDeletion etc. May throw a HectorException which is a RuntimeException.
@return A MutationResult holds the status.
-
me.prettyprint.hector.api.query.RangeSlicesQuery.execute()
-
me.prettyprint.hector.api.query.SuperSliceQuery.execute()
-
mitza.dynamic.compile.Executable.execute()
-
mod.AccountDB.GUI.Templates.AccountTemplateHandler.execute()
-
mod.tsql.TsqlInterpreter.execute()
Public interface to execute commands from Java. See the class documentation. Oops, we do not get SQLExceptions here, but we should.
-
modTransf.engine.Rule.execute()
Try to execute the rule on the specified argument. First, compute the local variable. Then, check the guard. If the guard return false, stop the execution. If the guard return true, execute the other rule actions. Return the guard result.
@param args
@param context
@return boolean
-
mojo.IndexBuilderMojo.execute()
-
mondrian.olap.Connection.execute()
Executes a query.
@throws RuntimeException if another thread calls {@link Query#cancel()}.
-
mondrian.rolap.RolapConnection.execute()
Executes a Query.
@throws ResourceLimitExceededException if some resource limit specified in theproperty file was exceeded
@throws QueryCanceledException if query was canceled during execution
@throws QueryTimeoutException if query exceeded timeout specified inthe property file
-
mondrian.rolap.agg.SegmentCacheManager.execute()
-
net.datacrow.core.wf.requests.IRequest.execute()
Executes this request.
@param items The items retrieved by the query (if any).
-
net.didion.jwnl.dictionary.database.Query.execute()
-
net.ftb.download.workers.AssetDownloader.execute()
-
net.ftb.updater.UpdateChecker.execute()
-
net.ftb.workers.AuthlibDLWorker.execute()
-
net.ftb.workers.LoginWorker.execute()
-
net.ftb.workers.MapManagerWorker.execute()
-
net.ftb.workers.UnreadNewsWorker.execute()
-
net.hasor.db.jdbc.core.JdbcTemplate.execute()
-
net.hydromatic.avatica.AvaticaStatement.execute()
-
net.hydromatic.optiq.tools.SqlRun.execute()
-
net.laubenberger.bogatyr.view.swing.worker.Worker.execute()
-
net.lightstone.cmd.CommandManager.execute()
Executes a command.
@param player The player that is trying to execute the command.
@param text The unparsed command string.
-
net.mindengine.galen.GalenMain.execute()
-
net.mindengine.galen.runner.JsTestCollector.execute()
-
net.mindengine.galen.suite.GalenPageAction.execute()
-
net.mindengine.galen.suite.actions.GalenPageActionCheck.execute()
-
net.mindengine.galen.suite.actions.GalenPageActionCookie.execute()
-
net.mindengine.galen.suite.actions.GalenPageActionDumpPage.execute()
-
net.mindengine.galen.suite.actions.GalenPageActionInjectJavascript.execute()
-
net.mindengine.galen.suite.actions.GalenPageActionProperties.execute()
-
net.mindengine.galen.suite.actions.GalenPageActionRunJavascript.execute()
-
net.mindengine.galen.suite.actions.GalenPageActionWait.execute()
-
net.opengis.wps10.ProcessBriefType.execute()
-
net.paoding.rose.jade.statement.Statement.execute()
按照给定的方法参数值,执行一次数据库检索或更新
您可以通过parameters.get(":1")、parameters.get(":2")获得方法中的第1、第2个参数(从1开始)
如果DAO方法中的参数设置了@SQLParam(name)
注解,您还可以从parameters.get(name)取得该参数。
@return
-
net.paoding.rose.jade.statement.expression.ExqlPattern.execute()
输出全部的语句内容。
@param context - 输出上下文
@param map - 参数表
@return 语句内容
@throws Exception
-
net.raymanoz.command.Command.execute()
-
net.raymanoz.migrate.Script.execute()
-
net.riccardocossu.autodoc.main.Engine.execute()
-
net.rim.device.api.command.Command.execute()
-
net.rim.device.api.database.Statement.execute()
-
net.sf.antcontrib.antserver.Command.execute()
Execute the command.
@param project The project which is being executed
@return If true, the connection will be closed
@throws Throwable
-
net.sf.antcontrib.cpptasks.CCTask.execute()
Executes the task. Compiles the given files.
@throws BuildException if someting goes wrong with the build
-
net.sf.antcontrib.cpptasks.ide.ProjectDef.execute()
Executes the task. Compiles the given files.
@param task cc task
@param sources source files (includes headers)
@param targets compilation targets
@param linkTarget link target
-
net.sf.archimede.security.SystemTransactionTemplate.execute()
-
net.sf.ehcache.search.expression.Criteria.execute()
Test this criteria against a cache element
@param element cache element
@param attributeExtractors map of attribute extractors to attribute value names
@return true if the criteria matches this element
-
net.sf.fec.core.ExternalExecutor.execute()
-
net.sf.graphiti.ui.commands.copyPaste.CopyCommand.execute()
-
net.sf.jmatchparser.template.engine.operation.Operation.execute()
-
net.sf.katta.operation.master.MasterOperation.execute()
@param context
@param runningOperations currently running {@link MasterOperation}s
@return null or a list of operationId which have to be completed before{@link #nodeOperationsComplete(MasterContext)} method is called.
@throws Exception
-
net.sf.katta.operation.node.NodeOperation.execute()
@param context
@return null or an {@link OperationResult}
@throws InterruptedException
-
net.sf.katta.operation.node.ShardRedeployOperation.execute()
-
net.sf.microlog.core.format.command.FormatCommandInterface.execute()
Set the necessary log data to convert.
@param clientID the client id.
@param name the name of the logger.
@param time the time since the first logging has done (in milliseconds).
@param level the log level.
@param message the log message.
@param throwable the logged Throwable
object.
@return a converted String
.
-
net.sf.mvc.mobile.command.ActionCommand.execute()
@return identifier of the next Displayable to show or null if no viewchange is required
-
net.sf.myjaut.cmd.HttpCommand.execute()
-
net.sf.parteg.base.testcasetree.actions.TestCaseGraphAddNodeAction.execute()
-
net.sf.pummel.loader.Loader.execute()
-
net.sf.rej.gui.Undoable.execute()
Execute the command/action that fulfills the Undoable contract.
-
net.sf.rej.gui.action.GroupAction.execute()
-
net.sf.rej.gui.action.ModifyClassInfoAction.execute()
-
net.sf.rej.gui.action.ModifyDescriptor.execute()
-
net.sf.rej.gui.action.ModifyNameAndTypeInfoAction.execute()
-
net.sf.rej.gui.action.RemoveAttributeAction.execute()
-
net.sf.rej.gui.action.RenameFieldAction.execute()
-
net.sf.rej.gui.action.RenameMethodAction.execute()
-
net.sf.sahi.rhino.ScriptRunner.execute()
-
net.sf.sahi.test.TestRunner.execute()
-
net.sf.wsdl2jibx.compiler.Compiler.execute()
@throws Exception
-
net.sf.xbus.technical.ObjectSender.execute()
The given object will be send to the neighbor system. The response of the neighbor system is the return value of this method.
Optionally a function can be specified. It can be used for calling different methods of the neighbor-system.
@param function used by some senders
@param callData the data that shall be send to the neighbor system
@return the response of the neighbor system
@throws XException if something goes wrong
-
net.sf.xbus.technical.TextSender.execute()
The given string will be send to the neighbor system. The response of the neighbor system is the return value of this method.
Optionally a function can be specified. It can be used for calling different methods of the neighbor-system.
@param function used by some senders
@param callData the data that shall be send to the neighbor system
@return the response of the neighbor system
@throws XException if something goes wrong
-
net.sourceforge.clownfish.mojo.glassfish.DeployMojo.execute()
Execute plugin.
@throws org.apache.maven.plugin.MojoExecutionException
-
net.sourceforge.clownfish.mojo.glassfish.ListMojo.execute()
Execute mojo.
@throws org.apache.maven.plugin.MojoExecutionException
-
net.sourceforge.clownfish.mojo.glassfish.RedeployMojo.execute()
Execute mojo.
@throws org.apache.maven.plugin.MojoExecutionException
-
net.sourceforge.clownfish.mojo.glassfish.StartMojo.execute()
Execute mojo.
@throws org.apache.maven.plugin.MojoExecutionException
-
net.sourceforge.clownfish.mojo.glassfish.StopMojo.execute()
Execute mojo.
@throws org.apache.maven.plugin.MojoExecutionException
-
net.sourceforge.cobertura.ant.InstrumentTask.execute()
-
net.sourceforge.cruisecontrol.util.Commandline.execute()
Executes the command.
-
net.sourceforge.cruisecontrol.util.ManagedCommandline.execute()
Executes the command.
-
net.sourceforge.javautil.ui.command.UICommand.execute()
Execute the implementation of this command, the command specific logic
@param ctx The command context
@param arguments The arguments for the command, or null if no arguments were provided
-
net.sourceforge.jivalo.plugin.maven.archetype.spi.CoreFinalizer.execute()
@see net.sourceforge.jivalo.plugin.maven.archetype.spi.Finalizer#execute(java.util.Properties)
-
net.sourceforge.jivalo.plugin.maven.archetype.spi.Finalizer.execute()
-
net.sourceforge.processdash.util.DrainableExecutor.execute()
-
net.sourceforge.squirrel_sql.client.mainframe.action.ConnectToAliasCommand.execute()
Display connection internal frame.
-
net.sourceforge.squirrel_sql.client.mainframe.action.OpenConnectionCommand.execute()
Display connection internal frame.
-
net.sourceforge.squirrel_sql.client.session.action.DumpSessionCommand.execute()
Dump the session.
-
net.sourceforge.squirrel_sql.fw.util.ICommand.execute()
-
net.sourceforge.squirrel_sql.plugins.dataimport.ImportDataIntoTableExecutor.execute()
Starts the thread that executes the insert operation.
-
net.sourceforge.squirrel_sql.plugins.dbdiff.ColumnDifference.execute()
Returns a boolean indicating whether or not the two columns are different in any aspect.
@return
-
net.sourceforge.squirrel_sql.plugins.sqlval.cmd.ConnectCommand.execute()
Connect to the web service.
-
net.sourceforge.squirrel_sql.plugins.sqlval.cmd.ValidateSQLCommand.execute()
-
net.sourceforge.stripes.action.Resolution.execute()
Called by the Stripes dispatcher to invoke the Resolution. Should use the request and response provided to direct the user to an appropriate view.
@param request the current HttpServletRequest
@param response the current HttpServletResponse
@throws Exception exceptions of any type may be thrown if the Resolution cannot beexecuted as intended
-
net.sourceforge.stripes.mock.MockRoundtrip.execute()
Executes the request in the servlet context that was provided in the constructor. If the request throws an Exception then that will be thrown from this method. Otherwise, once the execution has completed you can use the other methods on this class to examine the outcome.
-
net.sourceforge.urlrewriter4j.core.actions.IRewriteAction.execute()
Executes the action. Note that it is important to set the correct properties on the context (e.g., StatusCode, Location), rather than directly implementing the action (e.g., RewritePath). This allows for the correct pipeline processing of all the specified rules.
@param pContext The context to execute the action on.
@return how the rewriter should continue processing after this action has executed.
-
net.sphene.goim.rcp.extensionpoints.GameExtensionPoint.GameExtensionProxy.execute()
-
net.sprd.sampleapps.common.http.HttpCallCommand.execute()
-
net.sprd.tutorials.common.http.HttpCallCommand.execute()
-
net.wimpi.modbus.io.ModbusSerialTransaction.execute()
-
net.wimpi.modbus.io.ModbusTCPTransaction.execute()
-
net.wimpi.modbus.io.ModbusTransaction.execute()
Executes this
ModbusTransaction. Locks the
ModbusTransport for sending the
ModbusRequest and reading the related
ModbusResponse. If reconnecting is activated the connection will be opened for the transaction and closed afterwards.
@throws ModbusException if an I/O error occurs,or the response is a modbus protocol exception.
-
net.wimpi.modbus.io.ModbusUDPTransaction.execute()
-
net.wimpi.modbusme.io.ModbusSerialTransaction.execute()
-
net.wimpi.modbusme.io.ModbusTCPTransaction.execute()
-
net.wimpi.modbusme.io.ModbusTransaction.execute()
Executes this
ModbusTransaction. Locks the
ModbusTransport for sending the
ModbusRequest and reading the related
ModbusResponse. If reconnecting is activated the connection will be opened for the transaction and closed afterwards.
@throws ModbusException if an I/O error occurs,or the response is a modbus protocol exception.
-
net.wimpi.modbusme.io.ModbusUDPTransaction.execute()
-
nl.nuggit.swaf.interaction.Interaction.execute()
-
npanday.executable.NetExecutable.execute()
Compiles class files.
@throws npanday.executable.ExecutionException if the compiler writes to the standard error stream. artifact (module, library, exe, winexe) or the target artifact is not valid for the compiler
-
npanday.executable.compiler.CompilerExecutable.execute()
-
nux.xom.xquery.XQuery.execute()
3.org/TR/xpath#dt-document-order">document order, unless specified otherwise by the query.
@param contextNode the context node to execute the query against. The context node is available to the query as the value of the query expression ".". If this parameter is null
, the context node will be undefined.
@return a result sequence iterator producing zero or more results
@throws XQueryException if an error occurs during execution, for example division overflow, or a type error caused by type mismatch, or an error raised by the XQuery function fn:error().
-
open.dolphin.helper.DBTask.execute()
-
open.dolphin.helper.Task.execute()
-
opendap.dap.http.HTTPMethod.execute()
-
oracle.AWAction.BuildDatabase.Execute()
-
oracle.binding.OperationBinding.execute()
-
oracle.jdbc.OracleCallableStatement.execute()
-
oracle.jdbc.driver.OracleCallableStatement.execute()
-
org.aavso.tools.vstar.ui.task.ModellingTask.execute()
-
org.aavso.tools.vstar.ui.task.NewStarFromDatabaseTask.execute()
-
org.aavso.tools.vstar.ui.task.NewStarFromFileTask.execute()
-
org.aavso.tools.vstar.ui.task.NewStarFromObSourcePluginTask.execute()
-
org.aavso.tools.vstar.ui.task.NewStarFromObSourcePluginWithSuppliedFileTask.execute()
-
org.aavso.tools.vstar.ui.task.NewStarFromObSourcePluginWithSuppliedURLTask.execute()
-
org.aavso.tools.vstar.ui.task.ObsListFileSaveTask.execute()
-
org.aavso.tools.vstar.ui.task.PeriodAnalysisTask.execute()
-
org.aavso.tools.vstar.ui.task.PhasePlotTask.execute()
-
org.aavso.tools.vstar.ui.task.PluginManagerOperationTask.execute()
-
org.aavso.tools.vstar.util.ApacheCommonsExtremaFinder.execute()
-
org.aavso.tools.vstar.util.IExtremaFinder.execute()
-
org.aavso.tools.vstar.util.model.TSPolynomialFitter.execute()
@see org.aavso.tools.vstar.util.IAlgorithm#execute()
-
org.activemq.service.TransactionTask.execute()
-
org.activiti.bpmn.BpmnAutoLayout.execute()
-
org.activiti.crystalball.simulator.SimulationRun.execute()
executes simulation run according to configuration already set
@param execution execution is variable scope used to transfer input/output variable from and to simulation run.
@throws Exception
-
org.activiti.engine.delegate.JavaDelegate.execute()
-
org.activiti.engine.impl.bpmn.parser.BpmnParse.execute()
-
org.activiti.engine.impl.cmd.ActivateProcessDefinitionCmd.execute()
-
org.activiti.engine.impl.cmd.GetBpmnModelCmd.execute()
-
org.activiti.engine.impl.cmd.GetDeploymentProcessDefinitionCmd.execute()
-
org.activiti.engine.impl.cmd.SuspendProcessDefinitionCmd.execute()
-
org.activiti.engine.impl.db.upgrade.DbUpgradeStep.execute()
-
org.activiti.engine.impl.interceptor.CommandExecutor.execute()
Execute a command with the specified {@link CommandConfig}.
-
org.activiti.engine.impl.interceptor.RetryInterceptor.execute()
-
org.activiti.engine.impl.jobexecutor.JobHandler.execute()
-
org.activiti.engine.impl.persistence.entity.JobEntity.execute()
-
org.activiti.engine.impl.pvm.delegate.ActivityBehavior.execute()
-
org.activiti.engine.impl.pvm.runtime.AtomicOperation.execute()
-
org.activiti.upgrade.CleanPostgres.execute()
-
org.adoptopenjdk.jitwatch.sandbox.runtime.RuntimeJava.execute()
-
org.andromda.maven.plugin.AndroMDAMojo.execute()
@see org.andromda.maven.plugin.AbstractAndroMDAMojo#execute(org.andromda.core.configuration.Configuration)
-
org.any_openeai_enterprise.gateways.brg.RequestLogicExecutor.execute()
-
org.apache.accumulo.examples.wikisearch.parser.QueryParser.execute()
-
org.apache.accumulo.examples.wikisearch.parser.RangeCalculator.execute()
@param c
@param auths
@param indexedTerms
@param terms
@param query
@param logic
@param typeFilter
@throws ParseException
-
org.apache.activemq.console.command.Command.execute()
Execute the specified command
@param tokens - arguments to the command
@throws Exception
-
org.apache.activemq.console.command.ShutdownCommand.execute()
-
org.apache.activemq.console.command.StartCommand.execute()
-
org.apache.activemq.console.command.store.StoreExporter.execute()
-
org.apache.activemq.console.command.store.amq.AMQJournalTool.execute()
-
org.apache.activemq.thread.TaskRunnerFactory.execute()
-
org.apache.airavata.core.gfac.provider.Provider.execute()
Execution step
@param invocationContext
@return result of execution in Map as key and value pair
@throws ProviderException
-
org.apache.airavata.core.gfac.services.GenericService.execute()
-
org.apache.airavata.core.gfac.services.impl.PropertiesBasedServiceImpl.execute()
-
org.apache.airavata.gfac.local.provider.impl.LocalProvider.execute()
-
org.apache.ambari.server.api.query.Query.execute()
Execute the query.
@return the result of the query.
@throws UnsupportedPropertyException if the query or query predicate contains invalid non-existent properties
@throws SystemException an internal error occurred
@throws NoSuchResourceException the query didn't match any resources
@throws NoSuchParentResourceException a specified parent resource doesn't exist
-
org.apache.ant.compress.taskdefs.Unzip.execute()
-
org.apache.ant.dotnet.DotNetExecTask.execute()
Do the work.
@throws BuildException if executable is empty or <exec>throws an exception.
-
org.apache.archiva.indexer.merger.MergedRemoteIndexesTask.execute()
-
org.apache.avalon.excalibur.thread.impl.DefaultThreadPool.execute()
Run work in separate thread. Return a valid ThreadControl to control work thread.
@param work the work to be executed.
@return the ThreadControl
-
org.apache.avalon.excalibur.thread.impl.ResourceLimitingThreadPool.execute()
Run work in separate thread. Return a valid ThreadControl to control work thread.
@param work the work to be executed.
@return the ThreadControl
-
org.apache.axis.components.bridge.COMBridge.execute()
-
org.apache.axis2.client.OperationClient.execute()
Execute the MEP. This method is final and only serves to set (if appropriate) the lastOperationContext on the ServiceContext, and then it calls executeImpl(), which does the actual work.
@param block Indicates whether execution should block or return ASAP. Whatblock means is of course a function of the specific operation client.
@throws AxisFault if something goes wrong during the execution of the operationclient.
-
org.apache.axis2.clustering.ClusteringMessage.execute()
-
org.apache.axis2.clustering.context.ContextClusteringCommand.execute()
-
org.apache.axis2.clustering.control.AckCommand.execute()
-
org.apache.axis2.clustering.control.GetConfigurationCommand.execute()
-
org.apache.axis2.clustering.control.GetStateCommand.execute()
-
org.apache.axis2.clustering.control.wka.MemberListCommand.execute()
-
org.apache.axis2.clustering.management.GroupManagementCommand.execute()
-
org.apache.axis2.clustering.state.StateClusteringCommand.execute()
-
org.apache.axis2.util.threadpool.ThreadFactory.execute()
-
org.apache.batik.apps.rasterizer.Main.execute()
-
org.apache.bcel.verifier.structurals.InstructionContext.execute()
This method symbolically executes the Instruction held in the InstructionContext. It "merges in" the incoming execution frame situation (see The Java Virtual Machine Specification, 2nd edition, page 146). By so doing, the outgoing execution frame situation is calculated. This method is JustIce-specific and is usually of no sense for users of the ControlFlowGraph class. They should use getInstruction().accept(Visitor), possibly in conjunction with the ExecutionVisitor.
@see ControlFlowGraph
@see ExecutionVisitor
@see #getOutFrame(ArrayList)
@return true - if and only if the "outgoing" frame situationchanged from the one before execute()ing.
-
org.apache.beehive.netui.core.chain.Command.execute()
-
org.apache.cactus.maven2.mojos.CactifyEarMojo.execute()
The "main" method of the mojo.
@throws MojoExecutionException in case an error occurs.
@throws MojoFailureException in case a failure occurs.
-
org.apache.cactus.maven2.mojos.CactifyWarMojo.execute()
The "main" method of the mojo.
@throws MojoExecutionException in case an error occurs.
@throws MojoFailureException in case a failure occurs.
-
org.apache.cassandra.concurrent.IStage.execute()
This method is used to execute a piece of code on this stage. The idea is that the run() method of this Runnable instance is invoked on a thread from a thread pool that belongs to this stage.
@param runnable instance whose run() method needs to be invoked.
-
org.apache.cassandra.concurrent.JMXEnabledThreadPoolExecutor.execute()
-
org.apache.cassandra.concurrent.TracingAwareExecutorService.execute()
-
org.apache.cassandra.cql.common.Plan.execute()
-
org.apache.cassandra.cql3.operations.Operation.execute()
-
org.apache.cassandra.db.compaction.AbstractCompactionTask.execute()
-
org.apache.cassandra.db.compaction.CompactionTask.execute()
For internal use and testing only. The rest of the system should go through the submit* methods, which are properly serialized. Caller is in charge of marking/unmarking the sstables as compacting.
-
org.apache.cassandra.stress.util.JavaDriverClient.execute()
-
org.apache.cassandra.transport.SimpleClient.execute()
-
org.apache.catalina.ant.DeployTask.execute()
Execute the requested operation.
@exception BuildException if an error occurs
-
org.apache.catalina.ant.UndeployTask.execute()
Execute the requested operation.
@exception BuildException if an error occurs
-
org.apache.catalina.cluster.io.ObjectReader.execute()
Send buffer to cluster listener (callback) Is message complete receiver send message to callback
@see org.apache.catalina.cluster.tcp.SimpleTcpCluster#messageDataReceived(byte[])
@see XByteBuffer#doesPackageExist()
@see XByteBuffer#extractPackage()
@return number of received packages/messages
@throws java.io.IOException
-
org.apache.catalina.startup.TldConfig.execute()
Scan for and configure all tag library descriptors found in this web application.
@exception Exception if a fatal input/output or parsing error occurs
-
org.apache.catalina.tribes.io.ObjectReader.execute()
Send buffer to cluster listener (callback). Is message complete receiver send message to callback?
@see org.apache.catalina.tribes.tcp.ClusterReceiverBase#messageDataReceived(ChannelMessage)
@see XByteBuffer#doesPackageExist()
@see XByteBuffer#extractPackage(boolean)
@return number of received packages/messages
@throws java.io.IOException
-
org.apache.cayenne.access.DataPort.execute()
Runs DataPort. The instance must be fully configured by the time this method is invoked, having its delegate, source and destinatio nodes, and a list of entities set up.
-
org.apache.cayenne.gen.ClassGenerationAction.execute()
Executes class generation once per each artifact.
-
org.apache.cayenne.gen.DefaultClassGenerator.execute()
Runs class generation.
-
org.apache.cayenne.modeler.dialog.db.DbLoaderHelper.execute()
Performs reverse engineering of the DB using internal DbLoader. This method should be invoked outside EventDispatchThread, or it will throw an exception.
-
org.apache.cayenne.project.ProjectConfigurator.execute()
Performs reconfiguration of the project.
@throws ProjectException
-
org.apache.clerezza.rdf.core.sparql.QueryEngine.execute()
-
org.apache.cloudstack.api.BaseCmd.execute()
-
org.apache.cloudstack.api.command.user.vm.AddIpToVmNicCmd.execute()
-
org.apache.cloudstack.api.command.user.vm.RemoveIpFromVmNicCmd.execute()
-
org.apache.cocoon.components.cron.ConfigurableCronJob.execute()
-
org.apache.cocoon.components.thread.RunnableManager.execute()
Immediate Execution of a runnable in the background
@param command The command to execute
-
org.apache.cocoon.mail.command.MailCommands.execute()
Execute the list of commands
Gather all results of all commands.
@exception MessagingException Description of the Exception
-
org.apache.cocoon.pipeline.NonCachingPipeline.execute()
-
org.apache.cocoon.pipeline.Pipeline.execute()
After the pipeline has been setup ( {@link #setup(OutputStream,Map)}, this method can be invoked in order to produce the result.
@throws Exception Any problem that might occur while processing thepipeline.
-
org.apache.cocoon.pipeline.component.Starter.execute()
-
org.apache.cocoon.rest.controller.response.RestResponse.execute()
-
org.apache.cocoon.template.instruction.Call.execute()
-
org.apache.cocoon.template.script.event.Event.execute()
-
org.apache.cocoon.thread.RunnableManager.execute()
Immediate Execution of a runnable in the background
@param command The command to execute
-
org.apache.cocoon.util.RequestForwardingHttpMethod.execute()
-
org.apache.commons.attributes.compiler.AttributeCompiler.execute()
-
org.apache.commons.chain.Command.execute()
Execute a unit of processing work to be performed. This {@link Command} may either complete the required processingand return true
, or delegate remaining processing to the next {@link Command} in a {@link Chain} containing this{@link Command} by returning false
@param context The {@link Context} to be processed by this{@link Command}
@exception Exception general purpose exception returnto indicate abnormal termination
@exception IllegalArgumentException if context
is null
@return true
if the processing of this {@link Context}has been completed, or false
if the processing of this {@link Context} should be delegated to a subsequent{@link Command} in an enclosing {@link Chain}
-
org.apache.commons.collections.Closure.execute()
Performs some operation on the input object
-
org.apache.commons.exec.DefaultExecutor.execute()
@see org.apache.commons.exec.Executor#execute(CommandLine)
-
org.apache.commons.exec.Executor.execute()
Methods for starting synchronous execution. The child process inherits all environment variables of the parent process.
@param command the command to execute
@return process exit value
@throws ExecuteException execution of subprocess failed
-
org.apache.commons.httpclient.HttpMethod.execute()
Executes this method using the specified HttpConnection
and HttpState
.
@param state the {@link HttpState state} information to associate with this method
@param connection the {@link HttpConnection connection} used to executethis HTTP method
@throws IOException If an I/O (transport) error occurs. Some transport exceptionscan be recovered from.
@throws HttpException If a protocol exception occurs. Usually protocol exceptions cannot be recovered from.
@return the integer status code if one was obtained, or -1
-
org.apache.commons.httpclient.methods.DeleteMethod.execute()
-
org.apache.commons.httpclient.methods.GetMethod.execute()
-
org.apache.commons.httpclient.methods.HeadMethod.execute()
-
org.apache.commons.httpclient.methods.PostMethod.execute()
-
org.apache.commons.httpclient.methods.PutMethod.execute()
-
org.apache.commons.jelly.impl.Embedded.execute()
Execute the jelly script and capture the errors (ifany)within.
@throws JellyException
-
org.apache.commons.jexl.Script.execute()
Executes the script with the variables contained in the supplied {@link JexlContext}.
@param context A JexlContext containing variables.
@return The result of this script, usually the result of the last statement.
@throws Exception on any script parse or execution error.
-
org.apache.commons.jexl2.Script.execute()
Executes the script with the variables contained in the supplied {@link JexlContext}.
@param context A JexlContext containing variables.
@return The result of this script, usually the result of the last statement.
-
org.apache.commons.scaffold.util.ProcessBean.execute()
-
org.apache.commons.scxml2.model.Script.execute()
{@inheritDoc}
-
org.apache.crunch.impl.mr.exec.MRExecutor.execute()
-
org.apache.ctakes.jdl.AppJdl.execute()
Execute the loader of the data into the database.
-
org.apache.cxf.message.ExchangeImpl.execute()
-
org.apache.cxf.tools.wsdlto.frontend.jaxws.JAXWSContainer.execute()
-
org.apache.cxf.workqueue.AutomaticWorkQueue.execute()
-
org.apache.cxf.workqueue.WorkQueue.execute()
Submits a work item for execution at some time in the future, waiting for up to a specified amount of time for the item to be accepted.
@param work the workitem to submit for execution.
@param timeout the maximum amount of time (in milliseconds) to wait for it to be accepted.
@throws RejectedExecutionException
if this work item cannot be accepted for execution.
@throws NullPointerException
if work item is null.
-
org.apache.deltaspike.core.api.config.view.metadata.SimpleCallbackDescriptor.execute()
-
org.apache.deltaspike.data.impl.builder.QueryBuilder.execute()
-
org.apache.derby.iapi.sql.PreparedStatement.execute()
Execute the PreparedStatement and return results.
There is no executeQuery() or executeUpdate(); a method is provided in ResultSet to tell whether to expect rows to be returned.
@param activation The activation containing all the local stateto execute the plan.
@param rollbackParentContext True if 1) the statement context isNOT a top-level context, AND 2) in the event of a statement-level exception, the parent context needs to be rolled back, too.
@param timeoutMillis timeout value in milliseconds.
@return A ResultSet for a statement. A ResultSet representsthe results returned from the statement, if any. Will return NULL if the plan for the PreparedStatement has aged out of cache, or the plan is out of date.
@exception StandardException Thrown on failure
-
org.apache.derbyTesting.junit.BaseTestSuite.execute()
-
org.apache.directory.daemon.installers.archive.ArchiveInstallerCommand.execute()
Performs the following:
- Bail if the archive type is unknown
- Creates the Archive Installer for Apache DS
-
org.apache.directory.daemon.installers.bin.BinInstallerCommand.execute()
Performs the following:
- Bail if target is not for Linux
- Creates the Mac OS X PKG Installer for Apache DS
- Package it in a Mac OS X DMG (Disk iMaGe)
-
org.apache.directory.daemon.installers.deb.DebInstallerCommand.execute()
Performs the following:
- Bail if target is not for linux or the dpkg utility could not be found.
- Creates the Debian DEB package for Apache DS
-
org.apache.directory.daemon.installers.inno.InnoInstallerCommand.execute()
Performs the following:
- Bail if target is not for windows or current machine is not windows (no inno compiler)
- Filter and copy project supplied inno file into place if it has been specified and exists
- If no inno file exists filter and deposite into place bundled inno template & copy procrun executables
- Bail if we cannot find the inno compiler executable
- Execute inno compiler it on the inno file
-
org.apache.directory.daemon.installers.izpack.IzPackInstallerCommand.execute()
-
org.apache.directory.daemon.installers.macosxpkg.MacOsXPkgInstallerCommand.execute()
Performs the following:
- Bail if target is not for macosx or the PackageMaker or hdiutil utilities coud not be found.
- Creates the Mac OS X PKG Installer for Apache DS
- Package it in a Mac OS X DMG (Disk iMaGe)
-
org.apache.directory.daemon.installers.nsis.NsisInstallerCommand.execute()
Performs the following:
- Bail if target is not for windows
- Filter and copy project supplied .nsi file into place if it has been specified and exists
- If no .nsi file exists filter and deposite into place bundled nsis template & copy wrapper executables
- Bail if we cannot find the nsis compiler executable
- Execute nsis compiler it on the .nsi file
-
org.apache.directory.daemon.installers.rpm.RpmInstallerCommand.execute()
Performs the following:
- Bail if target is not for linux or current machine is not linux (no rpm builder)
- Filter and copy project supplied spec file into place if it has been specified and exists
- If no spec file exists filter and deposite into place bundled spec template
- Bail if we cannot find the rpm builder executable
- Execute rpm build on the filtered spec file
-
org.apache.directory.daemon.installers.solarispkg.SolarisPkgInstallerCommand.execute()
Performs the following:
- Bail if target is not for solaris or the pkgmk or pkgtrans utilities coud not be found.
- Creates the Solaris PKG Installer for Apache DS
-
org.apache.directory.ldap.client.template.LdapConnectionTemplate.execute()
-
org.apache.directory.ldapstudio.browser.core.jobs.ExportCsvJob.execute()
-
org.apache.directory.ldapstudio.browser.core.jobs.ExportDsmlJob.execute()
-
org.apache.directory.ldapstudio.browser.core.jobs.ExportLdifJob.execute()
-
org.apache.directory.ldapstudio.browser.core.jobs.ExportXlsJob.execute()
-
org.apache.directory.ldapstudio.browser.core.jobs.InitializeAttributesJob.execute()
-
org.apache.directory.ldapstudio.browser.core.jobs.OpenConnectionsJob.execute()
-
org.apache.directory.server.core.partition.impl.btree.gui.PartitionViewer.execute()
-
org.apache.directory.server.dns.store.jndi.operations.GetRecords.execute()
Note that the base is a relative path from the exiting context. It is not a DN.
-
org.apache.directory.server.installers.archive.ArchiveInstallerCommand.execute()
Performs the following:
- Bail if the archive type is unknown
- Creates the Archive Installer for ApacheDS
-
org.apache.directory.server.installers.bin.BinInstallerCommand.execute()
Performs the following:
- Bail if target is not for Linux
- Creates the Mac OS X PKG Installer for ApacheDS
- Package it in a Mac OS X DMG (Disk iMaGe)
-
org.apache.directory.server.installers.deb.DebInstallerCommand.execute()
Performs the following:
- Bail if target is not for linux or the dpkg utility could not be found.
- Creates the Debian DEB package for Apache DS
-
org.apache.directory.server.installers.macosxpkg.MacOsXPkgInstallerCommand.execute()
Performs the following:
- Bail if target is not for macosx or the PackageMaker or hdiutil utilities can't be found.
- Creates the Mac OS X PKG Installer for ApacheDS
- Package it in a Mac OS X DMG (Disk iMaGe)
-
org.apache.directory.server.installers.nsis.NsisInstallerCommand.execute()
Performs the following:
- Bail if target is not for windows or the NSIS compiler utility can't be found.
- Execute NSIS compiler (makensis) to create the NSIS installer.
-
org.apache.directory.server.installers.rpm.RpmInstallerCommand.execute()
Performs the following:
- Bail if target is not for linux or current machine is not linux (no rpm builder)
- Filter and copy project supplied spec file into place if it has been specified and exists
- If no spec file exists filter and deposite into place bundled spec template
- Bail if we cannot find the rpm builder executable
- Execute rpm build on the filtered spec file
-
org.apache.directory.server.kerberos.shared.store.operations.GetPrincipal.execute()
Note that the base is a relative path from the existing context. It is not a DN.
-
org.apache.directory.server.protocol.shared.kerberos.GetPrincipal.execute()
Note that the base is a relative path from the existing context. It is not a Dn.
-
org.apache.directory.server.protocol.shared.store.LdifFileLoader.execute()
Opens the LDIF file and loads the entries into the context.
@return The count of entries created.
-
org.apache.directory.studio.connection.core.jobs.CloseConnectionsJob.execute()
-
org.apache.directory.studio.connection.core.jobs.OpenConnectionsJob.execute()
-
org.apache.directory.studio.connection.core.jobs.StudioConnectionJob.execute()
Executes the job.
-
org.apache.directory.studio.ldapbrowser.core.jobs.ExportCsvJob.execute()
-
org.apache.directory.studio.ldapbrowser.core.jobs.ExportDsmlJob.execute()
-
org.apache.directory.studio.ldapbrowser.core.jobs.ExportLdifJob.execute()
-
org.apache.directory.studio.ldapbrowser.core.jobs.ExportOdfJob.execute()
-
org.apache.directory.studio.ldapbrowser.core.jobs.ExportXlsJob.execute()
-
org.apache.directory.studio.ldapbrowser.core.jobs.InitializeAttributesJob.execute()
-
org.apache.directory.studio.ldapbrowser.core.jobs.StudioBrowserJob.execute()
-
org.apache.directory.studio.maven.plugins.StudioCleanMojo.execute()
-
org.apache.easyant.man.EasyantOption.execute()
-
org.apache.easyant.tasks.AbstractImport.execute()
-
org.apache.easyant.tasks.ImportTestModule.execute()
-
org.apache.easyant.tasks.LoadModule.execute()
-
org.apache.easyant.tasks.SubModule.execute()
-
org.apache.examples.panorama.startup.impl.ExecuteStatic.execute()
-
org.apache.felix.dm.annotation.plugin.bnd.DescriptorGenerator.execute()
Starts the scanning.
@return true if some annotations were successfully parsed, false if not. corresponding generated descriptors can then be retrieved by invoking the getDescriptors/getDescriptorPaths methods.
-
org.apache.felix.gogo.commands.Action.execute()
-
org.apache.felix.gogo.commands.basic.AbstractCommand.execute()
-
org.apache.felix.gogo.runtime.Closure.execute()
-
org.apache.felix.karaf.admin.command.AdminCommandSupport.execute()
-
org.apache.felix.scrplugin.SCRDescriptorGenerator.execute()
Actually generates the Declarative Services and Metatype descriptors scanning the java sources provided by the {@link #setProject(Project)}
@return A list of generated file names, relative to the output directory
@throws SCRDescriptorException
@throws SCRDescriptorFailureException
-
org.apache.felix.service.command.CommandSession.execute()
Execute a program in this session.
@param commandline
@return the result of the execution
-
org.apache.felix.shell.Command.execute()
Executes the command using the supplied command line, output print stream, and error print stream.
@param line the complete command line, including the command name.
@param out the print stream to use for standard output.
@param err the print stream to use for standard error.
-
org.apache.flink.api.common.operators.CollectionExecutor.execute()
-
org.apache.flink.api.java.CollectionEnvironment.execute()
-
org.apache.flink.api.java.ExecutionEnvironment.execute()
Triggers the program execution. The environment will execute all parts of the program that have resulted in a "sink" operation. Sink operations are for example printing results ( {@link DataSet#print()}, writing results (e.g. {@link DataSet#writeAsText(String)}, {@link DataSet#write(org.apache.flink.api.common.io.FileOutputFormat,String)}, or other generic data sinks created with {@link DataSet#output(org.apache.flink.api.common.io.OutputFormat)}.
The program execution will be logged and displayed with a generated default name.
@return The result of the job execution, containing elapsed time and accumulators.
@throws Exception Thrown, if the program executions fails.
-
org.apache.flink.runtime.executiongraph.ExecutionGraph.execute()
-
org.apache.flink.streaming.api.environment.StreamExecutionEnvironment.execute()
Triggers the program execution. The environment will execute all parts of the program that have resulted in a "sink" operation. Sink operations are for example printing results or forwarding them to a message queue.
The program execution will be logged and displayed with a generated default name.
@throws Exception
-
org.apache.ftpserver.command.Command.execute()
Execute command.
@param session The current {@link FtpIoSession}
@param context The current {@link FtpServerContext}
@param request The current {@link FtpRequest}
@throws IOException
@throws FtpException
-
org.apache.ftpserver.interfaces.Command.execute()
Execute command.
@param session TODO
@param context TODO
-
org.apache.geronimo.datastore.impl.remote.messaging.CommandRequest.execute()
Executes the command against the specified target.
@return CommandResult wrapping the invocation result. if the commanddoes not exist for the specified target, then the CommandResult instance contains a NoSuchMethodException exception.
-
org.apache.geronimo.deployment.cli.AbstractCommand.execute()
-
org.apache.geronimo.deployment.cli.CommandDeploy.execute()
-
org.apache.geronimo.deployment.cli.CommandDistribute.execute()
-
org.apache.geronimo.deployment.cli.CommandEncrypt.execute()
-
org.apache.geronimo.deployment.cli.CommandInstallBundle.execute()
-
org.apache.geronimo.deployment.cli.CommandInstallCAR.execute()
-
org.apache.geronimo.deployment.cli.CommandInstallLibrary.execute()
-
org.apache.geronimo.deployment.cli.CommandListModules.execute()
-
org.apache.geronimo.deployment.cli.CommandListTargets.execute()
-
org.apache.geronimo.deployment.cli.CommandLogin.execute()
-
org.apache.geronimo.deployment.cli.CommandRedeploy.execute()
-
org.apache.geronimo.deployment.cli.CommandRestart.execute()
-
org.apache.geronimo.deployment.cli.CommandStart.execute()
-
org.apache.geronimo.deployment.cli.CommandStop.execute()
-
org.apache.geronimo.deployment.cli.CommandUndeploy.execute()
-
org.apache.geronimo.deployment.cli.CommandUninstallBundle.execute()
-
org.apache.geronimo.deployment.cli.CommandUnlockKeystore.execute()
-
org.apache.geronimo.gshell.command.Command.execute()
-
org.apache.geronimo.gshell.shell.InteractiveShell.execute()
-
org.apache.geronimo.gshell.shell.Shell.execute()
-
org.apache.geronimo.kernel.util.Main.execute()
-
org.apache.geronimo.main.Bootstrapper.execute()
-
org.apache.geronimo.network.protocol.control.commands.MenuItem.execute()
-
org.apache.geronimo.st.core.commands.IDeploymentCommand.execute()
-
org.apache.geronimo.st.core.operations.ImportDeploymentPlanOperation.execute()
-
org.apache.geronimo.st.core.operations.SharedLibEntryCreationOperation.execute()
-
org.apache.geronimo.twiddle.Twiddle.execute()
Execute a command line.
The first argument is assumed to be the command name.
@param args The command line.
@return The command status code.
@throws Exception An unhandled command failure has occured.
-
org.apache.hadoop.chukwa.datatrigger.TriggerAction.execute()
-
org.apache.hadoop.chukwa.inputtools.plugin.IPlugin.execute()
-
org.apache.hadoop.chukwa.util.DatabaseWriter.execute()
-
org.apache.hadoop.hbase.hbql.client.HConnection.execute()
-
org.apache.hadoop.hbase.hbql.client.HPreparedStatement.execute()
-
org.apache.hadoop.hbase.hbql.client.HStatement.execute()
-
org.apache.hadoop.hbase.hbql.statement.ConnectionStatement.execute()
-
org.apache.hadoop.hbase.hbql.statement.NonConnectionStatement.execute()
-
org.apache.hadoop.hbase.hbql.statement.VersionStatement.execute()
-
org.apache.hadoop.hbase.hql.Command.execute()
Execute a command
@param conf Configuration
@return Result of command execution
-
org.apache.hadoop.hbase.hql.ShowCommand.execute()
-
org.apache.hadoop.hbase.regionserver.SplitTransaction.execute()
Run the transaction.
@param server Hosting server instance. Can be null when testing (won't tryand update in zk if a null server)
@param services Used to online/offline regions.
@throws IOException If thrown, transaction failed. Call {@link #rollback(Server,RegionServerServices)}
@return Regions created
@throws IOException
@see #rollback(Server,RegionServerServices)
-
org.apache.hadoop.hbase.shell.Command.execute()
Execute a command
@param conf Configuration
@return Result of command execution
-
org.apache.hadoop.hbase.shell.ShowCommand.execute()
-
org.apache.hadoop.hive.common.cli.ShellCmdExecutor.execute()
-
org.apache.hadoop.hive.ql.exec.ExplainTask.execute()
-
org.apache.hadoop.hive.ql.exec.MapRedTask.execute()
-
org.apache.hadoop.hive.ql.exec.mr.MapRedTask.execute()
-
org.apache.hadoop.hive.ql.io.merge.MergeFileTask.execute()
start a new map-reduce job to do the merge, almost the same as ExecDriver.
-
org.apache.hadoop.hive.ql.io.rcfile.merge.BlockMergeTask.execute()
-
org.apache.hadoop.hive.ql.io.rcfile.truncate.ColumnTruncateTask.execute()
-
org.apache.hadoop.hive.service.HiveClient.execute()
-
org.apache.hadoop.lib.service.FileSystemAccess.execute()
-
org.apache.hadoop.tools.DistCp.execute()
Implements the core-execution. Creates the file-list for copy, and launches the Hadoop-job, to do the copy.
@return Job handle
@throws Exception , on failure.
-
org.apache.hadoop.util.AsyncDiskService.execute()
Execute the task sometime in the future, using ThreadPools.
-
org.apache.hadoop.util.Shell.ShellCommandExecutor.execute()
-
org.apache.harmony.sql.internal.rowset.SyncResolverImpl.execute()
-
org.apache.hivemind.ant.ConstructRegistry.execute()
-
org.apache.hivemind.ant.ManifestClassPath.execute()
-
org.apache.http.benchmark.HttpBenchmark.execute()
-
org.apache.http.client.ClientRequestDirector.execute()
Executes a request.
Note: For the time being, a new director is instantiated for each request. This is the same behavior as for HttpMethodDirector
in HttpClient 3.
@param roureq the route and request to execute
@param context the context for executing the request
@return the final response to the request.This is never an intermediate response with status code 1xx.
@throws HttpException in case of a problem
@throws IOException in case of an IO problem
-
org.apache.http.client.HttpClient.execute()
Executes a request using the default context.
@param request the request to execute
@return the response to the request. This is always a final response,never an intermediate response with an 1xx status code. Whether redirects or authentication challenges will be returned or handled automatically depends on the implementation and configuration of this client.
@throws IOException in case of a problem or the connection was aborted
@throws ClientProtocolException in case of an http protocol error
-
org.apache.http.client.RequestDirector.execute()
Executes a request.
Note: For the time being, a new director is instantiated for each request. This is the same behavior as for HttpMethodDirector
in HttpClient 3.
@param target the target host for the request.Implementations may accept null
if they can still determine a route, for example to a default target or by inspecting the request.
@param request the request to execute
@param context the context for executing the request
@return the final response to the request.This is never an intermediate response with status code 1xx.
@throws HttpException in case of a problem
@throws IOException in case of an IO problemor if the connection was aborted
-
org.apache.http.client.fluent.Executor.execute()
-
org.apache.http.client.fluent.Request.execute()
-
org.apache.http.impl.client.CloseableHttpClient.execute()
-
org.apache.http.impl.client.ContentEncodingHttpClient.execute()
-
org.apache.http.impl.client.DefaultHttpClient.execute()
-
org.apache.http.impl.client.FutureRequestExecutionService.execute()
Schedule a request for execution.
@param < T>
@param request request to execute
@param responseHandler handler that will process the response.
@return HttpAsyncClientFutureTask for the scheduled request.
@throws InterruptedException
-
org.apache.http.impl.client.SystemDefaultHttpClient.execute()
-
org.apache.http.impl.client.cache.CachingHttpClient.execute()
-
org.apache.http.impl.execchain.ClientExecChain.execute()
Executes th request either by transmitting it to the target server or by passing it onto the next executor in the request execution chain.
@param route connection route.
@param request current request.
@param clientContext current HTTP context.
@param execAware receiver of notifications of blocking I/O operations.
@return HTTP response either received from the opposite endpointor generated locally.
@throws IOException in case of a I/O error.(this type of exceptions are potentially recoverable).
@throws HttpException in case of an HTTP protocol error(usually this type of exceptions are non-recoverable).
-
org.apache.http.impl.nio.client.CloseableHttpAsyncClient.execute()
-
org.apache.http.impl.nio.client.DefaultHttpAsyncClient.execute()
-
org.apache.http.impl.nio.reactor.DefaultConnectingIOReactor.execute()
-
org.apache.http.impl.nio.reactor.DefaultListeningIOReactor.execute()
-
org.apache.http.nio.client.HttpAsyncClient.execute()
-
org.apache.http.nio.impl.reactor.DefaultConnectingIOReactor.execute()
-
org.apache.http.nio.impl.reactor.DefaultListeningIOReactor.execute()
-
org.apache.http.nio.protocol.HttpAsyncRequestExecutor.execute()
-
org.apache.http.nio.protocol.HttpAsyncRequester.execute()
Initiates asynchronous HTTP request execution.
@param < T> the result type of request execution.
@param requestProducer request producer callback.
@param responseConsumer response consumer callaback.
@param conn underlying HTTP connection.
@param context HTTP context
@param callback future callback.
@return future representing pending completion of the operation.
-
org.apache.http.nio.reactor.ConnectingIOReactor.execute()
-
org.apache.http.nio.reactor.ListeningIOReactor.execute()
-
org.apache.http.protocol.HttpRequestExecutor.execute()
Synchronously send a request and obtain the response.
@param request the request to send. It will be preprocessed.
@param conn the open connection over which to send
@return the response to the request, postprocessed
@throws HttpException in case of a protocol or processing problem
@throws IOException in case of an I/O problem
-
org.apache.ibatis.binding.MapperMethod.execute()
-
org.apache.isis.core.metamodel.facets.object.autocomplete.AutoCompleteFacet.execute()
-
org.apache.isis.core.metamodel.spec.feature.ObjectAction.execute()
Invokes the action's method on the target object given the specified set of parameters.
-
org.apache.isis.core.runtime.persistence.objectstore.transaction.CreateObjectCommand.execute()
-
org.apache.isis.core.runtime.persistence.objectstore.transaction.DestroyObjectCommand.execute()
-
org.apache.isis.core.runtime.persistence.objectstore.transaction.SaveObjectCommand.execute()
-
org.apache.isis.runtimes.dflt.remoting.common.exchange.Request.execute()
-
org.apache.isis.runtimes.dflt.runtime.persistence.objectstore.transaction.CreateObjectCommand.execute()
-
org.apache.isis.runtimes.dflt.runtime.persistence.objectstore.transaction.DestroyObjectCommand.execute()
-
org.apache.isis.runtimes.dflt.runtime.persistence.objectstore.transaction.SaveObjectCommand.execute()
-
org.apache.isis.viewer.dnd.view.action.ActionContent.execute()
-
org.apache.isis.viewer.html.action.Action.execute()
-
org.apache.isis.viewer.json.applib.RestfulRequest.execute()
-
org.apache.isis.viewer.restfulobjects.applib.client.RestfulRequest.execute()
-
org.apache.ivy.Ivy.execute()
Executes the given callback in the context of this Ivy instance.
Alternatively you can use the {@link #pushContext()} and {@link #popContext()} methods, butthis is not recommended:
Object result = null; pushContext(); try { result = callback.doInIvyContext(this, IvyContext.getContext()); } finally { popContext(); } doSomethingWithResult(result);
@param callback
@return
-
org.apache.ivy.ant.IvyPublish.execute()
-
org.apache.ivy.ant.IvyResolve.execute()
-
org.apache.jackrabbit.core.integration.random.operation.Operation.execute()
-
org.apache.jackrabbit.core.query.lucene.join.JahiaQueryEngine.execute()
Override QueryEngine.execute()
-
org.apache.jackrabbit.core.query.lucene.join.QueryEngine.execute()
-
org.apache.jackrabbit.mongomk.api.command.CommandExecutor.execute()
Executes the given {@link Command} and returns the result.
If an retry behavior is specified this will be taken care of by the implementation as well.
@param command
@return The result of the execution.
@throws Exception If an error occurred while executing.
-
org.apache.jackrabbit.mongomk.command.CommitCommandMongo.execute()
-
org.apache.jackrabbit.mongomk.command.GetBlobLengthCommandMongo.execute()
-
org.apache.jackrabbit.mongomk.command.GetHeadRevisionCommandMongo.execute()
-
org.apache.jackrabbit.mongomk.command.ReadBlobCommandMongo.execute()
-
org.apache.jackrabbit.mongomk.command.WriteBlobCommandMongo.execute()
-
org.apache.jackrabbit.mongomk.impl.action.FetchCommitAction.execute()
-
org.apache.jackrabbit.mongomk.impl.action.FetchCommitsAction.execute()
-
org.apache.jackrabbit.mongomk.impl.action.FetchHeadRevisionIdAction.execute()
-
org.apache.jackrabbit.mongomk.impl.action.FetchNodesAction.execute()
-
org.apache.jackrabbit.mongomk.impl.action.FetchNodesActionNew.execute()
-
org.apache.jackrabbit.mongomk.impl.command.CommandExecutorImpl.execute()
-
org.apache.jackrabbit.mongomk.impl.command.CommitCommand.execute()
-
org.apache.jackrabbit.mongomk.impl.command.NodeExistsCommand.execute()
-
org.apache.jackrabbit.mongomk.query.FetchNodeByPathQuery.execute()
-
org.apache.jackrabbit.mongomk.query.FetchNodesByPathAndDepthQuery.execute()
-
org.apache.jackrabbit.mongomk.query.FetchValidCommitsQuery.execute()
-
org.apache.jackrabbit.spi.commons.query.jsr283.qom.QueryObjectModel.execute()
-
org.apache.jackrabbit.vault.packaging.InstallHookProcessor.execute()
Executes the registered hooks with the current {@link InstallContext.Phase}.
@param context the context
@return true
if successful.
-
org.apache.jackrabbit.vault.vlt.VltContext.execute()
-
org.apache.james.mailbox.hbase.mail.HBaseMailboxMapper.execute()
-
org.apache.james.mailbox.jpa.mail.JPAMailboxMapper.execute()
-
org.apache.james.mailbox.store.user.SubscriptionMapper.execute()
-
org.apache.jasper.JspC.execute()
Executes the compilation.
@throws JasperException If an error occurs
-
org.apache.jetspeed.aggregator.RenderingJob.execute()
-
org.apache.jetspeed.util.OverwriteProperties.execute()
Description of the Method
-
org.apache.jmeter.engine.util.CompoundVariable.execute()
-
org.apache.jmeter.protocol.smtp.sampler.protocol.SendMailCommand.execute()
Sends message to mailserver, waiting for delivery if using synchronous mode.
@param message Message prior prepared by prepareMessage()
@throws MessagingException
@throws IOException
@throws InterruptedException
-
org.apache.jsieve.tests.ExecutableTest.execute()
Method execute executes a Test and answers a boolean indicating if the test was passed.
@param mail
@param arguments
@param context SieveContext
giving contextual information, not null
@return boolean
@throws SieveException
-
org.apache.juddi.IRegistry.execute()
@exception RegistryException
-
org.apache.juddi.function.IFunction.execute()
-
org.apache.juddi.proxy.RegistryProxy.execute()
-
org.apache.juddi.registry.RegistryEngine.execute()
-
org.apache.karaf.admin.command.AdminCommandSupport.execute()
-
org.apache.karaf.instance.command.InstanceCommandSupport.execute()
-
org.apache.karaf.shell.api.action.Action.execute()
Execute the action which has been injected with services from the registry, options and arguments from the command line.
@return null
or the result of the action execution
@throws Exception
-
org.apache.karaf.shell.api.console.Session.execute()
Execute a program in this session.
@param commandline
@return the result of the execution
-
org.apache.karaf.shell.commands.Action.execute()
-
org.apache.karaf.shell.commands.CommandWithAction.execute()
-
org.apache.karaf.shell.commands.Context.execute()
-
org.apache.karaf.shell.commands.basic.Context.execute()
-
org.apache.karaf.shell.console.impl.jline.ConsoleImpl.DelegateSession.execute()
-
org.apache.ldap.server.db.gui.PartitionViewer.execute()
-
org.apache.ldap.server.partition.impl.btree.gui.PartitionViewer.execute()
-
org.apache.lenya.cms.cocoon.task.CocoonTaskWrapper.execute()
-
org.apache.lenya.cms.task.AntTask.execute()
Execute the task. All parameters must have been set with parameterize().
@param servletContextPath The servlet context path.
@throws ExecutionException when the execution of the task failed.
-
org.apache.lenya.cms.task.DefaultTaskWrapper.execute()
Executes the task.
@throws ExecutionException when something went wrong.
-
org.apache.lenya.cms.task.Task.execute()
Execute the task. All parameters must have been set with parameterize().
@param servletContextPath the servlet-context
@throws ExecutionException if the execution fails
-
org.apache.lenya.cms.task.TaskWrapper.execute()
Executes the task.
@throws ExecutionException when something went wrong.
-
org.apache.lenya.cms.usecase.Usecase.execute()
Executes the usecase. During this method error and info messages are filled in. If getErrorMessages() returns an empty array, the operation succeeded. Otherwise, the operation failed.
@throws UsecaseException if an error occured that causes an unstablesystem.
-
org.apache.log4j.rolling.helper.Action.execute()
Perform an action.
@return true if action was successful. A return value of false will causethe rollover to be aborted if possible.
@throws IOException if IO error, a thrown exception will cause the rolloverto be aborted if possible.
-
org.apache.logging.log4j.core.appender.rolling.action.Action.execute()
Perform an action.
@return true if action was successful. A return value of false will causethe rollover to be aborted if possible.
@throws IOException if IO error, a thrown exception will cause the rolloverto be aborted if possible.
-
org.apache.logging.log4j.core.appender.rolling.action.FileRenameAction.execute()
Rename file.
@return true if successfully renamed.
-
org.apache.logging.log4j.core.appender.rolling.helper.Action.execute()
Perform an action.
@return true if action was successful. A return value of false will causethe rollover to be aborted if possible.
@throws IOException if IO error, a thrown exception will cause the rolloverto be aborted if possible.
-
org.apache.lucene.benchmark.byTask.Benchmark.execute()
Execute this benchmark
-
org.apache.lucene.benchmark.byTask.utils.Algorithm.execute()
Execute this algorithm
@throws Exception
-
org.apache.lucene.benchmark.quality.QualityBenchmark.execute()
Run the quality benchmark.
@param judge the judge that can tell if a certain result doc is relevant for a certain quality query. If null, no judgements would be made. Usually null for a submission run.
@param submitRep submission report is created if non null.
@param qualityLog If not null, quality run data would be printed for each query.
@return QualityStats of each quality query that was executed.
@throws Exception if quality benchmark failed to run.
-
org.apache.maven.Maven.execute()
-
org.apache.maven.artifact.ant.util.AntTaskModified.execute()
-
org.apache.maven.bootstrap.util.JarMojo.execute()
-
org.apache.maven.doxia.macro.Macro.execute()
Execute the current macro using the given MacroRequest, and emit events into the given sink.
@param sink The sink to receive the events.
@param request The corresponding MacroRequest.
@throws org.apache.maven.doxia.macro.MacroExecutionException if an error occurred during execution.
-
org.apache.maven.embedder.MavenEmbedder.execute()
-
org.apache.maven.enforcer.rule.api.EnforcerRule.execute()
This is the interface into the rule. This method should throw an exception containing a reason message if the rule fails the check. The plugin will then decide based on the fail flag if it should stop or just log the message as a warning.
@param helper The helper provides access to the log, MavenSession and hashelpers to get common components. It is also able to lookup components by class name.
@throws EnforcerRuleException the enforcer rule exception
-
org.apache.maven.plugin.AbstractMojo.execute()
-
org.apache.maven.plugin.Mojo.execute()
Perform whatever build-process behavior this Mojo
implements.
This is the main trigger for the Mojo
inside the Maven
system, and allows the Mojo
to communicate errors.
@throws MojoExecutionException if an unexpected problem occurs.Throwing this exception causes a "BUILD ERROR" message to be displayed.
@throws MojoFailureException if an expected problem (such as a compilation failure) occurs.Throwing this exception causes a "BUILD FAILURE" message to be displayed.
-
org.apache.maven.plugin.assembly.archive.phase.AssemblyArchiverPhase.execute()
Handle the associated section of the assembly descriptor.
@param assembly The assembly descriptor to use
@param archiver The archiver used to create the assembly archive, to which files/directories/artifacts are added
@param configSource The configuration for this assembly build, normally derived from the plugin that launched the assembly process.
@param context
-
org.apache.maven.plugin.assembly.archive.task.AddArtifactTask.execute()
-
org.apache.maven.plugin.assembly.archive.task.AddDependencySetsTask.execute()
-
org.apache.maven.plugin.assembly.archive.task.AddDirectoryTask.execute()
-
org.apache.maven.plugin.assembly.archive.task.AddFileSetsTask.execute()
-
org.apache.maven.plugin.assembly.mojos.AssemblyMojo.execute()
-
org.apache.maven.plugin.assembly.mojos.DirectoryInlineMojo.execute()
-
org.apache.maven.plugin.assembly.mojos.DirectoryMojo.execute()
-
org.apache.maven.plugin.assembly.mojos.UnpackMojo.execute()
Unpacks the archive file.
@throws MojoExecutionException
-
org.apache.maven.plugin.dependency.CopyDependenciesMojo.execute()
Main entry into mojo. Gets the list of dependencies and iterates through calling copyArtifact.
@throws MojoExecutionException with a message if an error occurs.
@see #getDependencies
@see #copyArtifact(Artifact,boolean)
-
org.apache.maven.plugin.dependency.analyze.AnalyzeDuplicateMojo.execute()
{@inheritDoc}
-
org.apache.maven.plugin.dependency.fromDependencies.BuildClasspathMojo.execute()
-
org.apache.maven.plugin.dependency.resolvers.ResolveDependenciesMojo.execute()
Main entry into mojo. Gets the list of dependencies and iterates through displaying the resolved version.
@throws MojoExecutionException with a message if an error occurs.
-
org.apache.maven.plugin.dependency.tree.TreeMojo.execute()
-
org.apache.maven.plugin.deploy.DeployMojo.execute()
-
org.apache.maven.scm.command.Command.execute()
@param repository not null
@param fileSet not null
@param parameters could be null
@return the result object
@throws ScmException if any
-
org.apache.maven.scm.provider.bazaar.command.add.BazaarAddCommand.execute()
-
org.apache.maven.scm.provider.bazaar.command.blame.BazaarBlameCommand.execute()
-
org.apache.maven.scm.provider.bazaar.command.changelog.BazaarChangeLogCommand.execute()
-
org.apache.maven.scm.provider.bazaar.command.checkin.BazaarCheckInCommand.execute()
-
org.apache.maven.scm.provider.bazaar.command.checkout.BazaarCheckOutCommand.execute()
-
org.apache.maven.scm.provider.bazaar.command.diff.BazaarDiffCommand.execute()
-
org.apache.maven.scm.provider.bazaar.command.remove.BazaarRemoveCommand.execute()
-
org.apache.maven.scm.provider.bazaar.command.status.BazaarStatusCommand.execute()
-
org.apache.maven.scm.provider.bazaar.command.tag.BazaarTagCommand.execute()
-
org.apache.maven.scm.provider.bazaar.command.update.BazaarUpdateCommand.execute()
-
org.apache.maven.scm.provider.clearcase.command.blame.ClearCaseBlameCommand.execute()
-
org.apache.maven.scm.provider.clearcase.command.changelog.ClearCaseChangeLogCommand.execute()
-
org.apache.maven.scm.provider.clearcase.command.checkin.ClearCaseCheckInCommand.execute()
-
org.apache.maven.scm.provider.clearcase.command.checkout.ClearCaseCheckOutCommand.execute()
-
org.apache.maven.scm.provider.clearcase.command.edit.ClearCaseEditCommand.execute()
-
org.apache.maven.scm.provider.clearcase.command.status.ClearCaseStatusCommand.execute()
-
org.apache.maven.scm.provider.clearcase.command.tag.ClearCaseTagCommand.execute()
-
org.apache.maven.scm.provider.clearcase.command.update.ClearCaseUpdateCommand.execute()
-
org.apache.maven.scm.provider.git.command.GitCommand.execute()
-
org.apache.maven.scm.provider.hg.command.add.HgAddCommand.execute()
-
org.apache.maven.scm.provider.hg.command.blame.HgBlameCommand.execute()
-
org.apache.maven.scm.provider.hg.command.branch.HgBranchCommand.execute()
-
org.apache.maven.scm.provider.hg.command.changelog.HgChangeLogCommand.execute()
-
org.apache.maven.scm.provider.hg.command.checkin.HgCheckInCommand.execute()
-
org.apache.maven.scm.provider.hg.command.checkout.HgCheckOutCommand.execute()
-
org.apache.maven.scm.provider.hg.command.diff.HgDiffCommand.execute()
-
org.apache.maven.scm.provider.hg.command.info.HgInfoCommand.execute()
-
org.apache.maven.scm.provider.hg.command.remove.HgRemoveCommand.execute()
-
org.apache.maven.scm.provider.hg.command.status.HgStatusCommand.execute()
-
org.apache.maven.scm.provider.hg.command.tag.HgTagCommand.execute()
-
org.apache.maven.scm.provider.hg.command.update.HgUpdateCommand.execute()
-
org.apache.maven.scm.provider.integrity.command.add.IntegrityAddCommand.execute()
-
org.apache.maven.scm.provider.integrity.command.blame.IntegrityBlameCommand.execute()
-
org.apache.maven.scm.provider.integrity.command.branch.IntegrityBranchCommand.execute()
-
org.apache.maven.scm.provider.integrity.command.changelog.IntegrityChangeLogCommand.execute()
-
org.apache.maven.scm.provider.integrity.command.checkin.IntegrityCheckInCommand.execute()
-
org.apache.maven.scm.provider.integrity.command.checkout.IntegrityCheckOutCommand.execute()
-
org.apache.maven.scm.provider.integrity.command.diff.IntegrityDiffCommand.execute()
-
org.apache.maven.scm.provider.integrity.command.edit.IntegrityEditCommand.execute()
-
org.apache.maven.scm.provider.integrity.command.export.IntegrityExportCommand.execute()
-
org.apache.maven.scm.provider.integrity.command.fileinfo.IntegrityFileInfoCommand.execute()
-
org.apache.maven.scm.provider.integrity.command.list.IntegrityListCommand.execute()
-
org.apache.maven.scm.provider.integrity.command.lock.IntegrityLockCommand.execute()
-
org.apache.maven.scm.provider.integrity.command.login.IntegrityLoginCommand.execute()
-
org.apache.maven.scm.provider.integrity.command.mkdir.IntegrityMkdirCommand.execute()
-
org.apache.maven.scm.provider.integrity.command.remove.IntegrityRemoveCommand.execute()
-
org.apache.maven.scm.provider.integrity.command.status.IntegrityStatusCommand.execute()
-
org.apache.maven.scm.provider.integrity.command.tag.IntegrityTagCommand.execute()
-
org.apache.maven.scm.provider.integrity.command.unedit.IntegrityUnEditCommand.execute()
-
org.apache.maven.scm.provider.integrity.command.unlock.IntegrityUnlockCommand.execute()
-
org.apache.maven.scm.provider.integrity.command.update.IntegrityUpdateCommand.execute()
-
org.apache.maven.scm.provider.jazz.command.JazzScmCommand.execute()
-
org.apache.maven.scm.provider.jazz.command.add.JazzAddCommand.execute()
-
org.apache.maven.scm.provider.jazz.command.blame.JazzBlameCommand.execute()
-
org.apache.maven.scm.provider.jazz.command.branch.JazzBranchCommand.execute()
-
org.apache.maven.scm.provider.jazz.command.changelog.JazzChangeLogCommand.execute()
-
org.apache.maven.scm.provider.jazz.command.checkin.JazzCheckInCommand.execute()
-
org.apache.maven.scm.provider.jazz.command.checkout.JazzCheckOutCommand.execute()
-
org.apache.maven.scm.provider.jazz.command.diff.JazzDiffCommand.execute()
-
org.apache.maven.scm.provider.jazz.command.edit.JazzEditCommand.execute()
-
org.apache.maven.scm.provider.jazz.command.list.JazzListCommand.execute()
-
org.apache.maven.scm.provider.jazz.command.status.JazzStatusCommand.execute()
-
org.apache.maven.scm.provider.jazz.command.tag.JazzTagCommand.execute()
-
org.apache.maven.scm.provider.jazz.command.unedit.JazzUnEditCommand.execute()
-
org.apache.maven.scm.provider.jazz.command.update.JazzUpdateCommand.execute()
-
org.apache.maven.scm.provider.local.command.add.LocalAddCommand.execute()
-
org.apache.maven.scm.provider.local.command.changelog.LocalChangeLogCommand.execute()
-
org.apache.maven.scm.provider.local.command.checkin.LocalCheckInCommand.execute()
-
org.apache.maven.scm.provider.local.command.checkout.LocalCheckOutCommand.execute()
-
org.apache.maven.scm.provider.local.command.list.LocalListCommand.execute()
-
org.apache.maven.scm.provider.local.command.mkdir.LocalMkdirCommand.execute()
-
org.apache.maven.scm.provider.local.command.status.LocalStatusCommand.execute()
-
org.apache.maven.scm.provider.local.command.tag.LocalTagCommand.execute()
-
org.apache.maven.scm.provider.local.command.update.LocalUpdateCommand.execute()
-
org.apache.maven.scm.provider.perforce.command.add.PerforceAddCommand.execute()
-
org.apache.maven.scm.provider.perforce.command.blame.PerforceBlameCommand.execute()
-
org.apache.maven.scm.provider.perforce.command.changelog.PerforceChangeLogCommand.execute()
-
org.apache.maven.scm.provider.perforce.command.checkin.PerforceCheckInCommand.execute()
-
org.apache.maven.scm.provider.perforce.command.checkout.PerforceCheckOutCommand.execute()
-
org.apache.maven.scm.provider.perforce.command.diff.PerforceDiffCommand.execute()
-
org.apache.maven.scm.provider.perforce.command.edit.PerforceEditCommand.execute()
-
org.apache.maven.scm.provider.perforce.command.login.PerforceLoginCommand.execute()
-
org.apache.maven.scm.provider.perforce.command.remove.PerforceRemoveCommand.execute()
-
org.apache.maven.scm.provider.perforce.command.status.PerforceStatusCommand.execute()
-
org.apache.maven.scm.provider.perforce.command.tag.PerforceTagCommand.execute()
-
org.apache.maven.scm.provider.perforce.command.unedit.PerforceUnEditCommand.execute()
-
org.apache.maven.scm.provider.perforce.command.update.PerforceUpdateCommand.execute()
-
org.apache.maven.scm.provider.starteam.command.add.StarteamAddCommand.execute()
-
org.apache.maven.scm.provider.starteam.command.changelog.StarteamChangeLogCommand.execute()
-
org.apache.maven.scm.provider.starteam.command.checkin.StarteamCheckInCommand.execute()
-
org.apache.maven.scm.provider.starteam.command.checkout.StarteamCheckOutCommand.execute()
-
org.apache.maven.scm.provider.starteam.command.diff.StarteamDiffCommand.execute()
-
org.apache.maven.scm.provider.starteam.command.edit.StarteamEditCommand.execute()
-
org.apache.maven.scm.provider.starteam.command.remove.StarteamRemoveCommand.execute()
-
org.apache.maven.scm.provider.starteam.command.status.StarteamStatusCommand.execute()
-
org.apache.maven.scm.provider.starteam.command.tag.StarteamTagCommand.execute()
-
org.apache.maven.scm.provider.starteam.command.unedit.StarteamUnEditCommand.execute()
-
org.apache.maven.scm.provider.starteam.command.update.StarteamUpdateCommand.execute()
-
org.apache.maven.scm.provider.synergy.command.add.SynergyAddCommand.execute()
-
org.apache.maven.scm.provider.synergy.command.changelog.SynergyChangeLogCommand.execute()
-
org.apache.maven.scm.provider.synergy.command.checkin.SynergyCheckInCommand.execute()
-
org.apache.maven.scm.provider.synergy.command.checkout.SynergyCheckOutCommand.execute()
-
org.apache.maven.scm.provider.synergy.command.edit.SynergyEditCommand.execute()
-
org.apache.maven.scm.provider.synergy.command.remove.SynergyRemoveCommand.execute()
-
org.apache.maven.scm.provider.synergy.command.status.SynergyStatusCommand.execute()
-
org.apache.maven.scm.provider.synergy.command.tag.SynergyTagCommand.execute()
-
org.apache.maven.scm.provider.synergy.command.update.SynergyUpdateCommand.execute()
-
org.apache.maven.scm.provider.tfs.command.TfsAddCommand.execute()
-
org.apache.maven.scm.provider.tfs.command.TfsBranchCommand.execute()
-
org.apache.maven.scm.provider.tfs.command.TfsChangeLogCommand.execute()
-
org.apache.maven.scm.provider.tfs.command.TfsCheckInCommand.execute()
-
org.apache.maven.scm.provider.tfs.command.TfsCheckOutCommand.execute()
-
org.apache.maven.scm.provider.tfs.command.TfsEditCommand.execute()
-
org.apache.maven.scm.provider.tfs.command.TfsListCommand.execute()
-
org.apache.maven.scm.provider.tfs.command.TfsStatusCommand.execute()
-
org.apache.maven.scm.provider.tfs.command.TfsTagCommand.execute()
-
org.apache.maven.scm.provider.tfs.command.TfsUnEditCommand.execute()
-
org.apache.maven.scm.provider.tfs.command.TfsUpdateCommand.execute()
-
org.apache.maven.scm.provider.tfs.command.blame.TfsBlameCommand.execute()
-
org.apache.maven.scm.provider.vss.commands.add.VssAddCommand.execute()
-
org.apache.maven.scm.provider.vss.commands.changelog.VssHistoryCommand.execute()
-
org.apache.maven.scm.provider.vss.commands.checkin.VssCheckInCommand.execute()
-
org.apache.maven.scm.provider.vss.commands.checkout.VssCheckOutCommand.execute()
-
org.apache.maven.scm.provider.vss.commands.edit.VssEditCommand.execute()
-
org.apache.maven.scm.provider.vss.commands.status.VssStatusCommand.execute()
-
org.apache.maven.scm.provider.vss.commands.tag.VssTagCommand.execute()
-
org.apache.maven.scm.provider.vss.commands.update.VssUpdateCommand.execute()
-
org.apache.maven.shared.invoker.DefaultInvoker.execute()
-
org.apache.maven.shared.invoker.Invoker.execute()
Executes Maven using the parameters specified by the given invocation request. Parameters not specified by the invocation request will be derived from the state of this invoker instance. In case both the invoker instance and the invocation request provide a value for a particular option, the value from the invocation request dominates.
@param request The invocation request to execute, must not be null
.
@return The result of the Maven invocation, never null
.
@throws MavenInvocationException
-
org.apache.maven.shared.release.phase.ReleasePhase.execute()
Execute the phase.
@param releaseDescriptor the configuration to use
@param releaseEnvironment the environmental configuration, such as Maven settings, Maven home, etc.
@param reactorProjects the reactor projects
@throws ReleaseExecutionException an exception during the execution of the phase
@throws ReleaseFailureException a failure during the execution of the phase
@return the release result
-
org.apache.maven.surefire.its.fixture.SurefireLauncher.execute()
-
org.apache.maven.tools.plugin.extractor.MojoDescriptorExtractor.execute()
Execute the mojo extraction.
@param request The {@link PluginToolsRequest} containing information for the extraction process.
@return a list of mojo descriptors.
@throws ExtractionException if any
@throws InvalidPluginDescriptorException if any
@since 2.5
-
org.apache.maven.tools.plugin.generator.Generator.execute()
Execute the generation for a given plugin descriptor.
@param destinationDirectory required
@param request required
@throws GeneratorException if any
@since 2.5
-
org.apache.maven.tools.plugin.generator.PluginDescriptorGenerator.execute()
{@inheritDoc}
-
org.apache.maven.tools.plugin.generator.PluginXdocGenerator.execute()
{@inheritDoc}
-
org.apache.maven.util.Expand.execute()
Do the work.
@throws IOException If an error occurs.
-
org.apache.maven.util.MD5Sum.execute()
Perform the MD5-Sum work.
@throws Exception If an error occurs while calculating the sum.
-
org.apache.metamodel.create.ColumnCreationBuilder.execute()
-
org.apache.metamodel.create.TableCreationBuilder.execute()
Commits the built table and requests that the table structure should be written to the {@link DataContext}.
@return the {@link Table} that was build
@throws MetaModelException if the {@link DataContext} was not able to create the table
-
org.apache.metamodel.delete.RowDeletionBuilder.execute()
Commits the row deletion operation. This operation will delete rows in the {@link DataContext}.
@throws MetaModelException if the operation was rejected
-
org.apache.metamodel.drop.TableDropBuilder.execute()
Executes the drop table operation
@throws MetaModelException if the operation was rejected
-
org.apache.metamodel.insert.RowInsertionBuilder.execute()
Commits the row insertion operation. This operation will write the row to the {@link DataContext}.
@throws MetaModelException if the operation was rejected
-
org.apache.metamodel.update.RowUpdationBuilder.execute()
Commits the row updation operation. This operation will overwrite rows in the {@link DataContext}.
@throws MetaModelException if the operation was rejected
-
org.apache.mina.service.executor.IoHandlerExecutor.execute()
execute a given event
@param event the event to execute
-
org.apache.mina.statemachine.transition.MethodTransition.execute()
-
org.apache.muse.ws.resource.properties.set.SetRequestComponent.execute()
Performs the set command on the given WSRP document. There may be one or more changes made to the document as the result of this command.
-
org.apache.ode.jacob.vpu.JacobVPU.execute()
Execute one VPU cycle.
@return true
if the run queue is not empty after this cycle, false
otherwise.
-
org.apache.ode.tools.bpelc.BpelCompileCommand.execute()
-
org.apache.ojb.odmg.link.LinkEntry.execute()
-
org.apache.ojb.odmg.oql.EnhancedOQLQuery.execute()
-
org.apache.oodt.cas.cli.action.PrintMessageAction.execute()
-
org.apache.oodt.cas.pushpull.expressions.Method.execute()
-
org.apache.oodt.commons.database.SqlScript.execute()
-
org.apache.oozie.action.hadoop.FileSystemActions.execute()
Method to execute the prepare actions based on the command
@param n Child node of the prepare XML
@throws LauncherException
-
org.apache.oozie.service.JPAService.execute()
Execute a {@link JPAExecutor}.
@param executor JPAExecutor to execute.
@return return value of the JPAExecutor.
@throws JPAExecutorException thrown if an jpa executor failed
-
org.apache.openejb.quartz.Job.execute()
-
org.apache.openejb.server.cli.command.AbstractCommand.execute()
-
org.apache.openjpa.jdbc.sql.Select.execute()
-
org.apache.openjpa.jdbc.sql.SelectExecutor.execute()
Execute this select in the context of the given store manager.
-
org.apache.openjpa.jdbc.sql.Union.execute()
-
org.apache.openjpa.kernel.Query.execute()
Execute.
-
org.apache.openjpa.tools.maven.OpenJpaEnhancerMojo.execute()
-
org.apache.phoenix.compile.MutationPlan.execute()
-
org.apache.phoenix.util.csv.CsvUpsertExecutor.execute()
Execute upserts for each CSV record contained in the given iterable, notifying this instance's {@code UpsertListener} for each completed upsert.
@param csvRecords iterable of CSV records to be upserted
-
org.apache.pivot.util.concurrent.Task.execute()
Synchronously executes the task.
@return The result of the task's execution.
@throws TaskExecutionException If an error occurs while executing the task.
-
org.apache.pivot.util.concurrent.TaskGroup.execute()
-
org.apache.pivot.util.concurrent.TaskSequence.execute()
-
org.apache.pivot.web.DeleteQuery.execute()
Synchronously executes the DELETE operation.
-
org.apache.pivot.web.GetQuery.execute()
Synchronously executes the GET operation.
@return The result of the operation, deserialized using the query's serializer.
-
org.apache.pivot.web.PostQuery.execute()
Synchronously executes the POST operation.
@return A URL that uniquely identifies the location of the resource created on the server by the operation, or null if the server did not return a location.
-
org.apache.pivot.web.PutQuery.execute()
Synchronously executes the PUT operation.
-
org.apache.protocol.common.store.LdifFileLoader.execute()
-
org.apache.qpid.tools.messagestore.commands.Command.execute()
-
org.apache.rat.mp.RatCheckMojo.execute()
Invoked by Maven to execute the Mojo.
@throws MojoFailureException An error in the plugin configuration was detected.
@throws MojoExecutionException Another error occurred while executing the plugin.
-
org.apache.roller.ui.core.security.AutoProvision.execute()
-
org.apache.roller.weblogger.ui.core.security.AutoProvision.execute()
-
org.apache.scaffold.model.ModelBean.execute()
Perform query for this bean, and return outcome in a ModelResult collection of this QueryBean class, e.g. execute(source, this).
@exception ModelException
@returns null on success, or the outcome in a ModelResult
-
org.apache.servicemix.jbi.management.task.DeployServiceAssemblyTask.execute()
-
org.apache.servicemix.jbi.management.task.InstallComponentTask.execute()
-
org.apache.servicemix.jbi.management.task.InstallSharedLibraryTask.execute()
-
org.apache.servicemix.jbi.management.task.ShutDownComponentTask.execute()
-
org.apache.servicemix.jbi.management.task.ShutDownServiceAssemblyTask.execute()
-
org.apache.servicemix.jbi.management.task.StartComponentTask.execute()
-
org.apache.servicemix.jbi.management.task.StartServiceAssemblyTask.execute()
-
org.apache.servicemix.jbi.management.task.StopComponentTask.execute()
-
org.apache.servicemix.jbi.management.task.StopServiceAssemblyTask.execute()
-
org.apache.servicemix.jbi.management.task.UndeployServiceAssemblyTask.execute()
-
org.apache.servicemix.jbi.management.task.UninstallComponentTask.execute()
-
org.apache.servicemix.jbi.management.task.UninstallSharedLibraryTask.execute()
-
org.apache.shale.clay.component.chain.CreateComponentCommand.execute()
Creates a new faces component from the component metadata.
@param context common chains
@return
true
if the chain is complete
@exception Exception propagated up to the top of the chain
-
org.apache.shale.clay.component.chain.PropertyValueCommand.execute()
Looks at the {@link AttributeBean} on the {@link ClayContext} to seeif the value is a binding EL. If it is not it just updates the component with the value. If the attribute is a value binding expression, then a ValueBinding
is created. If the attribute uses early binding the ValueBinding
is executed and result applied to the component. Otherwise, the binding expression is applied to the component in a prepared state. A true
value is always returned because this is the default handler.
@param context common chains
@return
true
if the chain is complete
@exception Exception propagated up to the top of the chain
-
org.apache.shindig.gadgets.http.RequestPipeline.execute()
Execute the given request. TODO: This should throw a custom exception type.
-
org.apache.shindig.protocol.RestHandler.execute()
Handle the request and return a Future from which the response object can be retrieved
-
org.apache.shindig.protocol.RpcHandler.execute()
Handle the request and return a Future from which the response object can be retrieved.
-
org.apache.shiro.subject.Subject.execute()
Associates the specified {@code Callable} with this {@code Subject} instance and then executes it on thecurrently running thread. If you want to execute the {@code Callable} on a different thread, it is better touse the {@link #associateWith(Callable)} method instead.
@param callable the Callable to associate with this subject and then execute.
@param < V> the type of return value the {@code Callable} will return
@return the resulting object returned by the {@code Callable}'s execution.
@throws ExecutionException if the {@code Callable}'s {@link Callable#call call} method throws an exception.
@since 1.0
-
org.apache.shiro.subject.support.DelegatingSubject.execute()
-
org.apache.slide.search.SearchQuery.execute()
Method execute
@return a SearchQueryResult
@throws ServiceAccessException
-
org.apache.slide.search.basic.IBasicExpression.execute()
Method execute
@return a Set of RequestedResource objects
@throws SearchException
-
org.apache.sling.commons.threads.ThreadPool.execute()
Execute a runnable
@param runnable The {@link Runnable} to execute
-
org.apache.sling.hc.api.HealthCheck.execute()
Execute this health check and return a {@link Result}This is meant to execute quickly, access to external systems, for example, should be managed asynchronously.
-
org.apache.sling.hc.support.impl.DefaultLoginsHealthCheck.execute()
-
org.apache.sling.installer.api.tasks.InstallTask.execute()
This is the heart of the task - it performs the actual task.
@param ctx The installation context.
-
org.apache.sling.launchpad.base.impl.bootstrapcommands.BootstrapCommandFile.execute()
Execute commands if needed, and store execution timestamp
@return If system bundle needs a restart.
-
org.apache.sling.replication.agent.ReplicationAgent.execute()
executes a {@link ReplicationRequest}
@param replicationRequest the replication request
@param resourceResolver the resource resolver used for authenticating the request,
@return a {@link ReplicationResponse}
@throws ReplicationAgentException if any error happens during the execution of the request or if the authentication fails
-
org.apache.sling.testing.tools.http.RequestExecutor.execute()
-
org.apache.solr.core.SolrCore.execute()
Get a {@link SolrIndexSearcher} or start the process of creating a new one.
The registered searcher is the default searcher used to service queries. A searcher will normally be registered after all of the warming and event handlers (newSearcher or firstSearcher events) have run. In the case where there is no registered searcher, the newly created searcher will be registered before running the event handlers (a slow searcher is better than no searcher).
These searchers contain read-only IndexReaders. To access a non read-only IndexReader, see newSearcher(String name, boolean readOnly).
If forceNew==true then A new searcher will be opened and registered regardless of whether there is already a registered searcher or other searchers in the process of being created.
If forceNew==false then:
- If a searcher is already registered, that searcher will be returned
- If no searcher is currently registered, but at least one is in the process of being created, then this call will block until the first searcher is registered
- If no searcher is currently registered, and no searchers in the process of being registered, a new searcher will be created.
If returnSearcher==true then a {@link RefCounted}< {@link SolrIndexSearcher}> will be returned with the reference count incremented. It must be decremented when no longer needed.
If waitSearcher!=null and a new {@link SolrIndexSearcher} was created,then it is filled in with a Future that will return after the searcher is registered. The Future may be set to null in which case the SolrIndexSearcher created has already been registered at the time this method returned.
@param forceNew if true, force the open of a new index searcher regardless if there is already one open.
@param returnSearcher if true, returns a {@link SolrIndexSearcher} holder with the refcount already incremented.
@param waitSearcher if non-null, will be filled in with a {@link Future} that will return after the new searcher is registered.
@throws IOException
-
org.apache.stanbol.commons.jobs.api.JobManager.execute()
Adds and runs an asynch process. Returns the String id to use for pinging its execution.
@param task
@return
-
org.apache.stanbol.commons.testing.http.RequestExecutor.execute()
Executes a {@link Request} using this executor.
Note that this cleans up all data of the previous executed request.
@param r the request to execute
@return this
@throws ClientProtocolException
@throws IOException
-
org.apache.stanbol.entityhub.ldpath.EntityhubLDPath.execute()
Executes the parsed {@link Program} and stores the {@link Program#getFields() fields} in a {@link Representation}. The actual implementation used for the {@link Representation} depends on the{@link ValueFactory} of this EntityhubLDPath instance
@param context the context
@param program the program
@return the {@link Representation} holding the results of the execution
@throws IllegalArgumentException if the parsed context or the program isnull
-
org.apache.stratos.cloud.controller.concurrent.ThreadExecutor.execute()
-
org.apache.struts.action.Action.execute()
Process the specified non-HTTP request, and create the corresponding non-HTTP response (or forward to another web component that will create it), with provision for handling exceptions thrown by the business logic. Return an {@link ActionForward} instance describing where andhow control should be forwarded, or null
if the response has already been completed.
The default implementation attempts to forward to the HTTP version of this method.
@param mapping The ActionMapping used to select this instance
@param form The optional ActionForm bean for this request (if any)
@param request The non-HTTP request we are processing
@param response The non-HTTP response we are creating
@return The forward to which control should be transferred, or
null
if the response has been completed.
@throws Exception if the application business logic throws anexception.
@since Struts 1.1
-
org.apache.struts.action.ExceptionHandler.execute()
Handle the Exception. Return the ActionForward instance (if any) returned by the called ExceptionHandler.
@param ex The exception to handle
@param ae The ExceptionConfig corresponding to the exception
@param mapping The ActionMapping we are processing
@param formInstance The ActionForm we are processing
@param request The servlet request we are processing
@param response The servlet response we are creating
@return The
ActionForward
instance (if any) returned bythe called
ExceptionHandler
.
@throws ServletException if a servlet exception occurs
@since Struts 1.1
-
org.apache.struts.tiles.Controller.execute()
Method associated to a tile and called immediately before the tile is included.
@param tileContext Current tile context.
@param request Current request
@param response Current response
@param servletContext Current servlet context
-
org.apache.struts2.jasper.JspC.execute()
Executes the compilation.
@throws JasperException If an error occurs
-
org.apache.struts2.views.freemarker.FreemarkerResult.execute()
-
org.apache.synapse.commons.executors.PriorityExecutor.execute()
Execute a given task with the priority specified. If the task throws an exception, it will be captured and logged to prevent the threads from dying.
@param task task to be executed
@param priority priority of the task
-
org.apache.synapse.startup.Task.execute()
Esecute method will be invoked by the SimpleQuartzStartup
-
org.apache.synapse.task.Task.execute()
Execute method will be invoked by the QuartzJOb.
-
org.apache.tapestry.ComponentAction.execute()
Passed a component instance, the action should operate upon the instance.
-
org.apache.tapestry.IScript.execute()
Executes the script, which will read and modify the symbols {@link Map}. The script works with the {@link IScriptProcessor} to get the generated JavaScriptincluded on the page.
@param cycle the current request cycle
@param processor an object that processes the results of the script, typicallyan instance of {@link org.apache.tapestry.html.Body}
@param symbols Map of input symbols; execution of the script may modify the map,creating new output symbols
@see org.apache.tapestry.html.Body#get(IRequestCycle)
-
org.apache.tapestry.test.assertions.AssertOutput.execute()
-
org.apache.tapestry.test.assertions.AssertRegexp.execute()
-
org.apache.tapestry5.ComponentAction.execute()
Passed a component instance, the action should operate upon the instance.
-
org.apache.tiles.preparer.ViewPreparer.execute()
Method associated to a tile and called immediately before the tile is included.
@param tilesContext Current tiles application context.
@param attributeContext Current tile context.
@throws PreparerException If something goes wrong during execution.
-
org.apache.tiles.request.freemarker.autotag.FreemarkerAutotagRuntime.execute()
{@inheritDoc}
-
org.apache.tomcat.task.Expand.execute()
Do the work.
@exception BuildException Thrown in unrecoverable error.
-
org.apache.tomcat.util.threads.DedicatedThreadExecutor.execute()
Executes the given {@link Callable} with the thread spawned for thecurrent {@link DedicatedThreadExecutor} instance, and returns its result.
@param < V> the type of the returned value
@param callable
@return the completed result
-
org.apache.tomee.webapp.command.CommandExecutor.execute()
-
org.apache.tomee.webapp.command.impl.RunInstaller.execute()
-
org.apache.tomee.webapp.command.impl.RunScript.execute()
-
org.apache.tomee.webapp.installer.Runner.execute()
-
org.apache.tools.ant.Target.execute()
-
org.apache.tools.ant.Task.execute()
Called by the project to let the task do it's work. Normally it does nothing.
@throws BuildException if someting goes wrong with the build
-
org.apache.tools.ant.UnknownElement.execute()
Executes the real object if it's a task. If it's not a task (e.g. a data type) then this method does nothing.
-
org.apache.tools.ant.taskdefs.Ant.execute()
Do the execution.
-
org.apache.tools.ant.taskdefs.BZip2.execute()
-
org.apache.tools.ant.taskdefs.CallTarget.execute()
hand off the work to the ant task of ours, after setting it up
@throws BuildException on validation failure or if the target didn'texecute
-
org.apache.tools.ant.taskdefs.Checksum.execute()
Calculate the checksum(s).
-
org.apache.tools.ant.taskdefs.Chmod.execute()
-
org.apache.tools.ant.taskdefs.Copy.execute()
Perform the copy operation.
@exception BuildException if an error occurs.
-
org.apache.tools.ant.taskdefs.Delete.execute()
-
org.apache.tools.ant.taskdefs.Echo.execute()
Does the work.
@exception BuildException if something goes wrong with the build
-
org.apache.tools.ant.taskdefs.ExecTask.execute()
Do the work.
@throws BuildException in a number of circumstances:
- if failIfExecFails is set to true and the process cannot be started
- the java13command launcher can send build exceptions
- this list is not exhaustive or limitative
-
org.apache.tools.ant.taskdefs.Execute.execute()
Creates a new execute object using PumpStreamHandler
for stream handling.
-
org.apache.tools.ant.taskdefs.ExecuteJava.execute()
-
org.apache.tools.ant.taskdefs.Expand.execute()
Do the work.
@exception BuildException Thrown in unrecoverable error.
-
org.apache.tools.ant.taskdefs.FixCRLF.execute()
Executes the task.
-
org.apache.tools.ant.taskdefs.GZip.execute()
-
org.apache.tools.ant.taskdefs.Get.execute()
Does the work.
@exception BuildException Thrown in unrecovrable error.
-
org.apache.tools.ant.taskdefs.ImportTask.execute()
This relies on the task order model.
-
org.apache.tools.ant.taskdefs.Jar.execute()
-
org.apache.tools.ant.taskdefs.Java.execute()
Do the execution.
-
org.apache.tools.ant.taskdefs.Javac.execute()
Executes the task.
-
org.apache.tools.ant.taskdefs.Javadoc.execute()
-
org.apache.tools.ant.taskdefs.LoadFile.execute()
read in a source file to a property
@exception BuildException if something goes wrong with the build
-
org.apache.tools.ant.taskdefs.LoadProperties.execute()
load Ant properties from the source file or resource
@exception BuildException if something goes wrong with the build
-
org.apache.tools.ant.taskdefs.MacroInstance.execute()
Execute the templates instance. Copies the unknown element, substitutes the attributes, and calls perform on the unknown element.
-
org.apache.tools.ant.taskdefs.ManifestTask.execute()
Create or update the Manifest when used as a task.
@throws BuildException if the manifest cannot be written.
-
org.apache.tools.ant.taskdefs.MatchingTask.execute()
-
org.apache.tools.ant.taskdefs.Mkdir.execute()
-
org.apache.tools.ant.taskdefs.Move.execute()
Performs the move operation.
-
org.apache.tools.ant.taskdefs.Parallel.execute()
Execute the parallel tasks
@exception BuildException if any of the threads failed.
-
org.apache.tools.ant.taskdefs.Property.execute()
set the property in the project to the value. if the task was give a file, resource or env attribute here is where it is loaded
@throws BuildException on error
-
org.apache.tools.ant.taskdefs.Replace.execute()
Do the execution.
@throws BuildException if we cant build
-
org.apache.tools.ant.taskdefs.SQLExec.execute()
Load the sql file and then execute it
@throws BuildException on error.
-
org.apache.tools.ant.taskdefs.Sequential.execute()
Execute all nestedTasks.
@throws BuildException if one of the nested tasks fails.
-
org.apache.tools.ant.taskdefs.Tar.execute()
-
org.apache.tools.ant.taskdefs.Taskdef.execute()
-
org.apache.tools.ant.taskdefs.TempFile.execute()
Creates the temporary file.
@exception BuildException if something goes wrong with the build
-
org.apache.tools.ant.taskdefs.Touch.execute()
Execute the touch operation.
-
org.apache.tools.ant.taskdefs.Typedef.execute()
-
org.apache.tools.ant.taskdefs.War.execute()
-
org.apache.tools.ant.taskdefs.XSLTProcess.execute()
Executes the task.
@exception BuildException if there is an execution problem.
@todo validate that if either in or our is defined, then both are
-
org.apache.tools.ant.taskdefs.XmlProperty.execute()
Run the task.
@throws BuildException The exception raised during task execution.
@todo validate the source file is valid before opening, print a better error message
@todo add a verbose level log message listing the name of the file being loaded
-
org.apache.tools.ant.taskdefs.Zip.execute()
validate and build
-
org.apache.tools.ant.taskdefs.compilers.CompilerAdapter.execute()
Executes the task.
@return has the compilation been successful
-
org.apache.tools.ant.taskdefs.optional.ANTLR.execute()
-
org.apache.tools.ant.taskdefs.optional.ReplaceRegExp.execute()
Execute the task
@throws BuildException is there is a problem in the task execution.
-
org.apache.tools.ant.taskdefs.optional.junit.JUnitTask.execute()
Runs the testcase.
@throws BuildException in case of test failures or errors
@since Ant 1.2
-
org.apache.tools.ant.taskdefs.optional.junit.XMLResultAggregator.execute()
Aggregate all testsuites into a single document and write it to the specified directory and file.
@throws BuildException thrown if there is a serious error while writingthe document.
-
org.apache.tools.ant.taskdefs.optional.unix.Symlink.execute()
The standard method for executing any task.
@throws BuildException on error.
-
org.apache.tools.ant.taskdefs.rmic.RmicAdapter.execute()
Executes the task.
@return has the compilation been successful
-
org.apache.torque.engine.database.transform.SQLToAppData.execute()
Execute the parser.
@throws IOException If an I/O error occurs
@throws ParseException error parsing the input file
-
org.apache.torque.generator.maven.TorqueGeneratorMojo.execute()
Configures and runs the Torque generator.
-
org.apache.torque.generator.outlet.Outlet.execute()
Generates the output for this template into the Generated object.
@param controllerState the current controller state, not null.
@return the output of the Outlet.
@throws GeneratorException if generation fails.
-
org.apache.torque.task.TorqueDataModelTask.execute()
This method creates an VelocityEngine instance, parses every template and creates the corresponding output. Unfortunately the TextenTask.execute() method makes everything for us but we just want to set our own VelocityTemplateLoader. TODO: change once TEXEN-14 is resolved and out.
@see org.apache.texen.ant.TexenTask#execute()
-
org.apache.torque.task.TorqueSQLExec.execute()
Load the sql file and then execute it
@throws BuildException
-
org.apache.torque.task.TorqueSQLTask.execute()
-
org.apache.turbine.torque.engine.database.transform.SQLToAppData.execute()
Execute the parser.
-
org.apache.tuscany.das.rdb.ApplyChangesCommand.execute()
The change history is scanned and modifications to the graph of data objects are flushed to the database.
@param root the topmost containing data object
-
org.apache.tuscany.das.rdb.Command.execute()
Performs the function defined by the command
-
org.apache.uima.ducc.cli.DuccManagedReservationSubmit.execute()
Execute collects the job parameters, does basic error and correctness checking, and sends the job properties to the DUCC orchestrator for execution.
@return True if the orchestrator accepts the job; false otherwise.
-
org.apache.uima.ducc.common.launcher.ssh.DuccRemoteLauncher.execute()
-
org.apache.velocity.runtime.parser.node.ASTReference.execute()
gets an Object that 'is' the value of the reference
@param o unused Object parameter
@param context context used to generate value
@return The execution result.
@throws MethodInvocationException
-
org.apache.velocity.runtime.parser.node.SimpleNode.execute()
-
org.apache.vysper.xmpp.modules.core.base.handler.IQHandler.execute()
-
org.apache.vysper.xmpp.protocol.StanzaHandler.execute()
executes a stanza
@param stanza
@param serverRuntimeContext
@param isOutboundStanza true, if the stanza was emitted by the client which is handled by the session belonging to the given sessionContext parameter. false, if the session is receiving the stanza targeted to the session's client.
@param sessionContext
@param sessionStateHolder
@return optionally returns a response which is passed to the session's client
-
org.apache.webdav.lib.methods.MkcolMethod.execute()
-
org.apache.webdav.lib.methods.OptionsMethod.execute()
-
org.apache.webdav.lib.methods.PropFindMethod.execute()
-
org.apache.webdav.lib.methods.PropPatchMethod.execute()
-
org.apache.webdav.lib.methods.SearchMethod.execute()
-
org.apache.webdav.ui.lib.methods.SPHeadMethod.execute()
-
org.apache.whirr.actions.BootstrapClusterAction.execute()
-
org.apache.whirr.actions.ByonClusterAction.execute()
-
org.apache.whirr.actions.CleanupClusterAction.execute()
-
org.apache.whirr.actions.ConfigureClusterAction.execute()
-
org.apache.whirr.actions.ConfigureServicesAction.execute()
-
org.apache.whirr.actions.DestroyClusterAction.execute()
-
org.apache.whirr.actions.StartServicesAction.execute()
-
org.apache.whirr.actions.StopServicesAction.execute()
-
org.apache.whirr.cluster.actions.BootstrapClusterAction.execute()
-
org.apache.whirr.cluster.actions.ConfigureClusterAction.execute()
-
org.apache.whirr.cluster.actions.DestroyClusterAction.execute()
-
org.apache.wicket.cluster.session.message.SessionMessage.execute()
-
org.apache.wicket.request.RequestHandlerStack.execute()
@param handler
-
org.apache.wiki.api.engine.PluginManager.execute()
Executes a plugin class in the given context.
Used to be private, but is public since 1.9.21.
@param context The current WikiContext.
@param classname The name of the class. Can also be ashortened version without the package name, since the class name is searched from the package search path.
@param params A parsed map of key-value pairs.
@return Whatever the plugin returns.
@throws PluginException If the plugin execution failed forsome reason.
@since 2.0
-
org.apache.wiki.api.plugin.WikiPlugin.execute()
This is the main entry point for any plugin. The parameters are parsed, and a special parameter called "_body" signifies the name of the plugin body, i.e. the part of the plugin that is not a parameter of the form "key=value". This has been separated using an empty line.
Note that it is preferred that the plugin returns XHTML-compliant HTML (i.e. close all tags, use <br /> instead of <br>, etc.
@param context The current WikiContext.
@param params A Map which contains key-value pairs. Anyparameter that the user has specified on the wiki page will contain String-String parameters, but it is possible that at some future date, JSPWiki will give you other things that are not Strings.
@return HTML, ready to be included into the rendered page.
@throws PluginException In case anything goes wrong.
-
org.apache.wiki.dav.methods.DavMethod.execute()
-
org.apache.wiki.dav.methods.GetMethod.execute()
-
org.apache.wiki.dav.methods.PropFindMethod.execute()
-
org.apache.wiki.plugin.PluginManager.execute()
{@inheritDoc}
@deprecated Remains because of old API compatobility; will be removed in 2.10 scope. Consider using {@link DefaultPluginManager#execute(WikiContext,String,Map)} instead
-
org.apache.ws.security.action.Action.execute()
-
org.apache.wss4j.dom.action.Action.execute()
-
org.apache.xalan.templates.ElemExsltFunction.execute()
-
org.apache.xalan.templates.ElemTemplate.execute()
Copy the template contents into the result tree. The content of the xsl:template element is the template that is instantiated when the template rule is applied.
@param transformer non-null reference to the the current transform-time state.
@throws TransformerException
-
org.apache.xalan.templates.ElemTemplateElement.execute()
Execute the element's primary function. Subclasses of this function may recursivly execute down the element tree.
@param transformer The XSLT TransformerFactory.
@param sourceNode The current context node.
@param mode The current mode.
@throws TransformerException if any checked exception occurs.
-
org.apache.xalan.xpath.XPath.execute()
Given an expression and a context, return the result.
@param expression The expression.
@param node The node that "." expresses.
@param namespaceContext The context in which namespaces in the queries are supposed to be expanded.
@exception XSLProcessorException thrown if the active ProblemListener and XMLParserLiaison decide the error condition is severe enough to halt processing.
-
org.apache.xindice.tools.command.Command.execute()
-
org.apache.xindice.webadmin.viewer.HtmlCollectionViewer.execute()
Executes request to a collection.
@param req request from servlet.
@param res servlet response.
@param col requested collection (not null).
-
org.apache.xindice.webadmin.viewer.HtmlDatabaseViewer.execute()
executes request to a collection.
@param req request from servlet.
@param res servlet response.
-
org.apache.xindice.webadmin.viewer.HtmlResourceViewer.execute()
executes request to a resource.
@param req request from servlet.
@param res servlet response.
@param col parent collection of the requested resource (not null).
@param resourceName name of the requested resource.
-
org.apache.xindice.webadmin.webdav.components.DAVComponent.execute()
Executes request to a target location, that can be either root ("/"), collection, resource or an unknown location.
@param req WebDAV request
@param res WebDAV servlet
@param target target location
-
org.apache.xmlgraphics.image.loader.pipeline.ImageProviderPipeline.execute()
Executes the image converter pipeline. First, the image indicated by the ImageInfo instance is loaded through an ImageLoader and then optionally converted by a series of ImageConverters. At the end of the pipeline, the fully loaded and converted image is returned.
@param info the image info object indicating the image to load
@param hints a Map of image conversion hints
@param context the session context
@return the requested image
@throws ImageException if an error occurs while loader or converting the image
@throws IOException if an I/O error occurs
-
org.apache.xmlgraphics.util.dijkstra.DijkstraAlgorithm.execute()
Run Dijkstra's shortest path algorithm. After this method is finished you can use {@link #getPredecessor(Vertex)} to reconstruct the best/shortest path starting from thedestination backwards.
@param start the starting vertex
@param destination the destination vertex.
-
org.apache.xmlrpc.XmlRpcClient.execute()
Generate an XML-RPC request and send it to the server. Parse the result and return the corresponding Java object.
@exception XmlRpcException : If the remote host returned a fault message.
@exception IOException : If the call could not be made because of lower level problems.
-
org.apache.xmlrpc.XmlRpcClientLite.execute()
-
org.apache.xmlrpc.XmlRpcHandler.execute()
Return the result, or throw an Exception if something went wrong.
-
org.apache.xmlrpc.XmlRpcServer.execute()
Parse the request and execute the handler method, if one is found. Returns the result as XML. The calling Java code doesn't need to know whether the call was successful or not since this is all packed into the response.
-
org.apache.xmlrpc.client.XmlRpcClient.execute()
Performs a request with the clients default configuration.
@param pMethodName The method being performed.
@param pParams The parameters.
@return The result object.
@throws XmlRpcException Performing the request failed.
-
org.apache.xmlrpc.common.XmlRpcRequestProcessor.execute()
Processes the given request and returns a result object.
@throws XmlRpcException Processing the request failed.
-
org.apache.xmlrpc.common.XmlRpcWorker.execute()
Performs a synchronous request. The client worker extends this interface with the ability to perform asynchronous requests.
@param pRequest The request being performed.
@return The requests result.
@throws XmlRpcException Performing the request failed.
-
org.apache.xmlrpc.server.XmlRpcServer.execute()
Performs the given request.
@param pRequest The request being executed.
@return The result object.
@throws XmlRpcException The request failed.
-
org.apache.xpath.Expression.execute()
Execute an expression in the XPath runtime context, and return the result of the expression.
@param xctxt The XPath runtime context.
@param currentNode The currentNode.
@return The result of the expression in the form of a XObject
.
@throws javax.xml.transform.TransformerException if a runtime exceptionoccurs.
-
org.apache.xpath.XPath.execute()
Given an expression and a context, evaluate the XPath and return the result.
@param xctxt The execution context.
@param contextNode The node that "." expresses.
@param namespaceContext The context in which namespaces in theXPath are supposed to be expanded.
@return The result of the XPath or null if callbacks are used.
@throws TransformerException thrown ifthe error condition is severe enough to halt processing.
@throws javax.xml.transform.TransformerException
-
org.apache.xpath.functions.Function.execute()
Execute an XPath function object. The function must return a valid object.
@param xctxt The execution current context.
@return A valid XObject.
@throws javax.xml.transform.TransformerException
-
org.apache.xpath.objects.XObject.execute()
For support of literal objects in xpaths.
@param xctxt The XPath execution context.
@return This object.
@throws javax.xml.transform.TransformerException
-
org.appfuse.mojo.HibernateExporterMojo.execute()
@see org.apache.maven.plugin.Mojo#execute()
-
org.appfuse.tool.ArtifactInstaller.execute()
-
org.appfuse.tool.ArtifactUninstaller.execute()
-
org.appfuse.tool.RenamePackages.execute()
This is the main method that gets invoked when ANT calls this task
-
org.araneaframework.backend.list.helper.HSqlListSqlHelper.execute()
-
org.arquillian.spacelift.process.impl.CommandTool.execute()
-
org.aspectj.apache.bcel.verifier.structurals.InstructionContext.execute()
This method symbolically executes the Instruction held in the InstructionContext. It "merges in" the incoming execution frame situation (see The Java Virtual Machine Specification, 2nd edition, page 146). By so doing, the outgoing execution frame situation is calculated. This method is JustIce-specific and is usually of no sense for users of the ControlFlowGraph class. They should use getInstruction().accept(Visitor), possibly in conjunction with the ExecutionVisitor.
@see ControlFlowGraph
@see ExecutionVisitor
@see #getOutFrame(ArrayList)
@return true - if and only if the "outgoing" frame situationchanged from the one before execute()ing.
-
org.asynchttpclient.BoundRequestBuilder.execute()
-
org.atomojo.app.db.sparql.QueryContext.execute()
-
org.beangle.ems.rule.engine.Engine.execute()
-
org.beangle.ems.rule.engine.RuleExecutor.execute()
-
org.beangle.ems.rule.engine.impl.SimpleEngine.execute()
-
org.beangle.rule.engine.Engine.execute()
-
org.beangle.rule.engine.RuleExecutor.execute()
-
org.beangle.rule.engine.impl.SimpleEngine.execute()
-
org.blueoxygen.common.dal.DbBean.execute()
-
org.boris.xlloop.IFunction.execute()
-
org.boris.xlloop.IFunctionHandler.execute()
-
org.boris.xlloop.script.ScriptRepository.execute()
-
org.broad.igv.batch.CommandExecutor.execute()
-
org.broadinstitute.gatk.engine.GenomeAnalysisEngine.execute()
Actually run the GATK with the specified walker.
@return the value of this traversal.
-
org.broadinstitute.gatk.engine.executive.MicroScheduler.execute()
Walks a walker over the given list of intervals.
@param walker Computation to perform over dataset.
@param shardStrategy A strategy for sharding the data.
@return the return type of the walker
-
org.caffinitas.mapper.core.CqlStatementList.execute()
Execute the statements in this container against the provided session.
@param session sesion to execute the statements against
-
org.camunda.bpm.application.ProcessApplicationInterface.execute()
The default implementation simply modifies the Context {@link ClassLoader}
@param callable the callable to be executed "within" the context of this process application.
@return the result of the callback
@throws Exception
-
org.camunda.bpm.engine.impl.bpmn.parser.BpmnParse.execute()
-
org.camunda.bpm.engine.impl.cmd.ActivateJobDefinitionCmd.execute()
-
org.camunda.bpm.engine.impl.cmd.ActivateProcessDefinitionCmd.execute()
-
org.camunda.bpm.engine.impl.cmd.CorrelateAllMessageCmd.execute()
-
org.camunda.bpm.engine.impl.cmd.CorrelateMessageCmd.execute()
-
org.camunda.bpm.engine.impl.cmd.SuspendJobDefinitionCmd.execute()
-
org.camunda.bpm.engine.impl.cmd.SuspendProcessDefinitionCmd.execute()
-
org.camunda.bpm.engine.impl.cmmn.cmd.CreateCaseInstanceCmd.execute()
-
org.camunda.bpm.engine.impl.interceptor.CommandExecutor.execute()
-
org.camunda.bpm.engine.impl.interceptor.RetryInterceptor.execute()
-
org.camunda.bpm.engine.impl.jobexecutor.JobHandler.execute()
-
org.camunda.bpm.engine.impl.persistence.deploy.DeleteDeploymentFailListener.execute()
-
org.camunda.bpm.engine.impl.persistence.deploy.DeploymentFailListener.execute()
-
org.camunda.bpm.engine.impl.persistence.entity.JobEntity.execute()
-
org.camunda.bpm.engine.impl.pvm.delegate.ActivityBehavior.execute()
-
org.camunda.bpm.engine.impl.scripting.env.ScriptingEnvironment.execute()
execute a given script in the environment
@param script the {@link ExecutableScript} to execute
@param scope the scope in which to execute the script
@return the result of the script evaluation
-
org.camunda.bpm.qa.performance.engine.framework.aggregate.SqlStatementCountAggregator.execute()
-
org.camunda.bpm.qa.performance.engine.framework.report.HtmlReportBuilder.execute()
-
org.cfeclipse.cfml.snippets.commands.InsertSnippetCommand.execute()
-
org.chiba.tools.schemabuilder.Schema2XForms.execute()
-
org.chromium.debug.core.model.PushChangesPlan.execute()
-
org.cishell.framework.algorithm.Algorithm.execute()
Executes and optionally returns a Data array
@return A Data array that was created. null
is ONLY acceptablewhen the algorithms out_data is null.
@throws AlgorithmExecutionException An exception has occured while executingthe algorithm. This exception should have a user-comprehendable message if at all possible.
-
org.cishell.testing.convertertester.core.converter.graph.Converter.execute()
-
org.cishell.testing.convertertester.core.tester2.ConverterTester2.execute()
-
org.codehaus.activemq.service.TransactionTask.execute()
-
org.codehaus.enunciate.main.Enunciate.execute()
Execute the mechanism.
-
org.codehaus.groovy.ant.Groovyc.execute()
Executes the task.
@throws BuildException if an error occurs
-
org.codehaus.groovy.tools.shell.Groovysh.execute()
-
org.codehaus.mojo.build.git.GitBranchParseCommand.execute()
-
org.codehaus.mojo.cobertura.tasks.CheckTask.execute()
-
org.codehaus.mojo.cobertura.tasks.InstrumentTask.execute()
-
org.codehaus.plexus.action.Action.execute()
-
org.codehaus.plexus.container.initialization.ContainerInitializationPhase.execute()
-
org.codehaus.plexus.interpolation.InterpolationPostProcessor.execute()
Given the starting expression and the fully-recursively-interpolated value, perform some post-processing step and return the resulting [possibly different] value, or null if no change was made..
@param expression the original expression
@param value the original value after fully recursive interpolation of expression
@return the processed value if a change was made; else return null
-
org.codehaus.plexus.lifecycle.phase.Phase.execute()
Execute the phase.
-
org.codehaus.plexus.util.Expand.execute()
Do the work.
@exception Exception Thrown in unrecoverable error.
-
org.codehaus.plexus.util.cli.Commandline.execute()
Executes the command.
-
org.codehaus.xfire.gen.WsGenTask.execute()
-
org.codehaus.xfire.gen.WsdlGenTask.execute()
-
org.contikios.cooja.TimeEvent.execute()
-
org.contikios.cooja.mspmote.MspMoteTimeEvent.execute()
-
org.corrib.s3b.mbb.service.RdfMetaService.execute()
-
org.corrib.s3b.sscf.trust.SSCFTrustEngineExecuter.execute()
-
org.crsh.shell.ShellProcess.execute()
Begin the process. The client of this method should make no assumption whether the process is executed in a synchronous or asynchronous manner. The process will be termined when the process signals it with an invocation of the {@link ShellProcessContext#end(ShellResponse)} method.
@param processContext the process context
@throws IllegalStateException if the process is already executing or has been executed
-
org.cyclopsgroup.jmxterm.Command.execute()
Execute command
@throws IOException IO errors
@throws JMException JMX errors
-
org.cyclopsgroup.jmxterm.cc.CommandCenter.execute()
Execute a command. Command can be a valid full command, a comment, command followed by comment or empty
@param command String command to execute
@return True if successful
-
org.damour.base.client.ui.authentication.CreateNewAccountCommand.execute()
-
org.databene.dbsanity.DbSanity.execute()
-
org.datanucleus.enhancer.asm.method.DefaultConstructor.execute()
Method to add the contents of the class method.
-
org.datanucleus.enhancer.asm.method.InitClass.execute()
Method to add the contents of the class method.
-
org.datanucleus.query.evaluator.JDOQLEvaluator.execute()
-
org.datanucleus.query.evaluator.JPQLEvaluator.execute()
-
org.datanucleus.query.evaluator.JavaQueryEvaluator.execute()
Method to perform the evaluation, applying the query restrictions that are required.
@param applyFilter Whether to apply any filter constraints on the results
@param applyOrdering Whether to apply any order constraints on the results
@param applyResult Whether to apply any result/grouping/having on the results
@param applyResultClass Whether to apply any resultClass constraint on the results
@param applyRange Whether to apply any range constraint on the results
@return The results after evaluation.
-
org.datanucleus.store.query.Query.execute()
Execute the query and return the filtered results.
@return the filtered results (List, or Object).
@see #executeWithArray(Object[] parameters)
-
org.datanucleus.store.rdbms.request.Request.execute()
Method to execute the request - to be implemented by deriving classes.
@param sm The StateManager for the object in question.
-
org.dbunit.operation.DatabaseOperation.execute()
Executes this operation on the specified database using the specified dataset contents.
@param connection the database connection.
@param dataSet the dataset to be used by this operation.
-
org.dmlite.model.action.EntitiesAction.execute()
Executes the action.
@return true
if executed
@throws dmLite action exception if there is a problem
-
org.dmlite.model.action.RemoveAction.execute()
-
org.dmlite.model.action.Transaction.execute()
Executes the transaction.
@return true
if executed
-
org.drools.StatelessSession.execute()
Insert a single fact, an fire the rules, returning when finished.
-
org.drools.command.CommandService.execute()
-
org.drools.command.SingleSessionCommandService.execute()
-
org.drools.command.impl.CommandBasedStatefulKnowledgeSession.execute()
-
org.drools.command.impl.GenericCommand.execute()
-
org.drools.common.WorkingMemoryAction.execute()
-
org.drools.core.StatelessSession.execute()
Insert a single fact, an fire the rules, returning when finished.
-
org.drools.core.command.CommandService.execute()
-
org.drools.core.command.impl.CommandBasedStatefulKnowledgeSession.execute()
-
org.drools.core.common.WorkingMemoryAction.execute()
-
org.drools.core.reteoo.test.dsl.Step.execute()
-
org.drools.eventmessaging.EventResponseHandler.execute()
-
org.drools.persistence.SingleSessionCommandService.execute()
-
org.drools.reteoo.test.dsl.Step.execute()
-
org.drools.runtime.CommandExecutor.execute()
Execute the command and return a ExecutionResults for the results of the Command.
@param command
@return
-
org.drools.runtime.StatefulKnowledgeSession.execute()
-
org.drools.runtime.StatelessKnowledgeSession.execute()
-
org.drools.scm.ScmActionFactory.execute()
-
org.drools.spi.Action.execute()
-
org.dru.clay.google.code.upload.GoogleCodeUploader.execute()
Just calls {@link #upload()}, wrapping any exceptions it might throw in a BuildException.
-
org.easycassandra.persistence.cassandra.BatchBuilder.execute()
-
org.eclipse.core.commands.Command.execute()
Executes this command by delegating to the current handler, if any. If the debugging flag is set, then this method prints information about which handler is selected for performing this command. This method will succeed regardless of whether the command is enabled or defined. It is generally preferred to call {@link #executeWithChecks(ExecutionEvent)}.
@param event An event containing all the information about the current state of the application; must not be null
.
@return The result of the execution; may be null
. Thisresult will be available to the client executing the command, and execution listeners.
@throws ExecutionException If the handler has problems executing this command.
@throws NotHandledException If there is no handler.
@deprecated Please use {@link #executeWithChecks(ExecutionEvent)}instead.
-
org.eclipse.core.commands.operations.IOperationHistory.execute()
Execute the specified operation and add it to the operations history if successful. This method is used by clients who wish operation history listeners to receive notifications before and after the execution of the operation. Execution of the operation is subject to approval by any registered {@link IOperationApprover2}. If execution is approved, listeners will be notified before (ABOUT_TO_EXECUTE
) and after (DONE
or OPERATION_NOT_OK
).
If the operation successfully executes, an additional notification that the operation has been added to the history (OPERATION_ADDED
) will be sent.
@param operation the operation to be executed and then added to the history
@param monitor the progress monitor to be used (or
null
) during the operation.
@param info the IAdaptable (or
null
) provided by the caller in order to supply UI information for prompting the user if necessary. When this parameter is not
null
, it should minimally contain an adapter for the org.eclipse.swt.widgets.Shell.class.
@return the IStatus indicating whether the execution succeeded.
The severity code in the returned status describes whether the operation succeeded and whether it was added to the history. OK
severity indicates that the execute operation was successful and that the operation has been added to the history. Listeners will receive notifications about the operation's success (DONE
) and about the operation being added to the history (OPERATION_ADDED
).
CANCEL
severity indicates that the user cancelled the operation and that the operation was not added to the history. ERROR
severity indicates that the operation did not successfully execute and that it was not added to the history. Any other severity code is not specifically interpreted by the history, and the operation will not be added to the history. For all severities other than OK
, listeners will receive the OPERATION_NOT_OK
notification instead of the DONE
notification if the execution was approved and attempted.
@throws ExecutionException if an exception occurred during execution.
-
org.eclipse.core.filebuffers.manipulation.FileBufferOperationRunner.execute()
-
org.eclipse.e4.xwt.input.ICommand.execute()
-
org.eclipse.ecf.core.jobs.JobsExecutor.execute()
-
org.eclipse.ecf.internal.bulletinboard.commons.webapp.GetRequest.execute()
-
org.eclipse.ecf.internal.bulletinboard.commons.webapp.PostRequest.execute()
-
org.eclipse.ecf.internal.bulletinboard.commons.webapp.WebRequest.execute()
-
org.eclipse.ecf.provider.irc.internal.bot.ICommandEntry.execute()
-
org.eclipse.egit.core.op.AddToIndexOperation.execute()
-
org.eclipse.egit.core.op.BranchOperation.execute()
-
org.eclipse.egit.core.op.CherryPickOperation.execute()
-
org.eclipse.egit.core.op.CommitOperation.execute()
-
org.eclipse.egit.core.op.ConnectProviderOperation.execute()
-
org.eclipse.egit.core.op.CreateLocalBranchOperation.execute()
-
org.eclipse.egit.core.op.CreatePatchOperation.execute()
-
org.eclipse.egit.core.op.DeleteBranchOperation.execute()
-
org.eclipse.egit.core.op.DeletePathsOperation.execute()
-
org.eclipse.egit.core.op.DeleteTagOperation.execute()
-
org.eclipse.egit.core.op.DiscardChangesOperation.execute()
-
org.eclipse.egit.core.op.DisconnectProviderOperation.execute()
-
org.eclipse.egit.core.op.EditCommitOperation.execute()
-
org.eclipse.egit.core.op.GarbageCollectOperation.execute()
Execute garbage collection
-
org.eclipse.egit.core.op.IgnoreOperation.execute()
-
org.eclipse.egit.core.op.MergeOperation.execute()
-
org.eclipse.egit.core.op.RebaseOperation.execute()
-
org.eclipse.egit.core.op.RemoveFromIndexOperation.execute()
-
org.eclipse.egit.core.op.ResetOperation.execute()
-
org.eclipse.egit.core.op.RevertCommitOperation.execute()
-
org.eclipse.egit.core.op.RewordCommitOperation.execute()
-
org.eclipse.egit.core.op.SquashCommitsOperation.execute()
-
org.eclipse.egit.core.op.StashApplyOperation.execute()
-
org.eclipse.egit.core.op.StashCreateOperation.execute()
-
org.eclipse.egit.core.op.StashDropOperation.execute()
-
org.eclipse.egit.core.op.SubmoduleAddOperation.execute()
-
org.eclipse.egit.core.op.SubmoduleSyncOperation.execute()
-
org.eclipse.egit.core.op.SubmoduleUpdateOperation.execute()
-
org.eclipse.egit.core.op.TagOperation.execute()
-
org.eclipse.egit.core.op.UntrackOperation.execute()
-
org.eclipse.egit.ui.internal.commands.shared.AbstractRebaseCommandHandler.execute()
Executes the given {@link RebaseOperation}
@param rebase
@throws ExecutionException
-
org.eclipse.egit.ui.internal.commands.shared.RebaseCurrentRefCommand.execute()
-
org.eclipse.egit.ui.internal.fetch.FetchOperationUI.execute()
Executes this directly, without showing a confirmation dialog
@param monitor
@return the result of the operation
@throws CoreException
-
org.eclipse.egit.ui.internal.pull.PullOperationUI.execute()
Starts this operation synchronously.
@param monitor
-
org.eclipse.egit.ui.internal.push.PushOperationUI.execute()
Executes this directly, without showing a confirmation dialog
@param monitor
@return the result of the operation
@throws CoreException
-
org.eclipse.emf.common.command.BasicCommandStack.execute()
-
org.eclipse.emf.common.command.Command.execute()
Performs the command activity required for the effect. The effect of calling execute
when canExecute
returns false
, or when canExecute
hasn't been called, is undefined.
-
org.eclipse.emf.common.command.CommandStack.execute()
Clears any redoable commands not yet redone, adds the command, and then executes the command.
@param command the command to execute.
-
org.eclipse.emf.common.command.CompoundCommand.execute()
Calls {@link Command#execute} for each command in the list.
-
org.eclipse.emf.edit.command.RemoveCommand.execute()
-
org.eclipse.emf.edit.command.SetCommand.execute()
-
org.eclipse.emf.query.statements.SELECT.execute()
-
org.eclipse.emf.workspace.AbstractEMFOperation.execute()
-
org.eclipse.gef.commands.Command.execute()
-
org.eclipse.gef.commands.CommandStack.execute()
-
org.eclipse.gef.commands.CompoundCommand.execute()
-
org.eclipse.gmf.runtime.common.core.command.ICommand.execute()
-
org.eclipse.gmf.runtime.diagram.core.commands.DeleteCommand.execute()
-
org.eclipse.gmf.runtime.emf.commands.core.command.AbstractTransactionalCommand.execute()
-
org.eclipse.graphiti.features.ICreateConnectionFeature.execute()
-
org.eclipse.jdt.internal.debug.eval.ast.instructions.Instruction.execute()
-
org.eclipse.jetty.util.thread.ThreadPool.execute()
-
org.eclipse.jface.operation.IRunnableWithProgress.execute()
-
org.eclipse.jgit.lib.BatchRefUpdate.execute()
Execute this batch update.
The default implementation of this method performs a sequential reference update over each reference.
@param walk a RevWalk to parse tags in case the storage system wants to store them pre-peeled, a common performance optimization.
@param monitor progress monitor to receive update status on.
@throws IOException the database is unable to accept the update. Individual command status must be tested to determine if there is a partial failure, or a total failure.
-
org.eclipse.jgit.pgm.TextBuiltin.execute()
Parse arguments and run this command.
@param args command line arguments passed after the command name.
@throws Exception an error occurred while processing the command. The main framework will catch the exception and print a message on standard error.
-
org.eclipse.jst.pagedesigner.commands.DesignerCommand.execute()
executes the Command. This method should not be called if the Command is not executable.
-
org.eclipse.jst.pagedesigner.commands.SourceViewerCommand.execute()
-
org.eclipse.jst.pagedesigner.commands.range.ApplyStyleCommand.execute()
-
org.eclipse.jst.pagedesigner.commands.single.AddSubNodeCommand.execute()
-
org.eclipse.jst.pagedesigner.commands.single.ChangeAttributeCommand.execute()
-
org.eclipse.jst.pagedesigner.commands.single.ChangeStyleCommand.execute()
-
org.eclipse.jst.pagedesigner.itemcreation.command.ContainerCreationCommand.execute()
-
org.eclipse.jst.pagedesigner.itemcreation.command.ElementCustomizationCommand.execute()
-
org.eclipse.m2e.core.embedder.IMaven.execute()
-
org.eclipse.osgi.framework.console.CommandInterpreter.execute()
Execute a command line as if it came from the end user and return the result.
@param cmd The command line to execute.
@return the result of the command.
-
org.eclipse.rap.rwt.client.service.JavaScriptExecutor.execute()
-
org.eclipse.sapphire.sdk.extensibility.ExtensionSummaryExportOp.execute()
-
org.eclipse.sapphire.ui.IExportModelDocumentationOp.execute()
-
org.eclipse.sapphire.ui.SapphireActionHandler.execute()
-
org.eclipse.sapphire.ui.diagram.actions.DiagramNodeAddActionHandler.execute()
-
org.eclipse.sapphire.ui.swt.gef.commands.DoubleClickNodeCommand.execute()
-
org.eclipse.sisu.equinox.launching.internal.P2ApplicationLauncher.execute()
-
org.eclipse.swt.browser.Browser.execute()
Executes the specified script.
Executes a script containing javascript commands in the context of the current document. If document-defined functions or properties are accessed by the script then this method should not be invoked until the document has finished loading (ProgressListener.completed()
gives notification of this).
@param script the script with javascript commands
@return true
if the operation was successful and false
otherwise
@exception IllegalArgumentException
- ERROR_NULL_ARGUMENT - if the script is null
@exception SWTException
- ERROR_THREAD_INVALID_ACCESS when called from the wrong thread
- ERROR_WIDGET_DISPOSED when the widget has been disposed
@see ProgressListener#completed(ProgressEvent)
@since 3.1
-
org.eclipse.swt.program.Program.execute()
Executes the program with the file as the single argument in the operating system. It is the responsibility of the programmer to ensure that the file contains valid data for this program.
@param fileName the file or program name
@return
true
if the file is launched, otherwise
false
@exception IllegalArgumentException
- ERROR_NULL_ARGUMENT when fileName is null
-
org.eclipse.team.internal.ccvs.core.client.RLog.execute()
-
org.eclipse.ui.ide.undo.CreateFileOperation.execute()
-
org.eclipse.ui.ide.undo.CreateFolderOperation.execute()
-
org.eclipse.ui.ide.undo.CreateProjectOperation.execute()
-
org.eclipse.ui.ide.undo.MoveProjectOperation.execute()
-
org.eclipse.ui.internal.intro.impl.model.url.IntroURL.execute()
Executes whatever valid Intro action is embedded in this Intro URL.
-
org.eclipse.ui.intro.config.IIntroURL.execute()
Executes whatever valid Intro command is embedded in this Intro URL. Returns true if action succeeded, and false otherwise.
-
org.eclipse.wst.common.frameworks.datamodel.IDataModelOperation.execute()
-
org.eclipse.wst.xml.ui.internal.dnd.DragNodeCommand.execute()
-
org.ejbca.core.model.approval.ApprovalRequest.execute()
A main function of the ApprovalRequest, the execute() method is run when all required approvals have been made. execute should perform the action or nothing if the requesting admin is supposed to try his action again.
-
org.ejbca.ui.cli.IAdminCommand.execute()
Runs the command
@throws IllegalAdminCommandException Error in command args
@throws ErrorAdminCommandException Error running command
-
org.elasticsearch.action.admin.cluster.health.ClusterHealthRequestBuilder.execute()
-
org.elasticsearch.action.admin.cluster.node.hotthreads.NodesHotThreadsRequestBuilder.execute()
-
org.elasticsearch.action.admin.cluster.node.info.NodesInfoRequestBuilder.execute()
-
org.elasticsearch.action.admin.cluster.node.stats.NodesStatsRequestBuilder.execute()
-
org.elasticsearch.action.admin.cluster.state.ClusterStateRequestBuilder.execute()
-
org.elasticsearch.action.admin.indices.alias.IndicesAliasesRequestBuilder.execute()
-
org.elasticsearch.action.admin.indices.create.CreateIndexRequestBuilder.execute()
-
org.elasticsearch.action.admin.indices.exists.indices.IndicesExistsRequestBuilder.execute()
-
org.elasticsearch.action.admin.indices.mapping.put.PutMappingRequestBuilder.execute()
-
org.elasticsearch.action.admin.indices.settings.put.UpdateSettingsRequestBuilder.execute()
-
org.elasticsearch.action.bulk.BulkRequestBuilder.execute()
-
org.elasticsearch.action.count.CountRequestBuilder.execute()
-
org.elasticsearch.action.delete.DeleteRequestBuilder.execute()
-
org.elasticsearch.action.deletebyquery.DeleteByQueryRequestBuilder.execute()
-
org.elasticsearch.action.get.GetRequestBuilder.execute()
-
org.elasticsearch.action.get.MultiGetRequestBuilder.execute()
-
org.elasticsearch.action.index.IndexRequestBuilder.execute()
-
org.elasticsearch.action.mlt.MoreLikeThisRequestBuilder.execute()
-
org.elasticsearch.action.percolate.PercolateRequestBuilder.execute()
-
org.elasticsearch.action.search.SearchRequestBuilder.execute()
-
org.elasticsearch.action.suggest.SuggestRequestBuilder.execute()
-
org.elasticsearch.action.update.UpdateRequestBuilder.execute()
-
org.elasticsearch.client.Client.execute()
-
org.elasticsearch.client.action.admin.indices.analyze.AnalyzeRequestBuilder.execute()
-
org.elasticsearch.client.action.bulk.BulkRequestBuilder.execute()
-
org.elasticsearch.client.action.delete.DeleteRequestBuilder.execute()
-
org.elasticsearch.client.action.get.GetRequestBuilder.execute()
-
org.elasticsearch.client.action.index.IndexRequestBuilder.execute()
-
org.elasticsearch.client.action.search.SearchRequestBuilder.execute()
-
org.elfinder.servlets.commands.AbstractCommand.execute()
-
org.encog.engine.opencl.EncogCLQueue.execute()
Execute the specified kernel.
@param kernel The kernel to execute.
-
org.encog.ml.bayesian.query.BayesianQuery.execute()
Execute the query.
-
org.encog.ml.bayesian.query.enumerate.EnumerationQuery.execute()
{@inheritDoc}
-
org.encog.ml.bayesian.query.sample.SamplingQuery.execute()
{@inheritDoc}
-
org.eobjects.metamodel.create.TableCreationBuilder.execute()
-
org.eobjects.metamodel.insert.RowInsertionBuilder.execute()
-
org.epic.core.util.PerlExecutor.execute()
Executes the Perl interpreter in the given working directory with the given command-line parameters and input. The execution is project-neutral, controlled only by global preferences.
@param workingDir working directory for the interpreter
@param args command-line arguments (Strings)
@param input input passed to the interpreter via stdin
-
org.epic.core.util.ProcessExecutor.execute()
Same as {@link #execute(String[],String,File,String)}, except the command-line is provided as a List of Strings rather than an array.
-
org.erlide.backend.debug.events.DebuggerEvent.execute()
-
org.eurekastreams.commons.server.service.ActionController.execute()
Execute the supplied {@link ServiceAction} with the given {@link PrincipalActionContext}.
@param inServiceActionContext - instance of the {@link PrincipalActionContext} with which to execution the {@link ServiceAction}.
@param inServiceAction - instance of the {@link ServiceAction} to execute.
@return - results from the execution of the ServiceAction.- GeneralException - when an unexpected error occurs. - ValidationException - when a {@link ValidationException} occurs. - AuthorizationException - when an {@link AuthorizationException}occurs. - ExecutionException - when an {@link ExecutionException} occurs.
-
org.evolizer.daforjava.commands.AbstractGraphEditCommand.execute()
-
org.evolizer.daforjava.commands.additions.AddEntitiesCommand.execute()
{@inheritDoc}
-
org.evolizer.daforjava.commands.additions.AddEntitiesViaInDependenciesCommand.execute()
{@inheritDoc}
-
org.evolizer.daforjava.commands.additions.AddEntitiesViaOutDependenciesCommand.execute()
{@inheritDoc}
-
org.eweb4j.mvc.action.ActionExecution.execute()
执行Action
@throws Exception
-
org.eweb4j.mvc.interceptor.InterExecution.execute()
-
org.exist.xmldb.XQueryService.execute()
-
org.exist.xquery.XQuery.execute()
-
org.exolab.castor.jdo.OQLQuery.execute()
-
org.exolab.castor.jdo.Query.execute()
Execute the query. The query is executed returning an enumeration of all the objects found. If no objects were found, the enumeration will be empty.
After execution the parameter list is reset. New parameters can be bound and the query re-executed.
@return Query results (zero or more objects)
@throws QueryException The query expression cannot be processed,or the query parameters are invalid
@throws TransactionNotInProgressException Method called whiletransaction is not in progress
@throws PersistenceException An error reported by thepersistence engine
-
org.exoplatform.applications.ooplugin.client.DavPropFind.execute()
-
org.exoplatform.applications.ooplugin.client.DavReport.execute()
-
org.exoplatform.applications.ooplugin.client.DavSearch.execute()
-
org.exoplatform.frameworks.jcr.cli.AddNodeCommand.execute()
-
org.exoplatform.frameworks.jcr.cli.CopyNodeCommand.execute()
-
org.exoplatform.frameworks.jcr.cli.GetContextInfoCommand.execute()
-
org.exoplatform.frameworks.jcr.cli.GetItemCommand.execute()
-
org.exoplatform.frameworks.jcr.cli.GetNodeCommand.execute()
-
org.exoplatform.frameworks.jcr.cli.GetNodesCommand.execute()
-
org.exoplatform.frameworks.jcr.cli.GetPropertiesCommand.execute()
-
org.exoplatform.frameworks.jcr.cli.GetPropertyCommand.execute()
-
org.exoplatform.frameworks.jcr.cli.HelpCommand.execute()
-
org.exoplatform.frameworks.jcr.cli.LoginCommand.execute()
-
org.exoplatform.frameworks.jcr.cli.MoveNodeCommand.execute()
-
org.exoplatform.frameworks.jcr.cli.RemoveItemCommand.execute()
-
org.exoplatform.frameworks.jcr.cli.SetPropertyCommand.execute()
-
org.exoplatform.frameworks.jcr.command.core.AddNodeCommand.execute()
-
org.exoplatform.frameworks.jcr.command.core.SaveCommand.execute()
-
org.exoplatform.services.command.action.Action.execute()
-
org.exoplatform.services.ftp.command.FtpCommand.execute()
-
org.exoplatform.services.jcr.ext.replication.external.BasicAuthenticationHttpClient.execute()
-
org.exoplatform.services.jcr.impl.core.query.QueryImpl.execute()
This method simply forwards the execute
call to the {@link ExecutableQuery} object returned by{@link QueryHandler#createExecutableQuery}. {@inheritDoc}
-
org.exoplatform.services.jcr.impl.core.query.RSyncJob.execute()
Executes RSYNC synchronization job
@throws IOException
-
org.exoplatform.services.jcr.impl.core.query.jbosscache.RSyncJob.execute()
Executes RSYNC synchronization job
@throws IOException
-
org.exoplatform.services.jcr.impl.storage.value.fs.operations.CASableDeleteValues.execute()
-
org.exoplatform.services.jcr.impl.storage.value.fs.operations.CASableWriteValue.execute()
{@inheritDoc}
-
org.exoplatform.services.jcr.impl.storage.value.fs.operations.DeleteValues.execute()
{@inheritDoc}
-
org.exoplatform.services.jcr.impl.storage.value.fs.operations.WriteValue.execute()
{@inheritDoc}
-
org.exoplatform.services.rpc.RemoteCommand.execute()
This method will execute the command on the local machine.
@param container The container from which the services needed for the commandwill be extracted
@param args The parameters needed to execute the command
@return arbitrary return value generated by performing this command
@throws Throwable in the event of problems.
-
org.exoplatform.services.scheduler.Task.execute()
-
org.exoplatform.social.client.api.net.SocialHttpClient.execute()
-
org.fao.geonet.kernel.csw.CatalogService.execute()
Executes the service on given input request
-
org.fao.geonet.utils.GeonetHttpRequestFactory.execute()
-
org.fao.geonet.utils.XmlRequest.execute()
Sends an xml request and obtains an xml response
-
org.fao.oaipmh.requests.GetRecordRequest.execute()
-
org.fao.oaipmh.requests.ListMetadataFormatsRequest.execute()
-
org.fao.oaipmh.requests.ListSetsRequest.execute()
-
org.fcrepo.common.http.PreemptiveAuth.execute()
-
org.flexunit.ant.launcher.commands.headless.XvncStartCommand.execute()
-
org.flexunit.ant.launcher.commands.headless.XvncStopCommand.execute()
-
org.flywaydb.core.internal.dbsupport.SqlScript.execute()
-
org.freeplane.features.mode.ModeController.execute()
-
org.freerealm.unit.Order.execute()
-
org.fto.jthink.jdbc.SQLExecutor.execute()
执行SQL语句对象, sql是由SQLBuilder构建的SQL语句
@param sql SQL对象
@return 结果集或null
-
org.fusesource.hawtdispatch.DispatchQueue.execute()
-
org.fusesource.ide.camel.editor.features.create.CreateFlowFeature.execute()
-
org.fusesource.ide.camel.editor.features.custom.CreateNodeConnectionFeature.execute()
-
org.fusesource.ide.commons.camel.tools.ArchetypeHelper.execute()
Main method which extracts given Maven Archetype in destination directory
@return
-
org.gatein.management.api.controller.ManagementController.execute()
The execute method is the means to communicate with all managed resources.
@param request The managed request holding the information about the request.
@return a managed response
@throws ResourceNotFoundException if the managed resource could not be located.
@throws OperationException if the operation failed.
-
org.gatein.management.api.operation.OperationHandler.execute()
Execute the operation, passing the result to {@code resultHandler}. This method must invoke one of the completion methods on {@code resultHandler} regardless of the outcome of the operation.
@param operationContext the context for this operation
@param resultHandler the result handler to invoke when the operation is complete
@throws ResourceNotFoundException this is to allow implementations who are registered via path template tothrow this exception when resolved template value does not match a known value.
@throws OperationException if the operation fails to execute correctly
-
org.geomajas.command.Command.execute()
Execute the command.
@param request request parameters
@param response response object
@throws Exception in case of problems
-
org.geomajas.gwt.client.map.feature.FeatureTransaction.execute()
Execute an operation on each of the features from the "newFeature" array. Also store the operation on a queue, so it is possible to undo all the changes afterwards.
@param op The operation to apply on each feature.
-
org.geomajas.gwt.client.map.feature.operation.FeatureOperation.execute()
General execution function of a single operation on a feature.
@param feature The feature on which to operate.
-
org.geomajas.gwt.client.map.feature.operation.SetCoordinateOp.execute()
-
org.geomajas.gwt.client.spatial.geometry.operation.AddRingOperation.execute()
Execute the operation! When the geometry is not a Polygon, null is returned.
-
org.geomajas.gwt.client.spatial.geometry.operation.InsertCoordinateOperation.execute()
Execute the operation!
@return Returns a new geometry. If the given geometry is null, or the given geometry is not a {@link LineString}or {@link LinearRing}, then null is returned.
-
org.geomajas.gwt.client.spatial.geometry.operation.InsertRingOperation.execute()
Execute the operation! When the geometry is not a Polygon, null is returned.
-
org.geomajas.gwt.client.spatial.geometry.operation.RemoveCoordinateOperation.execute()
Execute the operation!
@return Returns a new geometry. If the given geometry is null, or the given geometry is not a {@link LineString}or {@link LinearRing}, then null is returned.
-
org.geomajas.gwt.client.spatial.geometry.operation.RemoveRingOperation.execute()
Execute the operation! When the geometry is not a Polygon, null is returned. When the polygon does not have any interior rings, null is returned.
-
org.geomajas.gwt.client.spatial.geometry.operation.SetCoordinateOperation.execute()
Execute the operation!
@return Returns a new geometry. If the given geometry is null, or the given geometry is not a {@link LineString}or {@link LinearRing}, then null is returned.
-
org.geomajas.puregwt.client.command.CommandService.execute()
The execution function. Executes a server side command.
@param command The command to be executed. This command is a wrapper around the actual request object.
@param callbacks A CommandCallback
function to be executed when the command successfully returns.
@return deferred object which can be used to add extra call-backs
-
org.geoserver.kml.FeatureTimeTemplate.execute()
Executes the template against the feature.
This method returns:
{"01/01/07"}
: timestamp as 1 element array {"01/01/07","01/12/07"}
: timespan as 2 element array {null,"01/12/07"}
: open ended (start) timespan as 2 element array {"01/12/07",null}
: open ended (end) timespan as 2 element array {}
: no timestamp information as empty array
@param feature The feature to execute against.
-
org.geoserver.script.wps.ScriptProcess.execute()
-
org.geotools.data.Parameter.execute()
-
org.geotools.process.Process.execute()
Execute this process with the provided inputs.
@param input Input parameters for this process
@param monitor listener for handling the progress of the process
@return Map of results, (@see ProcessFactory for details), or null if canceled
-
org.geotools.process.raster.AreaGridProcess.execute()
-
org.geotools.process.raster.ContourProcess.execute()
-
org.geotools.process.raster.CropCoverage.execute()
-
org.geotools.process.raster.PolygonExtractionProcess.execute()
Executes the raster to vector process.
@param coverage the input grid coverage
@param band the coverage band to process; defaults to 0 if {@code null}
@param insideEdges whether boundaries between raster regions with data values(ie. not NODATA) should be returned; defaults to {@code true} if {@code null}
@param roi optional polygonal {@code Geometry} to define a sub-area within whichvectorizing will be done
@param noDataValues optional list of values to treat as NODATA; regions with thesevalues will not be represented in the returned features; if {@code null}, 0 is used as the single NODATA value; ignored if {@code classificationRanges} is provided
@param classificationRanges optional list of {@code Range} objects to pre-classifythe input coverage prior to vectorizing; values not included in the list will be treated as NODATA; values in the first {@code Range} are classified to 1, thosein the second {@code Range} to 2 etc.
@param progressListener an optional listener
@return a feature collection where each feature has a {@code Polygon} ("the_geom")and an attribute "value" with value of the corresponding region in either {@code coverage} or the classified coverage (when {@code classificationRanges}is used)
@throws ProcessException
-
org.geotools.process.vector.BufferFeatureCollection.execute()
-
org.geotools.process.vector.CentroidProcess.execute()
-
org.geotools.process.vector.ClipProcess.execute()
-
org.geotools.process.vector.InclusionFeatureCollection.execute()
-
org.geotools.process.vector.LRSGeocodeProcess.execute()
Process the input data set.
@param featureCollection the data set
@param crs the CRS
@param point the given point
@return the snapped to feature
@throws ProcessException error
-
org.geotools.process.vector.LRSMeasureProcess.execute()
Process the input data set.
@param featureCollection the data set
@param crs the CRS
@param point the given point
@return the snapped to feature
@throws ProcessException error
-
org.geotools.process.vector.LRSSegmentProcess.execute()
Process the input data set.
@param featureCollection the data set
@param crs the CRS
@param point the given point
@return the snapped to feature
@throws ProcessException error
-
org.geotools.process.vector.PointStackerProcess.execute()
-
org.geotools.process.vector.TransformProcess.execute()
-
org.geotools.process.vector.UnionFeatureCollection.execute()
-
org.geotools.renderer.lite.gridcoverage2d.RasterSymbolizerHelper.execute()
We are hacking here a solutions for whenever the user either did not specify a style or did specify a bad one and the resulting image seems not be drawable.
@return {@link GridCoverage2D} the result of this operation
-
org.geotools.renderer.lite.gridcoverage2d.SubchainStyleVisitorCoverageProcessingAdapter.execute()
-
org.gephi.datalab.spi.rows.merge.AttributeRowsMergeStrategy.execute()
-
org.gephi.desktop.datalab.general.actions.AddColumnUI.execute()
Execute the creation of the column, with the given parameters in setup and with the interface itself.
-
org.gephi.desktop.datalab.general.actions.MergeColumnsUI.execute()
-
org.gephi.desktop.statistics.api.StatisticsControllerUI.execute()
Execute the statistics in a background thread. The statistics
should implement {@link LongTask}.
@param statistics the statistics algorithm instance
-
org.gephi.statistics.api.StatisticsController.execute()
Execute the statistics algorithm. If statistics
implements LongTask
, execution is performed in a background thread and therefore this method returns immedialtely.
@param statistics the statistics algorithm instance
@param listener a listener that is notified when execution finished
-
org.gephi.statistics.plugin.ClusteringCoefficient.execute()
-
org.gephi.statistics.plugin.GraphDensity.execute()
-
org.gephi.statistics.plugin.GraphDistance.execute()
@param graphModel
-
org.gephi.utils.longtask.api.LongTaskExecutor.execute()
Execute a long task with cancel and progress support. Task can be null
. In this case runnable
will be executed normally, but without cancel and progress support.
@param task the task to be executed, can be null
.
@param runnable the runnable to be executed
@param taskName the name of the task, is displayed in the status bar if available
@param errorHandler error handler for exception retrieval during execution
@throws NullPointerException if runnable
or taskName
is null
@throws IllegalStateException if a task is still executing at this time
-
org.getopt.luke.SlowThread.execute()
-
org.glassfish.api.admin.AdminCommand.execute()
Executes the command with the command parameters passed as Properties where the keys are the parameter names and the values are the parameter values
@param context information
-
org.glassfish.api.admin.CommandRunner.CommandInvocation.execute()
-
org.globus.workspace.service.impls.async.WorkspaceRequest.execute()
All error reporting and request setup must happen out of band. WorkspaceRequestQueue just knows how to dequeue work requests and call execute.
-
org.goobi.production.flow.jobs.HistoryAnalyserJob.execute()
-
org.goobi.production.plugin.interfaces.ICommandPlugin.execute()
-
org.goobi.production.plugin.interfaces.IStepPlugin.execute()
-
org.gradle.api.artifacts.query.ArtifactResolutionQuery.execute()
Actually execute the query, returning a query result. Note that {@link #withArtifacts(Class,Class[])} must be called before executing the query.
-
org.gradle.api.internal.AbstractTask.execute()
-
org.gradle.api.internal.TaskInternal.execute()
Executes this task.
-
org.gradle.api.internal.file.copy.CopyActionImpl.execute()
-
org.gradle.api.internal.file.copy.FileCopyActionImpl.execute()
-
org.gradle.api.internal.plugins.DefaultObjectConfigurationAction.execute()
-
org.gradle.execution.BuildExecuter.execute()
Executes the selected tasks. Called after {@link #select(org.gradle.api.internal.GradleInternal)}.
-
org.gradle.internal.concurrent.StoppableExecutor.execute()
-
org.gradle.language.base.internal.tasks.SimpleStaleClassCleaner.execute()
-
org.gradle.language.base.internal.tasks.StaleClassCleaner.execute()
-
org.gradle.process.internal.ExecAction.execute()
-
org.gradle.process.internal.JavaExecAction.execute()
-
org.grouplens.lenskit.util.parallel.TaskGraphExecutor.execute()
Execute a task graph.
@param graph The graph to execute.
@param < T> The task type.
@param < E> The edge type.
@throws ExecutionException If there is an error executing one or more tasks.
@throws InterruptedException If task execution is interrupted.
-
org.gvt.command.CreateCommand.execute()
-
org.gvt.command.CreateConnectionCommand.execute()
-
org.gvt.command.DeleteCommand.execute()
-
org.gvt.command.DeleteConnectionCommand.execute()
-
org.gvt.command.LayoutCommand.execute()
-
org.gvt.command.RemoveCompoundCommand.execute()
-
org.h2.jdbc.JdbcPreparedStatement.execute()
Calling this method is not legal on a PreparedStatement.
@param sql ignored
@throws SQLException Unsupported Feature
-
org.h2.jdbc.JdbcStatement.execute()
Executes an arbitrary statement. If another result set exists for this statement, this will be closed (even if this statement fails). If the statement is a create or drop and does not throw an exception, the current transaction (if any) is committed after executing the statement. If auto commit is on, and the statement is not a select, this statement will be committed.
@param sql the SQL statement to execute
@return true if a result set is available, false if not
-
org.h2.test.db.Db.execute()
Execute the statement.
@return the object returned if this was a method call
-
org.h2.test.db.Db.Prepared.execute()
Execute the statement.
@return the object returned if this was a method call
-
org.h2.util.Task.execute()
Start the thread.
@return this
-
org.hibernate.bytecode.buildtime.Instrumenter.execute()
-
org.hibernate.search.test.performance.util.BatchSupport.execute()
-
org.hibernate.search.testsupport.concurrency.ConcurrentRunner.execute()
Invokes the {@link TaskFactory} and runs all the built tasks inan Executor.
@throws Exception if interrupted, any exception is thrown by the tasks,or any exception is thrown during the creation of tasks.
-
org.hibernate.tool.hbm2ddl.SchemaExport.execute()
-
org.hibernate.tool.hbm2ddl.SchemaUpdate.execute()
Execute the schema updates
@param script print all DDL to the console
-
org.hibernate.validator.ap.checks.ConstraintChecks.execute()
Executes the checks contained within this set against the given element and annotation.
@param element An annotated element.
@param annotation The annotation to check.
@return A set with errors. Will be empty in case all checks passedsuccessfully.
-
org.hightides.annotations.processor.Processor.execute()
-
org.hsqldb.Session.execute()
Executes the command encapsulated by the cmd argument.
@param cmd the command to execute
@return the result of executing the command
-
org.hsqldb.Statement.execute()
-
org.hsqldb.cmdline.SqlFile.execute()
Process all the commands from the file or Reader associated with "this" object. SQL commands in the content get executed against the current JDBC data source connection.
@throws SQLExceptions thrown by JDBC driver.Only possible if in "\c false" mode.
@throws SqlToolError all other errors.This includes including QuitNow, BreakException, ContinueException for recursive calls only.
-
org.hsqldb.util.SqlFile.execute()
Process all the commands on stdin.
@param conn The JDBC connection to use for SQL Commands.
@see #execute(Connection,PrintStream,PrintStream,boolean)
-
org.hsqldb_voltpatches.Statement.execute()
-
org.huihoo.workflow.xpdl.activity.Implementation.execute()
-
org.impalaframework.build.ant.SVNRevisionTask.execute()
-
org.impalaframework.command.basic.SearchClassCommand.execute()
-
org.impalaframework.command.basic.SelectMethodCommand.execute()
-
org.impalaframework.command.framework.Command.execute()
-
org.impalaframework.command.interactive.InteractiveTestCommand.execute()
-
org.impalaframework.interactive.command.ExitCommand.execute()
-
org.impalaframework.interactive.command.InteractiveTestCommand.execute()
-
org.impalaframework.module.operation.ModuleOperation.execute()
-
org.infinispan.cli.commands.Command.execute()
-
org.infinispan.cli.interpreter.Interpreter.execute()
-
org.infinispan.client.hotrod.impl.operations.AuthMechListOperation.execute()
-
org.infinispan.client.hotrod.impl.operations.AuthOperation.execute()
-
org.infinispan.client.hotrod.impl.operations.BulkGetKeysOperation.execute()
-
org.infinispan.client.hotrod.impl.operations.BulkGetOperation.execute()
-
org.infinispan.client.hotrod.impl.operations.ClearOperation.execute()
-
org.infinispan.client.hotrod.impl.operations.ContainsKeyOperation.execute()
-
org.infinispan.client.hotrod.impl.operations.GetOperation.execute()
-
org.infinispan.client.hotrod.impl.operations.GetWithMetadataOperation.execute()
-
org.infinispan.client.hotrod.impl.operations.GetWithVersionOperation.execute()
-
org.infinispan.client.hotrod.impl.operations.PingOperation.execute()
-
org.infinispan.client.hotrod.impl.operations.PutIfAbsentOperation.execute()
-
org.infinispan.client.hotrod.impl.operations.PutOperation.execute()
-
org.infinispan.client.hotrod.impl.operations.QueryOperation.execute()
-
org.infinispan.client.hotrod.impl.operations.RemoveIfUnmodifiedOperation.execute()
-
org.infinispan.client.hotrod.impl.operations.RemoveOperation.execute()
-
org.infinispan.client.hotrod.impl.operations.ReplaceIfUnmodifiedOperation.execute()
-
org.infinispan.client.hotrod.impl.operations.ReplaceOperation.execute()
-
org.infinispan.client.hotrod.impl.operations.StatsOperation.execute()
-
org.infinispan.profiling.testinternals.TaskRunner.execute()
-
org.infinispan.quickstart.compatibility.commands.Command.execute()
-
org.infinispan.remoting.transport.RetryOnFailureXSiteCommand.execute()
Invokes remotely the command using the {@code Transport} passed as parameter.
@param transport the {@link org.infinispan.remoting.transport.Transport} to use.
@param waitTimeBetweenRetries the waiting time if the command fails before retrying it.
@param unit the {@link java.util.concurrent.TimeUnit} of the waiting time.
@throws Throwable if the maximum retries is reached (defined by the {@link org.infinispan.remoting.transport.RetryOnFailureXSiteCommand.RetryPolicy}, the last exception occurred is thrown.
-
org.infinispan.util.concurrent.BlockingTaskAwareExecutorService.execute()
Executes the given command at some time in the future when the command is less probably to block a thread.
@param runnable the command to execute
-
org.infinispan.util.concurrent.BlockingTaskAwareExecutorServiceImpl.execute()
-
org.infozone.tools.xml.queries.XPathQuery.execute()
Execute the xpath.
@param rootNode The node from which the query should start or null.
@param nameSpace The node that resolves namespace queries or null.
@param filter The node filter which is to apply while querying or null.
@return The XObject insulating the query result.
-
org.infozone.tools.xml.queries.XUpdateQuery.execute()
Execute the XUpdate.
@param rootNode The node from which the query should start or null.
-
org.intellij.vcs.mks.DispatchBySandboxCommand.execute()
-
org.intellij.vcs.mks.sicommands.api.ListSandboxesAPI.execute()
-
org.intellij.vcs.mks.sicommands.api.SandboxesCommandAPI.execute()
-
org.intellij.vcs.mks.sicommands.api.ViewMemberHistoryAPICommand.execute()
-
org.intellij.vcs.mks.sicommands.cli.AbstractViewSandboxCommand.execute()
-
org.intellij.vcs.mks.sicommands.cli.GetContentRevision.execute()
-
org.intellij.vcs.mks.sicommands.cli.GetRevisionInfo.execute()
-
org.intellij.vcs.mks.sicommands.cli.LockMemberCommand.execute()
-
org.intellij.vcs.mks.sicommands.cli.RenameChangePackage.execute()
-
org.intellij.vcs.mks.sicommands.cli.ResyncCommand.execute()
-
org.intellij.vcs.mks.sicommands.cli.SandboxesCommand.execute()
-
org.intellij.vcs.mks.sicommands.cli.UnlockMemberCommand.execute()
-
org.intellij.vcs.mks.sicommands.cli.ViewSandboxRemoteChangesCommand.execute()
-
org.izi.binding.Binding.BindingRegistration.execute()
-
org.jacoco.ant.ReportTask.execute()
-
org.jahia.services.render.scripting.Script.execute()
Execute the script and return the result as a string
@param resource resource to display
@param context
@return the rendered resource
@throws org.jahia.services.render.RenderException
-
org.jamesii.core.experiments.BaseExperiment.execute()
Execute the experiment by using the internally set parameters.
-
org.jamesii.gui.application.action.ActionIAction.execute()
-
org.jasen.interfaces.AutoUpdateExecutor.execute()
Called by the auto update engine when an update contains an executable class
@throws JasenException
-
org.jasig.portal.channels.permissionsmanager.IPermissionCommand.execute()
-
org.jboss.adminclient.command.ClientCommand.execute()
Executes the agent prompt command with the given arguments.
@param client the ClientMain class itself
@param args the arguments passed to the agent on the agent prompt
@return true
if the agent can continue accepting prompt commands; false
if the agentshould die
-
org.jboss.aophelper.util.AopCompileCommand.execute()
-
org.jboss.aophelper.util.AopRunCommand.execute()
-
org.jboss.arquillian.container.test.spi.TestRunner.execute()
Run a single test method in a test class.
@param testClass The test case class to execute
@param methodName The method to execute
@return The result of the test
-
org.jboss.arquillian.persistence.script.ScriptExecutor.execute()
-
org.jboss.arquillian.spi.TestRunner.execute()
Run a single test method in a test class.
@param testClass The test case class to execute
@param methodName The method to execute
@return The result of the test
-
org.jboss.as.cli.impl.CLIModelControllerClient.execute()
-
org.jboss.as.cmp.jdbc.JDBCQueryCommand.execute()
-
org.jboss.as.console.client.administration.role.operation.ModifyRoleAssignmentOp.execute()
-
org.jboss.as.console.client.administration.role.operation.ModifyRoleOp.execute()
-
org.jboss.as.console.client.administration.role.operation.ShowMembersOperation.execute()
-
org.jboss.as.console.client.core.BootstrapCmd.execute()
-
org.jboss.as.console.client.core.bootstrap.BootstrapProcess.execute()
-
org.jboss.as.console.client.shared.dispatch.AsyncCommand.execute()
-
org.jboss.as.console.client.shared.general.model.LoadInterfacesCmd.execute()
-
org.jboss.as.console.client.shared.general.model.LoadSocketBindingsCmd.execute()
-
org.jboss.as.console.client.shared.jvm.CreateJvmCmd.execute()
-
org.jboss.as.console.client.shared.jvm.DeleteJvmCmd.execute()
-
org.jboss.as.console.client.shared.jvm.UpdateJvmCmd.execute()
-
org.jboss.as.console.client.shared.properties.CreatePropertyCmd.execute()
-
org.jboss.as.console.client.shared.properties.DeletePropertyCmd.execute()
-
org.jboss.as.console.client.shared.properties.LoadPropertiesCmd.execute()
-
org.jboss.as.console.client.shared.subsys.web.LoadConnectorCmd.execute()
-
org.jboss.as.controller.BasicModelController.execute()
-
org.jboss.as.controller.ModelController.execute()
Execute an operation, sending updates to the given handler. This method is not intended to be invoked directly by clients.
@param operation the operation to execute
@param handler the message handler
@param control the transaction control for this operation
@param attachments the operation attachments
@return the operation result
@throws SecurityException if the caller does not have {@link #ACCESS_PERMISSION}
-
org.jboss.as.controller.OperationHandler.execute()
Execute the operation, passing the result to {@code resultHandler}. The submodel is not available unless one of the subtypes of this interface is implemented. This method must invoke one of the completion methods on {@code resultHandler} regardless of the outcome of the operation.
@param context the context for this operation
@param operation the operation being executed
@param resultHandler the result handler to invoke when the operation is complete
@return a handle which may be used to asynchronously cancel this operation or retrieve the compensating model operation
@throws OperationFailedException If the operation fails to execute correctly
-
org.jboss.as.controller.OperationStepHandler.execute()
Execute this step. If the operation fails, {@link OperationContext#getFailureDescription() context.getFailureDescription()}must be called, before calling one of the {@link org.jboss.as.controller.OperationContext#completeStep(OperationContext.ResultHandler) context.completeStep variants}, or an {@link OperationFailedException} must be thrown.If the operation succeeded, {@link OperationContext#getResult() context.getResult()} shouldbe called and the result populated with the outcome, after which one of the {@link org.jboss.as.controller.OperationContext#completeStep(OperationContext.ResultHandler) context.completeStep variants}must be called.
When this method is invoked the {@link Thread#getContextClassLoader() thread context classloader} willbe set to be the defining class loader of the class that implements this interface.
@param context the operation context
@param operation the operation being executed
@throws OperationFailedException if the operation failed
before calling {@code context.completeStep()}
-
org.jboss.as.controller.ProxyController.execute()
Execute an operation, sending updates to the given handler and receiving the response via the given {@link ModelController.OperationTransactionControl}. When this operation returns, either the {@link ProxyOperationControl#operationPrepared(ModelController.OperationTransaction,org.jboss.dmr.ModelNode)}or the {@link ProxyOperationControl#operationFailed(org.jboss.dmr.ModelNode)} callbacks on the given {@code control}will have been invoked.
@param operation the operation to execute. Cannot be {@code null}
@param handler the message handler. May be {@code null}
@param control the callback handler for this operation. Cannot be {@code null}
@param attachments the operation attachments. May be {@code null}
-
org.jboss.as.controller.RuntimeTask.execute()
Execute the task.
@param context The runtime task context
@throws OperationFailedException If any problems occur
-
org.jboss.as.controller.client.ModelControllerClient.execute()
Execute an operation synchronously.
@param operation the operation to execute
@return the result of the operation
@throws IOException if an I/O error occurs while executing the operation
-
org.jboss.as.controller.client.helpers.domain.DomainClient.execute()
-
org.jboss.as.controller.client.helpers.domain.DomainDeploymentManager.execute()
Execute the deployment plan.
@param plan the deployment plan
@return the results of the deployment plan
@return {@link Future} from which the results of the deployment plan canbe obtained
-
org.jboss.as.controller.client.helpers.standalone.ServerDeploymentManager.execute()
Execute the deployment plan.
@param plan the deployment plan
@return {@link Future} from which the results of the deployment plan canbe obtained
-
org.jboss.as.controller.remote.RemoteProxyController.execute()
{@inheritDoc}
-
org.jboss.as.controller.remote.TransactionalProtocolClient.execute()
Execute an operation. This returns a future for the final result, which will only available after the prepared operation is committed.
@param listener the operation listener
@param operation the operation
@param messageHandler the operation message handler
@param attachments the operation attachments
@return the future result
@throws IOException
-
org.jboss.as.domain.controller.plan.NewRolloutPlanController.execute()
-
org.jboss.as.domain.controller.plan.RolloutPlanController.execute()
-
org.jboss.as.plugin.deployment.resource.AddResource.execute()
-
org.jboss.as.plugin.deployment.standalone.StandaloneDeployment.execute()
-
org.jboss.as.protocol.mgmt.support.SimpleHandlers.SimpleClient.execute()
-
org.jboss.byteman.rule.helper.HelperAdapter.execute()
-
org.jboss.cache.profiling.testinternals.TaskRunner.execute()
-
org.jboss.console.twiddle.command.Command.execute()
-
org.jboss.dashboard.database.hibernate.HibernateTxFragment.execute()
Execute this fragment.
-
org.jboss.dashboard.ui.controller.CommandResponse.execute()
Executes the response. It typically will be one of the response types that are provided in the org.jboss.dashboard.ui.controller.responses package.
@param cmdReq Object encapsulating the request information.
@return boolean if the execution has been successfuly executed, false otherwise.
-
org.jboss.dashboard.ui.panel.PanelDriver.execute()
Execute an action on this panel.
-
org.jboss.dna.graph.commands.executor.CommandExecutor.execute()
-
org.jboss.dna.graph.connector.RepositoryConnection.execute()
Execute the supplied commands against this repository source.
@param context the environment in which the commands are being executed; never null
@param request the request to be executed; never null
@throws PathNotFoundException if the request(s) contain paths to nodes that do not exist
@throws ReferentialIntegrityException if the request is or contains a delete operation, where the delete could not beperformed because some references to deleted nodes would have remained after the delete operation completed
@throws RepositorySourceException if there is a problem loading the node data
-
org.jboss.dna.graph.connectors.RepositoryConnection.execute()
-
org.jboss.dna.graph.query.QueryEngine.execute()
{@inheritDoc}
@see org.jboss.dna.graph.query.Queryable#execute(org.jboss.dna.graph.query.QueryContext,org.jboss.dna.graph.query.model.QueryCommand)
-
org.jboss.ejb.plugins.cmp.jdbc.JDBCQueryCommand.execute()
-
org.jboss.forge.addon.maven.projects.archetype.ArchetypeHelper.execute()
Main method which extracts given Maven Archetype in destination directory
@return
-
org.jboss.forge.addon.ui.UICommand.execute()
Called when the {@link UICommand} should be executed.This method should NEVER execute if {@link UICommand#isEnabled(UIContext)} returns falseand{@link UICommand#validate(UIValidationContext)} contains validation errors
@param context the context of the interaction
@return the result of this execution (see the {@link Results} class)
@throws Exception if anything wrong happens
-
org.jboss.forge.addon.ui.command.UICommand.execute()
Called when the {@link UICommand} should be executed.This method should NEVER execute if {@link UICommand#isEnabled(UIContext)} returns false and{@link UICommand#validate(UIValidationContext)} contains validation errors
@param context the context of the interaction
@return the result of this execution (see the {@link Results} class)
@throws Exception if anything wrong happens
-
org.jboss.forge.addon.ui.controller.CommandController.execute()
Calls {@link UICommand#execute(org.jboss.forge.addon.ui.context.UIExecutionContext)}. Causes available {@link CommandExecutionListener} instances to be called.
@throws IllegalStateException if {@link #initialize()} has not been called before invoking this method.
@throws Exception if problems occurred during initialization
-
org.jboss.forge.addon.ui.controller.WizardCommandController.execute()
-
org.jboss.forge.addon.ui.wizard.UIWizard.execute()
-
org.jboss.forge.classloader.mock.MockSimpleCountService.execute()
Return's the number of times this services has been previously called.
-
org.jboss.fresh.shell.Shell.execute()
-
org.jboss.fresh.shell.ejb.RemoteShell.execute()
-
org.jboss.fresh.shell.impl.ShellImpl.execute()
-
org.jboss.jbossts.qa.astests.taskdefs.ClientAction.execute()
Execute code in the context of an ant target
@param config Configuration for this execution loaded from the ant scriptthat triggered this action
@param params Arbitary collection of name/value pairs passed in from the ant scriptthat triggered this action
@return true to indicate that the action completed successfully
@see org.jboss.jbossts.qa.astests.taskdefs.ASClientTask
-
org.jboss.mbui.gui.reification.pipeline.ReificationPipeline.execute()
-
org.jboss.messaging.util.CompatibleExecutor.execute()
-
org.jboss.resteasy.client.ClientRequest.execute()
-
org.jboss.soa.esb.services.jbpm.cmd.Command.execute()
-
org.jboss.test.faces.FacesEnvironment.FacesRequest.execute()
-
org.jboss.test.jbossts.taskdefs.ClientAction.execute()
Execute code in the context of an ant target
@param config Configuration for this execution loaded from the ant scriptthat triggered this action
@param params Arbitary collection of name/value pairs passed in from the ant scriptthat triggered this action
@return true to indicate that the action completed successfully
@see org.jboss.test.jbossts.taskdefs.ASClientTask
-
org.jboss.test.sessionsync.interfaces.ActionExecutor.execute()
-
org.jbpm.ant.ProcessDeployer.execute()
-
org.jbpm.api.ProcessEngine.execute()
perform a user command. that allows users to span a transaction over their own updates, as well as the jbpm operations.
-
org.jbpm.api.activity.ActivityBehaviour.execute()
invoked when an execution arrives in an activity.
An ActivityBehaviour can control the propagation of execution. ActivityBehaviour's can become external activities when they invoke {@link ActivityExecution#waitForSignal()}. That means the activity will become a wait state. In that case, {@link ExternalActivityBehaviour} should be implemented to also handle the external signals.
-
org.jbpm.client.CommandService.execute()
@throws PvmException if command throws an exception.
-
org.jbpm.command.Command.execute()
-
org.jbpm.command.SignalCommand.execute()
-
org.jbpm.db.compatibility.JbpmSchemaUpdate.execute()
Executes the schema update tool.
@param printScript print DDL statements to the console
@param doUpdate post DDL statements to the database
@param outputFile write DDL statements to this file, can be null
-
org.jbpm.ejb.LocalCommandService.execute()
-
org.jbpm.env.session.Job.execute()
-
org.jbpm.eventmessaging.EventResponseHandler.execute()
-
org.jbpm.graph.def.Action.execute()
-
org.jbpm.graph.def.ActionHandler.execute()
-
org.jbpm.graph.def.Node.execute()
override this method to customize the node behaviour.
-
org.jbpm.job.Job.execute()
-
org.jbpm.job.Timer.execute()
-
org.jbpm.process.instance.impl.Action.execute()
-
org.jbpm.process.instance.impl.AssignmentAction.execute()
-
org.jbpm.pvm.Activity.execute()
piece of Java code that is to be included in a process as node behaviour or as a hidden listener to process events.
Activities can be used to implement the behaviour of nodes, in which case this behaviour is associated to a graphical node in the diagram, or they can be added as events, in that case, they are being hidden from the diagram.
If an activity is the node behaviour, then it can control the propagation of execution. Node behaviours can be external activities. That means their runtime behaviour is a wait state. In that case, {@link ExternalActivity} should be implemented to also handle the external triggers.
If an activity is being used as a listener to process events, the propagation of the execution can not be controlled in an activity. So following methods are not to be called during {@link Event}s.
- {@link Execution#cancel()}
- {@link Execution#end()}
- {@link Execution#end(String)}
- {@link Execution#end(String,boolean)}
- {@link Execution#execute(Node)}
- {@link Execution#move(Node)}
- {@link Execution#resume()}
- {@link Execution#signal()}
- {@link Execution#signal(java.util.Map)}
- {@link Execution#signal(String)}
- {@link Execution#signal(String,java.util.Map)}
- {@link Execution#suspend()}
- {@link Execution#takeDefaultTransition()}
- {@link Execution#take(String)}
- {@link Execution#take(Transition)}
- {@link Execution#waitForSignal()}
will result in a PvmException.
If an exception is thrown that is not handled by an {@link ExceptionHandler}, the exception will be wrapped and propagated to the original client that performed an operation on the execution.
-
org.jbpm.pvm.internal.cmd.CommandService.execute()
@throws JbpmException if command throws an exception.
-
org.jbpm.pvm.internal.cmd.ExecuteJobCmd.execute()
-
org.jbpm.pvm.internal.identity.cmd.FindGroupsCmd.execute()
-
org.jbpm.pvm.internal.job.TimerImpl.execute()
-
org.jbpm.pvm.internal.model.ExecutionImpl.execute()
@see Execution#execute(String)
-
org.jbpm.pvm.internal.query.AbstractQuery.execute()
-
org.jbpm.pvm.internal.xml.Parse.execute()
perform the actual parse operation with the specified input source.
-
org.jbpm.scheduler.exe.Timer.execute()
-
org.jclouds.abiquo.strategy.cloud.ListAttachedNics.execute()
-
org.jclouds.abiquo.strategy.cloud.ListVirtualDatacenters.execute()
-
org.jclouds.abiquo.strategy.enterprise.ListVirtualMachineTemplates.execute()
-
org.jclouds.rackspace.autoscale.v1.features.PolicyApi.execute()
This operation executes a specific scaling policy.
@return true if successful.
@see ScalingPolicy
-
org.jdesktop.swingworker.SwingWorker.execute()
Schedules this {@code SwingWorker} for execution on a
workerthread. There are a number of
worker threads available. In the event all
worker threads are busy handling other {@code SwingWorkers} this {@code SwingWorker} is placed in a waitingqueue.
Note: {@code SwingWorker} is only designed to be executed once. Executing a{@code SwingWorker} more than once will not result in invoking the{@code doInBackground} method twice.
-
org.jgroups.blocks.GroupRequest.execute()
-
org.jitterbit.integration.client.ui.deploy.option.DeployOption.execute()
Starts the deploy process, using this option. This option is guaranteed to have been activated through a call to setActive(true)
before this method is called.
@param tag an optional tag that will represent the deployed project version on the server
-
org.jitterbit.integration.server.db.lookup.DbExecute.execute()
Executes the given SQL statement and returns the resulting result set as a list of
String
s arrays.
The maxNumberOfRows
argument limits the number of rows to return. If the result set contains more rows they are ignored.
@param sql the SQL statement to execute
@param maxNumberOfRows the maximum number of rows to return. If < 1
all rows will be returned
@return a DbExecuteResult
object representing the result of executing thestatement
@throws SQLException if an error occurs when running the statement
-
org.jmanage.connector.plugin.oracle.DataAccessor.execute()
-
org.jnode.ant.taskdefs.Asm.execute()
Description of the Method.
@throws BuildException Description of Exception
-
org.jnode.install.CopyFile.execute()
-
org.joget.plugin.base.ApplicationPlugin.execute()
-
org.joget.plugin.base.AuditTrailPlugin.execute()
-
org.jolokia.client.J4pClient.execute()
Execute a single J4pRequest returning a single response. The HTTP Method used is determined automatically.
@param pRequest request to execute
@param < R> response type
@param < T> request type
@return the response as returned by the server
@throws java.io.IOException when the execution fails
@throws org.json.simple.parser.ParseException if parsing of the JSON answer fails
-
org.jooq.BatchBindStep.execute()
-
org.jooq.Query.execute()
Execute the query, if it has been created with a properly configured factory
@return A result value, depending on the concrete implementation of{@link Query}:
- {@link Delete} : the number of deleted records
- {@link Insert} : the number of inserted records
- {@link Merge} : the result may have no meaning
- {@link Select} : the number of resulting records
- {@link Truncate} : the result may have no meaning
- {@link Update} : the number of updated records
@throws DataAccessException If anything goes wrong in the database
-
org.jooq.SelectQuery.execute()
-
org.joshy.sketch.actions.SAction.execute()
-
org.josql.Query.execute()
-
org.jostraca.util.ExecutableCommand.execute()
-
org.jpokemon.battle.turn.Turn.execute()
Executes this turn. If {@link changeToSwap} was called, this turn will produce a swap between the leader and the first available awake pokemon. Otherwise,subclass implementation will be called.
-
org.jpox.enhancer.ClassMethod.execute()
Method to add the contents of the class method.
-
org.jpox.enhancer.asm.method.DefaultConstructor.execute()
Method to add the contents of the class method.
-
org.jpox.enhancer.asm.method.InitClass.execute()
Method to add the contents of the class method.
-
org.jpox.enhancer.bcel.method.PropertyGetterMethod.execute()
-
org.jpox.enhancer.bcel.method.PropertySetterMethod.execute()
-
org.jpox.store.rdbms.request.DeleteRequest.execute()
Method performing the deletion of the record from the datastore. Takes the constructed deletion query and populates with the specific record information.
@param sm The state manager for the record to be deleted.
-
org.jpox.store.rdbms.request.FetchRequest.execute()
Method performing the retrieval of the record from the datastore. Takes the constructed retrieval query and populates with the specific record information.
@param sm The state manager for the record to be retrieved
-
org.jpox.store.rdbms.request.InsertRequest.execute()
Method performing the insertion of the record from the datastore. Takes the constructed insert query and populates with the specific record information.
@param sm The state manager for the record to be inserted
-
org.jpox.store.rdbms.request.LocateRequest.execute()
Method performing the retrieval of the record from the datastore. Takes the constructed retrieval query and populates with the specific record information.
@param sm The state manager for the record to be retrieved
-
org.jpox.store.rdbms.request.UpdateRequest.execute()
Method performing the update of the record in the datastore. Takes the constructed update query and populates with the specific record information.
@param sm The state manager for the record to be updated
-
org.jpublish.action.ActionManager.execute()
-
org.jrest4guice.dao.actions.ActionContext.execute()
动作的执行方法
@param method DAO接口的方法对象
@param parameters 参数数组
@return
@throws Throwable
-
org.jsonschema2pojo.maven.Jsonschema2PojoMojo.execute()
Executes the plugin, to read the given source and behavioural properties and generate POJOs. The current implementation acts as a wrapper around the command line interface.
-
org.jsoup.Connection.execute()
Execute the request.
@return a response object
@throws IOException on error
-
org.jtrim.concurrent.GenericUpdateTaskExecutor.execute()
-
org.jtrim.concurrent.UpdateTaskExecutor.execute()
-
org.jugile.util.DBConnection.execute()
-
org.jvnet.hudson.reactor.Reactor.execute()
-
org.kapott.hbci.manager.HBCIHandler.execute()
Ausf�hren aller bisher erzeugten Auftr�ge. Diese Methode veranlasst den HBCI-Kernel, die Auftr�ge, die durch die Aufrufe der Methode {@link org.kapott.hbci.GV.HBCIJob#addToQueue(String)}zur Auftragsliste hinzugef�gt wurden, auszuf�hren.
Beim Hinzuf�gen der Auftr�ge zur Auftragsqueue (mit {@link org.kapott.hbci.GV.HBCIJob#addToQueue()}oder {@link org.kapott.hbci.GV.HBCIJob#addToQueue(String)}) wird implizit oder explizit eine Kunden-ID mit angegeben, unter der der jeweilige Auftrag ausgef�hrt werden soll. In den meisten F�llen hat ein Benutzer nur eine einzige Kunden-ID, so dass die Angabe entfallen kann, es wird dann automatisch die richtige verwendet. Werden aber mehrere Auftr�ge via addToQueue()
zur Auftragsqueue hinzugef�gt, und sind diese Auftr�ge unter teilweise unterschiedlichen Kunden-IDs auszuf�hren, dann wird f�r jede verwendete Kunden-ID ein separater HBCI-Dialog erzeugt und ausgef�hrt. Das �u�ert sich dann also darin, dass beim Aufrufen der Methode {@link #execute()}u.U. mehrere HBCI-Dialog mit der Bank gef�hrt werden, und zwar je einer f�r jede Kunden-ID, f�r die wenigstens ein Auftrag existiert. Innerhalb eines HBCI-Dialoges werden alle auszuf�hrenden Auftr�ge in m�glichst wenige HBCI-Nachrichten verpackt.
Dazu wird eine Reihe von HBCI-Nachrichten mit dem HBCI-Server der Bank ausgetauscht. Die Menge der dazu verwendeten HBCI-Nachrichten kann dabei nur bedingt beeinflusst werden, da HBCI4Java u.U. selbstst�ndig Nachrichten erzeugt, u.a. wenn ein Auftrag nicht mehr mit in eine Nachricht aufgenommen werden konnte, oder wenn eine Antwortnachricht nicht alle verf�gbaren Daten zur�ckgegeben hat, so dass HBCI4Java mit einer oder mehreren weiteren Nachrichten den Rest der Daten abholt.
Nach dem Nachrichtenaustausch wird ein Status-Objekt zur�ckgegeben, welches zur Auswertung aller ausgef�hrten Dialoge benutzt werden kann.
@return ein Status-Objekt, anhand dessen der Erfolg oder das Fehlschlagender Dialoge festgestellt werden kann.
-
org.kie.api.runtime.CommandExecutor.execute()
-
org.kie.api.runtime.KieSession.execute()
-
org.kie.api.runtime.StatelessKieSession.execute()
-
org.kie.internal.executor.api.Command.execute()
-
org.kie.internal.runtime.StatefulKnowledgeSession.execute()
-
org.kie.internal.runtime.StatelessKnowledgeSession.execute()
-
org.kie.runtime.KieSession.execute()
-
org.kie.runtime.StatefulKnowledgeSession.execute()
-
org.kie.runtime.StatelessKieSession.execute()
-
org.knopflerfish.service.console.CommandGroup.execute()
Executes a command in the command group. The command and its arguments are passed in the args parameter.
@param args argument list
@param out output write for command to print result to
@param in input reader for command to read interactively
@param session a handle to command session or null if single command
@return Status from execution, 0 means okey
-
org.lealone.jdbc.JdbcPreparedStatement.execute()
Executes an arbitrary statement. If another result set exists for this statement, this will be closed (even if this statement fails). If auto commit is on, and the statement is not a select, this statement will be committed.
@return true if a result set is available, false if not
@throws SQLException if this object is closed or invalid
-
org.lealone.jdbc.JdbcStatement.execute()
Executes a statement and returns the update count. This method just calls execute(String sql) internally. The method getGeneratedKeys supports at most one columns and row.
@param sql the SQL statement
@param autoGeneratedKeys ignored
@return the update count (number of row affected by an insert,update or delete, or 0 if no rows or the statement was a create, drop, commit or rollback)
@throws SQLException if a database error occurred or aselect statement was executed
-
org.lealone.util.Task.execute()
Start the thread.
@return this
-
org.lilypondbeans.util.Executor.execute()
-
org.lilystudio.httpclient.HttpClient.execute()
执行一次客户端调用
@param method 用于调用发送请求的方法操作接口
@return 调用产生的状态号
@throws IOException 如果数据传输失败
-
org.locationtech.geogig.cli.GeogigCLI.execute()
Processes a command, catching any exceptions and printing their messages to the console.
@param args
@return 0 for normal exit, -1 if there was an exception.
-
org.locationtech.udig.project.command.PostDeterminedEffectCommand.execute()
This method should return true if the method has changed state and will do something when undone.
@param monitor used to indicate the progress of the monitor.
@return true if the method has changed global state and command should be put on the undo stack.
-
org.locationtech.udig.project.command.UndoableComposite.execute()
-
org.menagerie.ZkCommandExecutor.execute()
-
org.mifosplatform.batch.command.CommandStrategy.execute()
Returns an object of type {@link org.mifosplatform.batch.domain.BatchResponse}. This takes {@link org.mifosplatform.batch.domain.BatchRequest} as it's singleargument and provides appropriate response.
@param batchRequest
@param uriInfo
@return BatchResponse
-
org.milyn.ect.ECTUnEdifactExecutor.execute()
-
org.milyn.ejc.EJCExecutor.execute()
-
org.milyn.function.StringFunctionExecutor.execute()
Takes a StringFunction definition and executes it on a string
@param input The input string
@return The result string
-
org.mitre.medfacts.i2b2.cli.BatchRunner.execute()
-
org.mitre.medfacts.i2b2.scanners.CueListScanner.execute()
-
org.mitre.medfacts.zoner.ZonerCli.execute()
-
org.mmisw.ont.admin.OntologyDeleter.execute()
Executes the POST operation to delete the ontology.
@return The message in the response from the POST operation, prefixed with "OK:" ifthe result was successfull; otherwise, the description of the error prefixed with "ERROR:"
@throws Exception
-
org.mobicents.slee.service.common.SimpleCallFlowState.execute()
-
org.modeshape.jcr.api.query.Query.execute()
-
org.modeshape.jcr.api.sequencer.Sequencer.execute()
Execute the sequencing operation on the specified property, which has recently been created or changed.
Each sequencer is expected to process the value of the property, extract information from the value, and write a structured representation (in the form of a node or a subgraph of nodes) using the supplied output node. Note that the output node will either be:
- the selected node, in which case the sequencer was configured to generate the output information directly under the selected input node; or
- a newly created node in a different location than node being sequenced (in this case, the primary type of the new node will be 'nt:unstructured', but the sequencer can easily change that using {@link Node#setPrimaryType(String)})
The implementation is expected to always clean up all resources that it acquired, even in the case of exceptions.
Note: This method must be threadsafe: ModeShape will likely invoke this method concurrently in separate threads, and the method should never modify the state or fields of the Sequencer implementation class. All initialization should be performed in {@link #initialize(NamespaceRegistry,NodeTypeManager)}.
@param inputProperty the property that was changed and that should be used as the input; never null
@param outputNode the node that represents the output for the derived information; never null, and will either be{@link Node#isNew() new} if the output is being placed outside of the selected node, or will not be new when theoutput is to be placed on the selected input node
@param context the context in which this sequencer is executing, and which may contain additional parameters useful whengenerating the output structure; never null
@return true if the sequencer's output should be saved, or false otherwise
@throws Exception if there was a problem with the sequencer that could not be handled. All exceptions will be loggedautomatically as errors by ModeShape.
-
org.modeshape.jcr.query.CancellableQuery.execute()
Execute the query and get the results. Note that this method can be called by multiple threads, and all will block until the query execution has completed. Subsequent calls to this method will return the same results.
@return the query results.
@throws QueryCancelledException if the query was cancelled
@throws RepositoryException if there was a problem executing the query
-
org.modeshape.jcr.query.QueryEngine.execute()
Execute the supplied query by planning, optimizing, and then processing it.
@param context the context in which the query should be executed
@param query the query that is to be executed
@return the query results; never null
@throws IllegalArgumentException if the context or query references are null
@throws QueryCancelledException if the query was cancelled
@throws RepositoryException if there was a problem executing the query
-
org.mokai.Action.execute()
This method is called by the routing engine to execute the action.
@param message the message that is being routed.
@throws Exception if something goes wrong.
-
org.mokai.action.AddPrefixAction.execute()
-
org.mokai.action.AddSpacesAction.execute()
-
org.mokai.action.AddSuffixAction.execute()
-
org.mokai.action.ConcatAction.execute()
-
org.mokai.action.CopyAction.execute()
-
org.mokai.action.JsonParserAction.execute()
-
org.mokai.action.RemoveAction.execute()
-
org.mokai.action.ReplaceAction.execute()
-
org.mokai.action.UpdateAction.execute()
-
org.mokai.action.mail.EmailToSmsAction.execute()
-
org.moresbycoffee.mbyhave8.MByHaveSpec.execute()
-
org.moresbycoffee.mbyhave8.structure.Scenario.execute()
-
org.moresbycoffee.mbyhave8.structure.Step.execute()
-
org.mule.api.FutureMessageResult.execute()
Start asynchronous execution of this task
-
org.mule.api.client.LocalMuleClient.execute()
-
org.mule.api.execution.ExecutionTemplate.execute()
-
org.mule.api.retry.RetryPolicyTemplate.execute()
-
org.mule.execution.ErrorHandlingExecutionTemplate.execute()
-
org.mule.execution.MessageProcessorExecutionTemplate.execute()
-
org.mule.execution.TransactionalErrorHandlingExecutionTemplate.execute()
-
org.mule.module.db.internal.domain.executor.BulkExecutor.execute()
Executes a bulk query
@param connection connection to the database where the query will be executed. Non null
@param bulkQuery contains a group of non parameterized queries to execute
@return a non null result of the query execution
@throws SQLException if a database access error occurs or this method is called on a closed connection
-
org.mule.module.db.internal.domain.executor.QueryExecutor.execute()
Executes a query
@param connection connection to the database where the query will be executed. Non null
@param query query to execute. Non null
@return a non null result of the query execution
@throws SQLException if a database access error occurs or this method is called on a closed connection
-
org.mule.module.db.internal.domain.executor.SelectExecutor.execute()
-
org.mule.module.db.internal.domain.executor.UpdateExecutor.execute()
-
org.mule.module.launcher.artifact.ShutdownListener.execute()
-
org.mule.retry.async.AsynchronousRetryTemplate.execute()
-
org.mule.transaction.TransactionTemplate.execute()
-
org.nanocontainer.nanowar.sample.webwork1.CheeseAction.execute()
-
org.neo4j.cypher.ExecutionEngine.execute()
-
org.neo4j.cypher.javacompat.ExecutionEngine.execute()
-
org.nutz.socialauth.alipay.util.httpClient.HttpProtocolHandler.execute()
执行Http请求
@param request
@return
-
org.objectstyle.woproject.ant.JApplication.execute()
-
org.odbms.Query.execute()
executes the query.
@return ObjectSet - the resultset of the Query
-
org.odmg.OQLQuery.execute()
Execute the query. After executing a query, the parameter list is reset. Some implementations may throw additional exceptions that are also derived from ODMGException
.
@return The object that represents the result of the query.The returned data, whatever its OQL type, is encapsulated into an object. For instance, when OQL returns an integer, the result is put into an Integer
object. When OQL returns a collection (literal or object), the result is always a Java collection object of the same kind (for instance, a DList
).
@exception QueryException An exception has occurred while executing the query.
-
org.ofbiz.service.xmlrpc.XmlRpcClient.execute()
-
org.ogce.gfac.provider.Provider.execute()
-
org.olat.core.dispatcher.mapper.MapperRegistry.execute()
@param hreq
@param hres
-
org.open2jam.gui.ChartModelLoader.execute()
-
org.openbp.server.handler.Handler.execute()
Executes the handler. Implement this method to execute the business logic of the activity.
@param hc Handler context that contains execution parameters
@return true if the handler handled the event, false to apply the default handling to the event
@throws Exception Any exception that may occur during execution of the handler will bepropagated to an exception handler if defined or abort the process execution otherwise.
-
org.openbravo.erpCommon.modules.ImportModule.execute()
Executes the modules installation, first one of the checkDependencies method should have been called in order to set the installable and updateable modules. This method receives a filename
-
org.openbravo.erpCommon.modules.UninstallModule.execute()
Executes the uninstall process for a comma separated list of modules, all these modules will be uninstalled as well as all their contained modules.
@param moduleIdList Comma separated list of module ids
-
org.openfaces.component.table.DataTablePaginatorAction.execute()
-
org.openhab.binding.digitalstrom.internal.client.job.SensorJob.execute()
-
org.openhab.binding.dmx.internal.cmd.DmxCommand.execute()
Execute a DMX command.
@param service on which to execute the command.
-
org.openhab.binding.netatmo.internal.messages.RefreshTokenRequest.execute()
-
org.openhab.binding.xbmc.rpc.calls.ApplicationGetProperties.execute()
-
org.openhab.binding.xbmc.rpc.calls.ApplicationSetVolume.execute()
-
org.openhab.binding.xbmc.rpc.calls.FilesPrepareDownload.execute()
-
org.openhab.binding.xbmc.rpc.calls.GUIShowNotification.execute()
-
org.openhab.binding.xbmc.rpc.calls.JSONRPCPing.execute()
-
org.openhab.binding.xbmc.rpc.calls.PlayerGetActivePlayers.execute()
-
org.openhab.binding.xbmc.rpc.calls.PlayerGetItem.execute()
-
org.openhab.binding.xbmc.rpc.calls.PlayerOpen.execute()
-
org.openhab.binding.xbmc.rpc.calls.PlayerPlayPause.execute()
-
org.openhab.binding.xbmc.rpc.calls.PlayerStop.execute()
-
org.openhab.binding.xbmc.rpc.calls.SystemHibernate.execute()
-
org.openhab.binding.xbmc.rpc.calls.SystemReboot.execute()
-
org.openhab.binding.xbmc.rpc.calls.SystemShutdown.execute()
-
org.openhab.binding.xbmc.rpc.calls.SystemSuspend.execute()
-
org.openhab.core.scriptengine.Script.execute()
Executes the script instance and returns the execution result
@return the execution result or null
, if the script does not have a return value
@throws ScriptExecutionException if an error occurs during the execution
-
org.openinvoice.ubl4j.task.create.order.CreateInvoiceBasedOnOrderTask.execute()
-
org.openinvoice.ubl4j.task.render.InvoiceRenderingTask.execute()
-
org.openqa.selenium.internal.CommandLine.execute()
-
org.openqa.selenium.os.CommandLine.execute()
-
org.openqa.selenium.remote.server.Session.execute()
-
org.openrdf.http.client.connections.HTTPRequest.execute()
-
org.openrdf.query.Update.execute()
-
org.opensocial.http.HttpClient.execute()
-
org.openspp.command.SpppCommand.execute()
-
org.openstreetmap.josm.corrector.ReverseWayTagCorrector.execute()
-
org.openstreetmap.osmosis.core.pipeline.common.Pipeline.execute()
Launches the execution of the tasks within the pipeline.
-
org.openxri.pipeline.Pipeline.execute()
A pipeline is executed by consecutively executing all its stages. The result XRD of one stage becomes the input XRD of the next.
@param store The store from which the authorities were retrieved.
@param xrd A XRD that is passed into the pipeline.
@param segment The XRI segment that resolves to the XRD being processed.
@param parent The parent authority, i.e. the authority describing the XRD.
@param subSegmentName The name of the subsegment that connects the two authorities.
@param authority The authority, i.e. the authority described by the XRD.
@return The result XRD of the pipeline.
@throws StageException
-
org.osgi.service.command.CommandSession.execute()
Execute a program in this session.
@param commandline ###
@return the result of the execution
@throws Exception ###
-
org.pdfsam.console.business.ConsoleServicesFacade.execute()
execute parsedCommand
@param parsedCommand
@throws ConsoleException.
-
org.pdtextensions.core.launch.execution.ScriptExecutor.execute()
-
org.pentaho.cdf.render.CdfHtmlRenderer.execute()
-
org.pentaho.cdf.xactions.ActionEngine.execute()
-
org.pentaho.di.job.Job.execute()
-
org.pentaho.di.trans.Trans.execute()
-
org.pentaho.mantle.client.commands.AbstractCommand.execute()
Checks if the user is logged in, if the user is then it perform operation other wise user if ask to perform the login operation again
@param feedback if the feedback needs to be sent back to the caller. Not used currently
-
org.pentaho.mantle.client.commands.FilePropertiesCommand.execute()
-
org.pentaho.mantle.client.commands.NewDropdownCommand.execute()
-
org.pentaho.mantle.client.commands.NewFolderCommand.execute()
-
org.pentaho.mantle.client.commands.OpenDocCommand.execute()
-
org.pentaho.mantle.client.commands.OpenFileCommand.execute()
-
org.pentaho.mantle.client.commands.PrintCommand.execute()
-
org.pentaho.mantle.client.commands.RefreshRepositoryCommand.execute()
-
org.pentaho.mantle.client.commands.RefreshSchedulesCommand.execute()
-
org.pentaho.mantle.client.commands.SaveCommand.execute()
-
org.pentaho.mantle.client.commands.ShareFileCommand.execute()
-
org.pentaho.mantle.client.commands.ShowBrowserCommand.execute()
-
org.pentaho.mondrian.publish.PublishToServerCommand.execute()
-
org.pentaho.platform.api.data.IDataComponent.execute()
-
org.pentaho.platform.api.engine.ISolutionEngine.execute()
Executes the action sequence specified
@param runtime The runtime context for the execution
@param actionPath path to the action
@param processId id for the given process, typically a GUID or unique id for this execution
@param async true if the execution should be asynchronous.
@param instanceEnds currently true indicating that the process ends with this execution
@param parameterProviderMap Map of parameter providers to use for the execution
@param outputHandler The output handler for dealing with user feedback
@return The runtime context for the execution
@see IRuntimeContext
@see IParameterProvider
@see IActionSequence
-
org.pentaho.platform.plugin.action.pentahometadata.MetadataQueryComponent.execute()
-
org.pentaho.platform.repository2.unified.jcr.JcrRepositoryDumpToFile.execute()
-
org.persvr.job.Job.execute()
-
org.persvr.job.Upgrade.execute()
-
org.prevayler.Prevayler.execute()
Executes the given Transaction on the prevalentSystem(). ALL operations that alter the observable state of the prevalentSystem() must be implemented as Transaction or TransactionWithQuery objects and must be executed using the Prevayler.execute() methods. This method synchronizes on the prevalentSystem() to execute the Transaction. It is therefore guaranteed that only one Transaction is executed at a time. This means the prevalentSystem() does not have to worry about concurrency issues among Transactions. Implementations of this interface can log the given Transaction for crash or shutdown recovery, for example, or execute it remotely on replicas of the prevalentSystem() for fault-tolerance and load-balancing purposes.
@see org.prevayler.PrevaylerFactory
-
org.prevayler.util.memento.MementoTransaction.execute()
Executes this command on the received system. See prevayler.demos for examples. The returned object has to be Serializable in preparation for future versions of Prevayler that will provide fault-tolerance through system replicas.
@param collector The memento collector to which to add the mementos. A mementocollector instead of a Prevayler instance is passed, so the command will not easily invoke subcommands through the prevayler (which is not allowed).
@param prevalentSystem The system on which to execute the command.
@return The object returned by the execution of this command. Most commands simply return null.
-
org.primefaces.context.RequestContext.execute()
Execute a javascript after current ajax request is completed.
@param script Javascript statement to execute.
-
org.puremvc.java.multicore.interfaces.ICommand.execute()
Execute the ICommand
's logic to handle a given INotification
.
@param notification an INotification
to handle.
-
org.qi4j.tools.shell.help.HelpCommand.execute()
-
org.quartz.Job.execute()
Called by the {@link Scheduler}
when a {@link Trigger}
fires that is associated with the Job
.
The implementation may wish to set a {@link JobExecutionContext#setResult(Object) result} object on the {@link JobExecutionContext} before this method exits. The result itselfis meaningless to Quartz, but may be informative to {@link JobListener}s
or {@link TriggerListener}s
that are watching the job's execution.
@throws JobExecutionException if there is an exception while executing the job.
-
org.quartz.spi.ThreadExecutor.execute()
Submit a task for execution
@param thread the thread to execute
-
org.qzerver.model.agent.action.providers.ActionExecutor.execute()
Execute action. Method should catch any exception occured and return a correct result descriptor
@param actionDefinition Definition of an action
@param scheduleExecutionId Execution identifier
@param nodeAddress Node address
@return Result of an action
-
org.red5.server.api.scheduling.IScheduledJob.execute()
Called each time the job is triggered by the scheduling service.
@param service the service that called the job
@throws CloneNotSupportedException throws if Darth Vader attempts to usethis object for his own nefarious purposes.
-
org.reficio.p2.bundler.ArtifactBundler.execute()
-
org.reficio.p2.publisher.BundlePublisher.execute()
-
org.reficio.p2.publisher.CategoryPublisher.execute()
-
org.rhq.common.jbossas.client.controller.DatasourceJBossASClient.execute()
-
org.rhq.common.jbossas.client.controller.InfinispanJBossASClient.execute()
-
org.rhq.common.jbossas.client.controller.JBossASClient.execute()
Convienence method that executes the request.
@param request
@return results
@throws Exception
-
org.rhq.common.jbossas.client.controller.MessagingJBossASClient.execute()
-
org.rhq.common.jbossas.client.controller.VaultJBossASClient.execute()
-
org.rhq.core.db.upgrade.DatabaseUpgradeTask.execute()
-
org.rhq.enterprise.agent.promptcmd.AgentPromptCommand.execute()
Executes the agent prompt command with the given arguments.
@param agent the agent itself
@param args the arguments passed to the agent on the agent prompt
@return true
if the agent can continue accepting prompt commands; false
if the agentshould die
-
org.rhq.enterprise.agent.promptcmd.PluginContainerPromptCommand.execute()
@see AgentPromptCommand#execute(AgentMain,String[])
-
org.rhq.enterprise.client.commands.ClientCommand.execute()
Executes the agent prompt command with the given arguments.
@param client the ClientMain class itself
@param args the arguments passed to the agent on the agent prompt
@return true
if the agent can continue accepting prompt commands; false
if theagent should die
-
org.rhq.enterprise.client.commands.LoginCommand.execute()
-
org.rhq.enterprise.client.commands.LogoutCommand.execute()
-
org.rhq.enterprise.server.resource.group.definition.framework.ExpressionEvaluator.execute()
-
org.rhq.enterprise.server.util.CriteriaQueryRunner.execute()
-
org.rhq.modules.plugins.jbossas7.ASConnection.execute()
Execute the passed Operation and return its Result. This is a shortcut of #execute(Operation, false)
@param op Operation to execute
@return Result of the execution
@see #execute(org.rhq.modules.plugins.jbossas7.json.Operation,boolean)
-
org.rhq.server.metrics.StorageSession.execute()
-
org.richfaces.test.staging.StagingConnection.execute()
Execute this connection request on the associated servlet or filter chain.
@throws TestException if any errors were during execution.
-
org.rsbot.script.web.Route.execute()
-
org.rstudio.core.client.widget.Operation.execute()
-
org.rzo.yajsw.action.Action.execute()
-
org.rzo.yajsw.script.Script.execute()
Execute.
@param id the id
@param state the state
@param count the count
@param pid the pid
@param exitCode the exit code
@param line the line
@param wrapperJavaProcess the wrapper java process
-
org.saiku.olap.query.IQuery.execute()
-
org.salamanca.commands.ICommand.execute()
-
org.salamandra.web.core.transformer.Transformer.execute()
-
org.scale7.cassandra.pelops.Mutator.execute()
Execute the mutations that have been specified by sending them to Cassandra in a single batch.
@param cLevel The Cassandra consistency level to be used
@throws PelopsException
-
org.semanticweb.HermiT.debugger.commands.DebuggerCommand.execute()
-
org.serviceconnector.api.cln.SCSessionService.execute()
Execute with default operation timeout. Execute is a synchronous operation with the SC. Any reply will be received as return of the method.
@param requestMsg the request message
@return the SC message
@throws SCServiceException session not active (not created yet or dead)
pending request, no second request allowed
execute on SC failed
error message received from SC
@throws SCMPValidatorException execute message is null
-
org.serviceconnector.server.CascadedSC.execute()
Execute.
@param msgToForward the message to forward
@param callback the callback
@param timeoutMillis the timeout milliseconds
-
org.serviceconnector.server.StatefulServer.execute()
Send data. Tries sending data to server asynchronous.
@param message the message
@param callback the callback
@param timeoutMillis the timeout millis
@throws ConnectionPoolBusyException the connection pool busy exception
-
org.sf.bee.commons.net.http.SimpleHttpClient.execute()
-
org.sfsoft.descargarficheros.tareas.Descarga.execute()
-
org.simpleframework.util.thread.Scheduler.execute()
This will execute the task within the executor immediately as it uses a delay duration of zero milliseconds. This can be used if the scheduler is to be used as a thread pool.
@param task this is the task to schedule for execution
-
org.skife.jdbi.v2.Batch.execute()
Execute all the queued up statements
@return an array of integers representing the return values from each statement's execution
-
org.skife.jdbi.v2.PreparedBatch.execute()
Execute the batch
@return the number of rows modified or inserted per batch part.
-
org.skife.jdbi.v2.Update.execute()
Execute the statement
@return the number of rows modified
-
org.snova.http.client.HttpClient.execute()
-
org.socialmusicdiscovery.server.business.logic.SearchRelationPostProcessor.execute()
-
org.sonar.api.task.Task.execute()
-
org.sonar.api.utils.command.CommandExecutor.execute()
@throws org.sonar.api.utils.command.TimeoutException on timeout, since 4.4
@throws CommandException on any other error
@param timeoutMilliseconds any negative value means no timeout.
@since 3.0
-
org.sonar.batch.scan.ProjectReactorBuilder.execute()
-
org.sonar.ide.intellij.worker.RefreshProjectListWorker.execute()
-
org.sonar.ide.intellij.worker.RefreshRuleWorker.execute()
-
org.sonar.ide.intellij.worker.ResourceLookupWorker.execute()
-
org.sonar.runner.api.Runner.execute()
-
org.sonar.server.db.migrations.MassUpdate.execute()
-
org.sonar.server.db.migrations.Upsert.execute()
-
org.sonatype.maven.shell.maven.MavenRuntime.execute()
-
org.sosy_lab.crocopat.cli.ExecuteCrocopat.execute()
Execute Crocopat with the given RML and RSF input. Return a list of all output.
@param rml
@param rsf
@return a list of output strings
@throws IOException
@throws CrocopatException if Crocopat wrote something to stderr
-
org.soybeanMilk.core.DefaultExecutor.execute()
-
org.soybeanMilk.core.Executor.execute()
执行,并返回可执行对象。
@param executableName 可执行对象名称
@param objSource 对象源
@throws ExecuteException
@throws ExecutableNotFoundException
-
org.soybeanMilk.core.exe.Invoke.execute()
-
org.spout.vanilla.util.explosion.ExplosionModel.execute()
-
org.spout.vanilla.util.explosion.ExplosionModelSpherical.execute()
-
org.springframework.amqp.rabbit.core.RabbitTemplate.execute()
-
org.springframework.batch.core.Job.execute()
Run the {@link JobExecution} and update the meta information like statusand statistics as necessary. This method should not throw any exceptions for failed execution. Clients should be careful to inspect the {@link JobExecution} status to determine success or failure.
@param execution a {@link JobExecution}
-
org.springframework.batch.core.Step.execute()
Process the step and assign progress and status meta information to the {@link StepExecution} provided. The{@link Step} is responsible for setting the meta information and also saving it if required by theimplementation.
It is not safe to re-use an instance of {@link Step} to process multiple concurrent executions.
@param stepExecution an entity representing the step to be executed
@throws JobInterruptedException if the step is interrupted externally
-
org.springframework.batch.core.step.AbstractStep.execute()
Template method for step execution logic - calls abstract methods for resource initialization ( {@link #open(ExecutionContext)}), execution logic ( {@link #doExecute(StepExecution)}) and resource closing ( {@link #close(ExecutionContext)}).
-
org.springframework.batch.core.step.tasklet.Tasklet.execute()
Given the current context in the form of a step contribution, do whatever is necessary to process this unit inside a transaction. Implementations return {@link RepeatStatus#FINISHED} if finished. If not they return{@link RepeatStatus#CONTINUABLE}. On failure throws an exception.
@param contribution mutable state to be passed back to update the currentstep execution
@param chunkContext attributes shared between invocations but not betweenrestarts
@return an {@link RepeatStatus} indicating whether processing iscontinuable.
-
org.springframework.binding.convert.ConversionExecutor.execute()
Execute the conversion for the provided source object.
@param source the source object to convert
-
org.springframework.cassandra.core.CqlTemplate.execute()
-
org.springframework.core.task.AsyncTaskExecutor.execute()
Execute the given task
.
@param task the Runnable
to execute (never null
)
@param startTimeout the time duration (milliseconds) within which the task issupposed to start. This is intended as a hint to the executor, allowing for preferred handling of immediate tasks. Typical values are {@link #TIMEOUT_IMMEDIATE}or {@link #TIMEOUT_INDEFINITE} (the default as used by {@link #execute(Runnable)}).
@throws TaskTimeoutException in case of the task being rejected becauseof the timeout (i.e. it cannot be started in time)
@throws TaskRejectedException if the given task was not accepted
-
org.springframework.core.task.SimpleAsyncTaskExecutor.execute()
Executes the given task, within a concurrency throttle if configured (through the superclass's settings).
@see #doExecute(Runnable)
-
org.springframework.core.task.TaskExecutor.execute()
Execute the given
task
.
The call might return immediately if the implementation uses an asynchronous execution strategy, or might block in the case of synchronous execution.
@param task the Runnable
to execute (never null
)
@throws TaskRejectedException if the given task was not accepted
-
org.springframework.data.cassandra.core.CassandraAdminTemplate.execute()
-
org.springframework.data.hadoop.batch.pig.PigTasklet.execute()
-
org.springframework.data.jpa.repository.query.JpaQueryExecution.ModifyingExecution.execute()
-
org.springframework.data.mongodb.core.MongoTemplate.execute()
-
org.springframework.data.redis.core.StringRedisTemplate.execute()
-
org.springframework.data.repository.query.RepositoryQuery.execute()
Executes the {@link RepositoryQuery} with the given parameters.
@param store
@param parameters
@return
-
org.springframework.expression.ConstructorExecutor.execute()
Execute a constructor in the specified context using the specified arguments.
@param context the evaluation context in which the command is being executed
@param arguments the arguments to the constructor call, should match (in terms of number and type) whatever thecommand will need to run
@return the new object
@throws AccessException if there is a problem executing the command or the CommandExecutor is no longer valid
-
org.springframework.expression.MethodExecutor.execute()
Execute a command using the specified arguments, and using the specified expression state.
@param context the evaluation context in which the command is being executed
@param target the target object of the call - null for static methods
@param arguments the arguments to the executor, should match (in terms of number and type) whatever thecommand will need to run
@return the value returned from execution
@throws AccessException if there is a problem executing the command or the MethodExecutor is no longer valid
-
org.springframework.extensions.jcr.JcrTemplate.execute()
-
org.springframework.extensions.webscripts.WebScript.execute()
-
org.springframework.http.client.ClientHttpRequest.execute()
Execute this request, resulting in a {@link ClientHttpResponse} that can be read.
@return the response result of the execution
@throws IOException in case of I/O errors
-
org.springframework.jca.cci.core.CciTemplate.execute()
-
org.springframework.jca.cci.object.SimpleRecordOperation.execute()
Execute the CCI interaction encapsulated by this operation object.
This method will call CCI's Interaction.execute
variant that returns an output Record.
@param inputRecord the input record
@return the output record
@throws DataAccessException if there is any problem
@see javax.resource.cci.Interaction#execute(javax.resource.cci.InteractionSpec,Record)
-
org.springframework.jdbc.core.JdbcOperations.execute()
Execute a JDBC data access operation, implemented as callback action working on a JDBC Connection. This allows for implementing arbitrary data access operations, within Spring's managed JDBC environment: that is, participating in Spring-managed transactions and converting JDBC SQLExceptions into Spring's DataAccessException hierarchy.
The callback action can return a result object, for example a domain object or a collection of domain objects.
@param action the callback object that specifies the action
@return a result object returned by the action, or null
@throws DataAccessException if there is any problem
-
org.springframework.jdbc.core.JdbcTemplate.execute()
-
org.springframework.jdbc.core.simple.SimpleJdbcCall.execute()
-
org.springframework.jdbc.core.simple.SimpleJdbcInsert.execute()
-
org.springframework.jdbc.datasource.init.ResourceDatabasePopulator.execute()
Execute this {@code ResourceDatabasePopulator} against the given{@link DataSource}.
Delegates to {@link DatabasePopulatorUtils#execute}.
@param dataSource the {@code DataSource} to execute against; never {@code null}
@throws ScriptException if an error occurs
@since 4.1
@see #populate(Connection)
-
org.springframework.jdbc.object.StoredProcedure.execute()
Execute the stored procedure. Subclasses should define a strongly typed execute method (with a meaningful name) that invokes this method, populating the input map and extracting typed values from the output map. Subclass execute methods will often take domain objects as arguments and return values. Alternatively, they can return void.
@param inParams map of input parameters, keyed by name as in parameterdeclarations. Output parameters need not (but can be) included in this map. It is legal for map entries to be null
, and this will produce the correct behavior using a NULL argument to the stored procedure.
@return map of output params, keyed by name as in parameter declarations.Output parameters will appear here, with their values after the stored procedure has been called.
-
org.springframework.jms.core.JmsTemplate.execute()
-
org.springframework.jms.core.JmsTemplate102.execute()
-
org.springframework.jndi.JndiTemplate.execute()
Execute the given JNDI context callback implementation.
@param contextCallback JndiCallback implementation
@return a result object returned by the callback, or null
@throws NamingException thrown by the callback implementation
@see #createInitialContext
-
org.springframework.orm.hibernate3.HibernateTemplate.execute()
-
org.springframework.retry.support.RetryTemplate.execute()
Keep executing the callback until it either succeeds or the policy dictates that we stop, in which case the most recent exception thrown by the callback will be rethrown.
@see RetryOperations#execute(RetryCallback)
@throws TerminatedRetryException if the retry has been manually terminated by alistener.
-
org.springframework.richclient.application.setup.SetupWizard.execute()
-
org.springframework.richclient.command.ActionCommand.execute()
-
org.springframework.richclient.command.ActionCommandExecutor.execute()
Performs the action.
-
org.springframework.roo.addon.tailor.actions.Action.execute()
Triggers action execution
@param command - resource to be processed
@param config - configuration of action
-
org.springframework.roo.shell.eclipse.Bootstrap.execute()
-
org.springframework.scheduling.concurrent.ThreadPoolTaskExecutor.execute()
Implementation of both the JDK 1.5 Executor interface and the Spring TaskExecutor interface, delegating to the ThreadPoolExecutor instance.
@see java.util.concurrent.Executor#execute(Runnable)
@see org.springframework.core.task.TaskExecutor#execute(Runnable)
-
org.springframework.transaction.support.TransactionOperations.execute()
Execute the action specified by the given callback object within a transaction.
Allows for returning a result object created within the transaction, that is, a domain object or a collection of domain objects. A RuntimeException thrown by the callback is treated as a fatal exception that enforces a rollback. Such an exception gets propagated to the caller of the template.
@param action the callback object that specifies the transactional action
@return a result object returned by the callback, or null
if none
@throws TransactionException in case of initialization, rollback, or system errors
@throws RuntimeException if thrown by the TransactionCallback
-
org.springframework.transaction.support.TransactionTemplate.execute()
-
org.springframework.util.exec.Execute.execute()
Creates a new execute object using PumpStreamHandler
for stream handling.
-
org.springframework.web.client.RestOperations.execute()
Execute the HTTP method to the given URI template, preparing the request with the {@link RequestCallback}, and reading the response with a {@link ResponseExtractor}.
URI Template variables are expanded using the given URI variables, if any.
@param url the URL
@param method the HTTP method (GET, POST, etc)
@param requestCallback object that prepares the request
@param responseExtractor object that extracts the return value from the response
@param uriVariables the variables to expand in the template
@return an arbitrary object, as returned by the {@link ResponseExtractor}
-
org.springframework.web.client.RestTemplate.execute()
-
org.springframework.webflow.execution.AnnotatedAction.execute()
-
org.springframework.yarn.boot.SpringApplicationTemplate.execute()
Execute spring application from a builder. This method will automatically close a context associated with a spring application.
@param action the action callback
@param args the boot application args
@param < T> return type
@return the value from an execution
-
org.springmodules.jcr.JcrTemplate.execute()
@see org.springmodules.jcr.JcrOperations#execute(org.springmodules.jcr.JcrCallback,boolean)
-
org.springmodules.prevayler.system.PrevalentSystem.execute()
-
org.springmodules.workflow.jbpm30.JbpmTemplate.execute()
Execute the action specified by the given action object within a JbpmSession.
@param callback
@return
-
org.springside.modules.nosql.redis.JedisTemplate.execute()
Execute with a call back action with result.
-
org.sqlite.ExtendedCommand.SQLExtension.execute()
-
org.squirrelframework.foundation.component.Heartbeat.execute()
Executes all commands since the most recent {@link #begin()}.
-
org.strecks.action.BasicAction.execute()
-
org.strecks.action.BasicFormAction.execute()
Do any necessary pre-processing before returning a String
, which will be mapped to an ActionForward
using ActionMapping.findForward(String)
-
org.strecks.action.BasicSubmitAction.execute()
Executed after form validation and domain model binding has occurred, if a html:cancel button was not used
-
org.strecks.action.NavigableAction.execute()
-
org.strecks.action.NavigableFormAction.execute()
-
org.strecks.action.NavigableSubmitAction.execute()
Executed after form validation and domain model binding has occurred, if a html:cancel button was not used
-
org.strecks.action.navigable.impl.NavigableFormRenderBean.execute()
-
org.strecks.action.navigable.impl.NavigableFormSubmitBean.execute()
-
org.strecks.action.navigable.impl.NavigableReadOnlyBean.execute()
-
org.structr.core.graph.CreateRelationshipCommand.execute()
-
org.structr.core.graph.DeleteNodeCommand.execute()
-
org.structr.core.graph.MaintenanceCommand.execute()
-
org.svnadmin.service.AjaxService.execute()
执行逻辑
@param parameters 参数
@return 结果
-
org.syncany.operations.init.ConnectOperation.execute()
-
org.syncany.operations.init.GenlinkOperation.execute()
-
org.syncany.operations.init.InitOperation.execute()
-
org.syncany.operations.ls.LsOperation.execute()
-
org.syncany.operations.ls_remote.LsRemoteOperation.execute()
-
org.syncany.operations.restore.RestoreOperation.execute()
-
org.syncany.operations.status.StatusOperation.execute()
-
org.syncany.operations.up.UpOperation.execute()
-
org.syrup.Function.execute()
Generates a Result given a Task's Context. Implementations should not throw Exceptions, retain Objects or any other resources after the calling Thread exits this method.
@param context The Context from which the Function get its parameters.
@return The Result after execution.
-
org.teavm.common.FiniteExecutor.execute()
-
org.teavm.common.SimpleFiniteExecutor.execute()
-
org.teiid.dqp.internal.datamgr.ConnectorWorkItem.execute()
-
org.teiid.dqp.internal.process.ThreadReuseExecutor.execute()
-
org.teiid.jdbc.AbstractQueryTest.execute()
-
org.teiid.query.optimizer.relational.OptimizerRule.execute()
-
org.teiid.test.framework.query.QueryExecution.execute()
-
org.teiid.translator.Execution.execute()
Execute the associated command. Results will be retrieved through a specific sub-interface call.
@throws TranslatorException
-
org.teiid.translator.ProcedureExecution.execute()
-
org.teiid.translator.salesforce.execution.QueryExecutionImpl.execute()
-
org.testng.TestNGAntTask.execute()
Launches TestNG in a new JVM. {@inheritDoc}
-
org.thymeleaf.standard.expression.EqualsExpression.execute()
-
org.thymeleaf.standard.expression.Expression.execute()
-
org.thymeleaf.standard.expression.IStandardExpression.execute()
Execute the expression.
@param configuration the Configuration object for the template execution environment.
@param processingContext the processing context object containing the variables to be applied to the expression.
@return the result of executing the expression.
-
org.tmatesoft.hg.core.HgAnnotateCommand.execute()
Annotate selected file
@param inspector
@throws HgException subclass thereof to indicate specific issue with the command arguments or repository state
@throws HgCallbackTargetException
@throws CancelledException if execution of the command was cancelled
-
org.tmatesoft.hg.core.HgCatCommand.execute()
Runs the command with current set of parameters and pipes data to provided sink.
@param sink output channel to write data to.
@throws HgBadArgumentException if no target file node found
@throws HgException subclass thereof to indicate specific issue with the command arguments or repository state
@throws CancelledException if execution of the command was cancelled
@throws IllegalArgumentException when command arguments are incomplete or wrong
-
org.tmatesoft.hg.core.HgCloneCommand.execute()
@return
@throws HgBadArgumentException
@throws HgRemoteConnectionException
@throws HgRepositoryNotFoundException
@throws HgException
@throws CancelledException
-
org.tmatesoft.hg.core.HgCommitCommand.execute()
@throws HgException subclass thereof to indicate specific issue with the command arguments or repository state
@throws HgRepositoryLockException if failed to lock the repo for modifications
@throws IOException propagated IO errors from status walker over working directory
@throws CancelledException if execution of the command was cancelled
-
org.tmatesoft.hg.core.HgLogCommand.execute()
Similar to {@link #execute(HgChangesetHandler)}, collects and return result as a list.
@see #execute(HgChangesetHandler)
@throws HgException subclass thereof to indicate specific issue with the command arguments or repository state
-
org.tmatesoft.hg.core.HgMergeCommand.execute()
-
org.tmatesoft.hg.core.HgPullCommand.execute()
-
org.tmatesoft.hg.core.HgPushCommand.execute()
-
org.tmatesoft.hg.core.HgStatusCommand.execute()
Perform status operation according to parameters set.
@param statusHandler callback to get status information
@throws HgCallbackTargetException propagated exception from the handler
@throws HgException subclass thereof to indicate specific issue with the command arguments or repository state
@throws IOException if there are (further unspecified) errors while walking working copy
@throws CancelledException if execution of the command was cancelled
@throws IllegalArgumentException if handler is null
@throws ConcurrentModificationException if this command already runs (i.e. being used from another thread)
-
org.tmatesoft.svn.core.internal.server.dav.handlers.ServletDAVHandler.execute()
-
org.tubo.resource.component.Component.execute()
-
org.uberfire.mvp.Command.execute()
-
org.uengine.kernel.ProcessInstance.execute()
-
org.unidal.initialization.ModuleInitializer.execute()
-
org.useware.kernel.gui.reification.pipeline.ReificationPipeline.execute()
-
org.vertx.java.core.impl.DefaultContext.execute()
-
org.vfny.geoserver.Response.execute()
Excecutes a request. If this method finalizes without throwing an Exception, the Response instance should be ready to write the response content through the writeTo method with the minimal posible risk of failure other than not beeing able to write to the output stream due to external reassons
We should clarify when a ServiceException is thrown? I would assume that a "failed" request should still result in a Response that we could write out.
@param request a Request object that implementations should cast to it'sRequest specialization, wich must contain the parsed and ready to use parameters sent by the calling client. In general, such a Request will be created by either a KVP or XML request reader; resulting in a Request object more usefull than a set of raw parameters, as can be the list of feature types requested as a set of FeatureTypeInfo objects rather than just a list of String type names
@throws ServiceException
-
org.vfny.geoserver.wms.responses.GetMapResponse.execute()
Implements the map production logic for a WMS GetMap request, delegating the encoding to the appropriate output format to a {@link GetMapProducer}appropriate for the required format.
Preconditions:
- request.getLayers().length > 0
- request.getStyles().length == request.getLayers().length
@param req a {@link GetMapRequest}
@throws ServiceException if an error occurs creating the map from the provided request TODO: This method have become a 300+ lines monster, refactore it to private methods from which names one can inferr what's going on... but get a decent test coverage on it first as to avoid regressions as much as possible
-
org.vfny.geoserver.wms.responses.featureInfo.FeatureTimeTemplate.execute()
Executes the template against the feature.
This method returns:
{"01/01/07"}
: timestamp as 1 element array {"01/01/07","01/12/07"}
: timespan as 2 element array {null,"01/12/07"}
: open ended (start) timespan as 2 element array {"01/12/07",null}
: open ended (end) timespan as 2 element array {}
: no timestamp information as empty array
@param feature The feature to execute against.
-
org.vietspider.net.client.WebClient.execute()
-
org.vnetcon.xml.ws.servlet.request.RequestHandler.execute()
This is called by RequestHandler creator and calling this will start the actual "job to be done".
@return
@throws Exception
-
org.voltdb.catalog.Catalog.execute()
Run one or more single-line catalog commands separated by newlines. See the docs for more info on catalog statements.
@param commands A string containing one or more catalog commands separated bynewlines
-
org.voltdb.client.exampleutils.ClientConnection.execute()
Executes a procedure synchronously and returns the result to the caller. The method internally tracks execution performance.
@param procedure the name of the procedure to call.
@param parameters the list of parameters to pass to the procedure.
@return the response sent back by the VoltDB cluster for the procedure execution.
-
org.waveprotocol.box.server.robots.operations.OperationService.execute()
Tries to execute the operation in the given context.
@param operation the operation to execute.
@param context the context of the operation.
@param participant the participant performing this operation.
@throws InvalidRequestException if the operation fails to perform.
-
org.waveprotocol.wave.client.scheduler.Scheduler.IncrementalTask.execute()
-
org.webharvest.runtime.Scraper.execute()
-
org.wicketstuff.console.engine.IScriptEngine.execute()
Executes a script.
@param script a script in the language supported by this engine
@return result of the script execution
-
org.wicketstuff.progressbar.spring.AsynchronousExecutor.execute()
-
org.wiztools.restclient.RequestExecuter.execute()
Use this method to execute the HTTP request.
@param request The request object.
@param views This is a vararg parameter. You may pass any number of Viewimplementation.
-
org.wiztools.restclient.bean.RequestExecuter.execute()
Use this method to execute the HTTP request.
@param request The request object.
@param views This is a vararg parameter. You may pass any number of Viewimplementation.
-
org.wso2.carbon.dataservices.core.description.event.EventTrigger.execute()
Executes the event trigger, this uses the "evaluate" method to check if an event should be fired, if so, it sends out the event notification.
-
org.wso2.carbon.registry.synchronization.operation.CheckInCommand.execute()
This method will execute the check-in command utilizing the various parameters passed when creating the instance of the command. This method accepts the users preference if a deletion of a file or directory is required in the process.
@param registry the registry instance to be used.
@param callback the instance of a callback that can be used to determine the user'spreference before deleting an existing file or directory during the update after the check-in has been done. If this parameter is null, the default behaviour of deleting the existing file will be used.
@throws SynchronizationException if the operation failed.
-
org.wso2.carbon.registry.synchronization.operation.CheckOutCommand.execute()
This method will execute the check-out command utilizing the various parameters passed when creating the instance of the command. This method accepts the users preference to whether a file or directory should be overwritten on the filesystem.
@param registry the registry instance to be used.
@param callback the instance of a callback that can be used to determine the user'spreference before overwriting an existing file or directory during operation. If this parameter is null, the default behaviour of overwriting the existing file will be used.
@throws SynchronizationException if the operation failed.
-
org.wso2.carbon.registry.synchronization.operation.UpdateCommand.execute()
This method will execute the update command utilizing the various parameters passed when creating the instance of the command. This method accepts the users preference to whether a file or directory should be deleted on the filesystem.
@param registry the registry instance to be used.
@param callback the instance of a callback that can be used to determine the user'spreference before deleting an existing file or directory during operation. If this parameter is null, the default behaviour of deleting the existing file will be used.
@throws SynchronizationException if the operation failed.
-
org.wso2.carbon.rule.core.Session.execute()
Execute the rule engine by providing facts as a List of Objects
@param facts facts as a list of objects
@return a list of results from the rule engine execution
-
org.xadoop.servlet.actions.AbstractAction.execute()
Execute this action.
@param req original servlet request.
@return the result of the execution of this action.
-
org.xdams.ajax.command.AjaxCommandNotInHier.execute()
-
org.xdams.ajax.command.AjaxCommandVocabolarioJson.execute()
-
org.xdams.ajax.command.AjaxCutPasteCopyCommand.execute()
-
org.xdams.ajax.command.AjaxDocInfoCommand.execute()
-
org.xdams.ajax.command.AjaxSearchRelatedRecordsCommand.execute()
-
org.xdams.ajax.command.AjaxSessionCommand.execute()
-
org.xdams.managing.command.EraseCommand.execute()
-
org.xdams.managing.command.ManageXML.execute()
-
org.xdams.managing.command.ModifyAuther.execute()
-
org.xdams.managing.command.MultiModCommand.execute()
-
org.xdams.managing.command.MultiModRenumberCommand.execute()
-
org.xdams.managing.command.MultiMove.execute()
-
org.xdams.managing.command.SortingCommand.execute()
-
org.xdams.managing.command.XML2PDF.execute()
-
org.xdams.page.command.EditingPageCommand.execute()
-
org.xdams.page.command.HierBrowserPageCommand.execute()
-
org.xdams.page.command.InfoTabCommand.execute()
-
org.xdams.page.command.InsertRecordCommand.execute()
-
org.xdams.page.command.LookupCommand.execute()
-
org.xdams.page.command.PreInsertPageCommand.execute()
-
org.xdams.page.command.QueryPageCommand.execute()
-
org.xdams.page.command.TitlePageCommand.execute()
-
org.xdams.page.command.ViewPageCommand.execute()
-
org.xdams.page.command.VocabolarioMultiCommand.execute()
-
org.xdams.page.factory.AjaxFactory.execute()
-
org.xdams.page.factory.ManagingFactory.execute()
-
org.xdams.page.multiarchive.command.MultiQueryPageCommand.execute()
-
org.xdams.page.multiarchive.command.MultiTitlePageCommand.execute()
-
org.xdams.page.query.command.FindDocumentCommand.execute()
-
org.xdams.page.upload.command.AssociateCommand.execute()
-
org.xdams.page.upload.command.UploadCommand.execute()
-
org.xdams.save.SaveDocumentCommand.execute()
-
org.xerial.util.opt.CommandLauncher.execute()
-
org.xmatthew.spy2servers.command.Command.execute()
-
org.xmldb.api.modules.XQueryService.execute()
-
org.xmldb.common.xml.queries.XPathQuery.execute()
Execute the xpath.
@param rootNode The node from which the query should start or null.
@return The XObject insulating the query result.
-
org.xmldb.common.xml.queries.XUpdateQuery.execute()
Execute the XUpdate.
@param rootNode The node from which the query should start or null.
-
org.xmldb.xupdate.lexus.XUpdateQueryImpl.execute()
-
org.xmldb.xupdate.lexus.commands.CommandObject.execute()
-
org.xmldb.xupdate.lexus.commands.DefaultCommand.execute()
-
org.xtreemfs.babudb.api.database.UserDefinedLookup.execute()
The method which is executed by the worker thread.
@param database direct access to synchronous database lookups
@return the result which is passed on to the listener
@throws BabuDBException in case of an error, is passed to the listener
-
org.xtreemfs.babudb.api.dev.plugin.PluginMain.execute()
-
org.yaorma.web.action.ActionInterface.execute()
-
org.z.system.ProcessExecuter.execute()
-
org.zanata.webtrans.server.rpc.GetTransUnitListHandler.execute()
-
org.zanata.webtrans.server.rpc.UpdateTransUnitHandler.execute()
-
org.zeroturnaround.exec.ProcessExecutor.execute()
Executes the sub process. This method waits until the process exits, a timeout occurs or the caller thread gets interrupted. In the latter cases the process gets destroyed as well.
@return exit code of the finished process.
@throws IOException an error occurred when process was started or stopped.
@throws InterruptedException this thread was interrupted.
@throws TimeoutException timeout set by {@link #timeout(long,TimeUnit)} was reached.
@throws InvalidExitValueException if invalid exit value was returned (@see {@link #exitValues(Integer)}).
-
pivot.web.DeleteQuery.execute()
Synchronously executes the DELETE operation.
-
pivot.web.GetQuery.execute()
Synchronously executes the GET operation.
@return The result of the operation, deserialized using the query's serializer.
-
pivot.web.PostQuery.execute()
Synchronously executes the POST operation.
@return A URL that uniquely identifies the location of the resource created on the server by the operation, or null if the server did not return a location.
-
pivot.web.PutQuery.execute()
Synchronously executes the PUT operation.
-
play.db.DBConfig.execute()
Execute an SQL update
@param SQL
@return false if update failed
-
presenter.command.AdicionarColunaCommand.execute()
-
presenter.command.Command.execute()
-
presenter.command.ImportarArvoresCommand.execute()
-
presenter.command.RemoverArvoresCommand.execute()
-
presenter.command.RemoverColunaArvoreCommand.execute()
-
presenter.command.SalvarArvoresCommand.execute()
-
prevaylerjr.PrevaylerJr.execute()
-
primarydatamanager.primarydataservice.PrimaryDataService.execute()
Gets the raw TV data and writes it to a directory
@param dir The directory to write the raw TV data to.
@param err The stream to print error messages to.
@return Whether there were errors.
-
proguard.retrace.ReTrace.execute()
Performs the subsequent ReTrace operations.
-
promauto.jroboplc.roboplant.Mchb.execute()
-
promauto.jroboplc.roboplant.MchbMdta.execute()
-
promauto.jroboplc.roboplant.Mdta.execute()
-
protocol.Query.execute()
-
ptolemy.actor.Manager.execute()
Execute the model. Begin with the initialization phase, followed by a sequence of iterations, followed by a wrapup phase. The sequence of iterations concludes when the postfire() method of the container (the top-level composite actor) returns false, or when the finish() method is called.
The execution is performed in the calling thread (the current thread), so this method returns only after execution finishes. If you wish to perform execution in a new thread, use startRun() instead. Even if an exception occurs during the execution, the wrapup() method is called (in a finally clause).
If an exception occurs during the execution, delegate to the exception handlers (if there are any) to handle these exceptions. If there are no exception handlers, it is up to the caller to handle (e.g. report) the exception. If you do not wish to handle exceptions, but want to execute within the calling thread, use run().
@see #run()
@exception KernelException If the model throws it.
@exception IllegalActionException If the model is already running, orif there is no container.
-
ptolemy.kernel.util.ChangeRequest.execute()
Execute the change. This method invokes the protected method _execute(), takes care of reporting execution to any listeners and then wakes up any threads that might be waiting in a call to waitForCompletion(). Listeners that are attached directly to this object (using the addChangeListener() and removeChangeListener() methods) are notified first of the status of the request, followed by global listeners that were set using the setListeners() method. If the change failed because an exception was thrown, and the exception was not reported to any global listeners, then we throw an InternalErrorException because it is a bug to not have a listener in this case.
This method should be called exactly once, by the object that the change request was queued with. Attempting to call this method more than once will throw an exception.
-
ptolemy.moml.MoMLChangeRequest.execute()
-
q_impress.pmi.lib.tasks.AbstractTask.execute()
-
ra.Term.execute()
-
railo.runtime.PageContext.execute()
execute a request n the pageConext
@param realPath
@throws PageException
@throws IOException
-
railo.runtime.PageContextImpl.execute()
-
railo.runtime.db.driver.PreparedStatementPro.execute()
-
railo.runtime.db.driver.StatementPro.execute()
-
railo.transformer.bytecode.Page.execute()
result byte code as binary array
@param classFile
@return byte code
@throws IOException
@throws TemplateException
-
redis.clients.jedis.Pipeline.execute()
-
reportgen.gui.genepanel.Report.execute()
-
rocket.logging.compiler.LoggerOptimiser.execute()
-
rocket.text.client.IndexedPlaceHolderReplacer.execute()
-
rocket.text.client.NamedPlaceHolderReplacer.execute()
-
ru.aristar.jnuget.query.Expression.execute()
Выполнить выражение для источника пакетов
@param packageSource источник пакетов
@return список пакетов, соответствующих выражению
-
samples.echo.TestClient.execute()
Execute the tests
-
scap.check.exec.FileExecutor.execute()
-
se.sics.cooja.TimeEvent.execute()
-
se.sics.cooja.mspmote.MspMoteTimeEvent.execute()
-
simpleserver.command.PlayerCommand.execute()
-
simpleserver.command.ServerCommand.execute()
-
sk.fiit.jim.init.Script.execute()
-
smartrics.rest.client.RestClient.execute()
-
smartrics.rest.client.RestClientImpl.execute()
-
sonia.jdf.ApplicationExecutor.execute()
Method description
@throws ApplicationException
@throws IOException
-
sonia.jdf.cmd.Command.execute()
Method description
@param application
@param args
@return
-
sos.connection.SOSConnection.execute()
executes a statement
@param query SQL query
@throws java.lang.Exception
@see #executeQuery(String)
@see #get()
-
sos.net.ssh.SOSSSHJob2.Execute()
\brief Execute - Start the Execution of commands or scripts on the SSH-Server-Site \details This Method is to start commands or a script on the SSH-Server-Site. What to start and how to handle is specified in the related Option-Class SOSSSHJobOptions. For more details see \see SOSSSHJob2JSAdapter \see SOSSSH2Main \return SOSSSHJob2
@return
-
sos.scheduler.reports.JSReportAllParameters.Execute()
\brief Execute - Start the Execution of JSReportAllParameters \details For more details see \see JobSchedulerAdapterClass \see JSReportAllParametersMain \return JSReportAllParameters
@return
-
sos.stresstest.dialogtest.SOSDialogTest.execute()
-
spark.api.Command.execute()
Execute the command and return the natural result style depending on the command.
@return The result of execution
-
spullara.util.Benchmarker.execute()
-
src.ConteudoMigration.execute()
-
src.CursoMigration.execute()
-
src.EncontroMigration.execute()
-
src.EquipamentoMigration.execute()
-
src.FilaInscricaoMigration.execute()
-
src.InscricaoMigration.execute()
-
src.Migrator.execute()
-
src.PresencaMigration.execute()
-
src.TelecentroMigration.execute()
-
src.TurmaMigration.execute()
-
src.UsuarioMigration.execute()
-
src.VisitaMigration.execute()
-
sun.jdbc.rowset.CachedRowSet.execute()
-
systole.view.workers.WorkerFilter.execute()
-
systole.view.workers.WorkerOpenAnalysis.execute()
-
systole.view.workers.WorkerProcessor.execute()
-
systole.view.workers.WorkerReport.execute()
-
systole.view.workers.WorkerSlicer.execute()
-
talkfeed.command.Command.execute()
-
test.command.TestInvocationContext.execute()
-
test.shell.base.BaseProcessContext.execute()
-
tiled.mapeditor.undo.AddObjectsEdit.execute()
-
uk.ac.bbsrc.tgac.miso.analysis.tgac.test.process.LocalGunzipProcess.execute()
-
uk.ac.bbsrc.tgac.miso.analysis.tgac.test.process.LocalGzipProcess.execute()
-
uk.ac.ebi.fgpt.conan.model.ConanProcess.execute()
-
uk.ac.starlink.vo.DalQuery.execute()
-
uk.ac.ucl.panda.applications.evaluation.trec.QualityBenchmark.execute()
Run the quality benchmark.
@param judge the judge that can tell if a certain result doc is relevant for a certain quality query. If null, no judgements would be made. Usually null for a submission run.
@param submitRep submission report is created if non null.
@param qualityLog If not null, quality run data would be printed for each query.
@return QualityStats of each quality query that was executed.
@throws Exception if quality benchmark failed to run.
-
uk.ac.uea.threadr.Threadr.execute()
Tests all the tasks provided to the API using the built in tests and any provided tests.
Classes are tested for their thread safety, and based on the results of the testing, are run in their own thread, in a new instance of the Java Virtual Machine, or sequentially.
@return A mapping of the tasks to their AbstractReturnType results as a {@link ThreadrResult} instance.
@since 1.0
-
uk.co.nimp.scard.SmartCardTask.execute()
-
uk.gov.nationalarchives.droid.command.FilterFieldCommand.execute()
{@inheritDoc}
-
uk.gov.nationalarchives.droid.gui.action.LoadProfileWorker.execute()
-
uk.gov.nationalarchives.droid.gui.action.NewProfileAction.execute()
-
uk.gov.nationalarchives.droid.gui.action.StopRunningProfilesAction.execute()
Returns true if all profiles were stopped; false otherwise.
@return true if the profiles were stopped, false otherwise.
-
uk.gov.nationalarchives.droid.gui.config.InstallSignatureFileAction.execute()
Executes this action.
@param parent the parent window
-
uk.gov.nationalarchives.droid.gui.export.ExportAction.execute()
-
uk.gov.nationalarchives.droid.gui.report.ReportAction.execute()
-
uk.org.ogsadai.client.toolkit.DataRequestExecutionResource.execute()
-
util.SQLHelper.execute()
Execute update query.
@param query The query to execute.
@param params The query parameters to use.
-
util.io.ExecutionHandler.execute()
Executes the given application with the given parameters in the given runtime directory.
@throws IOException Thrown if something went wrong on process building.
-
voldemort.store.routed.Pipeline.execute()
Process events in the order as they were received.
The overall time to process the events must be within the bounds of the timeout or an {@link InsufficientOperationalNodesException} will bethrown.
-
voldemort.store.routed.action.Action.execute()
Executes some portion of the overall logic in the routing pipeline.
@param pipeline {@link Pipeline} instance of which this action is a part,used for adding events to the event queue or getting the {@link Operation} that resulted in the action being called
-
voldemort.utils.RemoteOperation.execute()
Executes the specific remote operation which can span multiple remote hosts.
@throws RemoteOperationException Thrown if an error occurred performingthe remote operation
-
voldemort.utils.impl.RsyncDeployer.execute()
-
voldemort.utils.impl.SshClusterCleaner.execute()
-
voldemort.utils.impl.SshClusterStarter.execute()
-
voldemort.utils.impl.SshClusterStopper.execute()
-
voldemort.utils.impl.SshRemoteTest.execute()
-
webit.script.core.ast.ResetableValueExpression.execute()
-
weka.gui.GenericPropertiesCreator.execute()
generates the props-file for the GenericObjectEditor and stores it
@throws Exception if something goes wrong
@see #execute(boolean)
-
wintertools.swingworker.utilis.WorkTracer.execute()
-
wyvern.targets.Common.wyvernIL.interpreter.core.Interpreter.execute()
runs the interpreter and returns the last value encountered
@return a BytecodeValue object representing the last value encountered
-
xbird.engine.XQEngine.execute()
-
xbird.engine.XQEngineClient.execute()
-
xbird.server.backend.BackendProcessor.execute()
-
xbird.xquery.XQueryProcessor.execute()
-
xbird.xquery.ext.grid.DispatchQueryExecTask.execute()
-
xdoclet.DocletTask.execute()
-
xplanetconfigurator.downloader.DownloadStarter.execute()
-
zephyropen.api.API.execute()
Executes this API