Skip navigation links
jberet-core 1.2.0.Final
A B C D E F G H I J L M N O P R S T U V W X 

A

abandon(long) - Method in class org.jberet.operations.JobOperatorImpl
 
AbstractArtifactFactory - Class in org.jberet.creation
 
AbstractArtifactFactory() - Constructor for class org.jberet.creation.AbstractArtifactFactory
 
AbstractContext - Class in org.jberet.runtime.context
 
AbstractContext(String) - Constructor for class org.jberet.runtime.context.AbstractContext
 
AbstractContext(String, AbstractContext[]) - Constructor for class org.jberet.runtime.context.AbstractContext
 
AbstractExecution - Class in org.jberet.runtime
 
AbstractExecution() - Constructor for class org.jberet.runtime.AbstractExecution
 
AbstractJobXmlResolver - Class in org.jberet.tools
An abstract job XML resolver that returns an empty list for the job XML names and null for the job name.
AbstractJobXmlResolver() - Constructor for class org.jberet.tools.AbstractJobXmlResolver
 
AbstractPersistentRepository - Class in org.jberet.repository
 
AbstractPersistentRepository() - Constructor for class org.jberet.repository.AbstractPersistentRepository
 
AbstractRepository - Class in org.jberet.repository
 
AbstractRepository() - Constructor for class org.jberet.repository.AbstractRepository
 
AbstractRunner<C extends AbstractContext> - Class in org.jberet.runtime.runner
 
AbstractRunner(C, CompositeExecutionRunner) - Constructor for class org.jberet.runtime.runner.AbstractRunner
 
AbstractStepExecution - Class in org.jberet.runtime
 
addContext(AfterBeanDiscovery) - Method in class org.jberet.creation.BatchCDIExtension
 
addJob(ApplicationAndJobName, Job) - Method in class org.jberet.repository.AbstractRepository
 
addJob(ApplicationAndJobName, Job) - Method in interface org.jberet.repository.JobRepository
 
addJobExecution(JobExecution) - Method in class org.jberet.runtime.JobInstanceImpl
 
addJobParameter(String, String) - Method in class org.jberet.runtime.JobExecutionImpl
Adds job parameter key-value pair.
addPartitionExecution(StepExecutionImpl, PartitionExecutionImpl) - Method in class org.jberet.repository.AbstractRepository
 
addPartitionExecution(StepExecutionImpl, PartitionExecutionImpl) - Method in class org.jberet.repository.InfinispanRepository
 
addPartitionExecution(StepExecutionImpl, PartitionExecutionImpl) - Method in class org.jberet.repository.JdbcRepository
 
addPartitionExecution(StepExecutionImpl, PartitionExecutionImpl) - Method in interface org.jberet.repository.JobRepository
 
addPartitionExecution(StepExecutionImpl, PartitionExecutionImpl) - Method in class org.jberet.repository.MongoRepository
 
addStepExecution(JobExecutionImpl, StepExecutionImpl) - Method in class org.jberet.repository.AbstractRepository
 
addStepExecution(JobExecutionImpl, StepExecutionImpl) - Method in interface org.jberet.repository.JobRepository
 
addStepExecution(StepExecution) - Method in class org.jberet.runtime.JobExecutionImpl
 
addStepMetrics(StepMetrics) - Method in class org.jberet.runtime.metric.StepMetrics
 
addToContextArray(AbstractContext[], AbstractContext) - Static method in class org.jberet.runtime.context.AbstractContext
Appends a BatchContext to an array of BatchContext and return the expanded new array.
addTransitionElement(Transition) - Method in class org.jberet.job.model.Job
 
addTransitionElement(Transition) - Method in interface org.jberet.job.model.JobElement
Adds a org.jberet.job.model.Transition to the list of transition elements of this job element.
allowStartIfComplete(boolean...) - Method in class org.jberet.job.model.StepBuilder
Sets the allow-start-if-complete attribute value for the step.
ApplicationAndJobName - Class in org.jberet.repository
Used as a key to uniquely identify a job with both the name of the job and the name of the application that containing the job definition.
ApplicationAndJobName(String, String) - Constructor for class org.jberet.repository.ApplicationAndJobName
 
appName - Variable in class org.jberet.repository.ApplicationAndJobName
 
ARCHIVE_BATCH_XML - Static variable in class org.jberet.creation.ArchiveXmlLoader
 
ARCHIVE_JOB_XML_DIR - Static variable in class org.jberet.creation.ArchiveXmlLoader
 
ArchiveXmlLoader - Class in org.jberet.creation
 
ArchiveXmlLoader() - Constructor for class org.jberet.creation.ArchiveXmlLoader
 
ArtifactCreationContext - Class in org.jberet.creation
 
ArtifactCreationContext(JobContextImpl, StepContextImpl, Properties) - Constructor for class org.jberet.creation.ArtifactCreationContext
 
ArtifactFactory - Interface in org.jberet.spi
 
ArtifactFactoryWrapper - Class in org.jberet.creation
 
ArtifactFactoryWrapper(ArtifactFactory) - Constructor for class org.jberet.creation.ArtifactFactoryWrapper
 
awaitTermination(long, TimeUnit) - Method in class org.jberet.runtime.JobExecutionImpl
 

B

BatchArtifacts - Class in org.jberet.job.model
Corresponds to batch.xml root element type batch-artifacts.
BatchArtifacts() - Constructor for class org.jberet.job.model.BatchArtifacts
 
BatchBeanProducer - Class in org.jberet.creation
 
BatchBeanProducer() - Constructor for class org.jberet.creation.BatchBeanProducer
 
BatchCDIExtension - Class in org.jberet.creation
 
BatchCDIExtension() - Constructor for class org.jberet.creation.BatchCDIExtension
 
batchContext - Variable in class org.jberet.runtime.runner.AbstractRunner
 
BatchEnvironment - Interface in org.jberet.spi
Represents the environment for the batch runtime.
batchlet(String, String[]...) - Method in class org.jberet.job.model.StepBuilder
Sets the batchlet for the step.
batchlet(String, Properties) - Method in class org.jberet.job.model.StepBuilder
Sets the batchlet for the step, with batchlet properties.
BatchletRunner - Class in org.jberet.runtime.runner
 
BatchletRunner(StepContextImpl, CompositeExecutionRunner, StepExecutionRunner, RefArtifact) - Constructor for class org.jberet.runtime.runner.BatchletRunner
 
batchStatus - Variable in class org.jberet.runtime.AbstractExecution
 
BatchUtil - Class in org.jberet.util
 
BatchUtil() - Constructor for class org.jberet.util.BatchUtil
 
beforeBeanDiscovery(BeforeBeanDiscovery, BeanManager) - Method in class org.jberet.creation.BatchCDIExtension
 
begin() - Method in class org.jberet.tx.LocalTransactionManager
 
build() - Method in class org.jberet.job.model.DecisionBuilder
Builds the decision.
build() - Method in class org.jberet.job.model.FlowBuilder
Builds the flow.
build() - Method in class org.jberet.job.model.JobBuilder
Builds the job.
build() - Method in class org.jberet.job.model.SplitBuilder
Builds the split.
build() - Method in class org.jberet.job.model.StepBuilder
Builds the step.
bytesToSerializableObject(byte[], ClassLoader) - Static method in class org.jberet.util.BatchUtil
 

C

ChainedJobXmlResolver - Class in org.jberet.tools
A job XML resolver for chaining resolvers.
ChainedJobXmlResolver(JobXmlResolver...) - Constructor for class org.jberet.tools.ChainedJobXmlResolver
Creates a new chained job XML resolver.
ChainedJobXmlResolver(Iterable<JobXmlResolver>) - Constructor for class org.jberet.tools.ChainedJobXmlResolver
Creates a new chained job XML resolver.
ChainedJobXmlResolver(Iterable<JobXmlResolver>, JobXmlResolver...) - Constructor for class org.jberet.tools.ChainedJobXmlResolver
Creates a new chained job XML resolver.
ChainedJobXmlResolver(Collection<JobXmlResolver>) - Constructor for class org.jberet.tools.ChainedJobXmlResolver
Creates a new chained job XML resolver.
checkpointAlgorithm(String, String[]...) - Method in class org.jberet.job.model.StepBuilder
Sets checkpoint algorithm for a chunk-type step.
checkpointAlgorithm(String, Properties) - Method in class org.jberet.job.model.StepBuilder
Sets checkpoint algorithm for a chunk-type step, with checkpoint algorithm properties.
checkpointPolicy(String) - Method in class org.jberet.job.model.StepBuilder
Sets checkpoint policy for a chunk-type step.
Chunk - Class in org.jberet.job.model
Corresponds to jsl:Chunk job XML element type.
ChunkRunner - Class in org.jberet.runtime.runner
This runner class is responsible for running a chunk-type step (not just a chunk range of a step).
ChunkRunner(StepContextImpl, CompositeExecutionRunner, StepExecutionRunner, Chunk) - Constructor for class org.jberet.runtime.runner.ChunkRunner
 
classLoader - Variable in class org.jberet.runtime.context.AbstractContext
 
cleanUp() - Method in class org.jberet.runtime.JobExecutionImpl
 
clone() - Method in class org.jberet.job.model.Chunk
 
clone() - Method in class org.jberet.job.model.ExceptionClassFilter
 
clone() - Method in class org.jberet.job.model.Partition
 
clone() - Method in class org.jberet.job.model.PartitionPlan
 
clone() - Method in class org.jberet.job.model.Properties
 
clone() - Method in class org.jberet.job.model.RefArtifact
 
clone() - Method in class org.jberet.job.model.Script
 
clone() - Method in class org.jberet.runtime.AbstractExecution
 
clone() - Method in class org.jberet.runtime.AbstractStepExecution
 
clone() - Method in class org.jberet.runtime.context.AbstractContext
 
clone() - Method in class org.jberet.runtime.context.JobContextImpl
 
clone() - Method in class org.jberet.runtime.context.StepContextImpl
 
clone() - Method in class org.jberet.runtime.JobExecutionImpl
 
clone(T) - Static method in class org.jberet.util.BatchUtil
 
commit() - Method in class org.jberet.tx.LocalTransactionManager
 
CompositeExecutionRunner<C extends AbstractContext> - Class in org.jberet.runtime.runner
A runner for job elements that can contain other job elements.
CompositeExecutionRunner(C, CompositeExecutionRunner) - Constructor for class org.jberet.runtime.runner.CompositeExecutionRunner
 
convertFieldValue(String, Class<?>, Field, ClassLoader) - Static method in class org.jberet.creation.ValueConverter
 
countStepStartTimes(String, long) - Method in class org.jberet.repository.InfinispanRepository
 
countStepStartTimes(String, long) - Method in class org.jberet.repository.InMemoryRepository
 
countStepStartTimes(String, long) - Method in class org.jberet.repository.JdbcRepository
 
countStepStartTimes(String, long) - Method in interface org.jberet.repository.JobRepository
 
