-
KFramework30.Communication.dbTransactionClientClass.prepare()
Prepares the SQL string
-
Program.Program.prepare()
Создает временную директорию, куда складываются все необходимые файлы: 1) сначала файл с исходным кодом, 2) после компиляции бинарный файл, объектные и другие временные файлы. Инициализируются переменные dirPath
, srcPath
, binPath
.
@throws CanNotCreateTemporaryDirectoryException ошибка при созданиивременной директории (может возникнуть, например, при отсутствии прав на запись)
@throws CanNotCreateTemporaryFileException ошибка при создании файла сисходным кодом
@throws CanNotWriteFileException ошибка при попытке записи в файл,подготовленный для исходного кода
-
ariba.ui.table.AWTDataTable.Column.prepare()
-
ariba.util.core.ProgressMonitor.prepare()
-
backtype.storm.messaging.IContext.prepare()
This method is invoked at the startup of messaging plugin
@param storm_conf storm configuration
-
backtype.storm.serialization.SerializationDelegate.prepare()
Lifecycle step that will be called after instantiating with nullary constructor.
-
cascading.flow.stream.graph.StreamGraph.prepare()
Calls prepare starting at the tail and working backwards
-
cascading.operation.Filter.prepare()
-
cascading.stats.CascadeStats.prepare()
-
cascading.stats.FlowStats.prepare()
-
client.net.sf.saxon.ce.expr.number.NumberFormatter.prepare()
Tokenize the format pattern.
@param format the format specification. Contains one of the following values:
- "1": conventional decimal numbering
- "a": sequence a, b, c, ... aa, ab, ac, ...
- "A": sequence A, B, C, ... AA, AB, AC, ...
- "i": sequence i, ii, iii, iv, v ...
- "I": sequence I, II, III, IV, V, ...
This symbol may be preceded and followed by punctuation (any other characters) which is copied to the output string.
-
cn.wensiqun.asmsupport.block.control.Catch.prepare()
-
cn.wensiqun.asmsupport.block.control.Finally.prepare()
-
cn.wensiqun.asmsupport.block.control.Try.prepare()
-
cn.wensiqun.asmsupport.operators.numerical.arithmetic.AbstractArithmetic.prepare()
-
com.adito.agent.client.util.AbstractApplicationLauncher.prepare()
Prepare and download and process the extension descriptor.
@throws IOException on any error
-
com.alibaba.citrus.service.requestcontext.basic.impl.BasicRequestContextImpl.prepare()
-
com.alibaba.druid.pool.xa.JtdsXAResource.prepare()
-
com.alibaba.jstorm.message.netty.NettyContext.prepare()
initialization per Storm configuration
-
com.alibaba.jstorm.schedule.IToplogyScheduler.prepare()
-
com.alibaba.jstorm.schedule.default_assign.DefaultTopologyScheduler.prepare()
-
com.almworks.sqlite4java.SQLiteConnection.prepare()
3ref/prepare.html">sqlite3_prepare_v2
-
com.arjuna.ats.internal.jta.transaction.arjunacore.jca.XATerminatorImple.prepare()
Prepare the imported transaction.
@param xid the transaction to prepare.
@throws XAException thrown if any error occurs, including if thetransaction has rolled back.
@return either XAResource.XA_OK if the transaction prepared, orXAResource.XA_RDONLY if it was a read-only transaction (and in which case, a second phase message is not expected/required.)
-
com.arjuna.webservices.wsat.ParticipantInboundEvents.prepare()
Handle the prepare event.
@param prepare The prepare notification.
@param addressingContext The addressing context.
@param arjunaContext The arjuna context.
-
com.arjuna.webservices11.wsat.ParticipantInboundEvents.prepare()
Handle the prepare event.
@param prepare The prepare notification.
@param addressingProperties The addressing context.
@param arjunaContext The arjuna context.
-
com.atomikos.icatch.Participant.prepare()
Prepares the participant. Any locks for this participant's work should be recoverable (either saved to an external file OR be part of the instance's non-transient state so that they can be flushed into the transaction manager's log).
@return int READ_ONLY if no second round is needed.Participants that return this value on prepare will not be called by commit or rollback afterwards.
@exception RollbackException For a NO vote.This indicates that the participant has already rolled back (or marked for rollback) the work on behalf of this participant.
@exception HeurHazardException On possible conflicts.This happens for remote participants instances, in case of communication failures.
@exception HeurMixedException If some subordinateparticipants voted YES, timed out and committed heuristically whereas afterwards some NO votes where received.
@exception SysException
-
com.badlogic.gdx.graphics.TextureData.prepare()
-
com.cloud.template.TemplateAdapter.prepare()
-
com.esri.gpt.catalog.lucene.stats.StatsRequest.prepare()
Prepares the request prior to statistics collection.
A document filter bitset will be created associated with only those documents that are visible to the active user.
@param reader the Lucene index reader
@throws IOException if an index i/o exception occurs
-
com.eviware.soapui.impl.wsdl.teststeps.WsdlTestStep.prepare()
-
com.findwise.hydra.mongodb.MongoDocumentIO.prepare()
-
com.google.appengine.api.datastore.AsyncDatastoreService.prepare()
-
com.google.appengine.api.datastore.DatastoreService.prepare()
-
com.google.gdt.eclipse.designer.hosted.IBrowserShell.prepare()
Prepares browser shell to taking a screenshot, i.e., set location, visibility state and so on
-
com.google.gwt.dev.jjs.UnifiedAst.prepare()
Internally prepares a new AST for compilation if one is not already prepared.
-
com.hazelcast.transaction.impl.Transaction.prepare()
-
com.hp.hpl.jena.ontology.OntModel.prepare()
-
com.hp.hpl.jena.rdf.model.InfModel.prepare()
Perform any initial processing and caching. This call is optional. Most engines either have negligable set up work or will perform an implicit "prepare" if necessary. The call is provided for those occasions where substantial preparation work is possible (e.g. running a forward chaining rule system) and where an application might wish greater control over when this prepration is done rather than just leaving to be done at first query time.
-
com.hp.hpl.jena.reasoner.InfGraph.prepare()
Perform any initial processing and caching. This call is optional. Most engines either have negligable set up work or will perform an implicit "prepare" if necessary. The call is provided for those occasions where substantial preparation work is possible (e.g. running a forward chaining rule system) and where an application might wish greater control over when this prepration is done.
-
com.ibm.icu.text.StringPrep.prepare()
Prepare the input buffer for use in applications with the given profile. This operation maps, normalizes(NFKC), checks for prohibited and BiDi characters in the order defined by RFC 3454 depending on the options specified in the profile.
@param src A UCharacterIterator object containing the source string
@param options A bit set of options:- StringPrep.NONE Prohibit processing of unassigned code points in the input - StringPrep.ALLOW_UNASSIGNED Treat the unassigned code points are in the input as normal Unicode code points.
@return StringBuffer A StringBuffer containing the output
@throws StringPrepParseException
@stable ICU 2.8
-
com.inadco.hbl.client.PreparedAggregateQuery.prepare()
-
com.inadco.hbl.client.impl.PreparedAggregateQueryImpl.prepare()
-
com.mycila.testing.core.api.TestNotifier.prepare()
Ask for a test preparation
@throws TestPluginException If a plugin failed enhancing the test instance
-
com.opensymphony.xwork2.ActionProxy.prepare()
-
com.prupe.mcpatcher.sky.SkyRenderer$Layer.prepare()
-
com.pugh.sockso.db.Database.prepare()
returns a prepared statement for the specified sql
@param sql
@return Statement
-
com.sleepycat.collections.TransactionRunner.prepare()
-
com.sleepycat.je.XAEnvironment.prepare()
-
com.spoledge.audao.parser.gql.GqlExtDynamic.prepare()
Prepares (parses) GQL query.
@param gql the GQL query - the parameters to the GQL are referenced by :1, :2, ...
-
com.sun.enterprise.module.ImportPolicy.prepare()
callback from the module loading system when the module enters the {@link ModuleState#PREPARING PREPARING} phase.
@param module the module instance
-
com.sun.jini.qa.harness.QAConfig.prepare()
Convenience method to prepare an object using the named preparer which must be present in the test configuration. Returns the original object if the 'none' configuration is current.
@param preparerName the name of the preparer to use
@param target the object to prepare
@return the prepared object
@throws TestException if a configuration error occurs, ifthe preparer entry does not exist, or if a RemoteException
is thrown
-
com.sun.sgs.service.TransactionParticipant.prepare()
Tells the participant to prepare for commiting its state associated with the given transaction. This method returns a
boolean
flag stating whether the prepared state is read-only, meaning that no external state is modified by this participant. If this method returns true, then neither
commit
nor
abort
will be called.
If this method throws an exception, then the preparation failed, and the transaction will be aborted. If this method completes successfully, then the participant is required to be able to commit the transaction without failure.
@param txn the Transaction
object
@return true if this participant is read-only, false otherwise
@throws Exception if there are any failures in preparing
@throws IllegalStateException if this participant has already beenprepared, committed, or aborted, or if this participant is not participating in the given transaction
-
com.taobao.metamorphosis.server.transaction.Transaction.prepare()
-
com.trolltech.qt.sql.QSqlQuery.prepare()
-
com.volantis.mcs.dom2theme.impl.optimizer.PropertyClearerCheckerImpl.prepare()
Prepare the checker.
@param parentValues The parent values.
@param target The entity to which the values are targeted.
-
com.volantis.mcs.interaction.impl.validation.Prepare4Validation.prepare()
-
com.xuggle.xuggler.TestAudioSamplesGenerator.prepare()
-
cx.fbn.nevernote.sql.driver.NSqlQuery.prepare()
-
de.flapdoodle.embed.mongo.MongodStarter.prepare()
-
de.kumpelblase2.remoteentities.persistence.ISingleEntitySerializer.prepare()
Prepares the saveable data for the given entity
@param inEntity Entity to prepare the data for
@return The saveable data from the entity
-
de.lessvoid.nifty.loaderv2.types.ElementType.prepare()
-
de.lessvoid.nifty.loaderv2.types.PopupType.prepare()
-
de.lessvoid.nifty.tools.LinearInterpolator.prepare()
-
de.lmu.ifi.dbs.elki.utilities.scaling.outlier.MinusLogStandardDeviationScaling.prepare()
-
de.lmu.ifi.dbs.elki.utilities.scaling.outlier.OutlierScalingFunction.prepare()
Prepare is called once for each data set, before getScaled() will be called. This function can be used to extract global parameters such as means, minimums or maximums from the Database, Result or Annotation.
@param or Outlier result to use
-
de.lmu.ifi.dbs.elki.utilities.scaling.outlier.StandardDeviationScaling.prepare()
-
de.novanic.eventservice.service.connection.strategy.connector.streaming.StreamingServerConnector.prepare()
Prepares the {@link de.novanic.eventservice.service.connection.strategy.connector.streaming.StreamingServerConnector} with a response.The response is required to stream the events to the client. Therefore that method must be called before the listening for events starts.
@param aResponse response
@throws EventServiceException
-
de.sub.goobi.forms.ProzesskopieForm.Prepare()
-
edu.indiana.extreme.xbaya.workflow.proxy.WorkflowContext.prepare()
-
eu.planets_project.pp.plato.bean.PrepareChangesForPersist.prepare()
Tells entity
to prepare for persisting, if it implements {@link ITouchable}. The object will do a call back to {@link #visit(ITouchable)}.
@param entity
-
eu.scape_project.planning.bean.PrepareChangesForPersist.prepare()
Tells entity
to prepare for persisting, if it implements {@link ITouchable}. The object will do a call back to {@link #visit(ITouchable)}.
@param entity the entity to prepare
-
gc.solr.publish.DocBuilder.prepare()
-
io.lumify.core.model.longRunningProcess.LongRunningProcessRunner.prepare()
-
it.unimi.dsi.mg4j.search.visitor.CounterCollectionVisitor.prepare()
-
it.unimi.dsi.mg4j.search.visitor.CounterSetupVisitor.prepare()
Prepares the internal state of this visitor using data from the associated {@link TermCollectionVisitor}.
Note that because of this dependency, it is essential that you first prepare and visit with the associated {@link TermCollectionVisitor}, and then prepare and visit with this visitor.
-
it.unimi.dsi.mg4j.search.visitor.TermCollectionVisitor.prepare()
-
javax.resource.spi.XATerminator.prepare()
-
javax.transaction.xa.XAResource.prepare()
-
ke.go.moh.oec.mpi.match.FingerprintMatch.prepare()
Prepares a fingerprint to be matched as a search term. Note that the comparison between a search term fingerprint and a database fingerprint is not symmetric. The search term fingerprint requires extra preparation. This method does that extra preparation. Also, the search term fingerprint must be used by only one thread (at a time). So for concurrent threads, each thread must have its own prepared FingerprintMatch object.
-
lib.PatPeter.SQLibrary.Database.prepare()
-
net.jini.core.transaction.server.TransactionParticipant.prepare()
Requests that the participant prepare itself to commit the transaction, and to vote on the outcome of the transaction. The participant responds with either PREPARED
, indicating that it is prepared; ABORT
, indicating that it will abort, or NOTCHANGED
, indicating that it did not have any state changed by the transaction (i.e., it was read-only). If the response is PREPARED
, the participant must wait until it receives a commit or abort call from the transaction manager; it may query the transaction manager if needed as to the state of the transaction. If the response is ABORT
, the participant should roll its state back to undo any changes that occurred due to operations performed under the transaction; it can then discard any information about the transaction. If the response is NOTCHANGED
, the participant can immediately discard any knowledge of the transaction.
@param mgr the manager of the transaction
@param id the transaction ID
@return an int
representing this participant's state
@throws UnknownTransactionException if the transaction is unknown to the transaction manager, either because the transaction ID is incorrect or because the transaction is complete and its state has been discarded by the manager.
@throws RemoteException if there is a communication error
-
net.percederberg.grammatica.parser.Parser.prepare()
Initializes the parser. All the added production patterns will be analyzed for ambiguities and errors. This method also initializes internal data structures used during the parsing.
@throws ParserCreationException if the parser couldn't beinitialized correctly
-
net.rim.device.api.database.Statement.prepare()
-
net.rim.tumbler.file.FileManager.prepare()
-
net.sf.jftp.net.Transfer.prepare()
-
net.sf.saxon.number.NumberFormatter.prepare()
Tokenize the format pattern.
@param format the format specification. Contains one of the following values:
- "1": conventional decimal numbering
- "a": sequence a, b, c, ... aa, ab, ac, ...
- "A": sequence A, B, C, ... AA, AB, AC, ...
- "i": sequence i, ii, iii, iv, v ...
- "I": sequence I, II, III, IV, V, ...
This symbol may be preceded and followed by punctuation (any other characters) which is copied to the output string.
-
net.sourceforge.pebble.web.view.View.prepare()
Prepares the view for presentation.
-
nexj.core.persistence.Query.prepare()
Prepares the query for executing.
@param bPartial True if the query result will be retrieved partially.
-
no.hal.jex.views.actions.JexZipFile.prepare()
-
oracle.toplink.essentials.internal.databaseaccess.DatabaseCall.prepare()
INTERNAL: Allow pre-printing of the SQL string for fully bound calls, to save from reprinting. Should be called before translation.
-
oracle.toplink.essentials.internal.databaseaccess.DatasourceCall.prepare()
Allow pre-printing of the query/SQL string for fully bound calls, to save from reprinting.
-
org.activemq.service.Transaction.prepare()
-
org.apache.activemq.transaction.Transaction.prepare()
-
org.apache.aurora.scheduler.storage.Storage.prepare()
Requests the underlying storage prepare its data set; ie: initialize schemas, begin syncing out of date data, etc. This method should not block.
@throws StorageException if there was a problem preparing storage.
-
org.apache.cassandra.contrib.utils.service.CassandraServiceDataCleaner.prepare()
Creates all data dir if they don't exist and cleans them
@throws IOException
-
org.apache.cassandra.cql3.statements.CFStatement.prepare()
-
org.apache.cassandra.stress.util.JavaDriverClient.prepare()
-
org.apache.cocoon.portal.PortalManagerAspect.prepare()
-
org.apache.cocoon.portal.coplet.CopletFactory.prepare()
-
org.apache.cxf.transport.Conduit.prepare()
Prepare the message for sending. This will typically involve setting an OutputStream on the message, but it may do nothing at all.
@param message the message to be sent.
-
org.apache.felix.gogo.commands.basic.ActionPreparator.prepare()
-
org.apache.felix.gogo.commands.basic.DefaultActionPreparator.prepare()
-
org.apache.felix.ipojo.manipulation.Manipulator.prepare()
Checks the given bytecode, determines if the class was already manipulated, and collect the metadata about the class.
@param origin the bytecode
-
org.apache.hadoop.hbase.master.handler.EnableTableHandler.prepare()
-
org.apache.hadoop.hbase.master.handler.TruncateTableHandler.prepare()
-
org.apache.hadoop.hbase.regionserver.SplitTransaction.prepare()
Does checks on split inputs.
@return true
if the region is splittable elsefalse
if it is not (e.g. its already closed, etc.).
-
org.apache.ibatis.executor.statement.StatementHandler.prepare()
-
org.apache.jackrabbit.data.core.TransactionContext.prepare()
Prepare the transaction identified by this context. Prepares changes on all resources. If some resource reports an error on prepare, automatically rollback changes on all other resources. Throw exception at the end if errors were found.
@throws XAException if an error occurs
-
org.apache.jackrabbit.oak.query.ast.SourceImpl.prepare()
Prepare executing the query (recursively). This method will decide which index to use.
-
org.apache.karaf.features.internal.region.SubsystemResolver.prepare()
-
org.apache.karaf.shell.commands.basic.DefaultActionPreparator.prepare()
-
org.apache.karaf.shell.impl.action.command.DefaultActionPreparator.prepare()
-
org.apache.maven.continuum.release.ContinuumReleaseManager.prepare()
Prepare a project for release
@param project
@param releaseProperties
@param releaseVersions
@param developmentVersions
@param listener
@param workingDirectory
@return
@throws ContinuumReleaseException
-
org.apache.oozie.util.db.SqlStatement.prepare()
Assign the values to Prepared Statement. setValues should be called to set the Real Values for place holders
@param pStmt Prepared Statement
@return PreparedStatement with values set
@throws SQLException
-
org.apache.pivot.wtk.effects.Decorator.prepare()
Prepares the graphics context into which the component or prior decorator will paint. This method is called immediately prior to {@link Component#paint(Graphics2D)}; decorators are called in descending order.
@param component
@param graphics
@return The graphics context that should be used by the component or prior decorators.
-
org.apache.solr.handler.component.QueryComponent.prepare()
-
org.apache.tiles.TilesContainer.prepare()
Executes a preparer.
@param preparer The name of the preparer to execute.
@param requestItems the current request objects.
@throws TilesException is processing fails.
-
org.apache.tuscany.core.implementation.composite.CompositeComponentImpl.prepare()
-
org.apache.tuscany.core.wire.InboundInvocationChainImpl.prepare()
-
org.apache.tuscany.spi.component.Component.prepare()
-
org.apache.tuscany.spi.component.CompositeComponent.prepare()
-
org.apache.tuscany.spi.component.SystemAtomicComponent.prepare()
-
org.apache.tuscany.spi.wire.InboundInvocationChain.prepare()
-
org.apache.tuscany.spi.wire.OutboundInvocationChain.prepare()
-
org.apache.twill.api.TwillRunner.prepare()
Prepares to run the given {@link TwillRunnable} with {@link ResourceSpecification#BASIC} resource specification.
@param runnable The runnable to run through Twill when {@link TwillPreparer#start()} is called.
@return A {@link TwillPreparer} for setting up runtime options.
-
org.apache.twill.api.TwillRunnerService.prepare()
-
org.apache.twill.kafka.client.KafkaPublisher.prepare()
Prepares to publish to a given topic.
@param topic Name of the topic.
@return A {@link Preparer} to prepare for publishing.
-
org.apache.twill.yarn.YarnTwillRunnerService.prepare()
-
org.apache.ws.security.message.WSSecDKEncrypt.prepare()
-
org.apache.ws.security.message.WSSecDKSign.prepare()
-
org.apache.ws.security.message.WSSecEncrypt.prepare()
Initialize a WSSec Encrypt. The method prepares and initializes a WSSec Encrypt structure after the relevant information was set. After preparartion of the token references can be added and encrypted. This method does not add any element to the security header. This must be done explicitly.
@param doc The SOAP envelope as Document
@param crypto An instance of the Crypto API to handle keystore and certificates
@throws WSSecurityException
-
org.apache.ws.security.message.WSSecEncryptedKey.prepare()
Prepare the ephemeralKey and the tokens required to be added to the security header
@param doc The SOAP envelope as Document
@param crypto An instance of the Crypto API to handle keystore and certificates
@throws WSSecurityException
-
org.apache.ws.security.message.WSSecSAMLToken.prepare()
Creates a SAML token. The method prepares and initializes a WSSec UsernameToken structure after the relevant information was set. A Before calling prepare()
all parameters such as user, password, passwordType etc. must be set. A complete UsernameToken
is constructed.
@param doc The SOAP enevlope as W3C document
-
org.apache.ws.security.message.WSSecSecurityContextToken.prepare()
-
org.apache.ws.security.message.WSSecSignature.prepare()
Initialize a WSSec Signature. The method sets up and initializes a WSSec Signature structure after the relevant information was set. After setup of the references to elements to sign may be added. After all references are added they can be signed. This method does not add the Signature element to the security header. See prependSignatureElementToHeader()
method.
@param doc The SOAP envelope as Document
@param cr An instance of the Crypto API to handle keystore and certificates
@param secHeader The security header that will hold the Signature. This is usedto construct namespace prefixes for Signature. This method
@throws WSSecurityException
-
org.apache.ws.security.message.WSSecSignatureConfirmation.prepare()
Creates a SignatureConfimation element. The method prepares and initializes a WSSec SignatureConfirmation structure after the relevant information was set. Before calling prepare()
the filed signatureValue
must be set
@param doc The SOAP enevlope as W3C document
-
org.apache.ws.security.message.WSSecTimestamp.prepare()
Creates a Timestamp element. The method prepares and initializes a WSSec Timestamp structure after the relevant information was set. Before calling prepare()
the parameter such as timeToLive
can be set if the deafult value is not suitable.
@param doc The SOAP enevlope as W3C document
-
org.apache.ws.security.message.WSSecUsernameToken.prepare()
Creates a Username token. The method prepares and initializes a WSSec UsernameToken structure after the relevant information was set. A Before calling prepare()
all parameters such as user, password, passwordType etc. must be set. A complete UsernameToken
is constructed.
@param doc The SOAP enevlope as W3C document
-
org.apache.wss4j.dom.message.WSSecDKEncrypt.prepare()
-
org.apache.wss4j.dom.message.WSSecDKSign.prepare()
-
org.apache.wss4j.dom.message.WSSecEncrypt.prepare()
Initialize a WSSec Encrypt. The method prepares and initializes a WSSec Encrypt structure after the relevant information was set. After preparation of the token references can be added and encrypted. This method does not add any element to the security header. This must be done explicitly.
@param doc The SOAP envelope as Document
@param crypto An instance of the Crypto API to handle keystore and certificates
@throws WSSecurityException
-
org.apache.wss4j.dom.message.WSSecEncryptedKey.prepare()
Prepare the ephemeralKey and the tokens required to be added to the security header
@param doc The SOAP envelope as Document
@param crypto An instance of the Crypto API to handle keystore and certificates
@throws WSSecurityException
-
org.apache.wss4j.dom.message.WSSecSAMLToken.prepare()
Creates a SAML token. The method prepares and initializes a WSSec UsernameToken structure after the relevant information was set. A Before calling prepare()
all parameters such as user, password, passwordType etc. must be set. A complete UsernameToken
is constructed.
@param doc The SOAP envelope as W3C document
-
org.apache.wss4j.dom.message.WSSecSignature.prepare()
Initialize a WSSec Signature. The method sets up and initializes a WSSec Signature structure after the relevant information was set. After setup of the references to elements to sign may be added. After all references are added they can be signed. This method does not add the Signature element to the security header. See prependSignatureElementToHeader()
method.
@param doc The SOAP envelope as Document
@param cr An instance of the Crypto API to handle keystore and certificates
@param secHeader The security header that will hold the Signature. This is usedto construct namespace prefixes for Signature. This method
@throws WSSecurityException
-
org.apache.wss4j.dom.message.WSSecSignatureConfirmation.prepare()
Creates a SignatureConfimation element. The method prepares and initializes a WSSec SignatureConfirmation structure after the relevant information was set. Before calling prepare()
the filed signatureValue
must be set
@param doc The SOAP envelope as W3C document
-
org.apache.wss4j.dom.message.WSSecTimestamp.prepare()
Creates a Timestamp element. The method prepares and initializes a WSSec Timestamp structure after the relevant information was set. Before calling prepare()
the parameter such as timeToLive
can be set if the default value is not suitable.
@param doc The SOAP envelope as W3C document
-
org.apache.wss4j.dom.message.WSSecUsernameToken.prepare()
Creates a Username token. The method prepares and initializes a WSSec UsernameToken structure after the relevant information was set. A Before calling prepare()
all parameters such as user, password, passwordType etc. must be set. A complete UsernameToken
is constructed.
@param doc The SOAP envelope as W3C document
-
org.arabidopsis.ahocorasick.AhoCorasick.prepare()
Prepares the automaton for searching. This must be called before any searching().
-
org.castor.persist.TransactionContext.prepare()
Prepares the transaction prior to committing it. Indicates whether the transaction is read-only (i.e. no modified objects), can commit, or an error has occured and the transaction must be rolled back. This method performs actual storage into the persistence storage. Multiple calls to this method can be done, and do not release locks, allowing checkpoint to occur. An IllegalStateException is thrown if transaction is not in the proper state to perform this operation.
@return True if the transaction can commit, false if the transaction isread only
@throws TransactionAbortedException The transaction has been aborted due toinconsistency, duplicate object identity, error with the persistence engine or any other reason.
-
org.codehaus.activemq.service.Transaction.prepare()
-
org.dbpedia.downloader.connection.JDBC.prepare()
-
org.eclipse.emf.ecore.xmi.XMLDefaultHandler.prepare()
-
org.eclipse.persistence.internal.databaseaccess.DatabaseCall.prepare()
INTERNAL: Allow pre-printing of the SQL string for fully bound calls, to save from reprinting. Should be called before translation.
-
org.eclipse.persistence.internal.databaseaccess.DatasourceCall.prepare()
Allow pre-printing of the query/SQL string for fully bound calls, to save from reprinting.
-
org.enhydra.instantdb.jdbc.ConnectionExtensions.prepare()
-
org.geoserver.importer.Directory.prepare()
-
org.geoserver.importer.FileData.prepare()
-
org.geoserver.importer.mosaic.Mosaic.prepare()
-
org.glassfish.appclient.client.acc.AppClientContainer.prepare()
-
org.goobi.production.cli.helper.CopyProcess.Prepare()
-
org.h2.command.Parser.prepare()
Parse the statement and prepare it for execution.
@param sql the SQL statement to parse
@return the prepared object
-
org.h2.command.dml.Insert.prepare()
-
org.h2.command.dml.Query.prepare()
-
org.h2.engine.Session.prepare()
Parse and prepare the given SQL statement. This method also checks the rights.
@param sql the SQL statement
@return the prepared statement
-
org.h2.test.db.Db.prepare()
-
org.hibernate.cfg.CollectionPropertyHolder.prepare()
-
org.hibernate.hql.ast.tree.ConstructorNode.prepare()
-
org.hibernate.hql.internal.ast.tree.ConstructorNode.prepare()
-
org.hibernate.jdbc.Expectation.prepare()
Perform any special statement preparation.
@param statement The statement to be prepared
@return The number of bind positions consumed (if any)
@throws SQLException Exception from the JDBC driver
@throws HibernateException Problem performing preparation.
-
org.hornetq.api.core.client.ClientSession.prepare()
-
org.hornetq.core.transaction.Transaction.prepare()
-
org.hornetq.core.transaction.impl.TransactionImpl.prepare()
-
org.infinispan.transaction.TransactionCoordinator.prepare()
-
org.infinispan.transaction.impl.TransactionCoordinator.prepare()
-
org.infinispan.transaction.xa.TransactionXaAdapter.prepare()
This can be call for any transaction object. See Section 3.4.6 (Resource Sharing) from JTA spec v1.1.
-
org.infoglue.cms.providers.ComponentModel.prepare()
-
org.javex.ExpressionImpl.prepare()
-
org.jboss.cache.loader.CacheLoader.prepare()
Prepares a list of modifications. For example, for a DB-based CacheLoader:
- Create a local (JDBC) transaction
- Associate the local transaction with
tx
(tx is the key) - Execute the corresponding SQL statements against the DB (statements derived from modifications)
For non-transactional CacheLoader (e.g. file-based), the implementation could attempt to implement its own transactional logic, attempting to write data to a temp location (or memory) and writing it to the proper location upon commit.
@param tx The transaction, indended to be used by implementations as an identifier of the transaction (and not necessarily a JTA {@link javax.transaction.Transaction} object)
@param modifications A {@link List} containing {@link org.jboss.cache.Modification}s, for the given transaction
@param one_phase Persist immediately and (for example) commit the local JDBC transaction as well. When true,we won't get a {@link #commit(Object)} or {@link #rollback(Object)} method call later
@throws Exception
-
org.jboss.deployers.spi.management.deploy.DeploymentManager.prepare()
Prepare a set of deployments through their dependency analysis phase.
@param names the unique names of the deployments
@return a DeploymentProgress used to run and track the prepare progress.
@throws Exception for any error
-
org.jboss.jms.tx.MessagingXAResource.prepare()
-
org.jboss.messaging.core.impl.tx.Transaction.prepare()
-
org.jboss.messaging.core.tx.Transaction.prepare()
-
org.jiql.db.jdbc.stat.StatementProcessor.prepare()
-
org.jnode.awt.image.JNodeImage.prepare()
-
org.jrebirth.af.core.concurrent.JRebirthThread.prepare()
Launch the JRebirth thread.
@param application the javaFX application instance
-
org.jugile.util.DBConnection.prepare()
-
org.lealone.command.Parser.prepare()
Parse the statement and prepare it for execution.
@param sql the SQL statement to parse
@return the prepared object
-
org.lealone.command.dml.Insert.prepare()
-
org.lealone.command.dml.Query.prepare()
-
org.mindswap.pellet.KnowledgeBase.prepare()
-
org.mindswap.pellet.jena.PelletInfGraph.prepare()
-
org.neo4j.smack.pipeline.core.WorkTransactionPreparer.prepare()
-
org.olap4cloud.impl.CubeScan.prepare()
-
org.olat.core.gui.media.RedirectMediaResource.prepare()
@see org.olat.core.gui.media.MediaResource#prepare(javax.servlet.http.HttpServletResponse)
-
org.omg.CosTransactions.Resource.prepare()
-
org.openstreetmap.osmosis.core.pipeline.common.Pipeline.prepare()
Instantiates and configures all tasks within the pipeline.
@param taskInfoList The list of task information objects.
-
org.osgi.service.deploymentadmin.spi.ResourceProcessor.prepare()
This method is called on the Resource Processor immediately before calling the {@code commit} method. The Resource Processor has to checkwhether it is able to commit the operations since the last {@code begin}method call. If it determines that it is not able to commit the changes, it has to raise a {@code ResourceProcessorException} with the{@link ResourceProcessorException#CODE_PREPARE} error code.
@throws ResourceProcessorException if the resource processor is able todetermine it is not able to commit. Only the {@link ResourceProcessorException#CODE_PREPARE} error code isallowed.
-
org.pdf4j.saxon.number.NumberFormatter.prepare()
Tokenize the format pattern.
@param format the format specification. Contains one of the following values:
- "1": conventional decimal numbering
- "a": sequence a, b, c, ... aa, ab, ac, ...
- "A": sequence A, B, C, ... AA, AB, AC, ...
- "i": sequence i, ii, iii, iv, v ...
- "I": sequence I, II, III, IV, V, ...
This symbol may be preceded and followed by punctuation (any other characters) which is copied to the output string.
-
org.rascalmpl.test.infrastructure.TestFramework.prepare()
-
org.sonar.process.ProcessCommands.prepare()
-
org.springframework.batch.item.adapter.HippyMethodInvoker.prepare()
-
org.springframework.beans.support.ArgumentConvertingMethodInvoker.prepare()
-
org.springframework.data.jpa.repository.query.StringQuery.LikeParameterBinding.prepare()
-
org.springframework.data.jpa.repository.query.StringQuery.ParameterBinding.prepare()
-
org.springframework.data.mongodb.core.MongoTemplate.QueryCursorPreparer.prepare()
-
org.springframework.mail.javamail.MimeMessagePreparator.prepare()
Prepare the given new MimeMessage instance.
@param mimeMessage the message to prepare
@throws javax.mail.MessagingException passing any exceptions thrown by MimeMessagemethods through for automatic conversion to the MailException hierarchy
@throws java.io.IOException passing any exceptions thrown by MimeMessage methodsthrough for automatic conversion to the MailException hierarchy
@throws Exception if mail preparation failed, for example when aVelocity template cannot be rendered for the mail text
-
org.springframework.scheduling.support.MethodInvokingRunnable.prepare()
-
org.springframework.util.MethodInvoker.prepare()
Prepare the specified method. The method can be invoked any number of times afterwards.
@see #getPreparedMethod
@see #invoke
-
org.teiid.cache.Cachable.prepare()
-
org.terrier.matching.PostingListManager.prepare()
Counts the number of terms active. If firstMove is true, it will move each posting to the first posting.
@param firstMove move all postings to the start?
@throws IOException
-
org.tmatesoft.hg.internal.MergeStateBuilder.prepare()
-
org.tmatesoft.hg.internal.Transaction.prepare()
Record the file is going to be modified during this transaction, obtain actual destination to write to. The file to be modified not necessarily exists, might be just a name of an added file
-
org.tmatesoft.hg.internal.diff.BlameHelper.prepare()
Build history of the file for the specified range (follow renames if necessary). This history is used to access various file revision data during subsequent {@link #diff(int,int,int,int)} and{@link #annotateChange(int,int,int[],int[])} calls. Callers can use returned history for own approaches to iteration over file history.
NOTE, clogRevIndexEnd has to list name of the supplied file in the corresponding manifest, as it's not possible to trace rename history otherwise.
-
org.vfny.geoserver.wcs.responses.CoverageResponseDelegate.prepare()
-
org.vfny.geoserver.wfs.responses.GML2FeatureResponseDelegate.prepare()
prepares for encoding into GML2 format, optionally compressing its output in gzip, if outputFormat is equal to GML2-GZIP
@param outputFormat DOCUMENT ME!
@param results DOCUMENT ME!
@throws IOException DOCUMENT ME!
-
org.zkoss.zk.ui.event.EventThreadInit.prepare()
Prepares the initialization at the servlet thread.
It is invoked in the servlet thread (and before {@link #init}). Thus, you can NOT manipulate the deskop in this method.
If this method throws an exception, it will abort the execution and shows an error message to the end user. Note: {@link EventThreadCleanup#cleanup} won't be called if anexception is thrown in this method, since it executes in the main thread.
In addition to throwing an exception, you can prevent an event from processing by returning false in {@link #init}. The event is ignored 'silently' then.
-
pivot.wtk.effects.Decorator.prepare()
Prepares the graphics context into which the component or prior decorator will paint. This method is called immediately prior to {@link Component#paint(Graphics2D)}; decorators are called in descending order.
@param component
@param graphics
@return The graphics context that should be used by the component or prior decorators.
-
qat.parser.ParserInterface.prepare()
This is called at the beginning of a parser run on one or more tests.
@param projectResultsDir - the canonical pathname ofthe project file, used to decide where to place the parser trace files.
-
sun.awt.image.ImageRepresentation.prepare()
-
sun.net.idn.StringPrep.prepare()
Prepare the input buffer for use in applications with the given profile. This operation maps, normalizes(NFKC), checks for prohited and BiDi characters in the order defined by RFC 3454 depending on the options specified in the profile.
@param src A UCharacterIterator object containing the source string
@param options A bit set of options:- StringPrep.NONE Prohibit processing of unassigned code points in the input - StringPrep.ALLOW_UNASSIGNED Treat the unassigned code points are in the input as normal Unicode code points.
@return StringBuffer A StringBuffer containing the output
@throws ParseException
@draft ICU 2.8