countStepStartTimes(String, long) - Method in class org.jberet.repository.MongoRepository
 
create(String, Class<?>, ClassLoader) - Method in class org.jberet.creation.ArtifactFactoryWrapper
 
create(Configuration) - Static method in class org.jberet.repository.InfinispanRepository
 
create(Properties) - Static method in class org.jberet.repository.InfinispanRepository
 
create() - Static method in class org.jberet.repository.InMemoryRepository
Creates a new in-memory job repository.
create(Properties) - Static method in class org.jberet.repository.JdbcRepository
 
create(Properties) - Static method in class org.jberet.repository.MongoRepository
 
create(String, Class<?>, ClassLoader) - Method in interface org.jberet.spi.ArtifactFactory
The create method creates an instance corresponding to a ref value from a Job XML.
createArtifact(String, Class<?>, Properties, StepContextImpl...) - Method in class org.jberet.runtime.context.JobContextImpl
Creates a batch artifact by delegating to the proper ArtifactFactory and passing along data needed for artifact loading and creation.
createJobExecution(JobInstanceImpl, Properties) - Method in class org.jberet.repository.AbstractPersistentRepository
 
createJobExecution(JobInstanceImpl, Properties) - Method in class org.jberet.repository.InfinispanRepository
 
createJobExecution(JobInstanceImpl, Properties) - Method in class org.jberet.repository.InMemoryRepository
 
createJobExecution(JobInstanceImpl, Properties) - Method in interface org.jberet.repository.JobRepository
 
createJobInstance(Job, String, ClassLoader) - Method in class org.jberet.repository.AbstractPersistentRepository
 
createJobInstance(Job, String, ClassLoader) - Method in class org.jberet.repository.InfinispanRepository
 
createJobInstance(Job, String, ClassLoader) - Method in class org.jberet.repository.InMemoryRepository
 
createJobInstance(Job, String, ClassLoader) - Method in interface org.jberet.repository.JobRepository
 
createStepExecution(String) - Method in class org.jberet.repository.AbstractRepository
 
createStepExecution(String) - Method in interface org.jberet.repository.JobRepository
 
createTime - Variable in class org.jberet.runtime.JobExecutionImpl
 

D

DATASOURCE_JNDI_KEY - Static variable in class org.jberet.repository.JdbcRepository
 
DB_PASSWORD_KEY - Static variable in class org.jberet.repository.JdbcRepository
 
DB_PROPERTIES_KEY - Static variable in class org.jberet.repository.JdbcRepository
 
DB_PROPERTY_DELIM - Static variable in class org.jberet.repository.JdbcRepository
 
DB_URL_KEY - Static variable in class org.jberet.repository.JdbcRepository
 
DB_USER_KEY - Static variable in class org.jberet.repository.JdbcRepository
 
DDL_FILE_NAME_KEY - Static variable in class org.jberet.repository.JdbcRepository
 
Decision - Class in org.jberet.job.model
Corresponds to jsl:Decision job XML element type.
decision(Decision) - Method in class org.jberet.job.model.FlowBuilder
Adds a decision to the current flow.
decision(Decision) - Method in class org.jberet.job.model.JobBuilder
Adds a decision to the job.
DecisionBuilder - Class in org.jberet.job.model
Builder class for building a single Decision.
DecisionBuilder(String, String) - Constructor for class org.jberet.job.model.DecisionBuilder
Constructs a DecisionBuilder for building a decision with the specified id and decider name (deciderRef).
DEFAULT_PATH - Static variable in interface org.jberet.spi.JobXmlResolver
The default META-INF/batch-jobs/ path.
DefaultJobExecutionSelector - Class in org.jberet.repository
 
DefaultJobExecutionSelector(Boolean) - Constructor for class org.jberet.repository.DefaultJobExecutionSelector
 
destroy(Object) - Method in class org.jberet.creation.AbstractArtifactFactory
 
destroy(ConcurrentMap<Contextual<?>, JobScopedContextImpl.ScopedInstance<?>>) - Static method in class org.jberet.creation.JobScopedContextImpl.ScopedInstance
 
destroy(Object) - Method in interface org.jberet.spi.ArtifactFactory
The destroy method destroys an instance created by this factory.
destroyArtifact(Object...) - Method in class org.jberet.runtime.context.JobContextImpl
 
destroyArtifact(List<?>) - Method in class org.jberet.runtime.context.JobContextImpl
 
doInjection(Object, Class<?>, ClassLoader, JobContextImpl, StepContextImpl, Properties) - Method in class org.jberet.creation.AbstractArtifactFactory
 

E

enclosingRunner - Variable in class org.jberet.runtime.runner.AbstractRunner
 
endOn(String) - Method in class org.jberet.job.model.DecisionBuilder
Sets end transition condition for the decision.
endOn(String) - Method in class org.jberet.job.model.FlowBuilder
Sets end transition condition for the flow.
endOn(String) - Method in class org.jberet.job.model.StepBuilder
Sets end transition condition for the step.
endTime - Variable in class org.jberet.runtime.AbstractExecution
 
equals(Object) - Method in class org.jberet.job.model.Job
 
equals(Object) - Method in class org.jberet.repository.ApplicationAndJobName
 
equals(Object) - Method in class org.jberet.runtime.AbstractStepExecution
 
equals(Object) - Method in class org.jberet.runtime.JobExecutionImpl
 
equals(Object) - Method in class org.jberet.runtime.JobInstanceImpl
 
equals(Object) - Method in class org.jberet.runtime.metric.MetricImpl
 
equals(Object) - Method in class org.jberet.runtime.PartitionExecutionImpl
 
equals(Object) - Method in class org.jberet.runtime.StepExecutionImpl
 
ExceptionClassFilter - Class in org.jberet.job.model
Corresponds to jsl:ExceptionClassFilter job XML element type.
ExceptionClassFilter() - Constructor for class org.jberet.job.model.ExceptionClassFilter
 
execute(Runnable) - Method in class org.jberet.spi.JobExecutor
 
execute(JobTask) - Method in class org.jberet.spi.JobExecutor
Executes the given task at some time in the future.
executeRemoveQueries(String) - Method in class org.jberet.repository.MongoRepository
Executes MongoDB remove queries.
executeStatements(String, String) - Method in class org.jberet.repository.JdbcRepository
Executes a series of sql statements.
exitStatus(String...) - Method in class org.jberet.job.model.Transition.Termination
Sets the exit-status attribute value, which is the new exit status after matching the current transition element, and returns the current builder, such as StepBuilder, DecisionBuilder, or FlowBuilder.
exitStatus - Variable in class org.jberet.runtime.AbstractExecution
 

F

failOn(String) - Method in class org.jberet.job.model.DecisionBuilder
Sets fail transition condition for the decision.
failOn(String) - Method in class org.jberet.job.model.FlowBuilder
Sets fail transition condition for the flow.
failOn(String) - Method in class org.jberet.job.model.StepBuilder
Sets fail transition condition for the step.
findOriginalStepExecutionForRestart(String, JobExecutionImpl, ClassLoader) - Method in class org.jberet.repository.AbstractPersistentRepository
 
findOriginalStepExecutionForRestart(String, JobExecutionImpl, ClassLoader) - Method in class org.jberet.repository.InfinispanRepository
 
findOriginalStepExecutionForRestart(String, JobExecutionImpl, ClassLoader) - Method in class org.jberet.repository.InMemoryRepository
 
findOriginalStepExecutionForRestart(String, JobExecutionImpl, ClassLoader) - Method in class org.jberet.repository.JdbcRepository
 
findOriginalStepExecutionForRestart(String, JobExecutionImpl, ClassLoader) - Method in interface org.jberet.repository.JobRepository
 
findOriginalStepExecutionForRestart(String, JobExecutionImpl, ClassLoader) - Method in class org.jberet.repository.MongoRepository
 
Flow - Class in org.jberet.job.model
Corresponds to job element type jsl:Flow in job XML.
flow(Flow) - Method in class org.jberet.job.model.FlowBuilder
Adds a flow to the flow.
flow(Flow) - Method in class org.jberet.job.model.JobBuilder
Adds a flow to the job.
flow(Flow) - Method in class org.jberet.job.model.SplitBuilder
Adds a flow to the split.
FlowBuilder - Class in org.jberet.job.model
Builder class for building a single Flow.
FlowBuilder(String) - Constructor for class org.jberet.job.model.FlowBuilder
Constructs the FlowBuilder instance for building the flow with the specified id.
FlowContextImpl - Class in org.jberet.runtime.context
 
FlowContextImpl(Flow, AbstractContext[]) - Constructor for class org.jberet.runtime.context.FlowContextImpl
 
FlowExecutionImpl - Class in org.jberet.runtime
 
FlowExecutionImpl(String) - Constructor for class org.jberet.runtime.FlowExecutionImpl
 
FlowExecutionRunner - Class in org.jberet.runtime.runner
 
FlowExecutionRunner(FlowContextImpl, CompositeExecutionRunner, CountDownLatch) - Constructor for class org.jberet.runtime.runner.FlowExecutionRunner
 
FlowMerger - Class in org.jberet.job.model
Responsible for merging a child flow and its parent job, and resolving its JSL inheritance.
forName(String) - Static method in enum org.jberet.job.model.XmlElement
Looks up XmlElement enum instance by the local XML element name.

G

get(Contextual<T>, CreationalContext<T>) - Method in class org.jberet.creation.JobScopedContextImpl
 
get(Contextual<T>) - Method in class org.jberet.creation.JobScopedContextImpl
 
get(Contextual<T>, CreationalContext<T>) - Method in class org.jberet.creation.PartitionScopedContextImpl
 
get(Contextual<T>) - Method in class org.jberet.creation.PartitionScopedContextImpl
 
get(Contextual<T>, CreationalContext<T>) - Method in class org.jberet.creation.StepScopedContextImpl
 
get(Contextual<T>) - Method in class org.jberet.creation.StepScopedContextImpl
 
get(String) - Method in class org.jberet.job.model.Properties
Gets the value of a property by its name.
get(Metric.MetricType) - Method in class org.jberet.runtime.metric.StepMetrics
 
getAllowStartIfComplete() - Method in class org.jberet.job.model.Step
Gets the step's allow-start-if-complete attribute value.
getAllowStartIfComplete() - Method in class org.jberet.runtime.context.StepContextImpl
 
getAllowStartIfCompleteBoolean() - Method in class org.jberet.job.model.Step
Gets the step's allow-start-if-complete attribute value as boolean.
getAnalyzer() - Method in class org.jberet.job.model.Partition
Gets the partition analyzer.
getApplicationName() - Method in class org.jberet.runtime.JobInstanceImpl
 
getArtifactClass(String, ClassLoader) - Method in class org.jberet.creation.ArtifactFactoryWrapper
 
getArtifactClass(String) - Method in class org.jberet.runtime.context.JobContextImpl
 
getArtifactClass(String, ClassLoader) - Method in interface org.jberet.spi.ArtifactFactory
Gets the class type of the artifact represented by ref.
getArtifactFactory() - Method in class org.jberet.runtime.context.JobContextImpl
 
getArtifactFactory() - Method in interface org.jberet.spi.BatchEnvironment
Gets an implementation of ArtifactFactory appropriate for the current runtime environment.
getAttributeNext() - Method in class org.jberet.job.model.Flow
Gets the value of the next attribute, which specifies the next job element after this flow completes.
getAttributeNext() - Method in class org.jberet.job.model.Split
Gets the value of the next attribute, which specifies the next job element after this split completes.
getAttributeNext() - Method in class org.jberet.job.model.Step
Gets the value of the next attribute, which specifies the next job element after this step completes.
getBatchArtifacts() - Method in class org.jberet.runtime.context.JobContextImpl
 
getBatchConfigurationProperties() - Method in interface org.jberet.spi.BatchEnvironment
Gets configuration data for batch container.
getBatchEnvironment() - Method in class org.jberet.runtime.context.JobContextImpl
 
getBatchlet() - Method in class org.jberet.job.model.Step
Gets the step's batchlet as a RefArtifact.
getBatchStatus() - Method in class org.jberet.runtime.AbstractExecution
 
getBatchStatus() - Method in class org.jberet.runtime.context.AbstractContext
 
getBatchStatus() - Method in class org.jberet.runtime.context.FlowContextImpl
 
getBatchStatus() - Method in class org.jberet.runtime.context.JobContextImpl
 
getBatchStatus() - Method in class org.jberet.runtime.context.SplitContextImpl
 
getBatchStatus() - Method in class org.jberet.runtime.context.StepContextImpl
 
getBigBooleanArray(InjectionPoint) - Method in class org.jberet.creation.BatchBeanProducer
 
getBigByteArray(InjectionPoint) - Method in class org.jberet.creation.BatchBeanProducer
 
getBigDecimal(InjectionPoint) - Method in class org.jberet.creation.BatchBeanProducer
 
getBigDecimalArray(InjectionPoint) - Method in class org.jberet.creation.BatchBeanProducer
 
getBigDoubleArray(InjectionPoint) - Method in class org.jberet.creation.BatchBeanProducer
 
getBigFloatArray(InjectionPoint) - Method in class org.jberet.creation.BatchBeanProducer
 
getBigInteger(InjectionPoint) - Method in class org.jberet.creation.BatchBeanProducer
 
getBigIntegerArray(InjectionPoint) - Method in class org.jberet.creation.BatchBeanProducer
 
getBigLongArray(InjectionPoint) - Method in class org.jberet.creation.BatchBeanProducer
 
getBigShortArray(InjectionPoint) - Method in class org.jberet.creation.BatchBeanProducer
 
getBoolean(InjectionPoint) - Method in class org.jberet.creation.BatchBeanProducer
 
getBooleanArray(InjectionPoint) - Method in class org.jberet.creation.BatchBeanProducer
 
getByte(InjectionPoint) - Method in class org.jberet.creation.BatchBeanProducer
 
getByteArray(InjectionPoint) - Method in class org.jberet.creation.BatchBeanProducer
 
getCharacter(InjectionPoint) - Method in class org.jberet.creation.BatchBeanProducer
 
getCharacterArray(InjectionPoint) - Method in class org.jberet.creation.BatchBeanProducer
 
getCharArray(InjectionPoint) - Method in class org.jberet.creation.BatchBeanProducer
 
getCheckpointAlgorithm() - Method in class org.jberet.job.model.Chunk
Gets the chunk's checkpoint algorithm as a RefArtifact.
getCheckpointPolicy() - Method in class org.jberet.job.model.Chunk
Gets the chunk's checkpoint policy, either "item" (default), or "custom".
getChunk() - Method in class org.jberet.job.model.Step
Gets the step's chunk element.
getClassLoader() - Method in class org.jberet.runtime.context.AbstractContext
 
getClassLoader() - Method in interface org.jberet.spi.BatchEnvironment
Gets the class loader suitable for loading application classes and batch artifacts.
getClassNameForRef(String) - Method in class org.jberet.job.model.BatchArtifacts
Gets the fully-qualified class name for a batch artifact by its ref name.
getClazz(InjectionPoint) - Method in class org.jberet.creation.BatchBeanProducer
 
getClazzArray(InjectionPoint) - Method in class org.jberet.creation.BatchBeanProducer
 
getCollector() - Method in class org.jberet.job.model.Partition
Gets the partition collector.
getContent(ClassLoader) - Method in class org.jberet.job.model.Script
Gets the content of the script as string.
getCreateTime() - Method in class org.jberet.runtime.JobExecutionImpl
 
getCurrentArtifactCreationContext() - Static method in class org.jberet.creation.ArtifactCreationContext
 
getDate(InjectionPoint) - Method in class org.jberet.creation.BatchBeanProducer
 
getDateArray(InjectionPoint) - Method in class org.jberet.creation.BatchBeanProducer
 
getDouble(InjectionPoint) - Method in class org.jberet.creation.BatchBeanProducer
 
getDoubleArray(InjectionPoint) - Method in class org.jberet.creation.BatchBeanProducer
 
getEndTime() - Method in class org.jberet.runtime.AbstractExecution
 
getEngine(ClassLoader) - Method in class org.jberet.job.model.Script
Gets the javax.script.ScriptEngine for this script.
getException() - Method in class org.jberet.runtime.AbstractStepExecution
 
getException() - Method in class org.jberet.runtime.context.StepContextImpl
 
getExecutedStepIds() - Method in class org.jberet.runtime.context.JobContextImpl
 
getExecutionId() - Method in class org.jberet.runtime.context.JobContextImpl
 
getExecutionId() - Method in class org.jberet.runtime.JobExecutionImpl
 
getExitStatus() - Method in class org.jberet.job.model.Transition.Termination
Gets the exit-status attribute value, which is the new exit status after matching the current transition element.
getExitStatus() - Method in class org.jberet.runtime.AbstractExecution
 
getExitStatus() - Method in class org.jberet.runtime.context.AbstractContext
 
getExitStatus() - Method in class org.jberet.runtime.context.FlowContextImpl
 
getExitStatus() - Method in class org.jberet.runtime.context.JobContextImpl
 
getExitStatus() - Method in class org.jberet.runtime.context.SplitContextImpl
 
getExitStatus() - Method in class org.jberet.runtime.context.StepContextImpl
 
getFile(InjectionPoint) - Method in class org.jberet.creation.BatchBeanProducer
 
getFileArray(InjectionPoint) - Method in class org.jberet.creation.BatchBeanProducer
 
getFloat(InjectionPoint) - Method in class org.jberet.creation.BatchBeanProducer
 
getFloatArray(InjectionPoint) - Method in class org.jberet.creation.BatchBeanProducer
 
getFlow() - Method in class org.jberet.runtime.context.FlowContextImpl
 
getFlowExecution() - Method in class org.jberet.runtime.context.FlowContextImpl
 
getFlowExecutions() - Method in class org.jberet.runtime.context.SplitContextImpl
 
getFlowId() - Method in class org.jberet.runtime.FlowExecutionImpl
 
getFlows() - Method in class org.jberet.job.model.Split
Gets the list of flows contained in this split.
getId() - Method in interface org.jberet.job.model.JobElement
Gets the id of this job element.
getId() - Method in class org.jberet.runtime.context.AbstractContext
 
getInet4Address(InjectionPoint) - Method in class org.jberet.creation.BatchBeanProducer
 
getInet6Address(InjectionPoint) - Method in class org.jberet.creation.BatchBeanProducer
 
getInheritingJobElements() - Method in class org.jberet.job.model.Job
Gets all direct or indirect job elements in this job that inherit from a parent (ie, has a non-null parent attribute).
getInstance() - Static method in class org.jberet.repository.InMemoryRepository
Gets a singleton instance of an in-memory job repository.
getInstance() - Static method in class org.jberet.tx.LocalTransactionManager
 
getInstanceId() - Method in class org.jberet.runtime.context.JobContextImpl
 
getInstanceId() - Method in class org.jberet.runtime.JobInstanceImpl
 
getInt(InjectionPoint) - Method in class org.jberet.creation.BatchBeanProducer
 
getIntArray(InjectionPoint) - Method in class org.jberet.creation.BatchBeanProducer
 
getIntegerArray(InjectionPoint) - Method in class org.jberet.creation.BatchBeanProducer
 
getItemCount() - Method in class org.jberet.job.model.Chunk
Gets the chunk's item-count attribute value as string.
getItemCountInt() - Method in class org.jberet.job.model.Chunk
Gets the chunk's item-count attribute value as int.
getJarFile(InjectionPoint) - Method in class org.jberet.creation.BatchBeanProducer
 
getJarFileArray(InjectionPoint) - Method in class org.jberet.creation.BatchBeanProducer
 
getJob(ApplicationAndJobName) - Method in class org.jberet.repository.AbstractRepository
 
getJob(ApplicationAndJobName) - Method in interface org.jberet.repository.JobRepository
 
getJob() - Method in class org.jberet.runtime.context.JobContextImpl
 
getJobContext() - Method in class org.jberet.creation.BatchBeanProducer
 
getJobContext() - Method in class org.jberet.repository.DefaultJobExecutionSelector
 
getJobContext() - Method in interface org.jberet.repository.JobExecutionSelector
 
getJobContext() - Method in class org.jberet.runtime.context.AbstractContext
 
getJobContext() - Method in class org.jberet.runtime.context.JobContextImpl
 
getJobElements() - Method in class org.jberet.job.model.Flow
Gets the list of job elements contained inside this flow.
getJobElements() - Method in class org.jberet.job.model.Job
Gets the list of job elements, such as steps, decisions, flows or splits, contained in this job.
getJobElements() - Method in class org.jberet.runtime.runner.CompositeExecutionRunner
 
getJobElements() - Method in class org.jberet.runtime.runner.FlowExecutionRunner
 
getJobElements() - Method in class org.jberet.runtime.runner.JobExecutionRunner
 
getJobElements() - Method in class org.jberet.runtime.runner.SplitExecutionRunner
 
getJobExecution(long) - Method in class org.jberet.operations.JobOperatorImpl
 
getJobExecution(long) - Method in class org.jberet.repository.AbstractPersistentRepository
 
getJobExecution(long) - Method in class org.jberet.repository.InfinispanRepository
 
getJobExecution(long) - Method in class org.jberet.repository.InMemoryRepository
 
getJobExecution(long) - Method in class org.jberet.repository.JdbcRepository
 
getJobExecution(long) - Method in interface org.jberet.repository.JobRepository
 
getJobExecution(long) - Method in class org.jberet.repository.MongoRepository
 
getJobExecution() - Method in class org.jberet.runtime.context.JobContextImpl
 
getJobExecutions(JobInstance) - Method in class org.jberet.operations.JobOperatorImpl
 
getJobExecutions(JobInstance) - Method in class org.jberet.repository.InfinispanRepository
 
getJobExecutions(JobInstance) - Method in class org.jberet.repository.InMemoryRepository
 
getJobExecutions(JobInstance) - Method in class org.jberet.repository.JdbcRepository
 
getJobExecutions(JobInstance) - Method in interface org.jberet.repository.JobRepository
 
getJobExecutions(JobInstance) - Method in class org.jberet.repository.MongoRepository
 
getJobExecutions() - Method in class org.jberet.runtime.JobInstanceImpl
 
getJobInstance(long) - Method in class org.jberet.operations.JobOperatorImpl
 
getJobInstance(long) - Method in class org.jberet.repository.AbstractPersistentRepository
 
getJobInstance(long) - Method in class org.jberet.repository.InfinispanRepository
 
getJobInstance(long) - Method in class org.jberet.repository.InMemoryRepository
 
getJobInstance(long) - Method in class org.jberet.repository.JdbcRepository
 
getJobInstance(long) - Method in interface org.jberet.repository.JobRepository
 
getJobInstance(long) - Method in class org.jberet.repository.MongoRepository
 
getJobInstance() - Method in class org.jberet.runtime.JobExecutionImpl
 
getJobInstanceCount(String) - Method in class org.jberet.operations.JobOperatorImpl
 
getJobInstanceCount(String) - Method in class org.jberet.repository.InfinispanRepository
 
getJobInstanceCount(String) - Method in class org.jberet.repository.InMemoryRepository
 
getJobInstanceCount(String) - Method in class org.jberet.repository.JdbcRepository
 
getJobInstanceCount(String) - Method in interface org.jberet.repository.JobRepository
 
getJobInstanceCount(String) - Method in class org.jberet.repository.MongoRepository
 
getJobInstances(String, int, int) - Method in class org.jberet.operations.JobOperatorImpl
 
getJobInstances(String) - Method in class org.jberet.repository.InfinispanRepository
 
getJobInstances(String) - Method in class org.jberet.repository.InMemoryRepository
 
getJobInstances(String) - Method in class org.jberet.repository.JdbcRepository
 
getJobInstances(String) - Method in interface org.jberet.repository.JobRepository
 
getJobInstances(String) - Method in class org.jberet.repository.MongoRepository
 
getJobName() - Method in class org.jberet.runtime.context.JobContextImpl
 
getJobName() - Method in class org.jberet.runtime.JobExecutionImpl
 
getJobName() - Method in class org.jberet.runtime.JobInstanceImpl
 
getJobNames() - Method in class org.jberet.operations.JobOperatorImpl
 
getJobNames() - Method in class org.jberet.repository.AbstractRepository
 
getJobNames() - Method in interface org.jberet.repository.JobRepository
Gets all the job names from the job repository.
getJobParameters() - Method in class org.jberet.runtime.context.JobContextImpl
 
getJobParameters() - Method in class org.jberet.runtime.JobExecutionImpl
 
getJobRepository(BatchEnvironment) - Static method in class org.jberet.repository.JobRepositoryFactory
Deprecated.
 
getJobRepository() - Method in class org.jberet.runtime.context.JobContextImpl
 
getJobRepository() - Method in interface org.jberet.spi.BatchEnvironment
Returns the job repository used for this environment.
getJobXmlName() - Method in class org.jberet.job.model.Job
Gets Job.jobXmlName, which may be null.
getJobXmlNames(ClassLoader) - Method in interface org.jberet.spi.JobXmlResolver
Optionally returns a list of job XML names that are allowed to be used.
getJobXmlNames(ClassLoader) - Method in class org.jberet.tools.AbstractJobXmlResolver
 
getJobXmlNames(ClassLoader) - Method in class org.jberet.tools.ChainedJobXmlResolver
Optionally returns a list of job XML names that are allowed to be used.
getJobXmlResolver() - Method in interface org.jberet.spi.BatchEnvironment
Returns the job XML resolver used to locate the job XML content.
getLastStepExecution() - Method in class org.jberet.runtime.FlowExecutionImpl
 
getLastUpdatedTime() - Method in class org.jberet.runtime.JobExecutionImpl
 
getList(InjectionPoint) - Method in class org.jberet.creation.BatchBeanProducer
 
getListeners() - Method in class org.jberet.job.model.Flow
Disables getting listeners, since flow does not have listeners.
getListeners() - Method in class org.jberet.job.model.InheritableJobElement
Gets all listeners as Listeners for this job element.
getListeners() - Method in class org.jberet.job.model.Listeners
Gets the list of listeners as List<RefArtifact>.
getLocalName() - Method in enum org.jberet.job.model.XmlAttribute
Get the local name of this attribute.
getLocalName() - Method in enum org.jberet.job.model.XmlElement
Get the local name of the corresponding XML element.
getLogger(InjectionPoint) - Method in class org.jberet.creation.BatchBeanProducer
 
getLong(InjectionPoint) - Method in class org.jberet.creation.BatchBeanProducer
 
getLongArray(InjectionPoint) - Method in class org.jberet.creation.BatchBeanProducer
 
getMap(InjectionPoint) - Method in class org.jberet.creation.BatchBeanProducer
 
getMapper() - Method in class org.jberet.job.model.Partition
Gets the partition mapper.
getMaximumPoolSize() - Method in class org.jberet.spi.JobExecutor
Returns the maximum number of threads allowed to be executed.
getMetric(AbstractStepExecution, Metric.MetricType) - Static method in class org.jberet.runtime.metric.MetricImpl
 
getMetrics() - Method in class org.jberet.runtime.AbstractStepExecution
 
getMetrics() - Method in class org.jberet.runtime.context.StepContextImpl
 
getMetrics() - Method in class org.jberet.runtime.metric.StepMetrics
 
getNoRollbackExceptionClasses() - Method in class org.jberet.job.model.Chunk
Gets the chunk's no rollback exception classes filter.
getObjectName(InjectionPoint) - Method in class org.jberet.creation.BatchBeanProducer
 
getOn() - Method in class org.jberet.job.model.Transition
Gets the on attribute value.
getOriginalStepExecution() - Method in class org.jberet.runtime.context.StepContextImpl
 
getOuterContexts() - Method in class org.jberet.runtime.context.AbstractContext
 
getOuterContexts() - Method in class org.jberet.runtime.context.JobContextImpl
 
getParameters(long) - Method in class org.jberet.operations.JobOperatorImpl
 
getPartition() - Method in class org.jberet.job.model.Properties
Gets the partition index of this org.jberet.job.model.Properties.
getPartition() - Method in class org.jberet.job.model.Step
Gets the step's partition element.
getPartitionExecutions(long, StepExecutionImpl, boolean, ClassLoader) - Method in class org.jberet.repository.AbstractRepository
 
getPartitionExecutions(long, StepExecutionImpl, boolean, ClassLoader) - Method in class org.jberet.repository.InfinispanRepository
 
getPartitionExecutions(long, StepExecutionImpl, boolean, ClassLoader) - Method in class org.jberet.repository.JdbcRepository
 
getPartitionExecutions(long, StepExecutionImpl, boolean, ClassLoader) - Method in interface org.jberet.repository.JobRepository
 
getPartitionExecutions(long, StepExecutionImpl, boolean, ClassLoader) - Method in class org.jberet.repository.MongoRepository
 
getPartitionExecutions() - Method in class org.jberet.runtime.AbstractStepExecution
 
getPartitionExecutions() - Method in class org.jberet.runtime.PartitionExecutionImpl
 
getPartitionExecutions() - Method in class org.jberet.runtime.StepExecutionImpl
 
getPartitionId() - Method in class org.jberet.runtime.PartitionExecutionImpl
 
getPartitions() - Method in class org.jberet.job.model.PartitionPlan
Gets the number of partition as string.
getPartitionScopedBeans() - Method in class org.jberet.runtime.context.StepContextImpl
 
getPartitionsInt() - Method in class org.jberet.job.model.PartitionPlan
Gets the number of partitions as int.
getPattern(InjectionPoint) - Method in class org.jberet.creation.BatchBeanProducer
 
getPersistentUserData() - Method in class org.jberet.runtime.AbstractStepExecution
 
getPersistentUserData() - Method in class org.jberet.runtime.context.StepContextImpl
 
getPlan() - Method in class org.jberet.job.model.Partition
Gets the partition plan for this partition.
getProcessor() - Method in class org.jberet.job.model.Chunk
Gets the chunk's item processor as a RefArtifact.
getProperties() - Method in class org.jberet.job.model.Flow
Disables getting properties, since flow does not have properties.
getProperties() - Method in interface org.jberet.job.model.PropertiesHolder
Gets org.jberet.job.model.Properties in the current job model type.
getProperties() - Method in class org.jberet.job.model.RefArtifact
Gets the org.jberet.job.model.Properties belonging to this batch artifact.
getProperties() - Method in class org.jberet.job.model.Split
Disables getting properties, since split contains no batch properties.
getProperties() - Method in class org.jberet.runtime.context.JobContextImpl
 
getProperties() - Method in class org.jberet.runtime.context.StepContextImpl
 
getPropertiesList() - Method in class org.jberet.job.model.PartitionPlan
Gets the list of org.jberet.job.model.Properties for this partition plan.
getReader() - Method in class org.jberet.job.model.Chunk
Gets the chunk's item reader as a RefArtifact.
getReaderCheckpointInfo() - Method in class org.jberet.runtime.AbstractStepExecution
 
getReducer() - Method in class org.jberet.job.model.Partition
Gets the partition reducer.
getRef() - Method in class org.jberet.job.model.Decision
Gets the ref name for the associated decider.
getRef() - Method in class org.jberet.job.model.RefArtifact
Gets the ref value for this batch artifact.
getRequiredRemainingPermits() - Method in class org.jberet.runtime.runner.AbstractRunner
 
getRequiredRemainingPermits() - Method in class org.jberet.runtime.runner.JobExecutionRunner
 
getRequiredRemainingPermits() - Method in interface org.jberet.spi.JobTask
The number of threads in the pool required to be remaining before this task should execute.
getRestart() - Method in class org.jberet.job.model.Transition.Stop
Gets the restart attribute value, which should points to a job element to restart from.
getRestartable() - Method in class org.jberet.job.model.Job
Gets the job's restartable attribute value as string.
getRestartableBoolean() - Method in class org.jberet.job.model.Job
Gets the job's restartable attribute value as boolean.
getRestartPosition() - Method in class org.jberet.runtime.JobExecutionImpl
 
getRetryableExceptionClasses() - Method in class org.jberet.job.model.Chunk
Gets the chunk's retryable exception classes filter.
getRetryLimit() - Method in class org.jberet.job.model.Chunk
Gets the chunk's retry-limit attribute value.
getRunningExecutions(String) - Method in class org.jberet.operations.JobOperatorImpl
 
getRunningExecutions(String) - Method in class org.jberet.repository.InfinispanRepository
 
getRunningExecutions(String) - Method in class org.jberet.repository.InMemoryRepository
 
getRunningExecutions(String) - Method in class org.jberet.repository.JdbcRepository
 
getRunningExecutions(String) - Method in interface org.jberet.repository.JobRepository
Gets the ids of running job executions belonging to a specific job.
getRunningExecutions(String) - Method in class org.jberet.repository.MongoRepository
 
getScope() - Method in class org.jberet.creation.JobScopedContextImpl
 
getScope() - Method in class org.jberet.creation.PartitionScopedContextImpl
 
getScope() - Method in class org.jberet.creation.StepScopedContextImpl
 
getScopedBeans() - Method in class org.jberet.runtime.context.AbstractContext
 
getScript() - Method in class org.jberet.job.model.RefArtifact
Gets the script that is either included in or referenced by this batch artifact in job XML.
getSet(InjectionPoint) - Method in class org.jberet.creation.BatchBeanProducer
 
getShort(InjectionPoint) - Method in class org.jberet.creation.BatchBeanProducer
 
getShortArray(InjectionPoint) - Method in class org.jberet.creation.BatchBeanProducer
 
getSkipLimit() - Method in class org.jberet.job.model.Chunk
Gets the chunk's skip-limit attribute value.
getSkipLimitInt() - Method in class org.jberet.job.model.Chunk
Gets the chunk's skip-limit attribute value as int.
getSkippableExceptionClasses() - Method in class org.jberet.job.model.Chunk
Gets the chunk's skippable exception classes filter.
getSplit() - Method in class org.jberet.runtime.context.SplitContextImpl
 
getSplitId() - Method in class org.jberet.runtime.SplitExecutionImpl
 
getStartLimit() - Method in class org.jberet.job.model.Step
Gets the step's start-limit attribute value as string.
getStartLimitInt() - Method in class org.jberet.job.model.Step
Gets the step's start-limit attribute value as int.
getStartTime() - Method in class org.jberet.runtime.AbstractExecution
 
getStatus() - Method in class org.jberet.tx.LocalTransactionManager
 
getStep() - Method in class org.jberet.runtime.context.StepContextImpl
 
getStepContext() - Method in class org.jberet.creation.BatchBeanProducer
 
getStepContext() - Method in class org.jberet.repository.DefaultJobExecutionSelector
 
getStepContext() - Method in interface org.jberet.repository.JobExecutionSelector
 
getStepExecution() - Method in class org.jberet.runtime.context.StepContextImpl
 
getStepExecutionId() - Method in class org.jberet.runtime.AbstractStepExecution
 
getStepExecutionId() - Method in class org.jberet.runtime.context.StepContextImpl
 
getStepExecutions(long) - Method in class org.jberet.operations.JobOperatorImpl
 
getStepExecutions(long, ClassLoader) - Method in class org.jberet.repository.AbstractPersistentRepository
 
getStepExecutions(long, ClassLoader) - Method in class org.jberet.repository.InfinispanRepository
 
getStepExecutions(long, ClassLoader) - Method in class org.jberet.repository.InMemoryRepository
 
getStepExecutions(long, ClassLoader) - Method in interface org.jberet.repository.JobRepository
 
getStepExecutions() - Method in class org.jberet.runtime.JobExecutionImpl
 
getStepMetrics() - Method in class org.jberet.runtime.AbstractStepExecution
 
getStepName() - Method in class org.jberet.runtime.AbstractStepExecution
 
getStepName() - Method in class org.jberet.runtime.context.StepContextImpl
 
getString(InjectionPoint) - Method in class org.jberet.creation.BatchBeanProducer
 
getStringArray(InjectionPoint) - Method in class org.jberet.creation.BatchBeanProducer
 
getStringBuffer(InjectionPoint) - Method in class org.jberet.creation.BatchBeanProducer
 
getStringBuilder(InjectionPoint) - Method in class org.jberet.creation.BatchBeanProducer
 
getStringList(InjectionPoint) - Method in class org.jberet.creation.BatchBeanProducer
 
getStringMap(InjectionPoint) - Method in class org.jberet.creation.BatchBeanProducer
 
getStringSet(InjectionPoint) - Method in class org.jberet.creation.BatchBeanProducer
 
getSubstitutedJob() - Method in class org.jberet.runtime.JobExecutionImpl
 
getThreads() - Method in class org.jberet.job.model.PartitionPlan
Gets the number of threads as string.
getThreadsInt() - Method in class org.jberet.job.model.PartitionPlan
Gets the number of threads as int.
getTimeLimit() - Method in class org.jberet.job.model.Chunk
Gets the chunk's time-limit attribute value as string.
getTimeLimitInt() - Method in class org.jberet.job.model.Chunk
Gets the chunk's time-limit attribute value as int.
getTo() - Method in class org.jberet.job.model.Transition.Next
Gets the to attribute value, which should points to the next job element.
getTransaction() - Method in class org.jberet.tx.LocalTransactionManager
 
getTransactionManager() - Method in interface org.jberet.spi.BatchEnvironment
Returns a transaction manager to be used for executions that require a transaction.
getTransientUserData() - Method in class org.jberet.runtime.context.AbstractContext
 
getTransitionElements() - Method in class org.jberet.job.model.Job
 
getTransitionElements() - Method in interface org.jberet.job.model.JobElement
Gets the list of transition elements, such as Transition.End, Transition.Fail, Transition.Next, Transition.Stop.
getType() - Method in class org.jberet.job.model.Script
Gets the type of the script, for example, javascript.
getType() - Method in class org.jberet.runtime.metric.MetricImpl
 
getUnsubstitutedJob() - Method in class org.jberet.runtime.JobInstanceImpl
 
getURI(InjectionPoint) - Method in class org.jberet.creation.BatchBeanProducer
 
getURIArray(InjectionPoint) - Method in class org.jberet.creation.BatchBeanProducer
 
getURL(InjectionPoint) - Method in class org.jberet.creation.BatchBeanProducer
 
getURLArray(InjectionPoint) - Method in class org.jberet.creation.BatchBeanProducer
 
getValue() - Method in class org.jberet.runtime.metric.MetricImpl
 
getWriter() - Method in class org.jberet.job.model.Chunk
Gets the chunk's item writer as a RefArtifact.
getWriterCheckpointInfo() - Method in class org.jberet.runtime.AbstractStepExecution
 
getZipFileArray(InjectionPoint) - Method in class org.jberet.creation.BatchBeanProducer
 

H

hashCode() - Method in class org.jberet.job.model.Job
 
hashCode() - Method in class org.jberet.repository.ApplicationAndJobName
 
hashCode() - Method in class org.jberet.runtime.AbstractStepExecution
 
hashCode() - Method in class org.jberet.runtime.JobExecutionImpl
 
hashCode() - Method in class org.jberet.runtime.JobInstanceImpl
 
hashCode() - Method in class org.jberet.runtime.metric.MetricImpl
 
hashCode() - Method in class org.jberet.runtime.PartitionExecutionImpl
 
hashCode() - Method in class org.jberet.runtime.StepExecutionImpl
 

I

id - Variable in class org.jberet.runtime.context.AbstractContext
 
id - Variable in class org.jberet.runtime.runner.AbstractRunner
The id of the job element this runner represents.
increment(long) - Method in class org.jberet.runtime.metric.MetricImpl
 
increment(Metric.MetricType, long) - Method in class org.jberet.runtime.metric.StepMetrics
 
INFINISPAN_XML - Static variable in interface org.jberet.spi.PropertyKey
A key used to specify the resource path to the configuration XML for configuring infinispan job repository.
InfinispanRepository - Class in org.jberet.repository
 
InfinispanRepository(Configuration) - Constructor for class org.jberet.repository.InfinispanRepository
 
InfinispanRepository(String) - Constructor for class org.jberet.repository.InfinispanRepository
 
InheritableJobElement - Class in org.jberet.job.model
Abstract base class for those job elements that support JSL inheritance, such as job, step and flow.
InheritableJobElement(String) - Constructor for class org.jberet.job.model.InheritableJobElement
 
InMemoryRepository - Class in org.jberet.repository
 
InMemoryRepository() - Constructor for class org.jberet.repository.InMemoryRepository
 
invokeAnnotatedLifecycleMethod(Object, Class<?>, Class<? extends Annotation>) - Method in class org.jberet.creation.AbstractArtifactFactory
 
isAbstract() - Method in class org.jberet.job.model.InheritableJobElement
Checks if this job element is abstract, which is specified by its abstract attribute.
isActive() - Method in class org.jberet.creation.JobScopedContextImpl
 
isActive() - Method in class org.jberet.creation.PartitionScopedContextImpl
 
isActive() - Method in class org.jberet.creation.StepScopedContextImpl
 
isEnded() - Method in class org.jberet.runtime.FlowExecutionImpl
 
isRestart() - Method in class org.jberet.runtime.context.JobContextImpl
 
isStopRequested() - Method in class org.jberet.runtime.JobExecutionImpl
 
itemCount(int) - Method in class org.jberet.job.model.StepBuilder
Sets item-count attribue value for a chunk-type step.

J

JdbcRepository - Class in org.jberet.repository
 
JdbcRepository(Properties) - Constructor for class org.jberet.repository.JdbcRepository
 
JdbcRepository(DataSource) - Constructor for class org.jberet.repository.JdbcRepository
Creates a new JDBC job repository.
JdbcRepository(DataSource, Properties) - Constructor for class org.jberet.repository.JdbcRepository
Creates a new JDBC job repository.
Job - Class in org.jberet.job.model
Corresponds to jsl:Job type, the root element of job XML.
JOB_REPOSITORY_TYPE_KEY - Static variable in class org.jberet.repository.JobRepositoryFactory
Deprecated.
 
JOB_XML_NAME - Static variable in class org.jberet.job.model.Job
Job parameter key to specify job xml name when it differs from job id.
JobBuilder - Class in org.jberet.job.model
Builder class for building a single job.
JobBuilder(String) - Constructor for class org.jberet.job.model.JobBuilder
Constructs a JobBuilder for building the job with the specified id.
jobContext - Variable in class org.jberet.runtime.runner.AbstractRunner
 
JobContextImpl - Class in org.jberet.runtime.context
 
JobContextImpl(JobExecutionImpl, JobExecutionImpl, ArtifactFactory, JobRepository, BatchEnvironment) - Constructor for class org.jberet.runtime.context.JobContextImpl
 
JobElement - Interface in org.jberet.job.model
A common interface for all job elements: decision, flow, split and step.
JobExecutionImpl - Class in org.jberet.runtime
 
JobExecutionImpl(JobInstanceImpl, Properties) - Constructor for class org.jberet.runtime.JobExecutionImpl
 
JobExecutionImpl(JobInstanceImpl, long, Properties, Date, Date, Date, Date, String, String, String) - Constructor for class org.jberet.runtime.JobExecutionImpl
 
JobExecutionRunner - Class in org.jberet.runtime.runner
 
JobExecutionRunner(JobContextImpl) - Constructor for class org.jberet.runtime.runner.JobExecutionRunner
 
JobExecutionSelector - Interface in org.jberet.repository
 
JobExecutor - Class in org.jberet.spi
An executor service to be used with batch jobs.
JobExecutor(Executor) - Constructor for class org.jberet.spi.JobExecutor
Creates a new executor.
jobExists(String) - Method in class org.jberet.repository.AbstractRepository
 
jobExists(String) - Method in interface org.jberet.repository.JobRepository
Checks if a job with the specified jobName exists or not.
JobInstanceImpl - Class in org.jberet.runtime
 
JobInstanceImpl(Job, String, String) - Constructor for class org.jberet.runtime.JobInstanceImpl
 
JobMerger - Class in org.jberet.job.model
Responsible for merging a child job and its parent job, and resolving its JSL inheritance.
jobName - Variable in class org.jberet.repository.ApplicationAndJobName
 
JobOperatorImpl - Class in org.jberet.operations
 
JobOperatorImpl() - Constructor for class org.jberet.operations.JobOperatorImpl
 
jobParametersToken - Static variable in class org.jberet.job.model.PropertyResolver
 
JobParser - Class in org.jberet.job.model
StAX parser for batch job xml and batch xml files.
JobParser() - Constructor for class org.jberet.job.model.JobParser
 
jobPropertiesToken - Static variable in class org.jberet.job.model.PropertyResolver
 
JobRepository - Interface in org.jberet.repository
 
JobRepositoryFactory - Class in org.jberet.repository
JobScoped - Annotation Type in org.jberet.cdi
Custom CDI scope for job execution.
JobScopedContextImpl - Class in org.jberet.creation
 
JobScopedContextImpl.ScopedInstance<T> - Class in org.jberet.creation
 
JobStopNotificationListener - Interface in org.jberet.runtime
An interface to be implemented by classes that wish to be notified when its job is requested to stop.
JobTask - Interface in org.jberet.spi
A task to be used with the JobExecutor for leaving permits in a thread-pool open if required by the task being executed.
JobXmlResolver - Interface in org.jberet.spi
An interface used to resolve job XML content.

L

lastUpdatedTime - Variable in class org.jberet.runtime.JobExecutionImpl
 
listener(String, String[]...) - Method in class org.jberet.job.model.JobBuilder
Adds a job listener to the job.
listener(String, Properties) - Method in class org.jberet.job.model.JobBuilder
Adds a job listener to the job, with listener properties.
listener(String, String[]...) - Method in class org.jberet.job.model.StepBuilder
Adds a step listener to the step.
listener(String, Properties) - Method in class org.jberet.job.model.StepBuilder
Adds a step listener to the step, with listener properties.
Listeners - Class in org.jberet.job.model
Corresponds to jsl:Listeners job XML element type.
Listeners() - Constructor for class org.jberet.job.model.Listeners
 
loadBatchXml(ClassLoader) - Static method in class org.jberet.creation.ArchiveXmlLoader
Gets the batch artifacts definition object, loaded from the archive batch.xml if available.
loadJobXml(String, ClassLoader, List<Job>, JobXmlResolver) - Static method in class org.jberet.creation.ArchiveXmlLoader
Gets the job root element for a given job name.
LOCAL_TX - Static variable in interface org.jberet.spi.PropertyKey
A key used to indicate transactions should be kept local and not use the global transaction.
LocalTransactionManager - Class in org.jberet.tx
 

M

matches(Class<? extends Throwable>) - Method in class org.jberet.job.model.ExceptionClassFilter
Checks if an exception should be included or excluded.
matches(String, String) - Static method in class org.jberet.runtime.runner.AbstractRunner
 
merge() - Method in class org.jberet.job.model.FlowMerger
Performs the merge, and if the parent flow has its own parent, it is also resolved.
merge() - Method in class org.jberet.job.model.JobMerger
Performs the merge, and if the parent job has its own parent, it is also resolved.
merge() - Method in class org.jberet.job.model.StepMerger
Performs the merge, and if the parent has its own parent, it is also resolved.
MetaInfBatchJobsJobXmlResolver - Class in org.jberet.tools
A job XML resolver which resolves job XML files in the META-INF/batch-jobs directory on the class loader.
MetaInfBatchJobsJobXmlResolver() - Constructor for class org.jberet.tools.MetaInfBatchJobsJobXmlResolver
 
MetricImpl - Class in org.jberet.runtime.metric
 
MetricImpl(Metric.MetricType) - Constructor for class org.jberet.runtime.metric.MetricImpl
 
MongoRepository - Class in org.jberet.repository
 
MongoRepository(Properties) - Constructor for class org.jberet.repository.MongoRepository
 

N

next(String) - Method in class org.jberet.job.model.FlowBuilder
Sets the next attribute value for the flow.
next(String) - Method in class org.jberet.job.model.SplitBuilder
Sets the next attribute value for the split.
next(String) - Method in class org.jberet.job.model.StepBuilder
Sets the next attribute value for the step.
nextOn(String) - Method in class org.jberet.job.model.DecisionBuilder
Sets next transition condition for the decision.
nextOn(String) - Method in class org.jberet.job.model.FlowBuilder
Sets next transition condition for the flow.
nextOn(String) - Method in class org.jberet.job.model.StepBuilder
Sets next transition condition for the step.
NL - Static variable in class org.jberet.util.BatchUtil
 
noRollbackExceptionsExclude(Class<? extends Exception>...) - Method in class org.jberet.job.model.StepBuilder
Adds exception classes to the chunk-type step to exclude from no-rollback exceptions.
noRollbackExceptionsInclude(Class<? extends Exception>...) - Method in class org.jberet.job.model.StepBuilder
Adds exception classes to the chunk-type step to include as no-rollback exceptions.

O

objectToBytes(Object) - Static method in class org.jberet.util.BatchUtil
 
org.jberet.cdi - package org.jberet.cdi
 
org.jberet.creation - package org.jberet.creation
 
org.jberet.job.model - package org.jberet.job.model
 
org.jberet.operations - package org.jberet.operations
 
org.jberet.repository - package org.jberet.repository
 
org.jberet.runtime - package org.jberet.runtime
 
org.jberet.runtime.context - package org.jberet.runtime.context
 
org.jberet.runtime.metric - package org.jberet.runtime.metric
 
org.jberet.runtime.runner - package org.jberet.runtime.runner
 
org.jberet.spi - package org.jberet.spi
 
org.jberet.tools - package org.jberet.tools
 
org.jberet.tx - package org.jberet.tx
 
org.jberet.util - package org.jberet.util
 
outerContexts - Variable in class org.jberet.runtime.context.AbstractContext
Chain of batch contexts, the first one is the root JobContext.

P

parseBatchArtifacts(InputStream) - Static method in class org.jberet.job.model.JobParser
Parses batch.xml, which declares batch artifacts in xml format.
parseJob(InputStream, ClassLoader, XMLResolver) - Static method in class org.jberet.job.model.JobParser
Parses a job xml input stream, which defines a batch job.
Partition - Class in org.jberet.job.model
Corresponds to jsl:Partition job element type in job XML.
partitionAnalyzer(String, String[]...) - Method in class org.jberet.job.model.StepBuilder
Sets the partition analyzer for a partitioned step.
partitionAnalyzer(String, Properties) - Method in class org.jberet.job.model.StepBuilder
Sets the partition analyzer for a partitioned step, with partition analyzer properties.
partitionCollector(String, String[]...) - Method in class org.jberet.job.model.StepBuilder
Sets the partition collector for a partitioned step.
partitionCollector(String, Properties) - Method in class org.jberet.job.model.StepBuilder
Sets the partition collector for a partitioned step, with partition collector properties.
PartitionExecutionImpl - Class in org.jberet.runtime
 
PartitionExecutionImpl(int, long, String, BatchStatus, String, Serializable, Serializable, Serializable) - Constructor for class org.jberet.runtime.PartitionExecutionImpl
Creates a partition execution data structure.
PartitionExecutionImpl(AbstractStepExecution) - Constructor for class org.jberet.runtime.PartitionExecutionImpl
 
partitionMapper(String, String[]...) - Method in class org.jberet.job.model.StepBuilder
Sets the partition mapper for a partitioned step.
partitionMapper(String, Properties) - Method in class org.jberet.job.model.StepBuilder
Sets the partition mapper for a partitioned step, with partition mapper properties.
PartitionPlan - Class in org.jberet.job.model
Corresponds to jsl:PartitionPlan job element type in job XML.
partitionPlan(int, int, List<Properties>) - Method in class org.jberet.job.model.StepBuilder
Sets the partition plan for a partitioned step.
partitionPlan(int, List<Properties>) - Method in class org.jberet.job.model.StepBuilder
Sets the partition plan for a partitioned step.
partitionPlan(int, int...) - Method in class org.jberet.job.model.StepBuilder
Sets the partition plan for a partitioned step, with optional threadCount and without partition properties.
partitionPlanToken - Static variable in class org.jberet.job.model.PropertyResolver
 
partitionReducer(String, String[]...) - Method in class org.jberet.job.model.StepBuilder
Sets the partition reducer for a partitioned step.
partitionReducer(String, Properties) - Method in class org.jberet.job.model.StepBuilder
Sets the partition reducer for a partitioned step, with partition reducer properties.
PartitionScoped - Annotation Type in org.jberet.cdi
Custom CDI scope for step partition execution.
PartitionScopedContextImpl - Class in org.jberet.creation
 
process() - Method in class org.jberet.repository.PurgeBatchlet
 
processor(String, String[]...) - Method in class org.jberet.job.model.StepBuilder
Sets item processor for a chunk-type step.
processor(String, Properties) - Method in class org.jberet.job.model.StepBuilder
Sets item processor for a chunk-type step, with item processor properties.
Properties - Class in org.jberet.job.model
Corresponds to jsl:Properties of job XML element type.
PropertiesHolder - Interface in org.jberet.job.model
An interface to indicate that the implementing class and its corresponding job element can contain Properties.
propertiesToString(Properties) - Static method in class org.jberet.util.BatchUtil
 
PropertyKey - Interface in org.jberet.spi
Keys used for JBeret specific configuration and job properties.
PropertyResolver - Class in org.jberet.job.model
Responsible for resolving property expressions in job and job elements.
PropertyResolver() - Constructor for class org.jberet.job.model.PropertyResolver
 
PurgeBatchlet - Class in org.jberet.repository
 
PurgeBatchlet() - Constructor for class org.jberet.repository.PurgeBatchlet
 

R

reader(String, String[]...) - Method in class org.jberet.job.model.StepBuilder
Sets item reader for a chunk-type step.
reader(String, Properties) - Method in class org.jberet.job.model.StepBuilder
Sets item reader for a chunk-type step, with item reader properties.
RefArtifact - Class in org.jberet.job.model
Represents a batch artifact with a ref and properties.
registerJobStopNotifier(JobStopNotificationListener) - Method in class org.jberet.runtime.JobExecutionImpl
 
removeCurrentArtifactCreationContext() - Static method in class org.jberet.creation.ArtifactCreationContext
 
removeJob(String) - Method in class org.jberet.repository.AbstractPersistentRepository
 
removeJob(String) - Method in class org.jberet.repository.AbstractRepository
 
removeJob(String) - Method in class org.jberet.repository.InfinispanRepository
 
removeJob(String) - Method in class org.jberet.repository.InMemoryRepository
 
removeJob(String) - Method in interface org.jberet.repository.JobRepository
 
removeJobExecutions(JobExecutionSelector) - Method in class org.jberet.repository.AbstractPersistentRepository
 
removeJobExecutions(JobExecutionSelector) - Method in class org.jberet.repository.InfinispanRepository
 
removeJobExecutions(JobExecutionSelector) - Method in class org.jberet.repository.InMemoryRepository
 
removeJobExecutions(JobExecutionSelector) - Method in interface org.jberet.repository.JobRepository
Removes JobExecutions based on the criteria specified in jobExecutionSelector.
removeJobInstance(long) - Method in class org.jberet.repository.AbstractPersistentRepository
 
removeJobInstance(long) - Method in class org.jberet.repository.InfinispanRepository
 
removeJobInstance(long) - Method in class org.jberet.repository.InMemoryRepository
 
removeJobInstance(long) - Method in interface org.jberet.repository.JobRepository
 
REPOSITORY_TYPE_IN_MEMORY - Static variable in class org.jberet.repository.JobRepositoryFactory
Deprecated.
 
REPOSITORY_TYPE_JDBC - Static variable in class org.jberet.repository.JobRepositoryFactory
Deprecated.
 
REPOSITORY_TYPE_MONGODB - Static variable in class org.jberet.repository.JobRepositoryFactory
Deprecated.
 
resetArtifactCreationContext(JobContextImpl, StepContextImpl, Properties) - Static method in class org.jberet.creation.ArtifactCreationContext
 
resolve(Job) - Method in class org.jberet.job.model.PropertyResolver
Resolves property expressions for job-level elements contained in the job.
resolve(Step) - Method in class org.jberet.job.model.PropertyResolver
Resolves property expressions for step-level elements contained in the step.
resolveInheritance(Job, ClassLoader, List<Job>, JobXmlResolver) - Static method in class org.jberet.job.model.JobMerger
The main entry point to resolve JSL inheritance for a job, including any inheritance in its sub-elements.
resolveJobName(String, ClassLoader) - Method in interface org.jberet.spi.JobXmlResolver
Optionally resolves the job name from the job XML.
resolveJobName(String, ClassLoader) - Method in class org.jberet.tools.AbstractJobXmlResolver
 
resolveJobName(String, ClassLoader) - Method in class org.jberet.tools.ChainedJobXmlResolver
Optionally resolves the job name from the job XML.
resolveJobXml(String, ClassLoader) - Method in interface org.jberet.spi.JobXmlResolver
Locates the job XML and creates a stream to the contents.
resolveJobXml(String, ClassLoader) - Method in class org.jberet.tools.ChainedJobXmlResolver
Locates the job XML and creates a stream to the contents.
resolveJobXml(String, ClassLoader) - Method in class org.jberet.tools.MetaInfBatchJobsJobXmlResolver
 
resolveTransitionElements(List<?>, String, boolean) - Method in class org.jberet.runtime.runner.AbstractRunner
Resolves a list of next, end, stop and fail elements to determine the next job element.
restart(long, Properties) - Method in class org.jberet.operations.JobOperatorImpl
 
RESTART_MODE - Static variable in interface org.jberet.spi.PropertyKey
A key used to specify restart mode as an optional restart job parameter.
RESTART_MODE_DETECT - Static variable in interface org.jberet.spi.PropertyKey
 
RESTART_MODE_FORCE - Static variable in interface org.jberet.spi.PropertyKey
 
RESTART_MODE_STRICT - Static variable in interface org.jberet.spi.PropertyKey
 
restartable(boolean...) - Method in class org.jberet.job.model.JobBuilder
Sets the restartable attribute value on the job.
restartFrom(String) - Method in class org.jberet.job.model.Transition.Stop
Sets the restart attribute value, which should points to a job element to restart from, and returns the current builder, such as StepBuilder, DecisionBuilder, or FlowBuilder.
resume(Transaction) - Method in class org.jberet.tx.LocalTransactionManager
 
retryableExceptionsExclude(Class<? extends Exception>...) - Method in class org.jberet.job.model.StepBuilder
Adds exception classes to the chunk-type step to exclude from retryable exceptions.
retryableExceptionsInclude(Class<? extends Exception>...) - Method in class org.jberet.job.model.StepBuilder
Adds exception classes to the chunk-type step to include as retryable.
retryLimit(int) - Method in class org.jberet.job.model.StepBuilder
Sets retry-limit attribute value for a chunk-type step.
rollback() - Method in class org.jberet.tx.LocalTransactionManager
 
run() - Method in class org.jberet.runtime.runner.BatchletRunner
 
run() - Method in class org.jberet.runtime.runner.ChunkRunner
 
run() - Method in class org.jberet.runtime.runner.FlowExecutionRunner
 
run() - Method in class org.jberet.runtime.runner.JobExecutionRunner
 
run() - Method in class org.jberet.runtime.runner.SplitExecutionRunner
 
run() - Method in class org.jberet.runtime.runner.StepExecutionRunner
 
runDecision(Decision, StepExecution...) - Method in class org.jberet.runtime.runner.CompositeExecutionRunner
 
runFlow(Flow, CountDownLatch) - Method in class org.jberet.runtime.runner.CompositeExecutionRunner
 
runFromHeadOrRestartPoint(String) - Method in class org.jberet.runtime.runner.CompositeExecutionRunner
Runs the first job element, which then transitions to the next element.
runJobElement(String, StepExecution...) - Method in class org.jberet.runtime.runner.CompositeExecutionRunner
Runs the job element including step, decision, flow, and split.
runSplit(Split) - Method in class org.jberet.runtime.runner.CompositeExecutionRunner
 
runStep(Step) - Method in class org.jberet.runtime.runner.CompositeExecutionRunner
 

S

savePersistentData(JobExecution, AbstractStepExecution) - Method in class org.jberet.repository.AbstractRepository
 
savePersistentData(JobExecution, AbstractStepExecution) - Method in class org.jberet.repository.InfinispanRepository
 
savePersistentData(JobExecution, AbstractStepExecution) - Method in class org.jberet.repository.JdbcRepository
 
savePersistentData(JobExecution, AbstractStepExecution) - Method in interface org.jberet.repository.JobRepository
 
savePersistentData(JobExecution, AbstractStepExecution) - Method in class org.jberet.repository.MongoRepository
 
savePersistentData() - Method in class org.jberet.runtime.context.StepContextImpl
 
ScopedInstance(T, CreationalContext<T>) - Constructor for class org.jberet.creation.JobScopedContextImpl.ScopedInstance
 
Script - Class in org.jberet.job.model
Represents a script element under an enclosing element represented by RefArtifact.
select(JobExecution, Collection<Long>) - Method in class org.jberet.repository.DefaultJobExecutionSelector
 
select(JobExecution, Collection<Long>) - Method in interface org.jberet.repository.JobExecutionSelector
 
set(Metric.MetricType, long) - Method in class org.jberet.runtime.metric.StepMetrics
 
setBatchStatus(BatchStatus) - Method in class org.jberet.runtime.AbstractExecution
 
setBatchStatus(BatchStatus) - Method in class org.jberet.runtime.AbstractStepExecution
 
setBatchStatus(BatchStatus) - Method in class org.jberet.runtime.context.AbstractContext
 
setBatchStatus(BatchStatus) - Method in class org.jberet.runtime.context.FlowContextImpl
 
setBatchStatus(BatchStatus) - Method in class org.jberet.runtime.context.JobContextImpl
 
setBatchStatus(BatchStatus) - Method in class org.jberet.runtime.context.SplitContextImpl
 
setBatchStatus(BatchStatus) - Method in class org.jberet.runtime.context.StepContextImpl
 
setBatchStatus(BatchStatus) - Method in class org.jberet.runtime.JobExecutionImpl
 
setEnded(boolean) - Method in class org.jberet.runtime.FlowExecutionImpl
 
setException(Exception) - Method in class org.jberet.runtime.AbstractStepExecution
 
setException(Exception) - Method in class org.jberet.runtime.context.StepContextImpl
 
setExitStatus(String) - Method in class org.jberet.runtime.AbstractExecution
 
setExitStatus(String) - Method in class org.jberet.runtime.context.AbstractContext
 
setExitStatus(String) - Method in class org.jberet.runtime.context.FlowContextImpl
 
setExitStatus(String) - Method in class org.jberet.runtime.context.JobContextImpl
 
setExitStatus(String) - Method in class org.jberet.runtime.context.SplitContextImpl
 
setExitStatus(String) - Method in class org.jberet.runtime.context.StepContextImpl
 
setId(long) - Method in class org.jberet.runtime.AbstractStepExecution
 
setId(long) - Method in class org.jberet.runtime.JobExecutionImpl
 
setId(long) - Method in class org.jberet.runtime.JobInstanceImpl
 
setJobContext(JobContext) - Method in class org.jberet.repository.DefaultJobExecutionSelector
 
setJobContext(JobContext) - Method in interface org.jberet.repository.JobExecutionSelector
 
setJobParameters(Properties) - Method in class org.jberet.job.model.PropertyResolver
Sets job parameters to be used for resolving expressions referencing job parameters.
setJobXmlName(String) - Method in class org.jberet.job.model.Job
Sets Job.jobXmlName only if it differs from job id.
setLastStepExecution(StepExecution) - Method in class org.jberet.runtime.FlowExecutionImpl
 
setLastUpdatedTime(long) - Method in class org.jberet.runtime.JobExecutionImpl
 
setListeners(Listeners) - Method in class org.jberet.job.model.Flow
Disables setting listeners, since flow does not have listeners.
setListeners(Listeners) - Method in class org.jberet.job.model.InheritableJobElement
Sets all listerners for this job element.
setListeners(List<RefArtifact>) - Method in class org.jberet.job.model.Listeners
Sets the list of listeners.
setPartitionId(int) - Method in class org.jberet.runtime.PartitionExecutionImpl
 
setPartitionPlanProperties(Properties) - Method in class org.jberet.job.model.PropertyResolver
Sets partition plan properties to be used for resolving expressions referencing partition plan properties.
setPersistentUserData(Serializable) - Method in class org.jberet.runtime.AbstractStepExecution
 
setPersistentUserData(Serializable) - Method in class org.jberet.runtime.context.StepContextImpl
 
setProperties(Properties) - Method in class org.jberet.job.model.Flow
Disables setting properties, since flow does not have properties.
setProperties(Properties) - Method in interface org.jberet.job.model.PropertiesHolder
Sets org.jberet.job.model.Properties to the current job model type.
setProperties(Properties) - Method in class org.jberet.job.model.RefArtifact
Sets the org.jberet.job.model.Properties belonging to this batch artifact.
setProperties(Properties) - Method in class org.jberet.job.model.Split
Disables setting properties, since split contains no batch properties.
setReaderCheckpointInfo(Serializable) - Method in class org.jberet.runtime.AbstractStepExecution
 
setResolvePartitionPlanProperties(boolean) - Method in class org.jberet.job.model.PropertyResolver
Sets the flag whether this class need to resolve partition plan properties or not.
setRestartPosition(String) - Method in class org.jberet.runtime.JobExecutionImpl
 
setRollbackOnly() - Method in class org.jberet.tx.LocalTransactionManager
 
setStepContext(StepContext) - Method in class org.jberet.repository.DefaultJobExecutionSelector
 
setStepContext(StepContext) - Method in interface org.jberet.repository.JobExecutionSelector
 
setTransactionTimeout(int) - Method in class org.jberet.tx.LocalTransactionManager
 
setTransientUserData(Object) - Method in class org.jberet.runtime.context.AbstractContext
 
setUnsubstitutedJob(Job) - Method in class org.jberet.runtime.JobInstanceImpl
 
setValue(long) - Method in class org.jberet.runtime.metric.MetricImpl
 
setWriterCheckpointInfo(Serializable) - Method in class org.jberet.runtime.AbstractStepExecution
 
size() - Method in class org.jberet.job.model.Properties
Gets the size of this org.jberet.job.model.Properties, i.e., how many entries this properties contains.
skipLimit(int) - Method in class org.jberet.job.model.StepBuilder
Sets skip-limit attribute value for a chunk-type step.
skippableExceptionsExclude(Class<? extends Exception>...) - Method in class org.jberet.job.model.StepBuilder
Adds exception classes to the chunk-type step to exclude from skippable exceptions.
skippableExceptionsInclude(Class<? extends Exception>...) - Method in class org.jberet.job.model.StepBuilder
Adds exception classes to the chunk-type step to include as skippable.
split(Split) - Method in class org.jberet.job.model.FlowBuilder
Adds a split to the current flow.
split(Split) - Method in class org.jberet.job.model.JobBuilder
Adds a split to the job.
Split - Class in org.jberet.job.model
Corresponds to jsl:Split job element type in job XML.
SPLIT_TIMEOUT_SECONDS - Static variable in interface org.jberet.spi.PropertyKey
A key used to specify the number of seconds the split execution will wait for its constituent flows to complete.
SplitBuilder - Class in org.jberet.job.model
Builder class for building a single Split.
SplitBuilder(String) - Constructor for class org.jberet.job.model.SplitBuilder
Constructs the SplitBuilder instance for building the split with the specified id.
SplitContextImpl - Class in org.jberet.runtime.context
 
SplitContextImpl(Split, AbstractContext[]) - Constructor for class org.jberet.runtime.context.SplitContextImpl
 
SplitExecutionImpl - Class in org.jberet.runtime
 
SplitExecutionImpl(String) - Constructor for class org.jberet.runtime.SplitExecutionImpl
 
SplitExecutionRunner - Class in org.jberet.runtime.runner
 
SplitExecutionRunner(SplitContextImpl, CompositeExecutionRunner) - Constructor for class org.jberet.runtime.runner.SplitExecutionRunner
 
SQL_FILE_NAME_KEY - Static variable in class org.jberet.repository.JdbcRepository
 
start(String, Properties) - Method in class org.jberet.operations.JobOperatorImpl
 
start(Job, Properties) - Method in class org.jberet.operations.JobOperatorImpl
Starts a pre-configured Job instance, with job parameters.
startLimit(int) - Method in class org.jberet.job.model.StepBuilder
Sets the start-limit attribute value for the step.
startTime - Variable in class org.jberet.runtime.AbstractExecution
 
step(Step) - Method in class org.jberet.job.model.FlowBuilder
Adds a step to the current flow.
step(Step) - Method in class org.jberet.job.model.JobBuilder
Adds a step to the job.
Step - Class in org.jberet.job.model
Corresponds to jsl:Step job element type in job XML.
StepBuilder - Class in org.jberet.job.model
Builder class for building a single step.
StepBuilder(String) - Constructor for class org.jberet.job.model.StepBuilder
Constructs a StepBuilder for building the step with the specified id.
StepContextImpl - Class in org.jberet.runtime.context
Represents the execution context for either a step execution or partition execution.
StepContextImpl(Step, AbstractContext[]) - Constructor for class org.jberet.runtime.context.StepContextImpl
 
StepExecutionImpl - Class in org.jberet.runtime
 
StepExecutionImpl(String) - Constructor for class org.jberet.runtime.StepExecutionImpl
 
StepExecutionImpl(long, String, Date, Date, String, String, Serializable, long, long, long, long, long, long, long, long, Serializable, Serializable) - Constructor for class org.jberet.runtime.StepExecutionImpl
Creates StepExecutionImpl from database records.
StepExecutionRunner - Class in org.jberet.runtime.runner
 
StepExecutionRunner(StepContextImpl, CompositeExecutionRunner) - Constructor for class org.jberet.runtime.runner.StepExecutionRunner
 
StepMerger - Class in org.jberet.job.model
Responsible for merging a child step and its parent step, and resolving its JSL inheritance.
StepMetrics - Class in org.jberet.runtime.metric
Maintains execution metrics for a single step.
StepMetrics() - Constructor for class org.jberet.runtime.metric.StepMetrics
 
StepScoped - Annotation Type in org.jberet.cdi
Custom CDI scope for step execution.
StepScopedContextImpl - Class in org.jberet.creation
 
stop(long) - Method in class org.jberet.operations.JobOperatorImpl
 
stop() - Method in class org.jberet.repository.PurgeBatchlet
 
stop() - Method in class org.jberet.runtime.JobExecutionImpl
 
stopOn(String) - Method in class org.jberet.job.model.DecisionBuilder
Sets stop transition condition for the decision.
stopOn(String) - Method in class org.jberet.job.model.FlowBuilder
Sets stop transition condition for the flow.
stopOn(String) - Method in class org.jberet.job.model.StepBuilder
Sets stop transition condition for the step.
stopRequested() - Method in interface org.jberet.runtime.JobStopNotificationListener
Invoked when the current job is requested to stop.
stopRequested() - Method in class org.jberet.runtime.runner.BatchletRunner
 
stringToProperties(String) - Static method in class org.jberet.util.BatchUtil
 
submitTask(JobTask) - Method in interface org.jberet.spi.BatchEnvironment
Submits a runnable task for execution.
suspend() - Method in class org.jberet.tx.LocalTransactionManager
 
systemPropertiesToken - Static variable in class org.jberet.job.model.PropertyResolver
 

T

timeLimit(int, TimeUnit...) - Method in class org.jberet.job.model.StepBuilder
Sets time-limit attribute value for a chunk-type step.
to(String) - Method in class org.jberet.job.model.Transition.Next
Sets the to attribute value, which should points to the next job element, and returns the current builder, such as StepBuilder, DecisionBuilder, or FlowBuilder.
toJavaUtilProperties(Properties) - Static method in class org.jberet.job.model.Properties
Converts an instance of this type of properties to java.util.Properties.
toString() - Method in class org.jberet.repository.ApplicationAndJobName
 
toString() - Method in class org.jberet.runtime.metric.MetricImpl
 
toString() - Method in class org.jberet.runtime.metric.StepMetrics
 
transientUserData - Variable in class org.jberet.runtime.context.AbstractContext
 
Transition<T> - Class in org.jberet.job.model
Base class for all transition elements: end, fail, next and stop.
Transition.End<T> - Class in org.jberet.job.model
Transition element end.
Transition.Fail<T> - Class in org.jberet.job.model
Transition element fail.
Transition.Next<T> - Class in org.jberet.job.model
Transition element next.
Transition.Stop<T> - Class in org.jberet.job.model
Transition element stop.
Transition.Termination<T> - Class in org.jberet.job.model
Base class of all terminating transition elements, such as Transition.End, Transition.Stop, and Transition.Fail.

U

unregisterJobStopNotifier(JobStopNotificationListener) - Method in class org.jberet.runtime.JobExecutionImpl
 
UNRESTARTABLE - Static variable in class org.jberet.job.model.Job
Internal value to indicate that a job execution cannot be restarted.
updateJobExecution(JobExecutionImpl, boolean, boolean) - Method in class org.jberet.repository.AbstractRepository
 
updateJobExecution(JobExecutionImpl, boolean, boolean) - Method in class org.jberet.repository.InfinispanRepository
 
updateJobExecution(JobExecutionImpl, boolean, boolean) - Method in class org.jberet.repository.JdbcRepository
 
updateJobExecution(JobExecutionImpl, boolean, boolean) - Method in interface org.jberet.repository.JobRepository
 
updateJobExecution(JobExecutionImpl, boolean, boolean) - Method in class org.jberet.repository.MongoRepository
 
updateStepExecution(StepExecution) - Method in class org.jberet.repository.InfinispanRepository
 
updateStepExecution(StepExecution) - Method in class org.jberet.repository.InMemoryRepository
 
updateStepExecution(StepExecution) - Method in class org.jberet.repository.JdbcRepository
 
updateStepExecution(StepExecution) - Method in interface org.jberet.repository.JobRepository
 
updateStepExecution(StepExecution) - Method in class org.jberet.repository.MongoRepository
 

V

ValueConverter - Class in org.jberet.creation
Converts a property string value to the target field type.
ValueConverter() - Constructor for class org.jberet.creation.ValueConverter
 
valueOf(String) - Static method in enum org.jberet.job.model.XmlAttribute
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.jberet.job.model.XmlElement
Returns the enum constant of this type with the specified name.
values() - Static method in enum org.jberet.job.model.XmlAttribute
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.jberet.job.model.XmlElement
Returns an array containing the constants of this enum type, in the order they are declared.
version - Variable in class org.jberet.runtime.AbstractExecution
 

W

writer(String, String[]...) - Method in class org.jberet.job.model.StepBuilder
Sets item writer for a chunk-type step.
writer(String, Properties) - Method in class org.jberet.job.model.StepBuilder
Sets item writer for a chunk-type step, with item writer properties.

X

XmlAttribute - Enum in org.jberet.job.model
Enum type to hold all XML attribute names for job xml and batch.xml.
XmlElement - Enum in org.jberet.job.model
Enum type to hold all XML element names for job xml and batch.xml.
A B C D E F G H I J L M N O P R S T U V W X 
Skip navigation links
jberet-core 1.2.0.Final

Copyright © 2015 JBoss by Red Hat. All rights reserved.