A B C D E F G H I J K L M N O P R S T U V W X 

A

abandon(long) - Method in interface org.springframework.batch.core.launch.JobOperator
Mark the JobExecution as ABANDONED.
abandon(long) - Method in class org.springframework.batch.core.launch.support.SimpleJobOperator
 
abandonStepExecution() - Method in interface org.springframework.batch.core.job.flow.FlowExecutor
Handle any status changes that might be needed at the start of a state.
abandonStepExecution() - Method in class org.springframework.batch.core.job.flow.JobFlowExecutor
 
AbstractApplicationContextFactory - Class in org.springframework.batch.core.configuration.support
ApplicationContextFactory implementation that takes a parent context and a path to the context to create.
AbstractApplicationContextFactory(Object...) - Constructor for class org.springframework.batch.core.configuration.support.AbstractApplicationContextFactory
Create a factory instance with the resource specified.
AbstractBatchConfiguration - Class in org.springframework.batch.core.configuration.annotation
Base Configuration class providing common structure for enabling and using Spring Batch.
AbstractBatchConfiguration() - Constructor for class org.springframework.batch.core.configuration.annotation.AbstractBatchConfiguration
 
AbstractFlowParser - Class in org.springframework.batch.core.configuration.xml
 
AbstractFlowParser() - Constructor for class org.springframework.batch.core.configuration.xml.AbstractFlowParser
 
AbstractJdbcBatchMetadataDao - Class in org.springframework.batch.core.repository.dao
Encapsulates common functionality needed by JDBC batch metadata DAOs - provides jdbcTemplate for subclasses and handles table prefixes.
AbstractJdbcBatchMetadataDao() - Constructor for class org.springframework.batch.core.repository.dao.AbstractJdbcBatchMetadataDao
 
AbstractJob - Class in org.springframework.batch.core.job
Abstract implementation of the Job interface.
AbstractJob() - Constructor for class org.springframework.batch.core.job.AbstractJob
Default constructor.
AbstractJob(String) - Constructor for class org.springframework.batch.core.job.AbstractJob
Convenience constructor to immediately add name (which is mandatory but not final).
AbstractJobExplorerFactoryBean - Class in org.springframework.batch.core.explore.support
A FactoryBean that automates the creation of a SimpleJobExplorer.
AbstractJobExplorerFactoryBean() - Constructor for class org.springframework.batch.core.explore.support.AbstractJobExplorerFactoryBean
 
AbstractJobRepositoryFactoryBean - Class in org.springframework.batch.core.repository.support
A FactoryBean that automates the creation of a SimpleJobRepository.
AbstractJobRepositoryFactoryBean() - Constructor for class org.springframework.batch.core.repository.support.AbstractJobRepositoryFactoryBean
 
AbstractListenerFactoryBean - Class in org.springframework.batch.core.listener
FactoryBean implementation that builds a listener based on the various lifecycle methods or annotations that are provided.
AbstractListenerFactoryBean() - Constructor for class org.springframework.batch.core.listener.AbstractListenerFactoryBean
 
AbstractListenerParser - Class in org.springframework.batch.core.configuration.xml
 
AbstractListenerParser() - Constructor for class org.springframework.batch.core.configuration.xml.AbstractListenerParser
 
AbstractPartitionHandler - Class in org.springframework.batch.core.partition.support
Base PartitionHandler implementation providing common base features.
AbstractPartitionHandler() - Constructor for class org.springframework.batch.core.partition.support.AbstractPartitionHandler
 
AbstractState - Class in org.springframework.batch.core.job.flow.support.state
 
AbstractState(String) - Constructor for class org.springframework.batch.core.job.flow.support.state.AbstractState
 
AbstractStep - Class in org.springframework.batch.core.step
A Step implementation that provides common behavior to subclasses, including registering and calling listeners.
AbstractStep() - Constructor for class org.springframework.batch.core.step.AbstractStep
Default constructor.
AbstractStep(String) - Constructor for class org.springframework.batch.core.step.AbstractStep
Convenient constructor for setting only the name property.
AbstractStepParser - Class in org.springframework.batch.core.configuration.xml
Internal parser for the <step/> elements inside a job.
AbstractStepParser() - Constructor for class org.springframework.batch.core.configuration.xml.AbstractStepParser
 
AbstractTaskletStepBuilder<B extends AbstractTaskletStepBuilder<B>> - Class in org.springframework.batch.core.step.builder
Base class for step builders that want to build a TaskletStep.
AbstractTaskletStepBuilder(StepBuilderHelper<?>) - Constructor for class org.springframework.batch.core.step.builder.AbstractTaskletStepBuilder
 
add(Flow...) - Method in class org.springframework.batch.core.job.builder.FlowBuilder.SplitBuilder
Add flows to the split, in addition to the current state already present in the parent builder.
add(StepExecution) - Method in interface org.springframework.batch.core.repository.JobRepository
add(StepExecution) - Method in class org.springframework.batch.core.repository.support.SimpleJobRepository
 
add(W) - Method in class org.springframework.batch.core.step.item.Chunk
Add the item to the chunk.
addAll(Collection<StepExecution>) - Method in interface org.springframework.batch.core.repository.JobRepository
Save a collection of StepExecutions and each ExecutionContext.
addAll(Collection<StepExecution>) - Method in class org.springframework.batch.core.repository.support.SimpleJobRepository
 
addApplicationContextFactory(ApplicationContextFactory) - Method in class org.springframework.batch.core.configuration.support.AutomaticJobRegistrar
Add some factories to the set that will be used to load contexts and jobs.
addDate(String, Date) - Method in class org.springframework.batch.core.JobParametersBuilder
Add a new identifying Date parameter for the given key.
addDate(String, Date, boolean) - Method in class org.springframework.batch.core.JobParametersBuilder
Add a new Date parameter for the given key.
addDouble(String, Double) - Method in class org.springframework.batch.core.JobParametersBuilder
Add a new identifying Double parameter for the given key.
addDouble(String, Double, boolean) - Method in class org.springframework.batch.core.JobParametersBuilder
Add a new Double parameter for the given key.
addExitDescription(String) - Method in class org.springframework.batch.core.ExitStatus
Add an exit description to an existing ExitStatus.
addExitDescription(Throwable) - Method in class org.springframework.batch.core.ExitStatus
Extract the stack trace from the throwable provided and append it to the exist description.
addExitStatus(String) - Method in interface org.springframework.batch.core.job.flow.FlowExecutor
 
addExitStatus(String) - Method in class org.springframework.batch.core.job.flow.JobFlowExecutor
 
addFailureException(Throwable) - Method in class org.springframework.batch.core.JobExecution
Add the provided throwable to the failure exception list.
addFailureException(Throwable) - Method in class org.springframework.batch.core.StepExecution
 
addJobExecutionListener(JobExecutionListener) - Method in class org.springframework.batch.core.job.builder.JobBuilderHelper.CommonJobProperties
 
addLong(String, Long) - Method in class org.springframework.batch.core.JobParametersBuilder
Add a new identifying Long parameter for the given key.
addLong(String, Long, boolean) - Method in class org.springframework.batch.core.JobParametersBuilder
Add a new Long parameter for the given key.
addParameter(String, JobParameter) - Method in class org.springframework.batch.core.JobParametersBuilder
Add a new JobParameter for the given key.
addStep(Step) - Method in class org.springframework.batch.core.job.SimpleJob
Convenience method for adding a single step to the job.
addStepExecutionListener(StepExecutionListener) - Method in class org.springframework.batch.core.step.builder.StepBuilderHelper.CommonStepProperties
 
addStepExecutionListeners(List<JobExecutionListener>) - Method in class org.springframework.batch.core.job.builder.JobBuilderHelper.CommonJobProperties
 
addStepExecutionListeners(List<StepExecutionListener>) - Method in class org.springframework.batch.core.step.builder.StepBuilderHelper.CommonStepProperties
 
addStepExecutions(List<StepExecution>) - Method in class org.springframework.batch.core.JobExecution
Add some step executions.
addStepExecutions(JobExecution) - Method in class org.springframework.batch.core.repository.dao.JdbcStepExecutionDao
 
addStepExecutions(JobExecution) - Method in class org.springframework.batch.core.repository.dao.MapStepExecutionDao
 
addStepExecutions(JobExecution) - Method in interface org.springframework.batch.core.repository.dao.StepExecutionDao
Retrieve all the StepExecution for the parent JobExecution.
addString(String, String) - Method in class org.springframework.batch.core.JobParametersBuilder
Add a new identifying String parameter for the given key.
addString(String, String, boolean) - Method in class org.springframework.batch.core.JobParametersBuilder
Add a new String parameter for the given key.
AfterChunk - Annotation Type in org.springframework.batch.core.annotation
Marks a method to be called after a chunk is executed.

Expected signature: void afterChunk(ChunkContext context)
afterChunk(ChunkContext) - Method in interface org.springframework.batch.core.ChunkListener
Callback after the chunk is executed, outside the transaction.
afterChunk(ChunkContext) - Method in class org.springframework.batch.core.listener.ChunkListenerSupport
 
afterChunk(ChunkContext) - Method in class org.springframework.batch.core.listener.CompositeChunkListener
Call the registered listeners in order, respecting and prioritizing those that implement Ordered.
afterChunk(ChunkContext) - Method in class org.springframework.batch.core.listener.MulticasterBatchListener
 
afterChunk(ChunkContext) - Method in class org.springframework.batch.core.listener.StepListenerSupport
 
AfterChunkError - Annotation Type in org.springframework.batch.core.annotation
Marks a method to be called after a has failed and been marked for rollback.

Expected signature: void afterFailedChunk(ChunkContext context)
afterChunkError(ChunkContext) - Method in interface org.springframework.batch.core.ChunkListener
Callback after a chunk has been marked for rollback.
afterChunkError(ChunkContext) - Method in class org.springframework.batch.core.listener.ChunkListenerSupport
 
afterChunkError(ChunkContext) - Method in class org.springframework.batch.core.listener.CompositeChunkListener
 
afterChunkError(ChunkContext) - Method in class org.springframework.batch.core.listener.MulticasterBatchListener
 
afterChunkError(ChunkContext) - Method in class org.springframework.batch.core.listener.StepListenerSupport
 
AfterJob - Annotation Type in org.springframework.batch.core.annotation
Marks a method to be called after a Job has completed.
afterJob(JobExecution) - Method in interface org.springframework.batch.core.JobExecutionListener
Callback after completion of a job.
afterJob(JobExecution) - Method in class org.springframework.batch.core.listener.CompositeJobExecutionListener
Call the registered listeners in reverse order, respecting and prioritising those that implement Ordered.
afterJob(JobExecution) - Method in class org.springframework.batch.core.listener.JobExecutionListenerSupport
 
AfterProcess - Annotation Type in org.springframework.batch.core.annotation
Marks a method to be called after an item is passed to an ItemProcessor

Expected signature: void afterProcess(T item, S result)
afterProcess(T, S) - Method in interface org.springframework.batch.core.ItemProcessListener
Called after ItemProcessor.process(Object) returns.
afterProcess(T, S) - Method in class org.springframework.batch.core.listener.CompositeItemProcessListener
Call the registered listeners in reverse order, respecting and prioritising those that implement Ordered.
afterProcess(I, O) - Method in class org.springframework.batch.core.listener.ItemListenerSupport
 
afterProcess(T, S) - Method in class org.springframework.batch.core.listener.MulticasterBatchListener
 
afterProcess(T, S) - Method in class org.springframework.batch.core.listener.StepListenerSupport
 
afterPropertiesSet() - Method in class org.springframework.batch.core.configuration.support.AutomaticJobRegistrar
 
afterPropertiesSet() - Method in class org.springframework.batch.core.configuration.support.DefaultJobLoader
 
afterPropertiesSet() - Method in class org.springframework.batch.core.configuration.support.JobRegistryBeanPostProcessor
Make sure the registry is set before use.
afterPropertiesSet() - Method in class org.springframework.batch.core.configuration.xml.SimpleFlowFactoryBean
Check mandatory properties (name).
afterPropertiesSet() - Method in class org.springframework.batch.core.explore.support.JobExplorerFactoryBean
 
afterPropertiesSet() - Method in class org.springframework.batch.core.explore.support.MapJobExplorerFactoryBean
 
afterPropertiesSet() - Method in class org.springframework.batch.core.job.AbstractJob
Assert mandatory properties: JobRepository.
afterPropertiesSet() - Method in class org.springframework.batch.core.job.CompositeJobParametersValidator
 
afterPropertiesSet() - Method in class org.springframework.batch.core.job.DefaultJobParametersValidator
Check that there are no overlaps between required and optional keys.
afterPropertiesSet() - Method in class org.springframework.batch.core.job.flow.FlowStep
Ensure that the flow is set.
afterPropertiesSet() - Method in class org.springframework.batch.core.job.flow.support.SimpleFlow
Locate start state and pre-populate data structures needed for execution.
afterPropertiesSet() - Method in class org.springframework.batch.core.job.SimpleStepHandler
Check mandatory properties (jobRepository).
afterPropertiesSet() - Method in class org.springframework.batch.core.launch.support.SimpleJobLauncher
Ensure the required dependencies of a JobRepository have been set.
afterPropertiesSet() - Method in class org.springframework.batch.core.launch.support.SimpleJobOperator
Check mandatory properties.
afterPropertiesSet() - Method in class org.springframework.batch.core.listener.AbstractListenerFactoryBean
 
afterPropertiesSet() - Method in class org.springframework.batch.core.listener.ExecutionContextPromotionListener
 
afterPropertiesSet() - Method in class org.springframework.batch.core.partition.support.PartitionStep
Assert that mandatory properties are set (stepExecutionSplitter, partitionHandler) and delegate top superclass.
afterPropertiesSet() - Method in class org.springframework.batch.core.partition.support.RemoteStepExecutionAggregator
 
afterPropertiesSet() - Method in class org.springframework.batch.core.partition.support.SimpleStepExecutionSplitter
Check mandatory properties (step name, job repository and partitioner).
afterPropertiesSet() - Method in class org.springframework.batch.core.partition.support.TaskExecutorPartitionHandler
 
afterPropertiesSet() - Method in class org.springframework.batch.core.repository.dao.AbstractJdbcBatchMetadataDao
 
afterPropertiesSet() - Method in class org.springframework.batch.core.repository.dao.JdbcExecutionContextDao
 
afterPropertiesSet() - Method in class org.springframework.batch.core.repository.dao.JdbcJobExecutionDao
 
afterPropertiesSet() - Method in class org.springframework.batch.core.repository.dao.JdbcJobInstanceDao
 
afterPropertiesSet() - Method in class org.springframework.batch.core.repository.dao.JdbcStepExecutionDao
 
afterPropertiesSet() - Method in class org.springframework.batch.core.repository.dao.XStreamExecutionContextStringSerializer
 
afterPropertiesSet() - Method in class org.springframework.batch.core.repository.support.AbstractJobRepositoryFactoryBean
 
afterPropertiesSet() - Method in class org.springframework.batch.core.repository.support.JobRepositoryFactoryBean
 
afterPropertiesSet() - Method in class org.springframework.batch.core.resource.ListPreparedStatementSetter
 
afterPropertiesSet() - Method in class org.springframework.batch.core.step.AbstractStep
 
afterPropertiesSet() - Method in class org.springframework.batch.core.step.item.SimpleChunkProcessor
Check mandatory properties.
afterPropertiesSet() - Method in class org.springframework.batch.core.step.job.JobStep
 
afterPropertiesSet() - Method in class org.springframework.batch.core.step.tasklet.CallableTaskletAdapter
Assert that the callable is set.
afterPropertiesSet() - Method in class org.springframework.batch.core.step.tasklet.SystemCommandTasklet
 
afterPropertiesSet() - Method in class org.springframework.batch.core.step.tasklet.TaskletStep
 
AfterRead - Annotation Type in org.springframework.batch.core.annotation
Marks a method to be called after an item is read from an ItemReader

Expected signature: void afterRead(T item)
afterRead(T) - Method in interface org.springframework.batch.core.ItemReadListener
Called after ItemReader.read()
afterRead(T) - Method in class org.springframework.batch.core.listener.CompositeItemReadListener
Call the registered listeners in reverse order, respecting and prioritising those that implement Ordered.
afterRead(I) - Method in class org.springframework.batch.core.listener.ItemListenerSupport
 
afterRead(T) - Method in class org.springframework.batch.core.listener.MulticasterBatchListener
 
afterRead(T) - Method in class org.springframework.batch.core.listener.StepListenerSupport
 
AfterStep - Annotation Type in org.springframework.batch.core.annotation
Marks a method to be called after a Step has completed.
afterStep(StepExecution) - Method in class org.springframework.batch.core.listener.CompositeStepExecutionListener
Call the registered listeners in reverse order, respecting and prioritizing those that implement Ordered.
afterStep(StepExecution) - Method in class org.springframework.batch.core.listener.ExecutionContextPromotionListener
 
afterStep(StepExecution) - Method in class org.springframework.batch.core.listener.MulticasterBatchListener
 
afterStep(StepExecution) - Method in class org.springframework.batch.core.listener.StepExecutionListenerSupport
 
afterStep(StepExecution) - Method in class org.springframework.batch.core.listener.StepListenerSupport
 
afterStep(StepExecution) - Method in class org.springframework.batch.core.step.NoWorkFoundStepExecutionListener
 
afterStep(StepExecution) - Method in interface org.springframework.batch.core.StepExecutionListener
Give a listener a chance to modify the exit status from a step.
AfterWrite - Annotation Type in org.springframework.batch.core.annotation
Marks a method to be called after an item is passed to an ItemWriter

Expected signature: void afterWrite(List<? extends S> items)
afterWrite(List<? extends S>) - Method in interface org.springframework.batch.core.ItemWriteListener
Called after ItemWriter.write(java.util.List) This will be called before any transaction is committed, and before ChunkListener.afterChunk(ChunkContext)
afterWrite(List<? extends S>) - Method in class org.springframework.batch.core.listener.CompositeItemWriteListener
Call the registered listeners in reverse order, respecting and prioritising those that implement Ordered.
afterWrite(List<? extends O>) - Method in class org.springframework.batch.core.listener.ItemListenerSupport
 
afterWrite(List<? extends S>) - Method in class org.springframework.batch.core.listener.MulticasterBatchListener
 
afterWrite(List<? extends S>) - Method in class org.springframework.batch.core.listener.StepListenerSupport
 
aggregate(Collection<FlowExecution>) - Method in interface org.springframework.batch.core.job.flow.support.state.FlowExecutionAggregator
 
aggregate(Collection<FlowExecution>) - Method in class org.springframework.batch.core.job.flow.support.state.MaxValueFlowExecutionAggregator
Aggregate all of the FlowExecutionStatuses of the FlowExecutions into one status.
aggregate(StepExecution, Collection<StepExecution>) - Method in class org.springframework.batch.core.partition.support.DefaultStepExecutionAggregator
Aggregates the input executions into the result StepExecution.
aggregate(StepExecution, Collection<StepExecution>) - Method in class org.springframework.batch.core.partition.support.RemoteStepExecutionAggregator
Aggregates the input executions into the result StepExecution delegating to the delegate aggregator once the input has been refreshed from the JobExplorer.
aggregate(StepExecution, Collection<StepExecution>) - Method in interface org.springframework.batch.core.partition.support.StepExecutionAggregator
Take the inputs and aggregate, putting the aggregates into the result.
aggregator(StepExecutionAggregator) - Method in class org.springframework.batch.core.step.builder.PartitionStepBuilder
Provide a step execution aggregator for aggregating partitioned step executions into a single result for the PartitionStep itself.
allowStartIfComplete(boolean) - Method in class org.springframework.batch.core.step.builder.StepBuilderHelper
 
AlwaysSkipItemSkipPolicy - Class in org.springframework.batch.core.step.skip
Implementation of the SkipPolicy interface that will always return that an item should be skipped.
AlwaysSkipItemSkipPolicy() - Constructor for class org.springframework.batch.core.step.skip.AlwaysSkipItemSkipPolicy
 
and(ExitStatus) - Method in class org.springframework.batch.core.ExitStatus
Create a new ExitStatus with a logical combination of the exit code, and a concatenation of the descriptions.
ApplicationContextFactory - Interface in org.springframework.batch.core.configuration.support
Factory for the creation of ApplicationContexts.
ApplicationContextJobFactory - Class in org.springframework.batch.core.configuration.support
A JobFactory that creates its own ApplicationContext and pulls a bean out when asked to create a Job.
ApplicationContextJobFactory(String, ApplicationContextFactory) - Constructor for class org.springframework.batch.core.configuration.support.ApplicationContextJobFactory
 
apply(StepContribution) - Method in class org.springframework.batch.core.StepExecution
On successful execution just before a chunk commit, this method should be called.
applyConfiguration(SimpleStepBuilder<T, S>) - Method in class org.springframework.batch.core.step.factory.FaultTolerantStepFactoryBean
 
applyConfiguration(SimpleStepBuilder<T, S>) - Method in class org.springframework.batch.core.step.factory.SimpleStepFactoryBean
 
AutomaticJobRegistrar - Class in org.springframework.batch.core.configuration.support
Loads and unloads Jobs when the application context is created and destroyed.
AutomaticJobRegistrar() - Constructor for class org.springframework.batch.core.configuration.support.AutomaticJobRegistrar
 
autoregisterBeansForNamespace(ParserContext, Object) - Static method in class org.springframework.batch.core.configuration.xml.CoreNamespaceUtils
 

B

backOffPolicy(BackOffPolicy) - Method in class org.springframework.batch.core.step.builder.FaultTolerantStepBuilder
Provide a backoff policy to prevent items being retried immediately (e.g.
BatchConfigurationException - Exception in org.springframework.batch.core.configuration
Represents an error has occured in the configuration of base batch infrastructure (creation of a JobRepository for example.
BatchConfigurationException(Throwable) - Constructor for exception org.springframework.batch.core.configuration.BatchConfigurationException
 
BatchConfigurationSelector - Class in org.springframework.batch.core.configuration.annotation
Base Configuration class providing common structure for enabling and using Spring Batch.
BatchConfigurationSelector() - Constructor for class org.springframework.batch.core.configuration.annotation.BatchConfigurationSelector
 
BatchConfigurer - Interface in org.springframework.batch.core.configuration.annotation
Strategy interface for users to provide as a factory for custom components needed by a Batch system.
BatchRetryTemplate - Class in org.springframework.batch.core.step.item
A special purpose retry template that deals specifically with multi-valued stateful retry.
BatchRetryTemplate() - Constructor for class org.springframework.batch.core.step.item.BatchRetryTemplate
 
BatchStatus - Enum in org.springframework.batch.core
Enumeration representing the status of a an Execution.
BeanDefinitionUtils - Class in org.springframework.batch.core.configuration.xml
 
BeanDefinitionUtils() - Constructor for class org.springframework.batch.core.configuration.xml.BeanDefinitionUtils
 
BeforeChunk - Annotation Type in org.springframework.batch.core.annotation
Marks a method to be called before a chunk is executed.
beforeChunk(ChunkContext) - Method in interface org.springframework.batch.core.ChunkListener
Callback before the chunk is executed, but inside the transaction.
beforeChunk(ChunkContext) - Method in class org.springframework.batch.core.listener.ChunkListenerSupport
 
beforeChunk(ChunkContext) - Method in class org.springframework.batch.core.listener.CompositeChunkListener
Call the registered listeners in reverse order.
beforeChunk(ChunkContext) - Method in class org.springframework.batch.core.listener.MulticasterBatchListener
 
beforeChunk(ChunkContext) - Method in class org.springframework.batch.core.listener.StepListenerSupport
 
BeforeJob - Annotation Type in org.springframework.batch.core.annotation
Marks a method to be called before a Job is executed, which comes after a JobExecution is created and persisted, but before the first Step is executed.
beforeJob(JobExecution) - Method in interface org.springframework.batch.core.JobExecutionListener
Callback before a job executes.
beforeJob(JobExecution) - Method in class org.springframework.batch.core.listener.CompositeJobExecutionListener
Call the registered listeners in order, respecting and prioritising those that implement Ordered.
beforeJob(JobExecution) - Method in class org.springframework.batch.core.listener.JobExecutionListenerSupport
 
BeforeProcess - Annotation Type in org.springframework.batch.core.annotation
Marks a method to be called before an item is passed to an ItemProcessor

Expected signature: void beforeProcess(T item)
beforeProcess(T) - Method in interface org.springframework.batch.core.ItemProcessListener
beforeProcess(T) - Method in class org.springframework.batch.core.listener.CompositeItemProcessListener
Call the registered listeners in order, respecting and prioritising those that implement Ordered.
beforeProcess(I) - Method in class org.springframework.batch.core.listener.ItemListenerSupport
 
beforeProcess(T) - Method in class org.springframework.batch.core.listener.MulticasterBatchListener
 
beforeProcess(T) - Method in class org.springframework.batch.core.listener.StepListenerSupport
 
BeforeRead - Annotation Type in org.springframework.batch.core.annotation
Marks a method to be called before an item is read from an ItemReader

Expected signature: void beforeRead()
beforeRead() - Method in interface org.springframework.batch.core.ItemReadListener
Called before ItemReader.read()
beforeRead() - Method in class org.springframework.batch.core.listener.CompositeItemReadListener
Call the registered listeners in order, respecting and prioritising those that implement Ordered.
beforeRead() - Method in class org.springframework.batch.core.listener.ItemListenerSupport
 
beforeRead() - Method in class org.springframework.batch.core.listener.MulticasterBatchListener
 
beforeRead() - Method in class org.springframework.batch.core.listener.StepListenerSupport
 
BeforeStep - Annotation Type in org.springframework.batch.core.annotation
Marks a method to be called before a Step is executed, which comes after a StepExecution is created and persisted, but before the first item is read.
beforeStep(StepExecution) - Method in class org.springframework.batch.core.listener.CompositeStepExecutionListener
Call the registered listeners in order, respecting and prioritizing those that implement Ordered.
beforeStep(StepExecution) - Method in class org.springframework.batch.core.listener.JobParameterExecutionContextCopyListener
Copy attributes from the JobParameters to the Step ExecutionContext, if not already present.
beforeStep(StepExecution) - Method in class org.springframework.batch.core.listener.MulticasterBatchListener
 
beforeStep(StepExecution) - Method in class org.springframework.batch.core.listener.StepExecutionListenerSupport
 
beforeStep(StepExecution) - Method in class org.springframework.batch.core.listener.StepListenerSupport
 
beforeStep(StepExecution) - Method in class org.springframework.batch.core.resource.StepExecutionSimpleCompletionPolicy
Set up a SimpleCompletionPolicy with a commit interval taken from the JobParameters.
beforeStep(StepExecution) - Method in class org.springframework.batch.core.step.tasklet.SystemCommandTasklet
Get a reference to StepExecution for interrupt checks during system command execution.
beforeStep(StepExecution) - Method in interface org.springframework.batch.core.StepExecutionListener
Initialize the state of the listener with the StepExecution from the current scope.
BeforeWrite - Annotation Type in org.springframework.batch.core.annotation
Marks a method to be called before an item is passed to an ItemWriter

Expected signature: void beforeWrite(List<? extends S> items)
beforeWrite(List<? extends S>) - Method in interface org.springframework.batch.core.ItemWriteListener
beforeWrite(List<? extends S>) - Method in class org.springframework.batch.core.listener.CompositeItemWriteListener
Call the registered listeners in order, respecting and prioritising those that implement Ordered.
beforeWrite(List<? extends O>) - Method in class org.springframework.batch.core.listener.ItemListenerSupport
 
beforeWrite(List<? extends S>) - Method in class org.springframework.batch.core.listener.MulticasterBatchListener
 
beforeWrite(List<? extends S>) - Method in class org.springframework.batch.core.listener.StepListenerSupport
 
bind(JobFactory, Map<String, ?>) - Method in class org.springframework.batch.core.configuration.support.JobFactoryRegistrationListener
Take the JobFactory provided and register it with the JobRegistry.
build() - Method in class org.springframework.batch.core.job.builder.FlowBuilder
Validate the current state of the builder and build a flow.
build() - Method in class org.springframework.batch.core.job.builder.FlowJobBuilder
Build a job that executes the flow provided, normally composed of other steps.
build() - Method in class org.springframework.batch.core.job.builder.JobFlowBuilder
Build a flow and inject it into the parent builder.
build() - Method in class org.springframework.batch.core.job.builder.SimpleJobBuilder
 
build() - Method in class org.springframework.batch.core.step.builder.AbstractTaskletStepBuilder
Build the step from the components collected by the fluent setters.
build() - Method in class org.springframework.batch.core.step.builder.FaultTolerantStepBuilder
 
build() - Method in class org.springframework.batch.core.step.builder.FlowStepBuilder
Build a step that executes the flow provided, normally composed of other steps.
build() - Method in class org.springframework.batch.core.step.builder.JobStepBuilder
Build a step from the job provided.
build() - Method in class org.springframework.batch.core.step.builder.PartitionStepBuilder
 
build() - Method in class org.springframework.batch.core.step.builder.SimpleStepBuilder
Build a step with the reader, writer, processor as provided.

C

CallableTaskletAdapter - Class in org.springframework.batch.core.step.tasklet
Adapts a Callable<RepeatStatus> to the Tasklet interface.
CallableTaskletAdapter() - Constructor for class org.springframework.batch.core.step.tasklet.CallableTaskletAdapter
 
canRetry(RetryContext) - Method in class org.springframework.batch.core.step.item.BatchRetryTemplate
 
checkInterrupted(StepExecution) - Method in interface org.springframework.batch.core.step.StepInterruptionPolicy
Has the job been interrupted? If so then throw a JobInterruptedException.
checkInterrupted(StepExecution) - Method in class org.springframework.batch.core.step.ThreadStepInterruptionPolicy
Returns if the current job lifecycle has been interrupted by checking if the current thread is interrupted.
chunk(int) - Method in class org.springframework.batch.core.step.builder.SimpleStepBuilder
Sets the chunk size or commit interval for this step.
chunk(CompletionPolicy) - Method in class org.springframework.batch.core.step.builder.SimpleStepBuilder
Sets a completion policy for the chunk processing.
chunk(int) - Method in class org.springframework.batch.core.step.builder.StepBuilder
Build a step that processes items in chunks with the size provided.
chunk(CompletionPolicy) - Method in class org.springframework.batch.core.step.builder.StepBuilder
Build a step that processes items in chunks with the completion policy provided.
Chunk<W> - Class in org.springframework.batch.core.step.item
Encapsulation of a list of items to be processed and possibly a list of failed items to be skipped.
Chunk() - Constructor for class org.springframework.batch.core.step.item.Chunk
 
Chunk(Collection<? extends W>) - Constructor for class org.springframework.batch.core.step.item.Chunk
 
Chunk(Collection<? extends W>, List<SkipWrapper<W>>) - Constructor for class org.springframework.batch.core.step.item.Chunk
 
Chunk.ChunkIterator - Class in org.springframework.batch.core.step.item
Special iterator for a chunk providing the Chunk.ChunkIterator.remove(Throwable) method for dynamically removing an item and adding it to the skips.
Chunk.ChunkIterator(List<W>) - Constructor for class org.springframework.batch.core.step.item.Chunk.ChunkIterator
 
ChunkContext - Class in org.springframework.batch.core.scope.context
Context object for weakly typed data stored for the duration of a chunk (usually a group of items processed together in a transaction).
ChunkContext(StepContext) - Constructor for class org.springframework.batch.core.scope.context.ChunkContext
 
ChunkElementParser - Class in org.springframework.batch.core.configuration.xml
Internal parser for the <chunk/> element inside a step.
ChunkElementParser() - Constructor for class org.springframework.batch.core.configuration.xml.ChunkElementParser
 
ChunkListener - Interface in org.springframework.batch.core
Listener interface for the lifecycle of a chunk.
chunkListeners - Variable in class org.springframework.batch.core.step.builder.AbstractTaskletStepBuilder
 
ChunkListenerSupport - Class in org.springframework.batch.core.listener
Basic support implementation of ChunkListener
ChunkListenerSupport() - Constructor for class org.springframework.batch.core.listener.ChunkListenerSupport
 
ChunkMonitor - Class in org.springframework.batch.core.step.item
Manage the offset data between the last successful commit and updates made to an input chunk.
ChunkMonitor() - Constructor for class org.springframework.batch.core.step.item.ChunkMonitor
 
ChunkMonitor.ChunkMonitorData - Class in org.springframework.batch.core.step.item
 
ChunkMonitor.ChunkMonitorData(int, int) - Constructor for class org.springframework.batch.core.step.item.ChunkMonitor.ChunkMonitorData
 
chunkOperations(RepeatOperations) - Method in class org.springframework.batch.core.step.builder.SimpleStepBuilder
Instead of a chunk size or completion policy you can provide a complete repeat operations instance that handles the iteration over the item reader.
ChunkOrientedTasklet<I> - Class in org.springframework.batch.core.step.item
A Tasklet implementing variations on read-process-write item handling.
ChunkOrientedTasklet(ChunkProvider<I>, ChunkProcessor<I>) - Constructor for class org.springframework.batch.core.step.item.ChunkOrientedTasklet
 
ChunkProcessor<I> - Interface in org.springframework.batch.core.step.item
Interface defined for processing Chunks.
ChunkProvider<T> - Interface in org.springframework.batch.core.step.item
Interface for providing Chunks to be processed, used by the ChunkOrientedTasklet
chunkSize - Variable in class org.springframework.batch.core.step.item.ChunkMonitor.ChunkMonitorData
 
ClassPathXmlApplicationContextFactory - Class in org.springframework.batch.core.configuration.support
Deprecated.
ClassPathXmlApplicationContextFactory(Resource) - Constructor for class org.springframework.batch.core.configuration.support.ClassPathXmlApplicationContextFactory
Deprecated.
Create an application context factory for the resource specified.
ClasspathXmlApplicationContextsFactoryBean - Class in org.springframework.batch.core.configuration.support
A convenient factory for creating a set of ApplicationContextFactory components from a set of resources.
ClasspathXmlApplicationContextsFactoryBean() - Constructor for class org.springframework.batch.core.configuration.support.ClasspathXmlApplicationContextsFactoryBean
 
ClassPathXmlJobRegistry - Class in org.springframework.batch.core.configuration.support
Deprecated.
in version 2.1, please us AutomaticJobRegistrar instead
ClassPathXmlJobRegistry() - Constructor for class org.springframework.batch.core.configuration.support.ClassPathXmlJobRegistry
Deprecated.
 
clear() - Method in class org.springframework.batch.core.configuration.support.DefaultJobLoader
Unregister all the jobs and close all the contexts created by this loader.
clear() - Method in interface org.springframework.batch.core.configuration.support.JobLoader
Unregister all the jobs and close all the contexts created by this loader.
clear() - Method in class org.springframework.batch.core.repository.dao.MapExecutionContextDao
 
clear() - Method in class org.springframework.batch.core.repository.dao.MapJobExecutionDao
 
clear() - Method in class org.springframework.batch.core.repository.dao.MapJobInstanceDao
 
clear() - Method in class org.springframework.batch.core.repository.dao.MapStepExecutionDao
 
clear() - Method in class org.springframework.batch.core.repository.support.MapJobRepositoryFactoryBean
Convenience method to clear all the map daos globally, removing all entities.
clear() - Method in class org.springframework.batch.core.step.item.Chunk
Clear the items down to signal that we are done.
clearSkips() - Method in class org.springframework.batch.core.step.item.Chunk
Clear only the skips list.
close(FlowExecution) - Method in interface org.springframework.batch.core.job.flow.FlowExecutor
Chance to clean up resources at the end of a flow (whether it completed successfully or not).
close(FlowExecution) - Method in class org.springframework.batch.core.job.flow.JobFlowExecutor
 
close() - Method in class org.springframework.batch.core.scope.context.StepContext
Clean up the context at the end of a step execution.
close() - Static method in class org.springframework.batch.core.scope.context.StepSynchronizationManager
Method for de-registering the current context - should always and only be used by in conjunction with a matching StepSynchronizationManager.register(StepExecution) to ensure that StepSynchronizationManager.getContext() always returns the correct value.
close(ExecutionContext) - Method in class org.springframework.batch.core.step.AbstractStep
Extension point for subclasses to provide callbacks to their collaborators at the end of a step (right at the end of the finally block), to close or release resources.
close() - Method in class org.springframework.batch.core.step.item.ChunkMonitor
 
close(RetryContext, RetryCallback<T>, Throwable) - Method in class org.springframework.batch.core.step.item.SimpleRetryExceptionHandler
If retry is exhausted set up some state in the context that can be used to signal that the exception should be handled.
close(ExecutionContext) - Method in class org.springframework.batch.core.step.tasklet.TaskletStep
 
CommandLineJobRunner - Class in org.springframework.batch.core.launch.support
Basic launcher for starting jobs from the command line.
CommandLineJobRunner() - Constructor for class org.springframework.batch.core.launch.support.CommandLineJobRunner
 
compareTo(ExitStatus) - Method in class org.springframework.batch.core.ExitStatus
 
compareTo(FlowExecution) - Method in class org.springframework.batch.core.job.flow.FlowExecution
Create an ordering on FlowExecution instances by comparing their statuses.
compareTo(FlowExecutionStatus) - Method in class org.springframework.batch.core.job.flow.FlowExecutionStatus
Create an ordering on FlowExecutionStatus instances by comparing their statuses.
compareTo(StateTransition) - Method in class org.springframework.batch.core.job.flow.support.StateTransition
Sorts by decreasing specificity of pattern, based on just counting wildcards (with * taking precedence over ?).
COMPLETED - Static variable in class org.springframework.batch.core.ExitStatus
Convenient constant value representing finished processing.
COMPLETED - Static variable in class org.springframework.batch.core.job.flow.FlowExecutionStatus
Special well-known status value.
CompositeChunkListener - Class in org.springframework.batch.core.listener
 
CompositeChunkListener() - Constructor for class org.springframework.batch.core.listener.CompositeChunkListener
 
CompositeItemProcessListener<T,S> - Class in org.springframework.batch.core.listener
 
CompositeItemProcessListener() - Constructor for class org.springframework.batch.core.listener.CompositeItemProcessListener
 
CompositeItemReadListener<T> - Class in org.springframework.batch.core.listener
 
CompositeItemReadListener() - Constructor for class org.springframework.batch.core.listener.CompositeItemReadListener
 
CompositeItemWriteListener<S> - Class in org.springframework.batch.core.listener
 
CompositeItemWriteListener() - Constructor for class org.springframework.batch.core.listener.CompositeItemWriteListener
 
CompositeJobExecutionListener - Class in org.springframework.batch.core.listener
 
CompositeJobExecutionListener() - Constructor for class org.springframework.batch.core.listener.CompositeJobExecutionListener
 
CompositeJobParametersValidator - Class in org.springframework.batch.core.job
Composite JobParametersValidator that passes the job parameters through a sequence of injected JobParametersValidators
CompositeJobParametersValidator() - Constructor for class org.springframework.batch.core.job.CompositeJobParametersValidator
 
CompositeSkipListener<T,S> - Class in org.springframework.batch.core.listener
 
CompositeSkipListener() - Constructor for class org.springframework.batch.core.listener.CompositeSkipListener
 
CompositeSkipPolicy - Class in org.springframework.batch.core.step.skip
 
CompositeSkipPolicy() - Constructor for class org.springframework.batch.core.step.skip.CompositeSkipPolicy
 
CompositeSkipPolicy(SkipPolicy[]) - Constructor for class org.springframework.batch.core.step.skip.CompositeSkipPolicy
 
CompositeStepExecutionListener - Class in org.springframework.batch.core.listener
 
CompositeStepExecutionListener() - Constructor for class org.springframework.batch.core.listener.CompositeStepExecutionListener
 
concurrent() - Method in class org.springframework.batch.core.step.builder.AbstractTaskletStepBuilder
Convenience method for subclasses to determine if the step is concurrent.
ConfigurableSystemProcessExitCodeMapper - Class in org.springframework.batch.core.step.tasklet
Maps exit codes to ExitStatus according to injected map.
ConfigurableSystemProcessExitCodeMapper() - Constructor for class org.springframework.batch.core.step.tasklet.ConfigurableSystemProcessExitCodeMapper
 
CoreNamespaceHandler - Class in org.springframework.batch.core.configuration.xml
 
CoreNamespaceHandler() - Constructor for class org.springframework.batch.core.configuration.xml.CoreNamespaceHandler
 
CoreNamespacePostProcessor - Class in org.springframework.batch.core.configuration.xml
Post-process jobs and steps defined using the batch namespace to inject dependencies.
CoreNamespacePostProcessor() - Constructor for class org.springframework.batch.core.configuration.xml.CoreNamespacePostProcessor
 
CoreNamespaceUtils - Class in org.springframework.batch.core.configuration.xml
Utility methods used in parsing of the batch core namespace
CoreNamespaceUtils() - Constructor for class org.springframework.batch.core.configuration.xml.CoreNamespaceUtils
 
createApplicationContext() - Method in class org.springframework.batch.core.configuration.support.AbstractApplicationContextFactory
Creates an ApplicationContext from the provided path.
createApplicationContext(ConfigurableApplicationContext, Object...) - Method in class org.springframework.batch.core.configuration.support.AbstractApplicationContextFactory
 
createApplicationContext() - Method in interface org.springframework.batch.core.configuration.support.ApplicationContextFactory
 
createApplicationContext(ConfigurableApplicationContext, Object...) - Method in class org.springframework.batch.core.configuration.support.GenericApplicationContextFactory
 
createApplicationContext() - Method in class org.springframework.batch.core.configuration.support.OsgiBundleXmlApplicationContextFactory
Create an application context from the provided path, using the current OSGi BundleContext and the enclosing Spring ApplicationContext as a parent context.
createBuilder(String) - Method in class org.springframework.batch.core.step.factory.FaultTolerantStepFactoryBean
 
createBuilder(String) - Method in class org.springframework.batch.core.step.factory.SimpleStepFactoryBean
 
createChunkOperations() - Method in class org.springframework.batch.core.step.builder.SimpleStepBuilder
 
createEndStateTransition(State) - Static method in class org.springframework.batch.core.job.flow.support.StateTransition
Create a new end state StateTransition specification.
createEndStateTransition(State, String) - Static method in class org.springframework.batch.core.job.flow.support.StateTransition
Create a new end state StateTransition specification.
createExecutionContextDao() - Method in class org.springframework.batch.core.explore.support.AbstractJobExplorerFactoryBean
 
createExecutionContextDao() - Method in class org.springframework.batch.core.explore.support.JobExplorerFactoryBean
 
createExecutionContextDao() - Method in class org.springframework.batch.core.explore.support.MapJobExplorerFactoryBean
 
createExecutionContextDao() - Method in class org.springframework.batch.core.repository.support.AbstractJobRepositoryFactoryBean
 
createExecutionContextDao() - Method in class org.springframework.batch.core.repository.support.JobRepositoryFactoryBean
 
createExecutionContextDao() - Method in class org.springframework.batch.core.repository.support.MapJobRepositoryFactoryBean
 
createJob() - Method in interface org.springframework.batch.core.configuration.JobFactory
 
createJob() - Method in class org.springframework.batch.core.configuration.support.ApplicationContextJobFactory
Create an ApplicationContext from the factory provided and pull out a bean with the name given during initialization.
createJob() - Method in class org.springframework.batch.core.configuration.support.ReferenceJobFactory
Just return the instance passed in on initialization.
createJobExecution(String, JobParameters) - Method in interface org.springframework.batch.core.repository.JobRepository
Create a JobExecution for a given Job and JobParameters.
createJobExecution(String, JobParameters) - Method in class org.springframework.batch.core.repository.support.SimpleJobRepository
 
createJobExecutionDao() - Method in class org.springframework.batch.core.explore.support.AbstractJobExplorerFactoryBean
 
createJobExecutionDao() - Method in class org.springframework.batch.core.explore.support.JobExplorerFactoryBean
 
createJobExecutionDao() - Method in class org.springframework.batch.core.explore.support.MapJobExplorerFactoryBean
 
createJobExecutionDao() - Method in class org.springframework.batch.core.repository.support.AbstractJobRepositoryFactoryBean
 
createJobExecutionDao() - Method in class org.springframework.batch.core.repository.support.JobRepositoryFactoryBean
 
createJobExecutionDao() - Method in class org.springframework.batch.core.repository.support.MapJobRepositoryFactoryBean
 
createJobInstance(String, JobParameters) - Method in class org.springframework.batch.core.repository.dao.JdbcJobInstanceDao
In this jdbc implementation a job id is obtained by asking the jobIncrementer (which is likely a sequence) for the next long value, and then passing the Id and parameter values into an INSERT statement.
createJobInstance(String, JobParameters) - Method in interface org.springframework.batch.core.repository.dao.JobInstanceDao
Create a JobInstance with given name and parameters.
createJobInstance(String, JobParameters) - Method in class org.springframework.batch.core.repository.dao.MapJobInstanceDao
 
createJobInstanceDao() - Method in class org.springframework.batch.core.explore.support.AbstractJobExplorerFactoryBean
 
createJobInstanceDao() - Method in class org.springframework.batch.core.explore.support.JobExplorerFactoryBean
 
createJobInstanceDao() - Method in class org.springframework.batch.core.explore.support.MapJobExplorerFactoryBean
 
createJobInstanceDao() - Method in class org.springframework.batch.core.repository.support.AbstractJobRepositoryFactoryBean
 
createJobInstanceDao() - Method in class org.springframework.batch.core.repository.support.JobRepositoryFactoryBean
 
createJobInstanceDao() - Method in class org.springframework.batch.core.repository.support.MapJobRepositoryFactoryBean
 
createJobRepository() - Method in class org.springframework.batch.core.configuration.annotation.DefaultBatchConfigurer
 
createSemaphore() - Method in class org.springframework.batch.core.step.tasklet.TaskletStep
Extension point mainly for test purposes so that the behaviour of the lock can be manipulated to simulate various pathologies.
createSkipPolicy() - Method in class org.springframework.batch.core.step.builder.FaultTolerantStepBuilder
 
createState(List<?>) - Static method in class org.springframework.batch.core.step.item.BatchRetryTemplate
 
createState(List<?>, Classifier<? super Throwable, Boolean>) - Static method in class org.springframework.batch.core.step.item.BatchRetryTemplate
 
createStateTransition(State, String) - Static method in class org.springframework.batch.core.job.flow.support.StateTransition
Create a new state StateTransition specification with a wildcard pattern that matches all outcomes.
createStateTransition(State, String, String) - Static method in class org.springframework.batch.core.job.flow.support.StateTransition
Create a new StateTransition specification from one State to another (by name).
createStepContribution() - Method in class org.springframework.batch.core.StepExecution
Factory method for StepContribution.
createStepExecution(String) - Method in class org.springframework.batch.core.JobExecution
Register a step execution with the current job execution.
createStepExecutionDao() - Method in class org.springframework.batch.core.explore.support.AbstractJobExplorerFactoryBean
 
createStepExecutionDao() - Method in class org.springframework.batch.core.explore.support.JobExplorerFactoryBean
 
createStepExecutionDao() - Method in class org.springframework.batch.core.explore.support.MapJobExplorerFactoryBean
 
createStepExecutionDao() - Method in class org.springframework.batch.core.repository.support.AbstractJobRepositoryFactoryBean
 
createStepExecutionDao() - Method in class org.springframework.batch.core.repository.support.JobRepositoryFactoryBean
 
createStepExecutionDao() - Method in class org.springframework.batch.core.repository.support.MapJobRepositoryFactoryBean
 
createTask(Step, StepExecution) - Method in class org.springframework.batch.core.partition.support.TaskExecutorPartitionHandler
Creates the task executing the given step in the context of the given execution.
createTasklet() - Method in class org.springframework.batch.core.step.builder.AbstractTaskletStepBuilder
 
createTasklet() - Method in class org.springframework.batch.core.step.builder.FaultTolerantStepBuilder
Create a new chunk oriented tasklet with reader, writer and processor as provided.
createTasklet() - Method in class org.springframework.batch.core.step.builder.SimpleStepBuilder
 
createTasklet() - Method in class org.springframework.batch.core.step.builder.TaskletStepBuilder
 

D

DATE_TYPE - Static variable in class org.springframework.batch.core.converter.DefaultJobParametersConverter
 
decide(JobExecution, StepExecution) - Method in interface org.springframework.batch.core.job.flow.JobExecutionDecider
Strategy for branching an execution based on the state of an ongoing JobExecution.
DecisionParser - Class in org.springframework.batch.core.configuration.xml
Internal parser for the <decision/> elements inside a job.
DecisionParser() - Constructor for class org.springframework.batch.core.configuration.xml.DecisionParser
 
DecisionState - Class in org.springframework.batch.core.job.flow.support.state
State that requires a decider to make the status decision.
DecisionState(JobExecutionDecider, String) - Constructor for class org.springframework.batch.core.job.flow.support.state.DecisionState
 
DEFAULT_EXIT_MESSAGE_LENGTH - Static variable in class org.springframework.batch.core.repository.dao.AbstractJdbcBatchMetadataDao
 
DEFAULT_MAX_SKIPS_ON_READ - Static variable in class org.springframework.batch.core.step.item.FaultTolerantChunkProvider
Hard limit for number of read skips in the same chunk.
DEFAULT_TABLE_PREFIX - Static variable in class org.springframework.batch.core.repository.dao.AbstractJdbcBatchMetadataDao
Default value for the table prefix property.
DefaultBatchConfigurer - Class in org.springframework.batch.core.configuration.annotation
 
DefaultBatchConfigurer() - Constructor for class org.springframework.batch.core.configuration.annotation.DefaultBatchConfigurer
 
DefaultBatchConfigurer(DataSource) - Constructor for class org.springframework.batch.core.configuration.annotation.DefaultBatchConfigurer
 
DefaultExecutionContextSerializer - Class in org.springframework.batch.core.repository.dao
An implementation of the ExecutionContextSerializer using the default serialization implementations from Spring (DefaultSerializer and DefaultDeserializer).
DefaultExecutionContextSerializer() - Constructor for class org.springframework.batch.core.repository.dao.DefaultExecutionContextSerializer
 
DefaultItemFailureHandler - Class in org.springframework.batch.core.step.item
Default implementation of the ItemListenerSupport class that writes all exceptions via commons logging.
DefaultItemFailureHandler() - Constructor for class org.springframework.batch.core.step.item.DefaultItemFailureHandler
 
DefaultJobKeyGenerator - Class in org.springframework.batch.core
Default implementation of the JobKeyGenerator interface.
DefaultJobKeyGenerator() - Constructor for class org.springframework.batch.core.DefaultJobKeyGenerator
 
DefaultJobLoader - Class in org.springframework.batch.core.configuration.support
Default implementation of JobLoader.
DefaultJobLoader() - Constructor for class org.springframework.batch.core.configuration.support.DefaultJobLoader
Default constructor useful for declarative configuration.
DefaultJobLoader(JobRegistry) - Constructor for class org.springframework.batch.core.configuration.support.DefaultJobLoader
Creates a job loader with the job registry provided.
DefaultJobLoader(JobRegistry, StepRegistry) - Constructor for class org.springframework.batch.core.configuration.support.DefaultJobLoader
Creates a job loader with the job and step registries provided.
DefaultJobParametersConverter - Class in org.springframework.batch.core.converter
Converter for JobParameters instances using a simple naming convention for property keys.
DefaultJobParametersConverter() - Constructor for class org.springframework.batch.core.converter.DefaultJobParametersConverter
 
DefaultJobParametersExtractor - Class in org.springframework.batch.core.step.job
Simple implementation of JobParametersExtractor which pulls parameters with named keys out of the step execution context and the job parameters of the surrounding job.
DefaultJobParametersExtractor() - Constructor for class org.springframework.batch.core.step.job.DefaultJobParametersExtractor
 
DefaultJobParametersValidator - Class in org.springframework.batch.core.job
Default implementation of JobParametersValidator.
DefaultJobParametersValidator() - Constructor for class org.springframework.batch.core.job.DefaultJobParametersValidator
Convenient default constructor for unconstrained validation.
DefaultJobParametersValidator(String[], String[]) - Constructor for class org.springframework.batch.core.job.DefaultJobParametersValidator
Create a new validator with the required and optional job parameter keys provided.
DefaultStepExecutionAggregator - Class in org.springframework.batch.core.partition.support
Convenience class for aggregating a set of StepExecution instances into a single result.
DefaultStepExecutionAggregator() - Constructor for class org.springframework.batch.core.partition.support.DefaultStepExecutionAggregator
 
deserialize(InputStream) - Method in class org.springframework.batch.core.repository.dao.DefaultExecutionContextSerializer
Deserializes an execution context from the provided InputStream.
deserialize(InputStream) - Method in class org.springframework.batch.core.repository.dao.XStreamExecutionContextStringSerializer
Deserializes the supplied input stream into a new execution context.
destroy() - Method in class org.springframework.batch.core.configuration.support.JobRegistryBeanPostProcessor
De-register all the Job instances that were regsistered by this post processor.
doAfterWrite(List<O>) - Method in class org.springframework.batch.core.step.item.SimpleChunkProcessor
Call the listener's after write method.
doExecute(JobExecution) - Method in class org.springframework.batch.core.job.AbstractJob
Extension point for subclasses allowing them to concentrate on processing logic and ignore listeners and repository calls.
doExecute(JobExecution) - Method in class org.springframework.batch.core.job.flow.FlowJob
 
doExecute(StepExecution) - Method in class org.springframework.batch.core.job.flow.FlowStep
Delegate to the flow provided for the execution of the step.
doExecute(JobExecution) - Method in class org.springframework.batch.core.job.SimpleJob
Handler of steps sequentially as provided, checking each one for success before moving to the next.
doExecute(StepExecution) - Method in class org.springframework.batch.core.partition.support.PartitionStep
Delegate execution to the PartitionHandler provided.
doExecute(StepExecution) - Method in class org.springframework.batch.core.step.AbstractStep
Extension point for subclasses to execute business logic.
doExecute(StepExecution) - Method in class org.springframework.batch.core.step.job.JobStep
Execute the job provided by delegating to the JobLauncher to prevent duplicate executions.
doExecute(StepExecution) - Method in class org.springframework.batch.core.step.tasklet.TaskletStep
Process the step and update its context so that progress can be monitored by the caller.
doHandle(StepExecution, Set<StepExecution>) - Method in class org.springframework.batch.core.partition.support.AbstractPartitionHandler
Executes the specified StepExecution instances and returns an updated view of them.
doHandle(StepExecution, Set<StepExecution>) - Method in class org.springframework.batch.core.partition.support.TaskExecutorPartitionHandler
 
doInChunkContext(RepeatContext, ChunkContext) - Method in class org.springframework.batch.core.scope.context.StepContextRepeatCallback
Do the work required for this chunk of the step.
doInIteration(RepeatContext) - Method in class org.springframework.batch.core.scope.context.StepContextRepeatCallback
Manage the StepContext lifecycle.
doOnWriteError(Exception, List<O>) - Method in class org.springframework.batch.core.step.item.SimpleChunkProcessor
 
doParse(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.batch.core.configuration.xml.AbstractFlowParser
 
doParse(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.batch.core.configuration.xml.AbstractListenerParser
 
doParse(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.batch.core.configuration.xml.InlineFlowParser
 
doParse(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.batch.core.configuration.xml.JobParser
Create a bean definition for a FlowJob.
doParse(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.batch.core.configuration.xml.JobRepositoryParser
Parse and create a bean definition for a JobRepositoryFactoryBean .
doParse(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.batch.core.configuration.xml.TopLevelFlowParser
 
doParse(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.batch.core.configuration.xml.TopLevelJobListenerParser
 
doParse(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.batch.core.configuration.xml.TopLevelStepListenerParser
 
doProcess(I) - Method in class org.springframework.batch.core.step.item.SimpleChunkProcessor
 
doRead() - Method in class org.springframework.batch.core.step.item.SimpleChunkProvider
Surrounds the read call with listener callbacks.
doWrite(List<O>) - Method in class org.springframework.batch.core.step.item.SimpleChunkProcessor
Surrounds the actual write call with listener callbacks.
DuplicateJobException - Exception in org.springframework.batch.core.configuration
Checked exception that indicates a name clash when registering Job instances.
DuplicateJobException(String) - Constructor for exception org.springframework.batch.core.configuration.DuplicateJobException
Create an exception with the given message.
DuplicateJobException(String, Throwable) - Constructor for exception org.springframework.batch.core.configuration.DuplicateJobException
 

E

ELSE_KEY - Static variable in class org.springframework.batch.core.step.tasklet.ConfigurableSystemProcessExitCodeMapper
 
EMBEDDED - Static variable in class org.springframework.batch.core.launch.support.JobRegistryBackgroundJobRunner
System property key that switches the runner to "embedded" mode (returning immediately from the main method).
EnableBatchProcessing - Annotation Type in org.springframework.batch.core.configuration.annotation
Enable Spring Batch features and provide a base configuration for setting up batch jobs in an @Configuration class, roughly equivalent to using the <batch:*> XML namespace.
end() - Method in class org.springframework.batch.core.job.builder.FlowBuilder
A synonym for FlowBuilder.build() which callers might find useful.
end() - Method in class org.springframework.batch.core.job.builder.FlowBuilder.TransitionBuilder
Signal the successful end of the flow.
end(String) - Method in class org.springframework.batch.core.job.builder.FlowBuilder.TransitionBuilder
Signal the end of the flow with the status provided.
EndState - Class in org.springframework.batch.core.job.flow.support.state
State implementation for ending a job if it is in progress and continuing if just starting.
EndState(FlowExecutionStatus, String) - Constructor for class org.springframework.batch.core.job.flow.support.state.EndState
 
EndState(FlowExecutionStatus, String, String) - Constructor for class org.springframework.batch.core.job.flow.support.state.EndState
 
EndState(FlowExecutionStatus, String, String, boolean) - Constructor for class org.springframework.batch.core.job.flow.support.state.EndState
 
enhance(Job) - Method in class org.springframework.batch.core.job.builder.JobBuilderHelper
 
enhance(Step) - Method in class org.springframework.batch.core.step.builder.StepBuilderHelper
 
Entity - Class in org.springframework.batch.core
Batch Domain Entity class.
Entity() - Constructor for class org.springframework.batch.core.Entity
 
Entity(Long) - Constructor for class org.springframework.batch.core.Entity
 
equals(Object) - Method in class org.springframework.batch.core.configuration.support.AbstractApplicationContextFactory
 
equals(Object) - Method in class org.springframework.batch.core.configuration.support.GroupAwareJob
 
equals(Object) - Method in class org.springframework.batch.core.configuration.support.OsgiBundleXmlApplicationContextFactory
 
equals(Object) - Method in class org.springframework.batch.core.Entity
Attempt to establish identity based on id if both exist.
equals(Object) - Method in class org.springframework.batch.core.ExitStatus
Compare the fields one by one.
equals(Object) - Method in class org.springframework.batch.core.job.flow.FlowExecutionStatus
Check the equality of the statuses.
equals(Object) - Method in class org.springframework.batch.core.JobParameter
 
equals(Object) - Method in class org.springframework.batch.core.JobParameters
 
equals(Object) - Method in class org.springframework.batch.core.listener.MethodInvokerMethodInterceptor
equals(Object) - Method in class org.springframework.batch.core.scope.context.StepContext
Extend the base class method to include the step execution itself as a key (i.e.
equals(Object) - Method in class org.springframework.batch.core.StepContribution
 
equals(Object) - Method in class org.springframework.batch.core.StepExecution
 
ExceptionClassifierSkipPolicy - Class in org.springframework.batch.core.step.skip
A SkipPolicy that depends on an exception classifier to make its decision, and then delegates to the classifier result.
ExceptionClassifierSkipPolicy() - Constructor for class org.springframework.batch.core.step.skip.ExceptionClassifierSkipPolicy
 
exceptionHandler(ExceptionHandler) - Method in class org.springframework.batch.core.step.builder.AbstractTaskletStepBuilder
Sets the exception handler to use in the case of tasklet failures.
execute(JobExecution) - Method in class org.springframework.batch.core.configuration.support.GroupAwareJob
 
execute(JobExecution) - Method in class org.springframework.batch.core.job.AbstractJob
Run the specified job, handling all listener and repository calls, and delegating the actual processing to AbstractJob.doExecute(JobExecution).
execute(JobExecution) - Method in interface org.springframework.batch.core.Job
Run the JobExecution and update the meta information like status and statistics as necessary.
execute(Step, StepExecution) - Method in class org.springframework.batch.core.scope.context.StepScopeManager
 
execute(StepExecution) - Method in class org.springframework.batch.core.step.AbstractStep
Template method for step execution logic - calls abstract methods for resource initialization ( AbstractStep.open(ExecutionContext)), execution logic (AbstractStep.doExecute(StepExecution)) and resource closing ( AbstractStep.close(ExecutionContext)).
execute(StepExecution) - Method in interface org.springframework.batch.core.Step
Process the step and assign progress and status meta information to the StepExecution provided.
execute(RetryCallback<T>, Collection<RetryState>) - Method in class org.springframework.batch.core.step.item.BatchRetryTemplate
 
execute(RetryCallback<T>, RecoveryCallback<T>, Collection<RetryState>) - Method in class org.springframework.batch.core.step.item.BatchRetryTemplate
 
execute(RetryCallback<T>, RecoveryCallback<T>, RetryState) - Method in class org.springframework.batch.core.step.item.BatchRetryTemplate
 
execute(RetryCallback<T>, RecoveryCallback<T>) - Method in class org.springframework.batch.core.step.item.BatchRetryTemplate
 
execute(RetryCallback<T>, RetryState) - Method in class org.springframework.batch.core.step.item.BatchRetryTemplate
 
execute(RetryCallback<T>) - Method in class org.springframework.batch.core.step.item.BatchRetryTemplate
 
execute(StepContribution, ChunkContext) - Method in class org.springframework.batch.core.step.item.ChunkOrientedTasklet
 
execute(StepContribution, ChunkContext) - Method in class org.springframework.batch.core.step.tasklet.CallableTaskletAdapter
Execute the provided Callable and return its RepeatStatus.
execute(StepContribution, ChunkContext) - Method in class org.springframework.batch.core.step.tasklet.MethodInvokingTaskletAdapter
Delegate execution to the target object and translate the return value to an ExitStatus by invoking a method in the delegate POJO.
execute(StepContribution, ChunkContext) - Method in class org.springframework.batch.core.step.tasklet.SystemCommandTasklet
Execute system command and map its exit code to ExitStatus using SystemProcessExitCodeMapper.
execute(StepContribution, ChunkContext) - Method in interface org.springframework.batch.core.step.tasklet.Tasklet
Given the current context in the form of a step contribution, do whatever is necessary to process this unit inside a transaction.
executeStep(Step) - Method in interface org.springframework.batch.core.job.flow.FlowExecutor
 
executeStep(Step) - Method in class org.springframework.batch.core.job.flow.JobFlowExecutor
 
EXECUTING - Static variable in class org.springframework.batch.core.ExitStatus
Convenient constant value representing continuable state where processing is still taking place, so no further action is required.
ExecutionContextDao - Interface in org.springframework.batch.core.repository.dao
DAO interface for persisting and retrieving ExecutionContexts.
ExecutionContextPromotionListener - Class in org.springframework.batch.core.listener
This class can be used to automatically promote items from the Step ExecutionContext to the Job ExecutionContext at the end of a step.
ExecutionContextPromotionListener() - Constructor for class org.springframework.batch.core.listener.ExecutionContextPromotionListener
 
ExecutionContextSerializer - Interface in org.springframework.batch.core.repository
A composite interface that combines both serialization and deserialization of an execution context into a single implementation.
exit(int) - Method in class org.springframework.batch.core.launch.support.CommandLineJobRunner
Delegate to the exiter to (possibly) exit the VM gracefully.
exit(int) - Method in class org.springframework.batch.core.launch.support.JvmSystemExiter
Delegate call to System.exit() with the argument provided.
exit(int) - Method in interface org.springframework.batch.core.launch.support.SystemExiter
Terminate the currently running Java Virtual Machine.
ExitCodeMapper - Interface in org.springframework.batch.core.launch.support
This interface should be implemented when an environment calling the batch framework has specific requirements regarding the operating system process return status.
ExitStatus - Class in org.springframework.batch.core
Value object used to carry information about the status of a job or step execution.
ExitStatus(String) - Constructor for class org.springframework.batch.core.ExitStatus
 
ExitStatus(String, String) - Constructor for class org.springframework.batch.core.ExitStatus
 

F

fail() - Method in class org.springframework.batch.core.job.builder.FlowBuilder.TransitionBuilder
Signal the end of the flow with an error condition.
FAILED - Static variable in class org.springframework.batch.core.ExitStatus
Convenient constant value representing finished processing with an error.
FAILED - Static variable in class org.springframework.batch.core.job.flow.FlowExecutionStatus
Special well-known status value.
FatalStepExecutionException - Exception in org.springframework.batch.core.step
 
FatalStepExecutionException(String, Throwable) - Constructor for exception org.springframework.batch.core.step.FatalStepExecutionException
 
faultTolerant() - Method in class org.springframework.batch.core.step.builder.SimpleStepBuilder
 
FaultTolerantChunkProcessor<I,O> - Class in org.springframework.batch.core.step.item
FaultTolerant implementation of the ChunkProcessor interface, that allows for skipping or retry of items that cause exceptions during writing.
FaultTolerantChunkProcessor(ItemProcessor<? super I, ? extends O>, ItemWriter<? super O>, BatchRetryTemplate) - Constructor for class org.springframework.batch.core.step.item.FaultTolerantChunkProcessor
 
FaultTolerantChunkProvider<I> - Class in org.springframework.batch.core.step.item
FaultTolerant implementation of the ChunkProcessor interface, that allows for skipping or retry of items that cause exceptions during reading or processing.
FaultTolerantChunkProvider(ItemReader<? extends I>, RepeatOperations) - Constructor for class org.springframework.batch.core.step.item.FaultTolerantChunkProvider
 
FaultTolerantStepBuilder<I,O> - Class in org.springframework.batch.core.step.builder
A step builder for fully fault tolerant chunk-oriented item processing steps.
FaultTolerantStepBuilder(StepBuilderHelper<?>) - Constructor for class org.springframework.batch.core.step.builder.FaultTolerantStepBuilder
Create a new builder initialized with any properties in the parent.
FaultTolerantStepBuilder(SimpleStepBuilder<I, O>) - Constructor for class org.springframework.batch.core.step.builder.FaultTolerantStepBuilder
Create a new builder initialized with any properties in the parent.
FaultTolerantStepFactoryBean<T,S> - Class in org.springframework.batch.core.step.factory
Factory bean for step that provides options for configuring skip behavior.
FaultTolerantStepFactoryBean() - Constructor for class org.springframework.batch.core.step.factory.FaultTolerantStepFactoryBean
 
findJobExecutions(JobInstance) - Method in class org.springframework.batch.core.repository.dao.JdbcJobExecutionDao
 
findJobExecutions(JobInstance) - Method in interface org.springframework.batch.core.repository.dao.JobExecutionDao
Return all JobExecution for given JobInstance, sorted backwards by creation order (so the first element is the most recent).
findJobExecutions(JobInstance) - Method in class org.springframework.batch.core.repository.dao.MapJobExecutionDao
 
findRunningJobExecutions(String) - Method in interface org.springframework.batch.core.explore.JobExplorer
Retrieve running job executions.
findRunningJobExecutions(String) - Method in class org.springframework.batch.core.explore.support.SimpleJobExplorer
 
findRunningJobExecutions(String) - Method in class org.springframework.batch.core.repository.dao.JdbcJobExecutionDao
 
findRunningJobExecutions(String) - Method in interface org.springframework.batch.core.repository.dao.JobExecutionDao
 
findRunningJobExecutions(String) - Method in class org.springframework.batch.core.repository.dao.MapJobExecutionDao
 
flow() - Method in class org.springframework.batch.core.job.builder.FlowBuilder
 
flow(Flow) - Method in class org.springframework.batch.core.job.builder.FlowJobBuilder
Provide a single flow to execute as the job.
flow(Step) - Method in class org.springframework.batch.core.job.builder.JobBuilder
Create a new job builder that will execute a step or sequence of steps.
Flow - Interface in org.springframework.batch.core.job.flow
 
flow(Flow) - Method in class org.springframework.batch.core.step.builder.FlowStepBuilder
Provide a flow to execute during the step.
flow(Flow) - Method in class org.springframework.batch.core.step.builder.StepBuilder
Create a new step builder that will execute a flow.
FlowBuilder<Q> - Class in org.springframework.batch.core.job.builder
A builder for a flow of steps that can be executed as a job or as part of a job.
FlowBuilder(String) - Constructor for class org.springframework.batch.core.job.builder.FlowBuilder
 
FlowBuilder.SplitBuilder<Q> - Class in org.springframework.batch.core.job.builder
A builder for building a split state.
FlowBuilder.SplitBuilder(FlowBuilder<Q>, TaskExecutor) - Constructor for class org.springframework.batch.core.job.builder.FlowBuilder.SplitBuilder
 
FlowBuilder.TransitionBuilder<Q> - Class in org.springframework.batch.core.job.builder
A builder for transitions within a flow.
FlowBuilder.TransitionBuilder(FlowBuilder<Q>, String) - Constructor for class org.springframework.batch.core.job.builder.FlowBuilder.TransitionBuilder
 
FlowBuilder.UnterminatedFlowBuilder<Q> - Class in org.springframework.batch.core.job.builder
A builder for continuing a flow from a decision state.
FlowBuilder.UnterminatedFlowBuilder(FlowBuilder<Q>) - Constructor for class org.springframework.batch.core.job.builder.FlowBuilder.UnterminatedFlowBuilder
 
FlowBuilderException - Exception in org.springframework.batch.core.job.builder
 
FlowBuilderException(String, Exception) - Constructor for exception org.springframework.batch.core.job.builder.FlowBuilderException
 
FlowBuilderException(Exception) - Constructor for exception org.springframework.batch.core.job.builder.FlowBuilderException
 
FlowBuilderException(String) - Constructor for exception org.springframework.batch.core.job.builder.FlowBuilderException
 
FlowElementParser - Class in org.springframework.batch.core.configuration.xml
Internal parser for the <flow/> elements inside a job..
FlowElementParser() - Constructor for class org.springframework.batch.core.configuration.xml.FlowElementParser
 
FlowExecution - Class in org.springframework.batch.core.job.flow
 
FlowExecution(String, FlowExecutionStatus) - Constructor for class org.springframework.batch.core.job.flow.FlowExecution
 
FlowExecutionAggregator - Interface in org.springframework.batch.core.job.flow.support.state
Strategy interface for aggregating FlowExecution instances into a single exit status.
FlowExecutionException - Exception in org.springframework.batch.core.job.flow
 
FlowExecutionException(String) - Constructor for exception org.springframework.batch.core.job.flow.FlowExecutionException
 
FlowExecutionException(String, Throwable) - Constructor for exception org.springframework.batch.core.job.flow.FlowExecutionException
 
FlowExecutionStatus - Class in org.springframework.batch.core.job.flow
Represents the status of FlowExecution.
FlowExecutionStatus(String) - Constructor for class org.springframework.batch.core.job.flow.FlowExecutionStatus
 
FlowExecutor - Interface in org.springframework.batch.core.job.flow
Context and execution strategy for FlowJob to allow it to delegate its execution step by step.
FlowHolder - Interface in org.springframework.batch.core.job.flow
Convenient interface for components that contain nested flows.
FlowJob - Class in org.springframework.batch.core.job.flow
Implementation of the Job interface that allows for complex flows of steps, rather than requiring sequential execution.
FlowJob() - Constructor for class org.springframework.batch.core.job.flow.FlowJob
Create a FlowJob with null name and no flow (invalid state).
FlowJob(String) - Constructor for class org.springframework.batch.core.job.flow.FlowJob
Create a FlowJob with provided name and no flow (invalid state).
FlowJobBuilder - Class in org.springframework.batch.core.job.builder
A job builder for FlowJob instances.
FlowJobBuilder(JobBuilderHelper<?>) - Constructor for class org.springframework.batch.core.job.builder.FlowJobBuilder
Create a new builder initialized with any properties in the parent.
FlowState - Class in org.springframework.batch.core.job.flow.support.state
State that delegates to a Flow
FlowState(Flow, String) - Constructor for class org.springframework.batch.core.job.flow.support.state.FlowState
 
FlowStep - Class in org.springframework.batch.core.job.flow
A Step implementation that delegates to a Flow.
FlowStep() - Constructor for class org.springframework.batch.core.job.flow.FlowStep
Default constructor convenient for configuration purposes.
FlowStep(Flow) - Constructor for class org.springframework.batch.core.job.flow.FlowStep
Constructor for a FlowStep that sets the flow and of the step explicitly.
FlowStepBuilder - Class in org.springframework.batch.core.step.builder
A step builder for FlowStep instances.
FlowStepBuilder(StepBuilderHelper<?>) - Constructor for class org.springframework.batch.core.step.builder.FlowStepBuilder
Create a new builder initialized with any properties in the parent.
ForceRollbackForWriteSkipException - Exception in org.springframework.batch.core.step.item
Fatal exception to be thrown when a rollback must be forced, typically after catching an exception that otherwise would not cause a rollback.
ForceRollbackForWriteSkipException(String, Throwable) - Constructor for exception org.springframework.batch.core.step.item.ForceRollbackForWriteSkipException
 
from(Step) - Method in class org.springframework.batch.core.job.builder.FlowBuilder
Go back to a previously registered step and start a new path.
from(JobExecutionDecider) - Method in class org.springframework.batch.core.job.builder.FlowBuilder
Start again from a decision that was already registered.
from(Flow) - Method in class org.springframework.batch.core.job.builder.FlowBuilder
Start again from a subflow that was already registered.
fromPropertyName(String) - Static method in enum org.springframework.batch.core.listener.JobListenerMetaData
Return the relevant meta data for the provided property name.
fromPropertyName(String) - Static method in enum org.springframework.batch.core.listener.StepListenerMetaData
Return the relevant meta data for the provided property name.

G

generateKey(JobParameters) - Method in class org.springframework.batch.core.DefaultJobKeyGenerator
Generates the job key to be used based on the JobParameters instance provided.
generateKey(T) - Method in interface org.springframework.batch.core.JobKeyGenerator
Method to generate the unique key used to identify a job instance.
GenericApplicationContextFactory - Class in org.springframework.batch.core.configuration.support
ApplicationContextFactory implementation that takes a parent context and a path to the context to create.
GenericApplicationContextFactory(Object...) - Constructor for class org.springframework.batch.core.configuration.support.GenericApplicationContextFactory
Create an application context factory for the resource specified.
get(String) - Method in class org.springframework.batch.core.configuration.annotation.JobBuilderFactory
Creates a job builder and initializes its job repository.
get(String) - Method in class org.springframework.batch.core.configuration.annotation.StepBuilderFactory
Creates a step builder and initializes its job repository and transaction manager.
get(String, ObjectFactory) - Method in class org.springframework.batch.core.scope.StepScope
 
getAdjustedOutputs(Chunk<I>, Chunk<O>) - Method in class org.springframework.batch.core.step.item.FaultTolerantChunkProcessor
 
getAdjustedOutputs(Chunk<I>, Chunk<O>) - Method in class org.springframework.batch.core.step.item.SimpleChunkProcessor
Extension point for subclasses that want to adjust the outputs based on additional saved data in the inputs.
getAllFailureExceptions() - Method in class org.springframework.batch.core.JobExecution
Return all failure causing exceptions for this JobExecution, including step executions.
getAllowStartIfComplete() - Method in class org.springframework.batch.core.step.builder.StepBuilderHelper.CommonStepProperties
 
getAnnotation() - Method in enum org.springframework.batch.core.listener.JobListenerMetaData
 
getAnnotation() - Method in interface org.springframework.batch.core.listener.ListenerMetaData
 
getAnnotation() - Method in enum org.springframework.batch.core.listener.StepListenerMetaData
 
getAttribute(String, String, ConfigurableListableBeanFactory) - Static method in class org.springframework.batch.core.configuration.xml.BeanDefinitionUtils
 
getBeanClass(Element) - Method in class org.springframework.batch.core.configuration.xml.AbstractFlowParser
 
getBeanClass() - Method in class org.springframework.batch.core.configuration.xml.AbstractListenerParser
 
getBeanClass() - Method in class org.springframework.batch.core.configuration.xml.JobExecutionListenerParser
 
getBeanClass(Element) - Method in class org.springframework.batch.core.configuration.xml.JobParser
 
getBeanClass() - Method in class org.springframework.batch.core.configuration.xml.StepListenerParser
 
getBeanClass(Element) - Method in class org.springframework.batch.core.configuration.xml.TopLevelJobListenerParser
 
getBeanClass(Element) - Method in class org.springframework.batch.core.configuration.xml.TopLevelStepListenerParser
 
getBeanClassName(Element) - Method in class org.springframework.batch.core.configuration.xml.JobRepositoryParser
 
getBeanFactoryPostProcessorClasses() - Method in class org.springframework.batch.core.configuration.support.AbstractApplicationContextFactory
Protected access to the list of bean factory post processor classes that should be copied over to the context from the parent.
getChunkOperations() - Method in class org.springframework.batch.core.step.factory.SimpleStepFactoryBean
Protected getter for the chunk operations to make them available in subclasses.
getChunkSize() - Method in class org.springframework.batch.core.step.builder.SimpleStepBuilder
 
getClobTypeToUse() - Method in class org.springframework.batch.core.repository.dao.AbstractJdbcBatchMetadataDao
 
getCommitCount() - Method in class org.springframework.batch.core.StepExecution
Returns the current number of commits for this execution
getCompositeListener() - Method in class org.springframework.batch.core.step.AbstractStep
 
getConfigurer(Collection<BatchConfigurer>) - Method in class org.springframework.batch.core.configuration.annotation.AbstractBatchConfiguration
 
getContext() - Static method in class org.springframework.batch.core.scope.context.StepSynchronizationManager
Getter for the current context if there is one, otherwise returns null.
getConversationId() - Method in class org.springframework.batch.core.scope.StepScope
 
getCreateTime() - Method in class org.springframework.batch.core.JobExecution
 
getDate(String) - Method in class org.springframework.batch.core.JobParameters
Typesafe Getter for the Date represented by the provided key.
getDate(String, Date) - Method in class org.springframework.batch.core.JobParameters
Typesafe Getter for the Date represented by the provided key.
getDefaultListenerClass() - Method in class org.springframework.batch.core.listener.AbstractListenerFactoryBean
 
getDefaultListenerClass() - Method in class org.springframework.batch.core.listener.JobListenerFactoryBean
 
getDefaultListenerClass() - Method in class org.springframework.batch.core.listener.StepListenerFactoryBean
 
getDouble(String) - Method in class org.springframework.batch.core.JobParameters
Typesafe Getter for the Long represented by the provided key.
getDouble(String, double) - Method in class org.springframework.batch.core.JobParameters
Typesafe Getter for the Double represented by the provided key.
getEndTime() - Method in class org.springframework.batch.core.JobExecution
 
getEndTime() - Method in class org.springframework.batch.core.StepExecution
Returns the time that this execution ended
getErrorMessage() - Static method in class org.springframework.batch.core.launch.support.CommandLineJobRunner
Retrieve the error message set by an instance of CommandLineJobRunner as it exits.
getErrors() - Static method in class org.springframework.batch.core.launch.support.JobRegistryBackgroundJobRunner
Public getter for the startup errors encountered during parent context creation.
getErrors() - Method in class org.springframework.batch.core.step.item.Chunk
 
getException() - Method in class org.springframework.batch.core.step.item.SkipWrapper
Public getter for the exception.
getExceptionHandler() - Method in class org.springframework.batch.core.step.builder.AbstractTaskletStepBuilder
Convenience method for subclasses to access the exception handler that was injected by user.
getExceptionHandler() - Method in class org.springframework.batch.core.step.factory.SimpleStepFactoryBean
Protected getter for the ExceptionHandler.
getExecutionContext() - Method in class org.springframework.batch.core.JobExecution
Returns the ExecutionContext for this execution.
getExecutionContext(JobExecution) - Method in interface org.springframework.batch.core.repository.dao.ExecutionContextDao
 
getExecutionContext(StepExecution) - Method in interface org.springframework.batch.core.repository.dao.ExecutionContextDao
 
getExecutionContext(JobExecution) - Method in class org.springframework.batch.core.repository.dao.JdbcExecutionContextDao
 
getExecutionContext(StepExecution) - Method in class org.springframework.batch.core.repository.dao.JdbcExecutionContextDao
 
getExecutionContext(StepExecution) - Method in class org.springframework.batch.core.repository.dao.MapExecutionContextDao
 
getExecutionContext(JobExecution) - Method in class org.springframework.batch.core.repository.dao.MapExecutionContextDao
 
getExecutionContext() - Method in class org.springframework.batch.core.StepExecution
Returns the ExecutionContext for this execution
getExecutionContextDao() - Method in class org.springframework.batch.core.repository.support.MapJobRepositoryFactoryBean
 
getExecutions(long) - Method in interface org.springframework.batch.core.launch.JobOperator
List the JobExecutions associated with a particular JobInstance, in reverse order of creation (and therefore usually of execution).
getExecutions(long) - Method in class org.springframework.batch.core.launch.support.SimpleJobOperator
 
getExitCode() - Method in class org.springframework.batch.core.ExitStatus
Getter for the exit code (defaults to blank).
getExitDescription() - Method in class org.springframework.batch.core.ExitStatus
Getter for the exit description (defaults to blank)
getExitStatus() - Method in class org.springframework.batch.core.JobExecution
 
getExitStatus(int) - Method in class org.springframework.batch.core.step.tasklet.ConfigurableSystemProcessExitCodeMapper
 
getExitStatus(int) - Method in class org.springframework.batch.core.step.tasklet.SimpleSystemProcessExitCodeMapper
 
getExitStatus(int) - Method in interface org.springframework.batch.core.step.tasklet.SystemProcessExitCodeMapper
 
getExitStatus() - Method in class org.springframework.batch.core.StepContribution
Public getter for the status.
getExitStatus() - Method in class org.springframework.batch.core.StepExecution
 
getFailureExceptions() - Method in class org.springframework.batch.core.JobExecution
 
getFailureExceptions() - Method in class org.springframework.batch.core.StepExecution
 
getFilterCount(Chunk<I>, Chunk<O>) - Method in class org.springframework.batch.core.step.item.FaultTolerantChunkProcessor
 
getFilterCount(Chunk<I>, Chunk<O>) - Method in class org.springframework.batch.core.step.item.SimpleChunkProcessor
Extension point for subclasses to calculate the filter count.
getFilterCount() - Method in class org.springframework.batch.core.StepContribution
Public getter for the filter counter.
getFilterCount() - Method in class org.springframework.batch.core.StepExecution
Returns the current number of items filtered out of this execution
getFlows() - Method in interface org.springframework.batch.core.job.flow.FlowHolder
 
getFlows() - Method in class org.springframework.batch.core.job.flow.support.state.FlowState
 
getFlows() - Method in class org.springframework.batch.core.job.flow.support.state.SplitState
 
getGridSize() - Method in class org.springframework.batch.core.partition.support.AbstractPartitionHandler
Returns the number of step executions.
getGroupName(BeanDefinition, Job) - Method in class org.springframework.batch.core.configuration.support.JobRegistryBeanPostProcessor
Determine a group name for the job to be registered.
getId() - Method in class org.springframework.batch.core.Entity
 
getId() - Method in class org.springframework.batch.core.scope.context.StepContext
 
getItem() - Method in class org.springframework.batch.core.step.item.SkipWrapper
Public getter for the item.
getItemListeners() - Method in class org.springframework.batch.core.step.builder.SimpleStepBuilder
 
getItemProcessor() - Method in class org.springframework.batch.core.step.factory.SimpleStepFactoryBean
Protected getter for the ItemProcessor for subclasses to use
getItemReader() - Method in class org.springframework.batch.core.step.factory.SimpleStepFactoryBean
Protected getter for the ItemReader for subclasses to use.
getItems() - Method in class org.springframework.batch.core.step.item.Chunk
 
getItemWriter() - Method in class org.springframework.batch.core.step.factory.SimpleStepFactoryBean
Protected getter for the ItemWriter for subclasses to use
getJdbcTemplate() - Method in class org.springframework.batch.core.repository.dao.AbstractJdbcBatchMetadataDao
 
getJob(String) - Method in interface org.springframework.batch.core.configuration.JobLocator
Locates a Job at runtime.
getJob(String) - Method in class org.springframework.batch.core.configuration.support.MapJobRegistry
 
getJobExecution(Long) - Method in interface org.springframework.batch.core.explore.JobExplorer
Retrieve a JobExecution by its id.
getJobExecution(Long) - Method in class org.springframework.batch.core.explore.support.SimpleJobExplorer
 
getJobExecution() - Method in interface org.springframework.batch.core.job.flow.FlowExecutor
 
getJobExecution() - Method in class org.springframework.batch.core.job.flow.JobFlowExecutor
 
getJobExecution(Long) - Method in class org.springframework.batch.core.repository.dao.JdbcJobExecutionDao
 
getJobExecution(Long) - Method in interface org.springframework.batch.core.repository.dao.JobExecutionDao
 
getJobExecution(Long) - Method in class org.springframework.batch.core.repository.dao.MapJobExecutionDao
 
getJobExecution() - Method in class org.springframework.batch.core.StepExecution
Accessor for the execution context information of the enclosing job.
getJobExecutionContext() - Method in class org.springframework.batch.core.scope.context.StepContext
 
getJobExecutionDao() - Method in class org.springframework.batch.core.repository.support.MapJobRepositoryFactoryBean
 
getJobExecutionId() - Method in class org.springframework.batch.core.StepExecution
Accessor for the job execution id.
getJobExecutionListeners() - Method in class org.springframework.batch.core.job.builder.JobBuilderHelper.CommonJobProperties
 
getJobExecutions(JobInstance) - Method in interface org.springframework.batch.core.explore.JobExplorer
Retrieve job executions by their job instance.
getJobExecutions(JobInstance) - Method in class org.springframework.batch.core.explore.support.SimpleJobExplorer
 
getJobId() - Method in class org.springframework.batch.core.JobExecution
Convenience getter for for the id of the enclosing job.
getJobInstance(Long) - Method in interface org.springframework.batch.core.explore.JobExplorer
 
getJobInstance(Long) - Method in class org.springframework.batch.core.explore.support.SimpleJobExplorer
 
getJobInstance() - Method in class org.springframework.batch.core.JobExecution
 
getJobInstance(String, JobParameters) - Method in class org.springframework.batch.core.repository.dao.JdbcJobInstanceDao
The job table is queried for any jobs that match the given identifier, adding them to a list via the RowMapper callback.
getJobInstance(Long) - Method in class org.springframework.batch.core.repository.dao.JdbcJobInstanceDao
 
getJobInstance(JobExecution) - Method in class org.springframework.batch.core.repository.dao.JdbcJobInstanceDao
 
getJobInstance(String, JobParameters) - Method in interface org.springframework.batch.core.repository.dao.JobInstanceDao
Find the job instance that matches the given name and parameters.
getJobInstance(Long) - Method in interface org.springframework.batch.core.repository.dao.JobInstanceDao
Fetch the job instance with the provided identifier.
getJobInstance(JobExecution) - Method in interface org.springframework.batch.core.repository.dao.JobInstanceDao
Fetch the JobInstance for the provided JobExecution.
getJobInstance(String, JobParameters) - Method in class org.springframework.batch.core.repository.dao.MapJobInstanceDao
 
getJobInstance(Long) - Method in class org.springframework.batch.core.repository.dao.MapJobInstanceDao
 
getJobInstance(JobExecution) - Method in class org.springframework.batch.core.repository.dao.MapJobInstanceDao
 
getJobInstanceDao() - Method in class org.springframework.batch.core.repository.support.MapJobRepositoryFactoryBean
 
getJobInstances(String, int, int) - Method in interface org.springframework.batch.core.explore.JobExplorer
Fetch JobInstance values in descending order of creation (and therefore usually of first execution).
getJobInstances(String, int, int) - Method in class org.springframework.batch.core.explore.support.SimpleJobExplorer
 
getJobInstances(String, int, int) - Method in interface org.springframework.batch.core.launch.JobOperator
List the JobInstances for a given job name, in reverse order of creation (and therefore usually of first execution).
getJobInstances(String, int, int) - Method in class org.springframework.batch.core.launch.support.SimpleJobOperator
 
getJobInstances(String, int, int) - Method in class org.springframework.batch.core.repository.dao.JdbcJobInstanceDao
 
getJobInstances(String, int, int) - Method in interface org.springframework.batch.core.repository.dao.JobInstanceDao
Fetch the last job instances with the provided name, sorted backwards by primary key.
getJobInstances(String, int, int) - Method in class org.springframework.batch.core.repository.dao.MapJobInstanceDao
 
getJobLauncher() - Method in interface org.springframework.batch.core.configuration.annotation.BatchConfigurer
 
getJobLauncher() - Method in class org.springframework.batch.core.configuration.annotation.DefaultBatchConfigurer
 
getJobName() - Method in interface org.springframework.batch.core.configuration.JobFactory
 
getJobName() - Method in class org.springframework.batch.core.configuration.support.ApplicationContextJobFactory
Just return the name of instance passed in on initialization.
getJobName() - Method in class org.springframework.batch.core.configuration.support.ReferenceJobFactory
Just return the name of instance passed in on initialization.
getJobName() - Method in class org.springframework.batch.core.JobInstance
 
getJobName() - Method in class org.springframework.batch.core.scope.context.StepContext
Convenient accessor for current job name identifier.
getJobNames() - Method in interface org.springframework.batch.core.configuration.ListableJobLocator
Provides the currently registered job names.
getJobNames() - Method in class org.springframework.batch.core.configuration.support.MapJobRegistry
Provides an unmodifiable view of the job names.
getJobNames() - Method in interface org.springframework.batch.core.explore.JobExplorer
Query the repository for all unique JobInstance names (sorted alphabetically).
getJobNames() - Method in class org.springframework.batch.core.explore.support.SimpleJobExplorer
 
getJobNames() - Method in interface org.springframework.batch.core.launch.JobOperator
List the available job names that can be launched with JobOperator.start(String, String).
getJobNames() - Method in class org.springframework.batch.core.launch.support.SimpleJobOperator
 
getJobNames() - Method in class org.springframework.batch.core.repository.dao.JdbcJobInstanceDao
 
getJobNames() - Method in interface org.springframework.batch.core.repository.dao.JobInstanceDao
Retrieve the names of all job instances sorted alphabetically - i.e.
getJobNames() - Method in class org.springframework.batch.core.repository.dao.MapJobInstanceDao
 
getJobParameters(Properties) - Method in class org.springframework.batch.core.converter.DefaultJobParametersConverter
Check for suffix on keys and use those to decide how to convert the value.
getJobParameters(Properties) - Method in interface org.springframework.batch.core.converter.JobParametersConverter
Get a new JobParameters instance.
getJobParameters() - Method in class org.springframework.batch.core.JobExecution
 
getJobParameters(Properties) - Method in class org.springframework.batch.core.launch.support.ScheduledJobParametersFactory
 
getJobParameters(Long) - Method in class org.springframework.batch.core.repository.dao.JdbcJobExecutionDao
 
getJobParameters() - Method in class org.springframework.batch.core.scope.context.StepContext
 
getJobParameters(Job, StepExecution) - Method in class org.springframework.batch.core.step.job.DefaultJobParametersExtractor
 
getJobParameters(Job, StepExecution) - Method in interface org.springframework.batch.core.step.job.JobParametersExtractor
Extract job parameters from the step execution, for example from the execution context or other properties.
getJobParameters() - Method in class org.springframework.batch.core.StepExecution
Convenience method to get the current job parameters.
getJobParametersIncrementer() - Method in class org.springframework.batch.core.configuration.support.GroupAwareJob
 
getJobParametersIncrementer() - Method in class org.springframework.batch.core.job.AbstractJob
 
getJobParametersIncrementer() - Method in class org.springframework.batch.core.job.builder.JobBuilderHelper.CommonJobProperties
 
getJobParametersIncrementer() - Method in interface org.springframework.batch.core.Job
If clients need to generate new parameters for the next execution in a sequence they can use this incrementer.
getJobParametersValidator() - Method in class org.springframework.batch.core.configuration.support.GroupAwareJob
 
getJobParametersValidator() - Method in class org.springframework.batch.core.job.AbstractJob
 
getJobParametersValidator() - Method in class org.springframework.batch.core.job.builder.JobBuilderHelper.CommonJobProperties
 
getJobParametersValidator() - Method in interface org.springframework.batch.core.Job
A validator for the job parameters of a JobExecution.
getJobRepository() - Method in interface org.springframework.batch.core.configuration.annotation.BatchConfigurer
 
getJobRepository() - Method in class org.springframework.batch.core.configuration.annotation.DefaultBatchConfigurer
 
getJobRepository() - Method in class org.springframework.batch.core.job.AbstractJob
Convenience method for subclasses to access the job repository.
getJobRepository() - Method in class org.springframework.batch.core.job.builder.JobBuilderHelper.CommonJobProperties
 
getJobRepository() - Method in class org.springframework.batch.core.job.builder.JobBuilderHelper
 
getJobRepository() - Method in class org.springframework.batch.core.repository.support.AbstractJobRepositoryFactoryBean
Convenience method for clients to grab the JobRepository without a cast.
getJobRepository() - Method in class org.springframework.batch.core.step.AbstractStep
 
getJobRepository() - Method in class org.springframework.batch.core.step.builder.StepBuilderHelper.CommonStepProperties
 
getJobRepository() - Method in class org.springframework.batch.core.step.builder.StepBuilderHelper
 
getKey(Object) - Method in interface org.springframework.batch.core.step.item.KeyGenerator
 
getLastJobExecution(JobInstance) - Method in class org.springframework.batch.core.repository.dao.JdbcJobExecutionDao
 
getLastJobExecution(JobInstance) - Method in interface org.springframework.batch.core.repository.dao.JobExecutionDao
Find the last JobExecution to have been created for a given JobInstance.
getLastJobExecution(JobInstance) - Method in class org.springframework.batch.core.repository.dao.MapJobExecutionDao
 
getLastJobExecution(String, JobParameters) - Method in interface org.springframework.batch.core.repository.JobRepository
 
getLastJobExecution(String, JobParameters) - Method in class org.springframework.batch.core.repository.support.SimpleJobRepository
 
getLastStepExecution(JobInstance, String) - Method in interface org.springframework.batch.core.repository.JobRepository
 
getLastStepExecution(JobInstance, String) - Method in class org.springframework.batch.core.repository.support.SimpleJobRepository
 
getLastUpdated() - Method in class org.springframework.batch.core.JobExecution
Get the date representing the last time this JobExecution was updated in the JobRepository.
getLastUpdated() - Method in class org.springframework.batch.core.StepExecution
 
getListener(Object) - Static method in class org.springframework.batch.core.listener.JobListenerFactoryBean
Convenience method to wrap any object and expose the appropriate JobExecutionListener interfaces.
getListener(Object) - Static method in class org.springframework.batch.core.listener.StepListenerFactoryBean
Convenience method to wrap any object and expose the appropriate StepListener interfaces.
getListener() - Method in class org.springframework.batch.core.step.item.SimpleChunkProcessor
 
getListener() - Method in class org.springframework.batch.core.step.item.SimpleChunkProvider
 
getListenerInterface() - Method in enum org.springframework.batch.core.listener.JobListenerMetaData
 
getListenerInterface() - Method in interface org.springframework.batch.core.listener.ListenerMetaData
 
getListenerInterface() - Method in enum org.springframework.batch.core.listener.StepListenerMetaData
 
getListeners() - Method in class org.springframework.batch.core.step.factory.SimpleStepFactoryBean
Protected getter for the StepListeners.
getLong(String) - Method in class org.springframework.batch.core.JobParameters
Typesafe Getter for the Long represented by the provided key.
getLong(String, long) - Method in class org.springframework.batch.core.JobParameters
Typesafe Getter for the Long represented by the provided key.
getMapping() - Method in class org.springframework.batch.core.launch.support.SimpleJvmExitCodeMapper
 
getMetaDataFromPropertyName(String) - Method in class org.springframework.batch.core.listener.AbstractListenerFactoryBean
 
getMetaDataFromPropertyName(String) - Method in class org.springframework.batch.core.listener.JobListenerFactoryBean
 
getMetaDataFromPropertyName(String) - Method in class org.springframework.batch.core.listener.StepListenerFactoryBean
 
getMetaDataValues() - Method in class org.springframework.batch.core.configuration.xml.AbstractListenerParser
 
getMetaDataValues() - Method in class org.springframework.batch.core.configuration.xml.JobExecutionListenerParser
 
getMetaDataValues() - Method in class org.springframework.batch.core.configuration.xml.StepListenerParser
 
getMetaDataValues() - Method in class org.springframework.batch.core.listener.AbstractListenerFactoryBean
 
getMetaDataValues() - Method in class org.springframework.batch.core.listener.JobListenerFactoryBean
 
getMetaDataValues() - Method in class org.springframework.batch.core.listener.StepListenerFactoryBean
 
getMethodInvokerByName(String, Object, Class<?>...) - Method in class org.springframework.batch.core.listener.AbstractListenerFactoryBean
 
getMethodName() - Method in enum org.springframework.batch.core.listener.JobListenerMetaData
 
getMethodName() - Method in interface org.springframework.batch.core.listener.ListenerMetaData
 
getMethodName() - Method in enum org.springframework.batch.core.listener.StepListenerMetaData
 
getName() - Method in class org.springframework.batch.core.configuration.support.GroupAwareJob
Concatenates the group name and the delegate job name (joining with a ".").
getName() - Method in class org.springframework.batch.core.job.AbstractJob
 
getName() - Method in class org.springframework.batch.core.job.builder.JobBuilderHelper.CommonJobProperties
 
getName() - Method in class org.springframework.batch.core.job.builder.JobBuilderHelper
 
getName() - Method in interface org.springframework.batch.core.job.flow.Flow
 
getName() - Method in class org.springframework.batch.core.job.flow.FlowExecution
 
getName() - Method in class org.springframework.batch.core.job.flow.FlowExecutionStatus
 
getName() - Method in interface org.springframework.batch.core.job.flow.State
The name of the state.
getName() - Method in class org.springframework.batch.core.job.flow.support.SimpleFlow
Get the name for this flow.
getName() - Method in class org.springframework.batch.core.job.flow.support.state.AbstractState
 
getName() - Method in interface org.springframework.batch.core.Job
 
getName() - Method in class org.springframework.batch.core.step.AbstractStep
 
getName() - Method in class org.springframework.batch.core.step.builder.StepBuilderHelper.CommonStepProperties
 
getName() - Method in class org.springframework.batch.core.step.builder.StepBuilderHelper
 
getName() - Method in class org.springframework.batch.core.step.factory.SimpleStepFactoryBean
Public getter for the name of the step.
getName() - Method in interface org.springframework.batch.core.Step
 
getNext() - Method in class org.springframework.batch.core.job.flow.support.StateTransition
Public getter for the next State name.
getNext(JobParameters) - Method in interface org.springframework.batch.core.JobParametersIncrementer
Increment the provided parameters.
getNext(JobParameters) - Method in class org.springframework.batch.core.launch.support.RunIdIncrementer
Increment the run.id parameter (starting with 1).
getNextElements(ParserContext, BeanDefinition, Element) - Static method in class org.springframework.batch.core.configuration.xml.AbstractFlowParser
 
getNextElements(ParserContext, String, BeanDefinition, Element) - Static method in class org.springframework.batch.core.configuration.xml.AbstractFlowParser
 
getObject() - Method in class org.springframework.batch.core.configuration.support.ClasspathXmlApplicationContextsFactoryBean
getObject() - Method in class org.springframework.batch.core.configuration.xml.SimpleFlowFactoryBean
 
getObject() - Method in class org.springframework.batch.core.explore.support.JobExplorerFactoryBean
 
getObject() - Method in class org.springframework.batch.core.explore.support.MapJobExplorerFactoryBean
 
getObject() - Method in class org.springframework.batch.core.listener.AbstractListenerFactoryBean
 
getObject() - Method in class org.springframework.batch.core.repository.support.AbstractJobRepositoryFactoryBean
 
getObject() - Method in class org.springframework.batch.core.step.factory.SimpleStepFactoryBean
Create a Step from the configuration provided.
getObject() - Method in class org.springframework.batch.core.step.StepLocatorStepFactoryBean
 
getObjectType() - Method in class org.springframework.batch.core.configuration.support.ClasspathXmlApplicationContextsFactoryBean
The type of object returned by this factory - an array of ApplicationContextFactory.
getObjectType() - Method in class org.springframework.batch.core.configuration.xml.SimpleFlowFactoryBean
 
getObjectType() - Method in class org.springframework.batch.core.explore.support.AbstractJobExplorerFactoryBean
The type of object to be returned from FactoryBean.getObject().
getObjectType() - Method in class org.springframework.batch.core.listener.JobListenerFactoryBean
 
getObjectType() - Method in class org.springframework.batch.core.listener.StepListenerFactoryBean
 
getObjectType() - Method in class org.springframework.batch.core.repository.support.AbstractJobRepositoryFactoryBean
The type of object to be returned from AbstractJobRepositoryFactoryBean.getObject().
getObjectType() - Method in class org.springframework.batch.core.step.factory.SimpleStepFactoryBean
 
getObjectType() - Method in class org.springframework.batch.core.step.StepLocatorStepFactoryBean
Tell clients that we are a factory for Step instances.
getOffset() - Method in class org.springframework.batch.core.step.item.ChunkMonitor
 
getOrder() - Method in class org.springframework.batch.core.configuration.support.AutomaticJobRegistrar
 
getOrder() - Method in class org.springframework.batch.core.scope.StepScope
 
getParameters() - Method in class org.springframework.batch.core.JobParameters
Get a map of all parameters, including string, long, and date.
getParameters(long) - Method in interface org.springframework.batch.core.launch.JobOperator
Get the JobParameters as an easily readable String.
getParameters(long) - Method in class org.springframework.batch.core.launch.support.SimpleJobOperator
 
getParamTypes() - Method in enum org.springframework.batch.core.listener.JobListenerMetaData
 
getParamTypes() - Method in interface org.springframework.batch.core.listener.ListenerMetaData
 
getParamTypes() - Method in enum org.springframework.batch.core.listener.StepListenerMetaData
 
getPartitionNames(int) - Method in interface org.springframework.batch.core.partition.support.PartitionNameProvider
 
getProcessor() - Method in class org.springframework.batch.core.step.builder.SimpleStepBuilder
 
getProcessSkipCount() - Method in class org.springframework.batch.core.StepContribution
Public getter for the process skip count.
getProcessSkipCount() - Method in class org.springframework.batch.core.StepExecution
 
getProperties(JobParameters) - Method in class org.springframework.batch.core.converter.DefaultJobParametersConverter
Use the same suffixes to create properties (omitting the string suffix because it is the default).
getProperties(JobParameters) - Method in interface org.springframework.batch.core.converter.JobParametersConverter
The inverse operation: get a Properties instance.
getProperties(JobParameters) - Method in class org.springframework.batch.core.launch.support.ScheduledJobParametersFactory
Convert schedule date to Date, and assume all other parameters can be represented by their default string value.
getPropertyName() - Method in enum org.springframework.batch.core.listener.JobListenerMetaData
 
getPropertyName() - Method in interface org.springframework.batch.core.listener.ListenerMetaData
 
getPropertyName() - Method in enum org.springframework.batch.core.listener.StepListenerMetaData
 
getPropertyValue(String, String, ConfigurableListableBeanFactory) - Static method in class org.springframework.batch.core.configuration.xml.BeanDefinitionUtils
 
getQuery(String) - Method in class org.springframework.batch.core.repository.dao.AbstractJdbcBatchMetadataDao
 
getReadCount() - Method in class org.springframework.batch.core.StepContribution
Public access to the read counter.
getReadCount() - Method in class org.springframework.batch.core.StepExecution
Returns the current number of items read for this execution
getReader() - Method in class org.springframework.batch.core.step.builder.SimpleStepBuilder
 
getReadSkipCount() - Method in class org.springframework.batch.core.StepContribution
 
getReadSkipCount() - Method in class org.springframework.batch.core.StepExecution
 
getRestartable() - Method in class org.springframework.batch.core.job.builder.JobBuilderHelper.CommonJobProperties
 
getRollbackCount() - Method in class org.springframework.batch.core.StepExecution
Returns the current number of rollbacks for this execution
getRunningExecutions(String) - Method in interface org.springframework.batch.core.launch.JobOperator
Get the id values of all the running JobExecutions with the given job name.
getRunningExecutions(String) - Method in class org.springframework.batch.core.launch.support.SimpleJobOperator
 
getSkipCount() - Method in class org.springframework.batch.core.StepContribution
 
getSkipCount() - Method in class org.springframework.batch.core.StepExecution
 
getSkipLimit() - Method in exception org.springframework.batch.core.step.skip.SkipLimitExceededException
 
getSkips() - Method in class org.springframework.batch.core.step.item.Chunk
 
getStartLimit() - Method in class org.springframework.batch.core.step.AbstractStep
 
getStartLimit() - Method in class org.springframework.batch.core.step.builder.StepBuilderHelper.CommonStepProperties
 
getStartLimit() - Method in interface org.springframework.batch.core.Step
 
getStartTime() - Method in class org.springframework.batch.core.JobExecution
 
getStartTime() - Method in class org.springframework.batch.core.StepExecution
Gets the time this execution started
getState(String) - Method in interface org.springframework.batch.core.job.flow.Flow
Retrieve the State with the given name.
getState(String) - Method in class org.springframework.batch.core.job.flow.support.SimpleFlow
Retrieve the State with the given name.
getState() - Method in class org.springframework.batch.core.job.flow.support.StateTransition
Public getter for the State.
getStates() - Method in interface org.springframework.batch.core.job.flow.Flow
Convenient accessor for clients needing to explore the states of this flow.
getStates() - Method in class org.springframework.batch.core.job.flow.support.SimpleFlow
Convenient accessor for clients needing to explore the states of this flow.
getStateTransitionReference(ParserContext, BeanDefinition, String, String) - Static method in class org.springframework.batch.core.configuration.xml.AbstractFlowParser
 
getStatus() - Method in class org.springframework.batch.core.job.flow.FlowExecution
 
getStatus() - Method in class org.springframework.batch.core.JobExecution
 
getStatus() - Method in exception org.springframework.batch.core.JobInterruptedException
The desired status of the surrounding execution after the interruption.
getStatus() - Method in class org.springframework.batch.core.StepExecution
Returns the current status of this step
getStep(String, String) - Method in interface org.springframework.batch.core.configuration.StepRegistry
Returns the Step of the specified job based on its name.
getStep(String, String) - Method in class org.springframework.batch.core.configuration.support.MapStepRegistry
 
getStep(String) - Method in class org.springframework.batch.core.job.AbstractJob
Retrieve the step with the given name.
getStep(String) - Method in class org.springframework.batch.core.job.flow.FlowJob
Retrieve the step with the given name.
getStep() - Method in class org.springframework.batch.core.job.flow.support.state.StepState
 
getStep(String) - Method in class org.springframework.batch.core.job.SimpleJob
 
getStep() - Method in class org.springframework.batch.core.partition.support.TaskExecutorPartitionHandler
The step instance that will be executed in parallel by this handler.
getStep() - Method in interface org.springframework.batch.core.step.StepHolder
 
getStep(String) - Method in interface org.springframework.batch.core.step.StepLocator
 
getStepContext() - Method in class org.springframework.batch.core.scope.context.ChunkContext
 
getStepExecution(Long, Long) - Method in interface org.springframework.batch.core.explore.JobExplorer
Retrieve a StepExecution by its id and parent JobExecution id.
getStepExecution(Long, Long) - Method in class org.springframework.batch.core.explore.support.SimpleJobExplorer
 
getStepExecution() - Method in interface org.springframework.batch.core.job.flow.FlowExecutor
 
getStepExecution() - Method in class org.springframework.batch.core.job.flow.JobFlowExecutor
 
getStepExecution(JobExecution, Long) - Method in class org.springframework.batch.core.repository.dao.JdbcStepExecutionDao
 
getStepExecution(JobExecution, Long) - Method in class org.springframework.batch.core.repository.dao.MapStepExecutionDao
 
getStepExecution(JobExecution, Long) - Method in interface org.springframework.batch.core.repository.dao.StepExecutionDao
Retrieve a StepExecution from its id.
getStepExecution() - Method in class org.springframework.batch.core.scope.context.StepContext
The current StepExecution that is active in this context.
getStepExecutionContext() - Method in class org.springframework.batch.core.scope.context.StepContext
 
getStepExecutionCount(JobInstance, String) - Method in interface org.springframework.batch.core.repository.JobRepository
 
getStepExecutionCount(JobInstance, String) - Method in class org.springframework.batch.core.repository.support.SimpleJobRepository
 
getStepExecutionDao() - Method in class org.springframework.batch.core.repository.support.MapJobRepositoryFactoryBean
 
getStepExecutionListeners() - Method in class org.springframework.batch.core.step.builder.StepBuilderHelper.CommonStepProperties
 
getStepExecutions() - Method in class org.springframework.batch.core.JobExecution
Accessor for the step executions.
getStepExecutionSummaries(long) - Method in interface org.springframework.batch.core.launch.JobOperator
Summarise the StepExecution instances belonging to the JobExecution with the supplied id, giving details of status, start and end times etc.
getStepExecutionSummaries(long) - Method in class org.springframework.batch.core.launch.support.SimpleJobOperator
 
getStepName() - Method in interface org.springframework.batch.core.partition.StepExecutionSplitter
The name of the step configuration that will be executed remotely.
getStepName() - Method in class org.springframework.batch.core.partition.support.SimpleStepExecutionSplitter
 
getStepName() - Method in class org.springframework.batch.core.scope.context.StepContext
Convenient accessor for current step name identifier.
getStepName() - Method in class org.springframework.batch.core.StepExecution
 
getStepNames() - Method in class org.springframework.batch.core.job.AbstractJob
Retrieve the step names.
getStepNames() - Method in class org.springframework.batch.core.job.flow.FlowJob
Retrieve the step names.
getStepNames() - Method in class org.springframework.batch.core.job.SimpleJob
Convenience method for clients to inspect the steps for this job.
getStepNames() - Method in interface org.springframework.batch.core.step.StepLocator
 
getStepOperations() - Method in class org.springframework.batch.core.step.builder.AbstractTaskletStepBuilder
Convenience method for subclasses to access the step operations that were injected by user.
getStepOperations() - Method in class org.springframework.batch.core.step.factory.SimpleStepFactoryBean
Protected getter for the step operations to make them available in subclasses.
getStepSkipCount() - Method in class org.springframework.batch.core.StepContribution
 
getString(String) - Method in class org.springframework.batch.core.JobParameters
Typesafe Getter for the String represented by the provided key.
getString(String, String) - Method in class org.springframework.batch.core.JobParameters
Typesafe Getter for the String represented by the provided key.
getSummary(long) - Method in interface org.springframework.batch.core.launch.JobOperator
Summarise the JobExecution with the supplied id, giving details of status, start and end times etc.
getSummary(long) - Method in class org.springframework.batch.core.launch.support.SimpleJobOperator
 
getSummary() - Method in class org.springframework.batch.core.StepExecution
 
getSystemProperties() - Method in class org.springframework.batch.core.scope.context.StepContext
Convenient accessor for System properties to make it easy to access them from placeholder expressions.
getTablePrefix() - Method in class org.springframework.batch.core.repository.dao.AbstractJdbcBatchMetadataDao
 
getTaskExecutor() - Method in class org.springframework.batch.core.step.factory.SimpleStepFactoryBean
Mkae the TaskExecutor available to subclasses
getTransactionAttribute() - Method in class org.springframework.batch.core.step.factory.SimpleStepFactoryBean
Getter for the TransactionAttribute for subclasses only.
getTransactionManager() - Method in interface org.springframework.batch.core.configuration.annotation.BatchConfigurer
 
getTransactionManager() - Method in class org.springframework.batch.core.configuration.annotation.DefaultBatchConfigurer
 
getTransactionManager() - Method in class org.springframework.batch.core.repository.support.AbstractJobRepositoryFactoryBean
The transaction manager used in this factory.
getTransactionManager() - Method in class org.springframework.batch.core.step.builder.StepBuilderHelper.CommonStepProperties
 
getTransactionManager() - Method in class org.springframework.batch.core.step.builder.StepBuilderHelper
 
getType() - Method in class org.springframework.batch.core.JobParameter
 
getUserData() - Method in class org.springframework.batch.core.step.item.Chunk
 
getValue() - Method in class org.springframework.batch.core.JobParameter
 
getVersion() - Method in class org.springframework.batch.core.Entity
 
getWriteCount() - Method in class org.springframework.batch.core.StepContribution
Public access to the write counter.
getWriteCount() - Method in class org.springframework.batch.core.StepExecution
Returns the current number of items written for this execution
getWriter() - Method in class org.springframework.batch.core.step.builder.SimpleStepBuilder
 
getWriteSkipCount() - Method in class org.springframework.batch.core.StepContribution
 
getWriteSkipCount() - Method in class org.springframework.batch.core.StepExecution
 
gridSize(int) - Method in class org.springframework.batch.core.step.builder.PartitionStepBuilder
A hint to the PartitionStepBuilder.splitter(StepExecutionSplitter) about how many step executions are required.
GroupAwareJob - Class in org.springframework.batch.core.configuration.support
A Job that can optionally prepend a group name to another job's name, to make it fit a naming convention for type or origin.
GroupAwareJob(Job) - Constructor for class org.springframework.batch.core.configuration.support.GroupAwareJob
Create a new Job with the delegate and no group name.
GroupAwareJob(String, Job) - Constructor for class org.springframework.batch.core.configuration.support.GroupAwareJob
Create a new Job with the given group name and delegate.

H

handle(FlowExecutor) - Method in interface org.springframework.batch.core.job.flow.State
Handle some business or processing logic and return a status that can be used to drive a flow to the next State.
handle(FlowExecutor) - Method in class org.springframework.batch.core.job.flow.support.state.AbstractState
 
handle(FlowExecutor) - Method in class org.springframework.batch.core.job.flow.support.state.DecisionState
 
handle(FlowExecutor) - Method in class org.springframework.batch.core.job.flow.support.state.EndState
Return the FlowExecutionStatus stored.
handle(FlowExecutor) - Method in class org.springframework.batch.core.job.flow.support.state.FlowState
 
handle(FlowExecutor) - Method in class org.springframework.batch.core.job.flow.support.state.SplitState
Execute the flows in parallel by passing them to the TaskExecutor and wait for all of them to finish before proceeding.
handle(FlowExecutor) - Method in class org.springframework.batch.core.job.flow.support.state.StepState
 
handle(StepExecutionSplitter, StepExecution) - Method in interface org.springframework.batch.core.partition.PartitionHandler
Main entry point for PartitionHandler interface.
handle(StepExecutionSplitter, StepExecution) - Method in class org.springframework.batch.core.partition.support.AbstractPartitionHandler
 
handleException(RepeatContext, Throwable) - Method in class org.springframework.batch.core.step.item.SimpleRetryExceptionHandler
Check if the exception is going to be retried, and veto the handling if it is.
handleListenersElement(Element, BeanDefinition, ParserContext) - Method in class org.springframework.batch.core.configuration.xml.StepListenerParser
 
handleStep(Step, JobExecution) - Method in class org.springframework.batch.core.job.AbstractJob
Convenience method for subclasses to delegate the handling of a specific step in the context of the current JobExecution.
handleStep(Step, JobExecution) - Method in class org.springframework.batch.core.job.SimpleStepHandler
 
handleStep(Step, JobExecution) - Method in interface org.springframework.batch.core.job.StepHandler
Handle a step and return the execution for it.
hashCode() - Method in class org.springframework.batch.core.configuration.support.AbstractApplicationContextFactory
 
hashCode() - Method in class org.springframework.batch.core.configuration.support.GroupAwareJob
 
hashCode() - Method in class org.springframework.batch.core.configuration.support.OsgiBundleXmlApplicationContextFactory
 
hashCode() - Method in class org.springframework.batch.core.Entity
Use ID if it exists to establish hash code, otherwise fall back to Object.hashCode().
hashCode() - Method in class org.springframework.batch.core.ExitStatus
Compatible with the equals implementation.
hashCode() - Method in class org.springframework.batch.core.job.flow.FlowExecutionStatus
 
hashCode() - Method in class org.springframework.batch.core.JobParameter
 
hashCode() - Method in class org.springframework.batch.core.JobParameters
 
hashCode() - Method in class org.springframework.batch.core.listener.MethodInvokerMethodInterceptor
hashCode() - Method in class org.springframework.batch.core.scope.context.StepContext
Overrides the default behaviour to provide a hash code based only on the step execution.
hashCode() - Method in class org.springframework.batch.core.StepContribution
 
hashCode() - Method in class org.springframework.batch.core.StepExecution
 
hasNext() - Method in class org.springframework.batch.core.step.item.Chunk.ChunkIterator
 

I

ID_ATTR - Static variable in class org.springframework.batch.core.configuration.xml.AbstractStepParser
 
ID_KEY - Static variable in class org.springframework.batch.core.scope.StepScope
Context key for clients to use for conversation identifier.
incrementCommitCount() - Method in class org.springframework.batch.core.StepExecution
Increment the number of commits
incrementer(JobParametersIncrementer) - Method in class org.springframework.batch.core.job.builder.JobBuilderHelper
Add a job parameters incrementer.
incrementFilterCount(int) - Method in class org.springframework.batch.core.StepContribution
Increment the counter for the number of items processed.
incrementOffset() - Method in class org.springframework.batch.core.step.item.ChunkMonitor
 
incrementProcessSkipCount() - Method in class org.springframework.batch.core.StepContribution
 
incrementReadCount() - Method in class org.springframework.batch.core.StepContribution
Increment the counter for the number of items read.
incrementReadSkipCount() - Method in class org.springframework.batch.core.StepContribution
Increment the read skip count for this contribution
incrementReadSkipCount(int) - Method in class org.springframework.batch.core.StepContribution
Increment the read skip count for this contribution
incrementRollbackCount() - Method in class org.springframework.batch.core.StepExecution
On unsuccessful execution after a chunk has rolled back.
incrementVersion() - Method in class org.springframework.batch.core.Entity
Increment the version number
incrementWriteCount(int) - Method in class org.springframework.batch.core.StepContribution
Increment the counter for the number of items written.
incrementWriteSkipCount() - Method in class org.springframework.batch.core.StepContribution
Increment the write skip count for this contribution
init() - Method in class org.springframework.batch.core.configuration.xml.CoreNamespaceHandler
 
init() - Method in class org.springframework.batch.core.repository.dao.XStreamExecutionContextStringSerializer
 
initialize() - Method in class org.springframework.batch.core.configuration.annotation.DefaultBatchConfigurer
 
initialize() - Method in class org.springframework.batch.core.configuration.annotation.SimpleBatchConfiguration
Sets up the basic components by extracting them from the configurer, defaulting to some sensible values as long as a unique DataSource is available.
initializeUserData(Chunk<I>) - Method in class org.springframework.batch.core.step.item.FaultTolerantChunkProcessor
 
initializeUserData(Chunk<I>) - Method in class org.springframework.batch.core.step.item.SimpleChunkProcessor
Extension point for subclasses to allow them to memorise the contents of the inputs, in case they are needed for accounting purposes later.
InlineFlowParser - Class in org.springframework.batch.core.configuration.xml
 
InlineFlowParser(String, String) - Constructor for class org.springframework.batch.core.configuration.xml.InlineFlowParser
Construct a InlineFlowParser with the specified name and using the provided job repository ref.
InlineStepParser - Class in org.springframework.batch.core.configuration.xml
Internal parser for the <step/> elements inside a job.
InlineStepParser() - Constructor for class org.springframework.batch.core.configuration.xml.InlineStepParser
 
intValue(String) - Method in interface org.springframework.batch.core.launch.support.ExitCodeMapper
Convert the exit code from String into an integer that the calling environment as an operating system can interpret as an exit status.
intValue(String) - Method in class org.springframework.batch.core.launch.support.SimpleJvmExitCodeMapper
Get the operating system exit status that matches a certain Batch Framework Exitcode
invoke(MethodInvocation) - Method in class org.springframework.batch.core.launch.support.RuntimeExceptionTranslator
 
invoke(MethodInvocation) - Method in class org.springframework.batch.core.listener.MethodInvokerMethodInterceptor
 
isAbstract(Element) - Static method in class org.springframework.batch.core.configuration.xml.CoreNamespaceUtils
 
isAllowStartIfComplete() - Method in class org.springframework.batch.core.step.AbstractStep
 
isAllowStartIfComplete() - Method in class org.springframework.batch.core.step.builder.StepBuilderHelper
 
isAllowStartIfComplete() - Method in interface org.springframework.batch.core.Step
 
isBusy() - Method in class org.springframework.batch.core.step.item.Chunk
Query the chunk to see if anyone has registered an interest in keeping a reference to it.
isComplete(RepeatContext, RepeatStatus) - Method in class org.springframework.batch.core.resource.StepExecutionSimpleCompletionPolicy
 
isComplete(RepeatContext) - Method in class org.springframework.batch.core.resource.StepExecutionSimpleCompletionPolicy
 
isComplete() - Method in class org.springframework.batch.core.scope.context.ChunkContext
 
isComplete(Chunk<I>) - Method in class org.springframework.batch.core.step.item.FaultTolerantChunkProcessor
 
isComplete(Chunk<I>) - Method in class org.springframework.batch.core.step.item.SimpleChunkProcessor
Extension point for subclasses that want to store additional data in the inputs.
isCopyConfiguration() - Method in class org.springframework.batch.core.configuration.support.AbstractApplicationContextFactory
Protected access for subclasses to the flag determining whether configuration should be copied from parent context.
isEmpty() - Method in class org.springframework.batch.core.JobParameters
 
isEmpty() - Method in class org.springframework.batch.core.step.item.Chunk
 
isEnd() - Method in class org.springframework.batch.core.job.flow.FlowExecutionStatus
 
isEnd() - Method in class org.springframework.batch.core.job.flow.support.StateTransition
Check for a special next State signalling the end of a job.
isEnd() - Method in class org.springframework.batch.core.step.item.Chunk
Flag to indicate if the source data is exhausted.
isEndState() - Method in interface org.springframework.batch.core.job.flow.State
Inquire as to whether a State is an end state.
isEndState() - Method in class org.springframework.batch.core.job.flow.support.state.DecisionState
 
isEndState() - Method in class org.springframework.batch.core.job.flow.support.state.EndState
 
isEndState() - Method in class org.springframework.batch.core.job.flow.support.state.FlowState
 
isEndState() - Method in class org.springframework.batch.core.job.flow.support.state.SplitState
 
isEndState() - Method in class org.springframework.batch.core.job.flow.support.state.StepState
 
isFail() - Method in class org.springframework.batch.core.job.flow.FlowExecutionStatus
 
isGreaterThan(BatchStatus) - Method in enum org.springframework.batch.core.BatchStatus
 
isIdentifying() - Method in class org.springframework.batch.core.JobParameter
 
isJobInstanceExists(String, JobParameters) - Method in interface org.springframework.batch.core.repository.JobRepository
Check if an instance of this job already exists with the parameters provided.
isJobInstanceExists(String, JobParameters) - Method in class org.springframework.batch.core.repository.support.SimpleJobRepository
 
isLessThan(BatchStatus) - Method in enum org.springframework.batch.core.BatchStatus
 
isLessThanOrEqualTo(BatchStatus) - Method in enum org.springframework.batch.core.BatchStatus
 
isListener(Object, Class<?>, ListenerMetaData[]) - Static method in class org.springframework.batch.core.listener.AbstractListenerFactoryBean
Convenience method to check whether the given object is or can be made into a listener.
isListener(Object) - Static method in class org.springframework.batch.core.listener.JobListenerFactoryBean
Convenience method to check whether the given object is or can be made into a JobExecutionListener.
isListener(Object) - Static method in class org.springframework.batch.core.listener.StepListenerFactoryBean
Convenience method to check whether the given object is or can be made into a StepListener.
isReaderTransactionalQueue() - Method in class org.springframework.batch.core.step.builder.SimpleStepBuilder
 
isReaderTransactionalQueue() - Method in class org.springframework.batch.core.step.factory.SimpleStepFactoryBean
Convenience method for subclasses.
isRestart() - Method in interface org.springframework.batch.core.job.flow.FlowExecutor
 
isRestart() - Method in class org.springframework.batch.core.job.flow.JobFlowExecutor
 
isRestartable() - Method in class org.springframework.batch.core.configuration.support.GroupAwareJob
 
isRestartable() - Method in class org.springframework.batch.core.job.AbstractJob
 
isRestartable() - Method in class org.springframework.batch.core.job.builder.JobBuilderHelper
 
isRestartable() - Method in interface org.springframework.batch.core.Job
Flag to indicate if this job can be restarted, at least in principle.
isRunning() - Method in enum org.springframework.batch.core.BatchStatus
Convenience method to decide if a status indicates work is in progress.
isRunning() - Method in class org.springframework.batch.core.configuration.support.AutomaticJobRegistrar
Check if this component has been started.
isRunning() - Method in class org.springframework.batch.core.ExitStatus
Check if this status represents a running process.
isRunning() - Method in class org.springframework.batch.core.JobExecution
Test if this JobExecution indicates that it is running.
isSingleton() - Method in class org.springframework.batch.core.configuration.support.ClasspathXmlApplicationContextsFactoryBean
Optimization hint for bean factory.
isSingleton() - Method in class org.springframework.batch.core.configuration.xml.SimpleFlowFactoryBean
 
isSingleton() - Method in class org.springframework.batch.core.explore.support.AbstractJobExplorerFactoryBean
 
isSingleton() - Method in class org.springframework.batch.core.listener.AbstractListenerFactoryBean
 
isSingleton() - Method in class org.springframework.batch.core.repository.support.AbstractJobRepositoryFactoryBean
 
isSingleton() - Method in class org.springframework.batch.core.step.factory.SimpleStepFactoryBean
Returns true by default, but in most cases a Step should not be treated as thread safe.
isSingleton() - Method in class org.springframework.batch.core.step.StepLocatorStepFactoryBean
Always return true as optimization for bean factory.
isStop() - Method in class org.springframework.batch.core.job.flow.FlowExecutionStatus
 
isStopping() - Method in class org.springframework.batch.core.JobExecution
Test if this JobExecution indicates that it has been signalled to stop.
isTerminateOnly() - Method in class org.springframework.batch.core.StepExecution
 
isUnderspecified(Element) - Static method in class org.springframework.batch.core.configuration.xml.CoreNamespaceUtils
Should this element be treated as incomplete? If it has a parent or is abstract, then it may not have all properties.
isUnsuccessful() - Method in enum org.springframework.batch.core.BatchStatus
Convenience method to decide if a status indicates execution was unsuccessful.
itemListenerMetaData() - Static method in enum org.springframework.batch.core.listener.StepListenerMetaData
 
ItemListenerSupport<I,O> - Class in org.springframework.batch.core.listener
Basic no-op implementation of the ItemReadListener, ItemProcessListener, and ItemWriteListener interfaces.
ItemListenerSupport() - Constructor for class org.springframework.batch.core.listener.ItemListenerSupport
 
ItemProcessListener<T,S> - Interface in org.springframework.batch.core
Listener interface for the processing of an item.
itemReader - Variable in class org.springframework.batch.core.step.item.SimpleChunkProvider
 
ItemReadListener<T> - Interface in org.springframework.batch.core
Listener interface around the reading of an item.
ItemWriteListener<S> - Interface in org.springframework.batch.core
Listener interface for the writing of items.
iterator() - Method in class org.springframework.batch.core.step.item.Chunk
Get an unmodifiable iterator for the underlying items.

J

JdbcExecutionContextDao - Class in org.springframework.batch.core.repository.dao
JDBC DAO for ExecutionContext.
JdbcExecutionContextDao() - Constructor for class org.springframework.batch.core.repository.dao.JdbcExecutionContextDao
 
JdbcJobExecutionDao - Class in org.springframework.batch.core.repository.dao
JDBC implementation of JobExecutionDao.
JdbcJobExecutionDao() - Constructor for class org.springframework.batch.core.repository.dao.JdbcJobExecutionDao
 
JdbcJobInstanceDao - Class in org.springframework.batch.core.repository.dao
JDBC implementation of JobInstanceDao.
JdbcJobInstanceDao() - Constructor for class org.springframework.batch.core.repository.dao.JdbcJobInstanceDao
 
JdbcStepExecutionDao - Class in org.springframework.batch.core.repository.dao
JDBC implementation of StepExecutionDao.
Allows customization of the tables names used by Spring Batch for step meta data via a prefix property.
Uses sequences or tables (via Spring's DataFieldMaxValueIncrementer abstraction) to create all primary keys before inserting a new row.
JdbcStepExecutionDao() - Constructor for class org.springframework.batch.core.repository.dao.JdbcStepExecutionDao
 
Job - Interface in org.springframework.batch.core
Batch domain object representing a job.
job(Job) - Method in class org.springframework.batch.core.step.builder.JobStepBuilder
Provide a job to execute during the step.
job(Job) - Method in class org.springframework.batch.core.step.builder.StepBuilder
Create a new step builder that will execute a job.
JOB_NOT_PROVIDED - Static variable in interface org.springframework.batch.core.launch.support.ExitCodeMapper
 
JobBuilder - Class in org.springframework.batch.core.job.builder
Convenience for building jobs of various kinds.
JobBuilder(String) - Constructor for class org.springframework.batch.core.job.builder.JobBuilder
Create a new builder for a job with the given name.
JobBuilderException - Exception in org.springframework.batch.core.job.builder
 
JobBuilderException(Exception) - Constructor for exception org.springframework.batch.core.job.builder.JobBuilderException
 
JobBuilderFactory - Class in org.springframework.batch.core.configuration.annotation
Convenient factory for a JobBuilder which sets the JobRepository automatically.
JobBuilderFactory(JobRepository) - Constructor for class org.springframework.batch.core.configuration.annotation.JobBuilderFactory
 
JobBuilderHelper<B extends JobBuilderHelper<B>> - Class in org.springframework.batch.core.job.builder
A base class and utility for other job builders providing access to common properties like job repository.
JobBuilderHelper(String) - Constructor for class org.springframework.batch.core.job.builder.JobBuilderHelper
 
JobBuilderHelper(JobBuilderHelper<?>) - Constructor for class org.springframework.batch.core.job.builder.JobBuilderHelper
Create a new builder initialized with any properties in the parent.
JobBuilderHelper.CommonJobProperties - Class in org.springframework.batch.core.job.builder
 
JobBuilderHelper.CommonJobProperties() - Constructor for class org.springframework.batch.core.job.builder.JobBuilderHelper.CommonJobProperties
 
JobBuilderHelper.CommonJobProperties(JobBuilderHelper.CommonJobProperties) - Constructor for class org.springframework.batch.core.job.builder.JobBuilderHelper.CommonJobProperties
 
jobBuilders() - Method in class org.springframework.batch.core.configuration.annotation.AbstractBatchConfiguration
 
JobExecution - Class in org.springframework.batch.core
Batch domain object representing the execution of a job.
JobExecution(JobInstance, Long, JobParameters) - Constructor for class org.springframework.batch.core.JobExecution
Because a JobExecution isn't valid unless the job is set, this constructor is the only valid one from a modeling point of view.
JobExecution(JobInstance, JobParameters) - Constructor for class org.springframework.batch.core.JobExecution
Constructor for transient (unsaved) instances.
JobExecution(Long, JobParameters) - Constructor for class org.springframework.batch.core.JobExecution
 
JobExecution(Long) - Constructor for class org.springframework.batch.core.JobExecution
 
JobExecutionAlreadyRunningException - Exception in org.springframework.batch.core.repository
 
JobExecutionAlreadyRunningException(String) - Constructor for exception org.springframework.batch.core.repository.JobExecutionAlreadyRunningException
 
JobExecutionAlreadyRunningException(String, Throwable) - Constructor for exception org.springframework.batch.core.repository.JobExecutionAlreadyRunningException
 
JobExecutionDao - Interface in org.springframework.batch.core.repository.dao
Data Access Object for job executions.
JobExecutionDecider - Interface in org.springframework.batch.core.job.flow
Interface allowing for programmatic access to the decision on what the status of a flow should be.
JobExecutionException - Exception in org.springframework.batch.core
Root of exception hierarchy for checked exceptions in job and step execution.
JobExecutionException(String) - Constructor for exception org.springframework.batch.core.JobExecutionException
Construct a JobExecutionException with a generic message.
JobExecutionException(String, Throwable) - Constructor for exception org.springframework.batch.core.JobExecutionException
Construct a JobExecutionException with a generic message and a cause.
JobExecutionListener - Interface in org.springframework.batch.core
Provide callbacks at specific points in the lifecycle of a Job.
JobExecutionListenerParser - Class in org.springframework.batch.core.configuration.xml
Parser for a step listener element.
JobExecutionListenerParser() - Constructor for class org.springframework.batch.core.configuration.xml.JobExecutionListenerParser
 
JobExecutionListenerSupport - Class in org.springframework.batch.core.listener
 
JobExecutionListenerSupport() - Constructor for class org.springframework.batch.core.listener.JobExecutionListenerSupport
 
JobExecutionNotFailedException - Exception in org.springframework.batch.core.launch
Checked exception to indicate that user asked for a job execution to be resumed when actually it didn't fail.
JobExecutionNotFailedException(String) - Constructor for exception org.springframework.batch.core.launch.JobExecutionNotFailedException
Create an exception with the given message.
JobExecutionNotFailedException(String, Throwable) - Constructor for exception org.springframework.batch.core.launch.JobExecutionNotFailedException
 
JobExecutionNotRunningException - Exception in org.springframework.batch.core.launch
Execution indicating that a JobExecution that is not currently running has been requested to stop.
JobExecutionNotRunningException(String) - Constructor for exception org.springframework.batch.core.launch.JobExecutionNotRunningException
Create a JobExecutionNotRunningException with a message.
JobExecutionNotStoppedException - Exception in org.springframework.batch.core.launch
Checked exception to indicate that user asked for a job execution to be aborted when hasn't been stopped.
JobExecutionNotStoppedException(String) - Constructor for exception org.springframework.batch.core.launch.JobExecutionNotStoppedException
Create an exception with the given message.
JobExplorer - Interface in org.springframework.batch.core.explore
Entry point for browsing executions of running or historical jobs and steps.
JobExplorerFactoryBean - Class in org.springframework.batch.core.explore.support
A FactoryBean that automates the creation of a SimpleJobExplorer using JDBC DAO implementations.
JobExplorerFactoryBean() - Constructor for class org.springframework.batch.core.explore.support.JobExplorerFactoryBean
 
JobFactory - Interface in org.springframework.batch.core.configuration
Strategy for creating a single job.
JobFactoryRegistrationListener - Class in org.springframework.batch.core.configuration.support
Generic service that can bind and unbind a JobFactory in a JobRegistry.
JobFactoryRegistrationListener() - Constructor for class org.springframework.batch.core.configuration.support.JobFactoryRegistrationListener
 
JobFlowBuilder - Class in org.springframework.batch.core.job.builder
 
JobFlowBuilder(FlowJobBuilder) - Constructor for class org.springframework.batch.core.job.builder.JobFlowBuilder
 
JobFlowBuilder(FlowJobBuilder, Step) - Constructor for class org.springframework.batch.core.job.builder.JobFlowBuilder
 
JobFlowBuilder(FlowJobBuilder, JobExecutionDecider) - Constructor for class org.springframework.batch.core.job.builder.JobFlowBuilder
 
JobFlowBuilder(FlowJobBuilder, Flow) - Constructor for class org.springframework.batch.core.job.builder.JobFlowBuilder
 
JobFlowExecutor - Class in org.springframework.batch.core.job.flow
Implementation of FlowExecutor for use in components that need to execute a flow related to a JobExecution.
JobFlowExecutor(JobRepository, StepHandler, JobExecution) - Constructor for class org.springframework.batch.core.job.flow.JobFlowExecutor
 
JobInstance - Class in org.springframework.batch.core
Batch domain object representing a uniquely identifiable job run.
JobInstance(Long, String) - Constructor for class org.springframework.batch.core.JobInstance
 
JobInstanceAlreadyCompleteException - Exception in org.springframework.batch.core.repository
An exception indicating an illegal attempt to restart a job that was already completed successfully.
JobInstanceAlreadyCompleteException(String) - Constructor for exception org.springframework.batch.core.repository.JobInstanceAlreadyCompleteException
 
JobInstanceAlreadyCompleteException(String, Throwable) - Constructor for exception org.springframework.batch.core.repository.JobInstanceAlreadyCompleteException
 
JobInstanceAlreadyExistsException - Exception in org.springframework.batch.core.launch
Checked exception to indicate that a required Job is not available.
JobInstanceAlreadyExistsException(String) - Constructor for exception org.springframework.batch.core.launch.JobInstanceAlreadyExistsException
Create an exception with the given message.
JobInstanceAlreadyExistsException(String, Throwable) - Constructor for exception org.springframework.batch.core.launch.JobInstanceAlreadyExistsException
 
JobInstanceDao - Interface in org.springframework.batch.core.repository.dao
Data Access Object for job instances.
JobInterruptedException - Exception in org.springframework.batch.core
Exception to indicate the the job has been interrupted.
JobInterruptedException(String) - Constructor for exception org.springframework.batch.core.JobInterruptedException
 
JobInterruptedException(String, BatchStatus) - Constructor for exception org.springframework.batch.core.JobInterruptedException
 
JobKeyGenerator<T> - Interface in org.springframework.batch.core
Strategy interface for the generation of the key used in identifying unique JobInstance.
jobLauncher() - Method in class org.springframework.batch.core.configuration.annotation.AbstractBatchConfiguration
 
jobLauncher() - Method in class org.springframework.batch.core.configuration.annotation.ModularBatchConfiguration
 
jobLauncher() - Method in class org.springframework.batch.core.configuration.annotation.SimpleBatchConfiguration
 
JobLauncher - Interface in org.springframework.batch.core.launch
Simple interface for controlling jobs, including possible ad-hoc executions, based on different runtime identifiers.
JobListenerFactoryBean - Class in org.springframework.batch.core.listener
This AbstractListenerFactoryBean implementation is used to create a JobExecutionListener.
JobListenerFactoryBean() - Constructor for class org.springframework.batch.core.listener.JobListenerFactoryBean
 
JobListenerMetaData - Enum in org.springframework.batch.core.listener
Enumeration for JobExecutionListener meta data, which ties together the names of methods, their interfaces, annotation, and expected arguments.
JobLoader - Interface in org.springframework.batch.core.configuration.support
 
JobLocator - Interface in org.springframework.batch.core.configuration
A runtime service locator interface for retrieving job configurations by name.
JobOperator - Interface in org.springframework.batch.core.launch
Low level interface for inspecting and controlling jobs with access only to primitive and collection types.
JobParameter - Class in org.springframework.batch.core
Domain representation of a parameter to a batch job.
JobParameter(String, boolean) - Constructor for class org.springframework.batch.core.JobParameter
Construct a new JobParameter as a String.
JobParameter(Long, boolean) - Constructor for class org.springframework.batch.core.JobParameter
Construct a new JobParameter as a Long.
JobParameter(Date, boolean) - Constructor for class org.springframework.batch.core.JobParameter
Construct a new JobParameter as a Date.
JobParameter(Double, boolean) - Constructor for class org.springframework.batch.core.JobParameter
Construct a new JobParameter as a Double.
JobParameter(String) - Constructor for class org.springframework.batch.core.JobParameter
Construct a new JobParameter as a String.
JobParameter(Long) - Constructor for class org.springframework.batch.core.JobParameter
Construct a new JobParameter as a Long.
JobParameter(Date) - Constructor for class org.springframework.batch.core.JobParameter
Construct a new JobParameter as a Date.
JobParameter(Double) - Constructor for class org.springframework.batch.core.JobParameter
Construct a new JobParameter as a Double.
JobParameter.ParameterType - Enum in org.springframework.batch.core
Enumeration representing the type of a JobParameter.
JobParameterExecutionContextCopyListener - Class in org.springframework.batch.core.listener
This class can be used to automatically copy items from the JobParameters to the Step ExecutionContext.
JobParameterExecutionContextCopyListener() - Constructor for class org.springframework.batch.core.listener.JobParameterExecutionContextCopyListener
 
JobParameters - Class in org.springframework.batch.core
Value object representing runtime parameters to a batch job.
JobParameters() - Constructor for class org.springframework.batch.core.JobParameters
 
JobParameters(Map<String, JobParameter>) - Constructor for class org.springframework.batch.core.JobParameters
 
JobParametersBuilder - Class in org.springframework.batch.core
Helper class for creating JobParameters.
JobParametersBuilder() - Constructor for class org.springframework.batch.core.JobParametersBuilder
Default constructor.
JobParametersBuilder(JobParameters) - Constructor for class org.springframework.batch.core.JobParametersBuilder
Copy constructor.
JobParametersConverter - Interface in org.springframework.batch.core.converter
A factory for JobParameters instances.
JobParametersExtractor - Interface in org.springframework.batch.core.step.job
Strategy interface for translating a StepExecution into JobParameters.
JobParametersIncrementer - Interface in org.springframework.batch.core
Interface for obtaining the next JobParameters in a sequence.
JobParametersInvalidException - Exception in org.springframework.batch.core
Exception for Job to signal that some JobParameters are invalid.
JobParametersInvalidException(String) - Constructor for exception org.springframework.batch.core.JobParametersInvalidException
 
JobParametersNotFoundException - Exception in org.springframework.batch.core.launch
Checked exception to indicate that a required JobParametersIncrementer is not available.
JobParametersNotFoundException(String) - Constructor for exception org.springframework.batch.core.launch.JobParametersNotFoundException
Create an exception with the given message.
JobParametersNotFoundException(String, Throwable) - Constructor for exception org.springframework.batch.core.launch.JobParametersNotFoundException
 
JobParametersValidator - Interface in org.springframework.batch.core
Strategy interface for a Job to use in validating its parameters for an execution.
JobParser - Class in org.springframework.batch.core.configuration.xml
Parser for the lt;job/gt; element in the Batch namespace.
JobParser() - Constructor for class org.springframework.batch.core.configuration.xml.JobParser
 
jobRegistrar() - Method in class org.springframework.batch.core.configuration.annotation.ModularBatchConfiguration
 
jobRegistry() - Method in class org.springframework.batch.core.configuration.annotation.AbstractBatchConfiguration
 
jobRegistry() - Method in class org.springframework.batch.core.configuration.annotation.SimpleBatchConfiguration
 
JobRegistry - Interface in org.springframework.batch.core.configuration
A runtime service registry interface for registering job configurations by name.
JobRegistryBackgroundJobRunner - Class in org.springframework.batch.core.launch.support
Command line launcher for registering jobs with a JobRegistry.
JobRegistryBackgroundJobRunner(String) - Constructor for class org.springframework.batch.core.launch.support.JobRegistryBackgroundJobRunner
 
JobRegistryBeanPostProcessor - Class in org.springframework.batch.core.configuration.support
A BeanPostProcessor that registers Job beans with a JobRegistry.
JobRegistryBeanPostProcessor() - Constructor for class org.springframework.batch.core.configuration.support.JobRegistryBeanPostProcessor
 
jobRepository() - Method in class org.springframework.batch.core.configuration.annotation.AbstractBatchConfiguration
 
jobRepository() - Method in class org.springframework.batch.core.configuration.annotation.ModularBatchConfiguration
 
jobRepository() - Method in class org.springframework.batch.core.configuration.annotation.SimpleBatchConfiguration
 
JobRepository - Interface in org.springframework.batch.core.repository
Repository responsible for persistence of batch meta-data entities.
JobRepositoryFactoryBean - Class in org.springframework.batch.core.repository.support
A FactoryBean that automates the creation of a SimpleJobRepository using JDBC DAO implementations which persist batch metadata in database.
JobRepositoryFactoryBean() - Constructor for class org.springframework.batch.core.repository.support.JobRepositoryFactoryBean
 
JobRepositoryParser - Class in org.springframework.batch.core.configuration.xml
Parser for the lt;job-repository/gt; element in the Batch namespace.
JobRepositoryParser() - Constructor for class org.springframework.batch.core.configuration.xml.JobRepositoryParser
 
JobRestartException - Exception in org.springframework.batch.core.repository
An exception indicating an illegal attempt to restart a job.
JobRestartException(String) - Constructor for exception org.springframework.batch.core.repository.JobRestartException
 
JobRestartException(String, Throwable) - Constructor for exception org.springframework.batch.core.repository.JobRestartException
 
JobStep - Class in org.springframework.batch.core.step.job
A Step that delegates to a Job to do its work.
JobStep() - Constructor for class org.springframework.batch.core.step.job.JobStep
 
JobStepBuilder - Class in org.springframework.batch.core.step.builder
A step builder for JobStep instances.
JobStepBuilder(StepBuilderHelper<?>) - Constructor for class org.springframework.batch.core.step.builder.JobStepBuilder
Create a new builder initialized with any properties in the parent.
JVM_EXITCODE_COMPLETED - Static variable in interface org.springframework.batch.core.launch.support.ExitCodeMapper
 
JVM_EXITCODE_GENERIC_ERROR - Static variable in interface org.springframework.batch.core.launch.support.ExitCodeMapper
 
JVM_EXITCODE_JOB_ERROR - Static variable in interface org.springframework.batch.core.launch.support.ExitCodeMapper
 
JvmSystemExiter - Class in org.springframework.batch.core.launch.support
Implementation of the SystemExiter interface that calls the standards System.exit method.
JvmSystemExiter() - Constructor for class org.springframework.batch.core.launch.support.JvmSystemExiter
 

K

keyGenerator(KeyGenerator) - Method in class org.springframework.batch.core.step.builder.FaultTolerantStepBuilder
Sets the key generator for identifying retried items.
KeyGenerator - Interface in org.springframework.batch.core.step.item
Interface for defining keys to uniquely identify items.

L

launcher(JobLauncher) - Method in class org.springframework.batch.core.step.builder.JobStepBuilder
Add a job launcher.
LimitCheckingItemSkipPolicy - Class in org.springframework.batch.core.step.skip
SkipPolicy that determines whether or not reading should continue based upon how many items have been skipped.
LimitCheckingItemSkipPolicy() - Constructor for class org.springframework.batch.core.step.skip.LimitCheckingItemSkipPolicy
Convenience constructor that assumes all exception types are fatal.
LimitCheckingItemSkipPolicy(int, Map<Class<? extends Throwable>, Boolean>) - Constructor for class org.springframework.batch.core.step.skip.LimitCheckingItemSkipPolicy
 
LimitCheckingItemSkipPolicy(int, Classifier<Throwable, Boolean>) - Constructor for class org.springframework.batch.core.step.skip.LimitCheckingItemSkipPolicy
 
ListableJobLocator - Interface in org.springframework.batch.core.configuration
A listable extension of JobLocator.
listener(JobExecutionListener) - Method in class org.springframework.batch.core.job.builder.JobBuilderHelper
Register a job execution listener.
listener(ChunkListener) - Method in class org.springframework.batch.core.step.builder.AbstractTaskletStepBuilder
Register a chunk listener.
listener(Object) - Method in class org.springframework.batch.core.step.builder.FaultTolerantStepBuilder
Registers objects using the annotation based listener configuration.
listener(SkipListener<? super I, ? super O>) - Method in class org.springframework.batch.core.step.builder.FaultTolerantStepBuilder
Register a skip listener.
listener(ChunkListener) - Method in class org.springframework.batch.core.step.builder.FaultTolerantStepBuilder
 
listener(RetryListener) - Method in class org.springframework.batch.core.step.builder.FaultTolerantStepBuilder
Register a retry listener.
listener(Object) - Method in class org.springframework.batch.core.step.builder.SimpleStepBuilder
Registers objects using the annotation based listener configuration.
listener(ItemReadListener<? super I>) - Method in class org.springframework.batch.core.step.builder.SimpleStepBuilder
Register an item reader listener.
listener(ItemWriteListener<? super O>) - Method in class org.springframework.batch.core.step.builder.SimpleStepBuilder
Register an item writer listener.
listener(ItemProcessListener<? super I, ? super O>) - Method in class org.springframework.batch.core.step.builder.SimpleStepBuilder
Register an item processor listener.
listener(Object) - Method in class org.springframework.batch.core.step.builder.StepBuilderHelper
Registers objects using the annotation based listener configuration.
listener(StepExecutionListener) - Method in class org.springframework.batch.core.step.builder.StepBuilderHelper
 
ListenerMetaData - Interface in org.springframework.batch.core.listener
A common interface for listener meta data enumerations.
ListPreparedStatementSetter - Class in org.springframework.batch.core.resource
Implementation of the PreparedStatementSetter interface that accepts a list of values to be set on a PreparedStatement.
ListPreparedStatementSetter() - Constructor for class org.springframework.batch.core.resource.ListPreparedStatementSetter
 
load(ApplicationContextFactory) - Method in class org.springframework.batch.core.configuration.support.DefaultJobLoader
 
load(ApplicationContextFactory) - Method in interface org.springframework.batch.core.configuration.support.JobLoader
Load an application context and register all the jobs.
logger - Static variable in class org.springframework.batch.core.job.AbstractJob
 
logger - Variable in class org.springframework.batch.core.job.builder.JobBuilderHelper
 
logger - Static variable in class org.springframework.batch.core.launch.support.CommandLineJobRunner
 
logger - Static variable in class org.springframework.batch.core.launch.support.SimpleJobLauncher
 
logger - Variable in class org.springframework.batch.core.launch.support.SimpleJvmExitCodeMapper
 
logger - Static variable in class org.springframework.batch.core.repository.support.JobRepositoryFactoryBean
 
logger - Variable in class org.springframework.batch.core.step.builder.StepBuilderHelper
 
logger - Variable in class org.springframework.batch.core.step.factory.SimpleStepFactoryBean
 
logger - Static variable in class org.springframework.batch.core.step.item.DefaultItemFailureHandler
 
logger - Variable in class org.springframework.batch.core.step.item.SimpleChunkProvider
 
logger - Static variable in class org.springframework.batch.core.step.tasklet.SystemCommandTasklet
 
logger - Static variable in class org.springframework.batch.core.step.ThreadStepInterruptionPolicy
 
LONG_TYPE - Static variable in class org.springframework.batch.core.converter.DefaultJobParametersConverter
 

M

main(String[]) - Static method in class org.springframework.batch.core.launch.support.CommandLineJobRunner
Launch a batch job using a CommandLineJobRunner.
main(String...) - Static method in class org.springframework.batch.core.launch.support.JobRegistryBackgroundJobRunner
Supply a list of application context locations, starting with the parent context, and followed by the children.
MapExecutionContextDao - Class in org.springframework.batch.core.repository.dao
In-memory implementation of ExecutionContextDao backed by maps.
MapExecutionContextDao() - Constructor for class org.springframework.batch.core.repository.dao.MapExecutionContextDao
 
MapJobExecutionDao - Class in org.springframework.batch.core.repository.dao
In-memory implementation of JobExecutionDao.
MapJobExecutionDao() - Constructor for class org.springframework.batch.core.repository.dao.MapJobExecutionDao
 
MapJobExplorerFactoryBean - Class in org.springframework.batch.core.explore.support
A FactoryBean that automates the creation of a SimpleJobExplorer using in-memory DAO implementations.
MapJobExplorerFactoryBean(MapJobRepositoryFactoryBean) - Constructor for class org.springframework.batch.core.explore.support.MapJobExplorerFactoryBean
Create an instance with the provided MapJobRepositoryFactoryBean as a source of Dao instances.
MapJobExplorerFactoryBean() - Constructor for class org.springframework.batch.core.explore.support.MapJobExplorerFactoryBean
Create a factory with no MapJobRepositoryFactoryBean.
MapJobInstanceDao - Class in org.springframework.batch.core.repository.dao
In-memory implementation of JobInstanceDao.
MapJobInstanceDao() - Constructor for class org.springframework.batch.core.repository.dao.MapJobInstanceDao
 
MapJobRegistry - Class in org.springframework.batch.core.configuration.support
Simple, thread-safe, map-based implementation of JobRegistry.
MapJobRegistry() - Constructor for class org.springframework.batch.core.configuration.support.MapJobRegistry
 
MapJobRepositoryFactoryBean - Class in org.springframework.batch.core.repository.support
A FactoryBean that automates the creation of a SimpleJobRepository using non-persistent in-memory DAO implementations.
MapJobRepositoryFactoryBean() - Constructor for class org.springframework.batch.core.repository.support.MapJobRepositoryFactoryBean
Create a new instance with a ResourcelessTransactionManager.
MapJobRepositoryFactoryBean(PlatformTransactionManager) - Constructor for class org.springframework.batch.core.repository.support.MapJobRepositoryFactoryBean
Create a new instance with the provided transaction manager.
mapResult(Object) - Method in class org.springframework.batch.core.step.tasklet.MethodInvokingTaskletAdapter
If the result is an ExitStatus already just return that, otherwise return ExitStatus.COMPLETED.
MapStepExecutionDao - Class in org.springframework.batch.core.repository.dao
In-memory implementation of StepExecutionDao.
MapStepExecutionDao() - Constructor for class org.springframework.batch.core.repository.dao.MapStepExecutionDao
 
MapStepRegistry - Class in org.springframework.batch.core.configuration.support
Simple map-based implementation of StepRegistry.
MapStepRegistry() - Constructor for class org.springframework.batch.core.configuration.support.MapStepRegistry
 
match(String) - Static method in enum org.springframework.batch.core.BatchStatus
Find a BatchStatus that matches the beginning of the given value.
matches(String) - Method in class org.springframework.batch.core.job.flow.support.StateTransition
Check if the provided status matches the pattern, signalling that the next State should be executed.
max(BatchStatus, BatchStatus) - Static method in enum org.springframework.batch.core.BatchStatus
 
MaxValueFlowExecutionAggregator - Class in org.springframework.batch.core.job.flow.support.state
Implementation of the FlowExecutionAggregator interface that aggregates FlowExecutionStatus', using the status with the high precedence as the aggregate status.
MaxValueFlowExecutionAggregator() - Constructor for class org.springframework.batch.core.job.flow.support.state.MaxValueFlowExecutionAggregator
 
MethodInvokerMethodInterceptor - Class in org.springframework.batch.core.listener
MethodInterceptor that, given a map of method names and MethodInvokers, will execute all methods tied to a particular method name, with the provided arguments.
MethodInvokerMethodInterceptor(Map<String, Set<MethodInvoker>>) - Constructor for class org.springframework.batch.core.listener.MethodInvokerMethodInterceptor
 
MethodInvokerMethodInterceptor(Map<String, Set<MethodInvoker>>, boolean) - Constructor for class org.springframework.batch.core.listener.MethodInvokerMethodInterceptor
 
MethodInvokingTaskletAdapter - Class in org.springframework.batch.core.step.tasklet
A Tasklet that wraps a method in a POJO.
MethodInvokingTaskletAdapter() - Constructor for class org.springframework.batch.core.step.tasklet.MethodInvokingTaskletAdapter
 
ModularBatchConfiguration - Class in org.springframework.batch.core.configuration.annotation
Base Configuration class providing common structure for enabling and using Spring Batch.
ModularBatchConfiguration() - Constructor for class org.springframework.batch.core.configuration.annotation.ModularBatchConfiguration
 
MulticasterBatchListener<T,S> - Class in org.springframework.batch.core.listener
 
MulticasterBatchListener() - Constructor for class org.springframework.batch.core.listener.MulticasterBatchListener
Initialise the listener instance.
MultiResourcePartitioner - Class in org.springframework.batch.core.partition.support
Implementation of Partitioner that locates multiple resources and associates their file names with execution context keys.
MultiResourcePartitioner() - Constructor for class org.springframework.batch.core.partition.support.MultiResourcePartitioner
 

N

namespaceMatchesVersion(Element) - Static method in class org.springframework.batch.core.configuration.xml.CoreNamespaceUtils
Check that the schema location declared in the source file being parsed matches the Spring Batch version.
NeverSkipItemSkipPolicy - Class in org.springframework.batch.core.step.skip
SkipPolicy implementation that always returns false, indicating that an item should not be skipped.
NeverSkipItemSkipPolicy() - Constructor for class org.springframework.batch.core.step.skip.NeverSkipItemSkipPolicy
 
next(Step) - Method in class org.springframework.batch.core.job.builder.FlowBuilder
Transition to the next step on successful completion of the current step.
next(JobExecutionDecider) - Method in class org.springframework.batch.core.job.builder.FlowBuilder
Transition to the decider on successful completion of the current step.
next(Flow) - Method in class org.springframework.batch.core.job.builder.FlowBuilder
Go next on successful completion to a subflow.
next(JobExecutionDecider) - Method in class org.springframework.batch.core.job.builder.SimpleJobBuilder
Continue with this decider if the previous step was successful.
next(Step) - Method in class org.springframework.batch.core.job.builder.SimpleJobBuilder
Continue or end a job with this step if the previous step was successful.
next() - Method in class org.springframework.batch.core.step.item.Chunk.ChunkIterator
 
NO_SUCH_JOB - Static variable in interface org.springframework.batch.core.launch.support.ExitCodeMapper
 
NonSkippableProcessException - Exception in org.springframework.batch.core.step.skip
Fatal exception to be thrown when a process operation could not be skipped.
NonSkippableProcessException(String, Throwable) - Constructor for exception org.springframework.batch.core.step.skip.NonSkippableProcessException
 
NonSkippableReadException - Exception in org.springframework.batch.core.step.skip
Fatal exception to be thrown when a read operation could not be skipped.
NonSkippableReadException(String, Throwable) - Constructor for exception org.springframework.batch.core.step.skip.NonSkippableReadException
 
NonSkippableWriteException - Exception in org.springframework.batch.core.step.skip
Fatal exception to be thrown when a process operation could not be skipped.
NonSkippableWriteException(String, Throwable) - Constructor for exception org.springframework.batch.core.step.skip.NonSkippableWriteException
 
NOOP - Static variable in class org.springframework.batch.core.ExitStatus
Convenient constant value representing job that did no processing (e.g.
noRetry(Class<? extends Throwable>) - Method in class org.springframework.batch.core.step.builder.FaultTolerantStepBuilder
Explicitly ask for an exception (and subclasses) to be excluded from retry.
noRollback(Class<? extends Throwable>) - Method in class org.springframework.batch.core.step.builder.FaultTolerantStepBuilder
Mark this exception as ignorable during item read or processing operations.
noSkip(Class<? extends Throwable>) - Method in class org.springframework.batch.core.step.builder.FaultTolerantStepBuilder
Explicitly prevent certain exceptions (and subclasses) from being skipped.
NoSuchJobException - Exception in org.springframework.batch.core.launch
Checked exception to indicate that a required Job is not available.
NoSuchJobException(String) - Constructor for exception org.springframework.batch.core.launch.NoSuchJobException
Create an exception with the given message.
NoSuchJobException(String, Throwable) - Constructor for exception org.springframework.batch.core.launch.NoSuchJobException
 
NoSuchJobExecutionException - Exception in org.springframework.batch.core.launch
Checked exception to indicate that a required JobExecution is not available.
NoSuchJobExecutionException(String) - Constructor for exception org.springframework.batch.core.launch.NoSuchJobExecutionException
Create an exception with the given message.
NoSuchJobExecutionException(String, Throwable) - Constructor for exception org.springframework.batch.core.launch.NoSuchJobExecutionException
 
NoSuchJobInstanceException - Exception in org.springframework.batch.core.launch
Exception that signals that the user requested an operation on a non-existent JobInstance.
NoSuchJobInstanceException(String) - Constructor for exception org.springframework.batch.core.launch.NoSuchJobInstanceException
Create an exception with the given message.
NoSuchJobInstanceException(String, Throwable) - Constructor for exception org.springframework.batch.core.launch.NoSuchJobInstanceException
 
NoSuchObjectException - Exception in org.springframework.batch.core.repository.dao
This exception identifies that a batch domain object is invalid, which is generally caused by an invalid ID.
NoSuchObjectException(String) - Constructor for exception org.springframework.batch.core.repository.dao.NoSuchObjectException
 
NoSuchStepException - Exception in org.springframework.batch.core.step
Exception to signal that a step was requested that is unknown or does not exist.
NoSuchStepException(String) - Constructor for exception org.springframework.batch.core.step.NoSuchStepException
Create a new exception instance with the message provided.
NoWorkFoundStepExecutionListener - Class in org.springframework.batch.core.step
Fails the step if no items have been processed ( item count is 0).
NoWorkFoundStepExecutionListener() - Constructor for class org.springframework.batch.core.step.NoWorkFoundStepExecutionListener
 

O

offset - Variable in class org.springframework.batch.core.step.item.ChunkMonitor.ChunkMonitorData
 
on(String) - Method in class org.springframework.batch.core.job.builder.FlowBuilder
Start a transition to a new state if the exit status from the previous state matches the pattern given.
on(String) - Method in class org.springframework.batch.core.job.builder.FlowBuilder.UnterminatedFlowBuilder
Start a transition to a new state if the exit status from the previous state matches the pattern given.
on(String) - Method in class org.springframework.batch.core.job.builder.SimpleJobBuilder
Branch into a flow conditional on the outcome of the current step.
onApplicationEvent(ApplicationEvent) - Method in class org.springframework.batch.core.configuration.support.AutomaticJobRegistrar
Creates all the application contexts required and set up job registry entries with all the instances of Job found therein.
OnProcessError - Annotation Type in org.springframework.batch.core.annotation
Marks a method to be called if an exception is thrown by an ItemProcessor

Expected signature: void onProcessError(T item, Exception e)
onProcessError(T, Exception) - Method in interface org.springframework.batch.core.ItemProcessListener
Called if an exception was thrown from ItemProcessor.process(Object).
onProcessError(T, Exception) - Method in class org.springframework.batch.core.listener.CompositeItemProcessListener
Call the registered listeners in reverse order, respecting and prioritising those that implement Ordered.
onProcessError(I, Exception) - Method in class org.springframework.batch.core.listener.ItemListenerSupport
 
onProcessError(T, Exception) - Method in class org.springframework.batch.core.listener.MulticasterBatchListener
 
onProcessError(T, Exception) - Method in class org.springframework.batch.core.listener.StepListenerSupport
 
OnReadError - Annotation Type in org.springframework.batch.core.annotation
Marks a method to be called if an exception is thrown by an ItemReader

Expected signature: void onReadError(Exception ex)
onReadError(Exception) - Method in interface org.springframework.batch.core.ItemReadListener
Called if an error occurs while trying to read.
onReadError(Exception) - Method in class org.springframework.batch.core.listener.CompositeItemReadListener
Call the registered listeners in reverse order, respecting and prioritising those that implement Ordered.
onReadError(Exception) - Method in class org.springframework.batch.core.listener.ItemListenerSupport
 
onReadError(Exception) - Method in class org.springframework.batch.core.listener.MulticasterBatchListener
 
onReadError(Exception) - Method in class org.springframework.batch.core.listener.StepListenerSupport
 
onReadError(Exception) - Method in class org.springframework.batch.core.step.item.DefaultItemFailureHandler
 
OnSkipInProcess - Annotation Type in org.springframework.batch.core.annotation
Marks a method to be called when an item is skipped due to an exception thrown in the ItemProcessor.

Expected signature: void onSkipInProcess(T item, Throwable t)
onSkipInProcess(T, Throwable) - Method in class org.springframework.batch.core.listener.CompositeSkipListener
Call the registered listeners in order, respecting and prioritising those that implement Ordered.
onSkipInProcess(T, Throwable) - Method in class org.springframework.batch.core.listener.MulticasterBatchListener
 
onSkipInProcess(T, Throwable) - Method in class org.springframework.batch.core.listener.SkipListenerSupport
 
onSkipInProcess(T, Throwable) - Method in class org.springframework.batch.core.listener.StepListenerSupport
 
onSkipInProcess(T, Throwable) - Method in interface org.springframework.batch.core.SkipListener
This item failed on processing with the given exception, and a skip was called for.
OnSkipInRead - Annotation Type in org.springframework.batch.core.annotation
Marks a method to be called when an item is skipped due to an exception thrown in the ItemReader

Expected signature: void onSkipInRead(Throwable t)
onSkipInRead(Throwable) - Method in class org.springframework.batch.core.listener.CompositeSkipListener
Call the registered listeners in order, respecting and prioritising those that implement Ordered.
onSkipInRead(Throwable) - Method in class org.springframework.batch.core.listener.MulticasterBatchListener
 
onSkipInRead(Throwable) - Method in class org.springframework.batch.core.listener.SkipListenerSupport
 
onSkipInRead(Throwable) - Method in class org.springframework.batch.core.listener.StepListenerSupport
 
onSkipInRead(Throwable) - Method in interface org.springframework.batch.core.SkipListener
Callback for a failure on read that is legal, so is not going to be re-thrown.
OnSkipInWrite - Annotation Type in org.springframework.batch.core.annotation
Marks a method to be called when an item is skipped due to an exception thrown in the ItemWriter.

Expected signature: void onSkipInWrite(S item, Throwable t)
onSkipInWrite(S, Throwable) - Method in class org.springframework.batch.core.listener.CompositeSkipListener
Call the registered listeners in order, respecting and prioritising those that implement Ordered.
onSkipInWrite(S, Throwable) - Method in class org.springframework.batch.core.listener.MulticasterBatchListener
 
onSkipInWrite(S, Throwable) - Method in class org.springframework.batch.core.listener.SkipListenerSupport
 
onSkipInWrite(S, Throwable) - Method in class org.springframework.batch.core.listener.StepListenerSupport
 
onSkipInWrite(S, Throwable) - Method in interface org.springframework.batch.core.SkipListener
This item failed on write with the given exception, and a skip was called for.
OnWriteError - Annotation Type in org.springframework.batch.core.annotation
Marks a method to be called if an exception is thrown by an ItemWriter

Expected signature: void onWriteError(Exception exception, List<? extends S> items)
onWriteError(Exception, List<? extends S>) - Method in interface org.springframework.batch.core.ItemWriteListener
Called if an error occurs while trying to write.
onWriteError(Exception, List<? extends S>) - Method in class org.springframework.batch.core.listener.CompositeItemWriteListener
Call the registered listeners in reverse order, respecting and prioritising those that implement Ordered.
onWriteError(Exception, List<? extends O>) - Method in class org.springframework.batch.core.listener.ItemListenerSupport
 
onWriteError(Exception, List<? extends S>) - Method in class org.springframework.batch.core.listener.MulticasterBatchListener
 
onWriteError(Exception, List<? extends S>) - Method in class org.springframework.batch.core.listener.StepListenerSupport
 
onWriteError(Exception, List<? extends Object>) - Method in class org.springframework.batch.core.step.item.DefaultItemFailureHandler
 
open(ExecutionContext) - Method in class org.springframework.batch.core.step.AbstractStep
Extension point for subclasses to provide callbacks to their collaborators at the beginning of a step, to open or acquire resources.
open(ExecutionContext) - Method in class org.springframework.batch.core.step.item.ChunkMonitor
 
open(ExecutionContext) - Method in class org.springframework.batch.core.step.tasklet.TaskletStep
 
org.springframework.batch.core - package org.springframework.batch.core
Core domain context for Spring Batch covering jobs, steps, configuration and execution abstractions.
org.springframework.batch.core.annotation - package org.springframework.batch.core.annotation
 
org.springframework.batch.core.configuration - package org.springframework.batch.core.configuration
Interfaces for registration and location of job configurations.
org.springframework.batch.core.configuration.annotation - package org.springframework.batch.core.configuration.annotation
 
org.springframework.batch.core.configuration.support - package org.springframework.batch.core.configuration.support
Specific implementations of configuration concerns.
org.springframework.batch.core.configuration.xml - package org.springframework.batch.core.configuration.xml
 
org.springframework.batch.core.converter - package org.springframework.batch.core.converter
Support classes for implementations of the batch APIs.
org.springframework.batch.core.explore - package org.springframework.batch.core.explore
Interfaces and related classes to support meta data browsing.
org.springframework.batch.core.explore.support - package org.springframework.batch.core.explore.support
Specific implementations of explorer concerns.
org.springframework.batch.core.job - package org.springframework.batch.core.job
Specific implementations of job concerns.
org.springframework.batch.core.job.builder - package org.springframework.batch.core.job.builder
 
org.springframework.batch.core.job.flow - package org.springframework.batch.core.job.flow
 
org.springframework.batch.core.job.flow.support - package org.springframework.batch.core.job.flow.support
 
org.springframework.batch.core.job.flow.support.state - package org.springframework.batch.core.job.flow.support.state
 
org.springframework.batch.core.launch - package org.springframework.batch.core.launch
Interfaces and simple implementations of launch concerns.
org.springframework.batch.core.launch.support - package org.springframework.batch.core.launch.support
Support classes for use in bootstrap and launch implementations or configurations.
org.springframework.batch.core.listener - package org.springframework.batch.core.listener
Generic implementations of core batch listener interfaces.
org.springframework.batch.core.partition - package org.springframework.batch.core.partition
 
org.springframework.batch.core.partition.support - package org.springframework.batch.core.partition.support
 
org.springframework.batch.core.repository - package org.springframework.batch.core.repository
Interfaces and generic implementations of repository concerns.
org.springframework.batch.core.repository.dao - package org.springframework.batch.core.repository.dao
Specific implementations of dao concerns.
org.springframework.batch.core.repository.support - package org.springframework.batch.core.repository.support
Specific implementations of repository concerns.
org.springframework.batch.core.resource - package org.springframework.batch.core.resource
 
org.springframework.batch.core.scope - package org.springframework.batch.core.scope
 
org.springframework.batch.core.scope.context - package org.springframework.batch.core.scope.context
 
org.springframework.batch.core.step - package org.springframework.batch.core.step
Specific implementations of step concerns.
org.springframework.batch.core.step.builder - package org.springframework.batch.core.step.builder
 
org.springframework.batch.core.step.factory - package org.springframework.batch.core.step.factory
 
org.springframework.batch.core.step.item - package org.springframework.batch.core.step.item
Specific implementations of step concerns for item-oriented approach.
org.springframework.batch.core.step.job - package org.springframework.batch.core.step.job
 
org.springframework.batch.core.step.skip - package org.springframework.batch.core.step.skip
Specific implementations of skip concerns for items in a step.
org.springframework.batch.core.step.tasklet - package org.springframework.batch.core.step.tasklet
Interfaces and generic implementations of tasklet concerns.
OsgiBundleXmlApplicationContextFactory - Class in org.springframework.batch.core.configuration.support
ApplicationContextFactory that can be used to load a context from an XML location in a bundle.
OsgiBundleXmlApplicationContextFactory() - Constructor for class org.springframework.batch.core.configuration.support.OsgiBundleXmlApplicationContextFactory
 

P

parametersExtractor(JobParametersExtractor) - Method in class org.springframework.batch.core.step.builder.JobStepBuilder
Provide a job parameters extractor.
parse(Element, ParserContext) - Method in class org.springframework.batch.core.configuration.xml.AbstractListenerParser
 
parse(Element, AbstractBeanDefinition, ParserContext, boolean) - Method in class org.springframework.batch.core.configuration.xml.ChunkElementParser
 
parse(Element, ParserContext) - Method in class org.springframework.batch.core.configuration.xml.DecisionParser
Parse the decision and turn it into a list of transitions.
parse(Element, ParserContext) - Method in class org.springframework.batch.core.configuration.xml.FlowElementParser
Parse the flow and turn it into a list of transitions.
parse(Element, ParserContext, String) - Method in class org.springframework.batch.core.configuration.xml.InlineStepParser
Parse the step and turn it into a list of transitions.
parse(Element, ParserContext) - Method in class org.springframework.batch.core.configuration.xml.SplitParser
Parse the split and turn it into a list of transitions.
parse(Element, ParserContext) - Method in class org.springframework.batch.core.configuration.xml.StandaloneStepParser
Parse the step and turn it into a list of transitions.
parseBeanElement(Element, ParserContext) - Method in class org.springframework.batch.core.configuration.xml.JobParser
 
parseInternal(Element, ParserContext) - Method in class org.springframework.batch.core.configuration.xml.TopLevelStepParser
 
parseListenerElement(Element, ParserContext, BeanDefinition) - Static method in class org.springframework.batch.core.configuration.xml.AbstractListenerParser
 
parseStep(Element, ParserContext, String) - Method in class org.springframework.batch.core.configuration.xml.AbstractStepParser
 
parseTasklet(Element, Element, AbstractBeanDefinition, ParserContext, boolean) - Method in class org.springframework.batch.core.configuration.xml.TaskletParser
 
partition(int) - Method in class org.springframework.batch.core.partition.support.MultiResourcePartitioner
Assign the filename of each of the injected resources to an ExecutionContext.
partition(int) - Method in interface org.springframework.batch.core.partition.support.Partitioner
Create a set of distinct ExecutionContext instances together with a unique identifier for each one.
partition(int) - Method in class org.springframework.batch.core.partition.support.SimplePartitioner
 
Partitioner - Interface in org.springframework.batch.core.partition.support
Central strategy interface for creating input parameters for a partitioned step in the form of ExecutionContext instances.
partitioner(String, Partitioner) - Method in class org.springframework.batch.core.step.builder.PartitionStepBuilder
Add a partitioner which can be used to create a StepExecutionSplitter.
partitioner(String, Partitioner) - Method in class org.springframework.batch.core.step.builder.StepBuilder
Create a partition step builder for a remote (or local) step.
partitioner(Step) - Method in class org.springframework.batch.core.step.builder.StepBuilder
Create a partition step builder for a remote (or local) step.
PartitionHandler - Interface in org.springframework.batch.core.partition
Interface defining the responsibilities of controlling the execution of a partitioned StepExecution.
partitionHandler(PartitionHandler) - Method in class org.springframework.batch.core.step.builder.PartitionStepBuilder
Provide an explicit partition handler that will carry out the work of the partition step.
PartitionNameProvider - Interface in org.springframework.batch.core.partition.support
Optional interface for Partitioner implementations that need to use a custom naming scheme for partitions.
PartitionStep - Class in org.springframework.batch.core.partition.support
Implementation of Step which partitions the execution and spreads the load using a PartitionHandler.
PartitionStep() - Constructor for class org.springframework.batch.core.partition.support.PartitionStep
 
PartitionStepBuilder - Class in org.springframework.batch.core.step.builder
Step builder for PartitionStep instances.
PartitionStepBuilder(StepBuilderHelper<?>) - Constructor for class org.springframework.batch.core.step.builder.PartitionStepBuilder
Create a new builder initialized with any properties in the parent.
postProcess(StepContribution, Chunk<T>) - Method in interface org.springframework.batch.core.step.item.ChunkProvider
 
postProcess(StepContribution, Chunk<I>) - Method in class org.springframework.batch.core.step.item.FaultTolerantChunkProvider
 
postProcess(StepContribution, Chunk<I>) - Method in class org.springframework.batch.core.step.item.SimpleChunkProvider
 
postProcessAfterInitialization(Object, String) - Method in class org.springframework.batch.core.configuration.support.JobRegistryBeanPostProcessor
If the bean is an instance of Job then register it.
postProcessAfterInitialization(Object, String) - Method in class org.springframework.batch.core.configuration.xml.CoreNamespacePostProcessor
 
postProcessBeanFactory(ConfigurableListableBeanFactory) - Method in class org.springframework.batch.core.configuration.xml.CoreNamespacePostProcessor
 
postProcessBeanFactory(ConfigurableListableBeanFactory) - Method in class org.springframework.batch.core.scope.StepScope
Register this scope with the enclosing BeanFactory.
postProcessBeforeInitialization(Object, String) - Method in class org.springframework.batch.core.configuration.support.JobRegistryBeanPostProcessor
Do nothing.
postProcessBeforeInitialization(Object, String) - Method in class org.springframework.batch.core.configuration.xml.CoreNamespacePostProcessor
 
prepareBeanFactory(ConfigurableListableBeanFactory, ConfigurableListableBeanFactory) - Method in class org.springframework.batch.core.configuration.support.AbstractApplicationContextFactory
Extension point for special subclasses that want to do more complex things with the bean factory prior to refresh.
prepareContext(ConfigurableApplicationContext, ConfigurableApplicationContext) - Method in class org.springframework.batch.core.configuration.support.AbstractApplicationContextFactory
Extension point for special subclasses that want to do more complex things with the context prior to refresh.
presetSystemExiter(SystemExiter) - Static method in class org.springframework.batch.core.launch.support.CommandLineJobRunner
Static setter for the SystemExiter so it can be adjusted before dependency injection.
preventRestart() - Method in class org.springframework.batch.core.job.builder.JobBuilderHelper
Set a flag to prevent restart an execution of this job even if it has failed.
process(StepContribution, Chunk<I>) - Method in interface org.springframework.batch.core.step.item.ChunkProcessor
 
process(StepContribution, Chunk<I>) - Method in class org.springframework.batch.core.step.item.SimpleChunkProcessor
 
processor(ItemProcessor<? super I, ? extends O>) - Method in class org.springframework.batch.core.step.builder.SimpleStepBuilder
An item processor that processes or transforms a stream of items.
processorNonTransactional() - Method in class org.springframework.batch.core.step.builder.FaultTolerantStepBuilder
Mark the item processor as non-transactional (default is the opposite).
properties - Variable in class org.springframework.batch.core.step.builder.StepBuilderHelper
 
provide(StepContribution) - Method in interface org.springframework.batch.core.step.item.ChunkProvider
 
provide(StepContribution) - Method in class org.springframework.batch.core.step.item.SimpleChunkProvider
 

R

read(StepContribution, Chunk<I>) - Method in class org.springframework.batch.core.step.item.FaultTolerantChunkProvider
 
read(StepContribution, Chunk<I>) - Method in class org.springframework.batch.core.step.item.SimpleChunkProvider
reader(ItemReader<? extends I>) - Method in class org.springframework.batch.core.step.builder.SimpleStepBuilder
An item reader that provides a stream of items.
readerIsTransactionalQueue() - Method in class org.springframework.batch.core.step.builder.SimpleStepBuilder
Sets a flag to say that the reader is transactional (usually a queue), which is to say that failed items might be rolled back and re-presented in a subsequent transaction.
ReferenceJobFactory - Class in org.springframework.batch.core.configuration.support
A JobFactory that just keeps a reference to a Job.
ReferenceJobFactory(Job) - Constructor for class org.springframework.batch.core.configuration.support.ReferenceJobFactory
 
register(JobFactory) - Method in interface org.springframework.batch.core.configuration.JobRegistry
Registers a Job at runtime.
register(String, Collection<Step>) - Method in interface org.springframework.batch.core.configuration.StepRegistry
Registers all the step of the given job.
register(JobFactory) - Method in class org.springframework.batch.core.configuration.support.MapJobRegistry
 
register(String, Collection<Step>) - Method in class org.springframework.batch.core.configuration.support.MapStepRegistry
 
register(ChunkListener) - Method in class org.springframework.batch.core.listener.CompositeChunkListener
Register additional listener.
register(ItemProcessListener<? super T, ? super S>) - Method in class org.springframework.batch.core.listener.CompositeItemProcessListener
Register additional listener.
register(ItemReadListener<? super T>) - Method in class org.springframework.batch.core.listener.CompositeItemReadListener
Register additional listener.
register(ItemWriteListener<? super S>) - Method in class org.springframework.batch.core.listener.CompositeItemWriteListener
Register additional listener.
register(JobExecutionListener) - Method in class org.springframework.batch.core.listener.CompositeJobExecutionListener
Register additional listener.
register(SkipListener<? super T, ? super S>) - Method in class org.springframework.batch.core.listener.CompositeSkipListener
Register additional listener.
register(StepExecutionListener) - Method in class org.springframework.batch.core.listener.CompositeStepExecutionListener
Register additional listener.
register(StepListener) - Method in class org.springframework.batch.core.listener.MulticasterBatchListener
Register the listener for callbacks on the appropriate interfaces implemented.
register(StepExecution) - Static method in class org.springframework.batch.core.scope.context.StepSynchronizationManager
Register a context with the current thread - always put a matching StepSynchronizationManager.close() call in a finally block to ensure that the correct context is available in the enclosing block.
registerChunkListener(ChunkListener) - Method in class org.springframework.batch.core.step.tasklet.TaskletStep
Register a chunk listener for callbacks at the appropriate stages in a step execution.
registerDestructionCallback(String, Runnable) - Method in class org.springframework.batch.core.scope.context.StepContext
Allow clients to register callbacks for clean up on close.
registerDestructionCallback(String, Runnable) - Method in class org.springframework.batch.core.scope.StepScope
 
registerItemStream(ItemStream) - Method in class org.springframework.batch.core.step.item.ChunkMonitor
 
registerJobExecutionListener(JobExecutionListener) - Method in class org.springframework.batch.core.job.AbstractJob
Register a single listener for the JobExecutionListener callbacks.
registerListener(RetryListener) - Method in class org.springframework.batch.core.step.item.BatchRetryTemplate
 
registerListener(StepListener) - Method in class org.springframework.batch.core.step.item.SimpleChunkProcessor
Register a listener for callbacks at the appropriate stages in a process.
registerListener(StepListener) - Method in class org.springframework.batch.core.step.item.SimpleChunkProvider
Register a listener for callbacks at the appropriate stages in a process.
registerStepExecutionListener(StepExecutionListener) - Method in class org.springframework.batch.core.step.AbstractStep
Register a step listener for callbacks at the appropriate stages in a step execution.
registerStream(ItemStream) - Method in class org.springframework.batch.core.step.tasklet.TaskletStep
Register a single ItemStream for callbacks to the stream interface.
release() - Static method in class org.springframework.batch.core.scope.context.StepSynchronizationManager
A convenient "deep" close operation.
reload(ApplicationContextFactory) - Method in class org.springframework.batch.core.configuration.support.DefaultJobLoader
 
reload(ApplicationContextFactory) - Method in interface org.springframework.batch.core.configuration.support.JobLoader
Load an application context and register all the jobs, having first unregistered them if already registered.
RemoteStepExecutionAggregator - Class in org.springframework.batch.core.partition.support
Convenience class for aggregating a set of StepExecution instances when the input comes from remote steps, so the data need to be refreshed from the repository.
RemoteStepExecutionAggregator() - Constructor for class org.springframework.batch.core.partition.support.RemoteStepExecutionAggregator
Create a new instance (useful for configuration purposes).
RemoteStepExecutionAggregator(JobExplorer) - Constructor for class org.springframework.batch.core.partition.support.RemoteStepExecutionAggregator
Create a new instance with a job explorer that can be used to refresh the data when aggregating.
remove(String) - Method in class org.springframework.batch.core.scope.StepScope
 
remove(Throwable) - Method in class org.springframework.batch.core.step.item.Chunk.ChunkIterator
 
remove() - Method in class org.springframework.batch.core.step.item.Chunk.ChunkIterator
 
removeAttribute(String) - Method in class org.springframework.batch.core.scope.context.StepContext
Override base class behaviour to ensure destruction callbacks are unregistered as well as the default behaviour.
replaceExitCode(String) - Method in class org.springframework.batch.core.ExitStatus
Add an exit code to an existing ExitStatus.
repository(JobRepository) - Method in class org.springframework.batch.core.job.builder.JobBuilderHelper
Sets the job repository for the job.
repository(JobRepository) - Method in class org.springframework.batch.core.step.builder.StepBuilderHelper
 
resetOffset() - Method in class org.springframework.batch.core.step.item.ChunkMonitor
 
resolveContextualObject(String) - Method in class org.springframework.batch.core.scope.StepScope
This will be used to resolve expressions in step-scoped beans.
resolveId(Element, AbstractBeanDefinition, ParserContext) - Method in class org.springframework.batch.core.configuration.xml.JobRepositoryParser
 
restart(long) - Method in interface org.springframework.batch.core.launch.JobOperator
Restart a failed or stopped JobExecution.
restart(long) - Method in class org.springframework.batch.core.launch.support.SimpleJobOperator
 
resume(String, FlowExecutor) - Method in interface org.springframework.batch.core.job.flow.Flow
 
resume(String, FlowExecutor) - Method in class org.springframework.batch.core.job.flow.support.SimpleFlow
 
retry(Class<? extends Throwable>) - Method in class org.springframework.batch.core.step.builder.FaultTolerantStepBuilder
Explicitly ask for an exception (and subclasses) to be retried.
retryContextCache(RetryContextCache) - Method in class org.springframework.batch.core.step.builder.FaultTolerantStepBuilder
Provide an explicit retry context cache.
retryLimit(int) - Method in class org.springframework.batch.core.step.builder.FaultTolerantStepBuilder
The maximum number of times to try a failed item.
retryPolicy(RetryPolicy) - Method in class org.springframework.batch.core.step.builder.FaultTolerantStepBuilder
Provide an explicit retry policy instead of using the FaultTolerantStepBuilder.retryLimit(int) and retryable exceptions provided elsewhere.
ROLLBACK_EXCEPTION_KEY - Static variable in interface org.springframework.batch.core.ChunkListener
 
run(Job, JobParameters) - Method in interface org.springframework.batch.core.launch.JobLauncher
Start a job execution for the given Job and JobParameters .
run(Job, JobParameters) - Method in class org.springframework.batch.core.launch.support.SimpleJobLauncher
Run the provided job with the given JobParameters.
RunIdIncrementer - Class in org.springframework.batch.core.launch.support
 
RunIdIncrementer() - Constructor for class org.springframework.batch.core.launch.support.RunIdIncrementer
 
RuntimeExceptionTranslator - Class in org.springframework.batch.core.launch.support
 
RuntimeExceptionTranslator() - Constructor for class org.springframework.batch.core.launch.support.RuntimeExceptionTranslator
 

S

saveExecutionContext(JobExecution) - Method in interface org.springframework.batch.core.repository.dao.ExecutionContextDao
Persist the execution context associated with the given jobExecution, persistent entry for the context should not exist yet.
saveExecutionContext(StepExecution) - Method in interface org.springframework.batch.core.repository.dao.ExecutionContextDao
Persist the execution context associated with the given stepExecution, persistent entry for the context should not exist yet.
saveExecutionContext(JobExecution) - Method in class org.springframework.batch.core.repository.dao.JdbcExecutionContextDao
 
saveExecutionContext(StepExecution) - Method in class org.springframework.batch.core.repository.dao.JdbcExecutionContextDao
 
saveExecutionContext(JobExecution) - Method in class org.springframework.batch.core.repository.dao.MapExecutionContextDao
 
saveExecutionContext(StepExecution) - Method in class org.springframework.batch.core.repository.dao.MapExecutionContextDao
 
saveExecutionContexts(Collection<StepExecution>) - Method in interface org.springframework.batch.core.repository.dao.ExecutionContextDao
Persist the execution context associated with each stepExecution in a given collection, persistent entry for the context should not exist yet.
saveExecutionContexts(Collection<StepExecution>) - Method in class org.springframework.batch.core.repository.dao.JdbcExecutionContextDao
 
saveExecutionContexts(Collection<StepExecution>) - Method in class org.springframework.batch.core.repository.dao.MapExecutionContextDao
 
saveJobExecution(JobExecution) - Method in class org.springframework.batch.core.repository.dao.JdbcJobExecutionDao
SQL implementation using Sequences via the Spring incrementer abstraction.
saveJobExecution(JobExecution) - Method in interface org.springframework.batch.core.repository.dao.JobExecutionDao
Save a new JobExecution.
saveJobExecution(JobExecution) - Method in class org.springframework.batch.core.repository.dao.MapJobExecutionDao
 
saveStepExecution(StepExecution) - Method in class org.springframework.batch.core.repository.dao.JdbcStepExecutionDao
Save a StepExecution.
saveStepExecution(StepExecution) - Method in class org.springframework.batch.core.repository.dao.MapStepExecutionDao
 
saveStepExecution(StepExecution) - Method in interface org.springframework.batch.core.repository.dao.StepExecutionDao
Save the given StepExecution.
saveStepExecutions(Collection<StepExecution>) - Method in class org.springframework.batch.core.repository.dao.JdbcStepExecutionDao
Batch insert StepExecutions
saveStepExecutions(Collection<StepExecution>) - Method in class org.springframework.batch.core.repository.dao.MapStepExecutionDao
 
saveStepExecutions(Collection<StepExecution>) - Method in interface org.springframework.batch.core.repository.dao.StepExecutionDao
Save the given collection of StepExecution as a batch.
SCHEDULE_DATE_KEY - Static variable in class org.springframework.batch.core.launch.support.ScheduledJobParametersFactory
 
ScheduledJobParametersFactory - Class in org.springframework.batch.core.launch.support
 
ScheduledJobParametersFactory() - Constructor for class org.springframework.batch.core.launch.support.ScheduledJobParametersFactory
 
selectImports(AnnotationMetadata) - Method in class org.springframework.batch.core.configuration.annotation.BatchConfigurationSelector
 
serialize(Object, OutputStream) - Method in class org.springframework.batch.core.repository.dao.DefaultExecutionContextSerializer
Serializes an execution context to the provided OutputStream.
serialize(Object, OutputStream) - Method in class org.springframework.batch.core.repository.dao.XStreamExecutionContextStringSerializer
Serializes the passed execution context to the supplied OutputStream.
setAllowStartIfComplete(boolean) - Method in class org.springframework.batch.core.partition.support.SimpleStepExecutionSplitter
Flag to indicate that the partition target step is allowed to start if an execution is complete.
setAllowStartIfComplete(boolean) - Method in class org.springframework.batch.core.step.AbstractStep
Public setter for flag that determines whether the step should start again if it is already complete.
setAllowStartIfComplete(Boolean) - Method in class org.springframework.batch.core.step.builder.StepBuilderHelper.CommonStepProperties
 
setAllowStartIfComplete(boolean) - Method in class org.springframework.batch.core.step.factory.SimpleStepFactoryBean
Public setter for the flag to indicate that the step should be replayed on a restart, even if successful the first time.
setApplicationContext(ApplicationContext) - Method in class org.springframework.batch.core.configuration.support.AbstractApplicationContextFactory
Setter for the parent application context.
setApplicationContext(ApplicationContext) - Method in class org.springframework.batch.core.configuration.support.AutomaticJobRegistrar
The enclosing application context, which can be used to check if events come from the expected source.
setApplicationContext(ApplicationContext) - Method in class org.springframework.batch.core.configuration.support.ClasspathXmlApplicationContextsFactoryBean
An application context that can be used as a parent context for all the factories.
setApplicationContext(ApplicationContext) - Method in class org.springframework.batch.core.configuration.support.OsgiBundleXmlApplicationContextFactory
Setter for the parent application context.
setApplicationContext(ApplicationContext) - Method in class org.springframework.batch.core.configuration.xml.CoreNamespacePostProcessor
 
setApplicationContextFactories(ApplicationContextFactory[]) - Method in class org.springframework.batch.core.configuration.support.AutomaticJobRegistrar
Add some factories to the set that will be used to load contexts and jobs.
setAutoProxy(boolean) - Method in class org.springframework.batch.core.scope.StepScope
Flag to indicate that bean definitions need not be auto proxied.
setBackOffPolicy(BackOffPolicy) - Method in class org.springframework.batch.core.step.factory.FaultTolerantStepFactoryBean
Public setter for the BackOffPolicy.
setBackOffPolicy(BackOffPolicy) - Method in class org.springframework.batch.core.step.item.BatchRetryTemplate
 
setBeanFactory(BeanFactory) - Method in class org.springframework.batch.core.configuration.support.JobRegistryBeanPostProcessor
 
setBeanFactoryPostProcessorClasses(Class<? extends BeanFactoryPostProcessor>[]) - Method in class org.springframework.batch.core.configuration.support.AbstractApplicationContextFactory
Determines which bean factory post processors (like property placeholders) should be copied from the parent context.
setBeanFactoryPostProcessorClasses(Class<? extends BeanFactoryPostProcessor>[]) - Method in class org.springframework.batch.core.configuration.support.ClasspathXmlApplicationContextsFactoryBean
Determines which bean factory post processors (like property placeholders) should be copied from the parent context.
setBeanName(String) - Method in class org.springframework.batch.core.job.AbstractJob
Set the name property if it is not already set.
setBeanName(String) - Method in class org.springframework.batch.core.step.AbstractStep
Set the name property if it is not already set.
setBeanName(String) - Method in class org.springframework.batch.core.step.factory.SimpleStepFactoryBean
Set the bean name property, which will become the name of the Step when it is created.
setBeanPostProcessorExcludeClasses(Class<?>[]) - Method in class org.springframework.batch.core.configuration.support.AbstractApplicationContextFactory
Determines by exclusion which bean post processors should be copied from the parent context.
setBeanPostProcessorExcludeClasses(Class<?>[]) - Method in class org.springframework.batch.core.configuration.support.ClasspathXmlApplicationContextsFactoryBean
Determines by exclusion which bean post processors should be copied from the parent context.
setBuffering(boolean) - Method in class org.springframework.batch.core.step.item.ChunkOrientedTasklet
Flag to indicate that items should be buffered once read.
setBuffering(boolean) - Method in class org.springframework.batch.core.step.item.FaultTolerantChunkProcessor
A flag to indicate that items have been buffered and therefore will always come back as a chunk after a rollback.
setBundleContext(BundleContext) - Method in class org.springframework.batch.core.configuration.support.OsgiBundleXmlApplicationContextFactory
Stash the BundleContext for creating a job application context later.
setBusy(boolean) - Method in class org.springframework.batch.core.step.item.Chunk
Register an interest in the chunk to prevent it from being cleaned up before the flag is reset to false.
setCacheCapacity(int) - Method in class org.springframework.batch.core.step.factory.FaultTolerantStepFactoryBean
Public setter for the capacity of the cache in the retry policy.
setCallable(Callable<RepeatStatus>) - Method in class org.springframework.batch.core.step.tasklet.CallableTaskletAdapter
Public setter for the Callable.
setChunkCompletionPolicy(CompletionPolicy) - Method in class org.springframework.batch.core.step.factory.SimpleStepFactoryBean
Public setter for the CompletionPolicy applying to the chunk level.
setChunkListeners(ChunkListener[]) - Method in class org.springframework.batch.core.step.tasklet.TaskletStep
Register each of the objects as listeners.
setChunkMonitor(ChunkMonitor) - Method in class org.springframework.batch.core.step.item.FaultTolerantChunkProcessor
 
setChunkOperations(RepeatOperations) - Method in class org.springframework.batch.core.step.factory.SimpleStepFactoryBean
Public setter for the chunkOperations.
setChunkSize(int) - Method in class org.springframework.batch.core.step.item.ChunkMonitor
 
setClobType(int) - Method in class org.springframework.batch.core.repository.support.JobRepositoryFactoryBean
 
setClobTypeToUse(int) - Method in class org.springframework.batch.core.repository.dao.AbstractJdbcBatchMetadataDao
 
setCommand(String) - Method in class org.springframework.batch.core.step.tasklet.SystemCommandTasklet
 
setCommitCount(int) - Method in class org.springframework.batch.core.StepExecution
Sets the current number of commits for this execution
setCommitInterval(int) - Method in class org.springframework.batch.core.step.factory.SimpleStepFactoryBean
Set the commit interval.
setComplete() - Method in class org.springframework.batch.core.scope.context.ChunkContext
Setter for the flag to signal complete processing of a chunk.
setCopyConfiguration(boolean) - Method in class org.springframework.batch.core.configuration.support.AbstractApplicationContextFactory
Flag to indicate that configuration such as bean post processors and custom editors should be copied from the parent context.
setCopyConfiguration(boolean) - Method in class org.springframework.batch.core.configuration.support.ClasspathXmlApplicationContextsFactoryBean
Flag to indicate that configuration such as bean post processors and custom editors should be copied from the parent context.
setCreateTime(Date) - Method in class org.springframework.batch.core.JobExecution
 
setDatabaseType(String) - Method in class org.springframework.batch.core.repository.support.JobRepositoryFactoryBean
Sets the database type.
setDataSource(DataSource) - Method in class org.springframework.batch.core.configuration.annotation.DefaultBatchConfigurer
 
setDataSource(DataSource) - Method in class org.springframework.batch.core.explore.support.JobExplorerFactoryBean
Public setter for the DataSource.
setDataSource(DataSource) - Method in class org.springframework.batch.core.repository.support.JobRepositoryFactoryBean
Public setter for the DataSource.
setDateFormat(DateFormat) - Method in class org.springframework.batch.core.converter.DefaultJobParametersConverter
Public setter for injecting a date format.
setDateFormat(DateFormat) - Method in class org.springframework.batch.core.launch.support.ScheduledJobParametersFactory
Public setter for injecting a date format.
setDelegate(Object) - Method in class org.springframework.batch.core.listener.AbstractListenerFactoryBean
 
setDelegate(StepExecutionAggregator) - Method in class org.springframework.batch.core.partition.support.RemoteStepExecutionAggregator
 
setDisplayName(String) - Method in class org.springframework.batch.core.configuration.support.OsgiBundleXmlApplicationContextFactory
 
setEnd() - Method in class org.springframework.batch.core.step.item.Chunk
Set the flag to say that this chunk represents an end of stream (there is no more data to process).
setEndTime(Date) - Method in class org.springframework.batch.core.JobExecution
 
setEndTime(Date) - Method in class org.springframework.batch.core.StepExecution
Sets the time that this execution ended
setEnvironmentParams(String[]) - Method in class org.springframework.batch.core.step.tasklet.SystemCommandTasklet
 
setExceptionClassifier(SubclassClassifier<Throwable, SkipPolicy>) - Method in class org.springframework.batch.core.step.skip.ExceptionClassifierSkipPolicy
The classifier that will be used to choose a delegate policy.
setExceptionHandler(ExceptionHandler) - Method in class org.springframework.batch.core.step.factory.SimpleStepFactoryBean
Public setter for the ExceptionHandler.
setExecutionContext(ExecutionContext) - Method in class org.springframework.batch.core.job.SimpleStepHandler
A context containing values to be added to the step execution before it is handled.
setExecutionContext(ExecutionContext) - Method in class org.springframework.batch.core.JobExecution
Sets the ExecutionContext for this execution
setExecutionContext(ExecutionContext) - Method in class org.springframework.batch.core.StepExecution
Sets the ExecutionContext for this execution
setExitCodeMapper(ExitCodeMapper) - Method in class org.springframework.batch.core.launch.support.CommandLineJobRunner
Injection setter for the ExitCodeMapper.
setExitMessageLength(int) - Method in class org.springframework.batch.core.repository.dao.JdbcJobExecutionDao
Public setter for the exit message length in database.
setExitMessageLength(int) - Method in class org.springframework.batch.core.repository.dao.JdbcStepExecutionDao
Public setter for the exit message length in database.
setExitStatus(ExitStatus) - Method in class org.springframework.batch.core.JobExecution
 
setExitStatus(ExitStatus) - Method in class org.springframework.batch.core.StepContribution
Set the ExitStatus for this contribution.
setExitStatus(ExitStatus) - Method in class org.springframework.batch.core.StepExecution
 
setFilterCount(int) - Method in class org.springframework.batch.core.StepExecution
Public setter for the number of items filtered out of this execution.
setFlow(Flow) - Method in class org.springframework.batch.core.job.flow.FlowJob
Public setter for the flow.
setFlow(Flow) - Method in class org.springframework.batch.core.job.flow.FlowStep
Public setter for the flow.
setGridSize(int) - Method in class org.springframework.batch.core.partition.support.AbstractPartitionHandler
Passed to the StepExecutionSplitter in the AbstractPartitionHandler.handle(StepExecutionSplitter, StepExecution) method, instructing it how many StepExecution instances are required, ideally.
setGroupName(String) - Method in class org.springframework.batch.core.configuration.support.JobRegistryBeanPostProcessor
The group name for jobs registered by this component.
setHierarchicalStreamDriver(HierarchicalStreamDriver) - Method in class org.springframework.batch.core.repository.dao.XStreamExecutionContextStringSerializer
 
setId(Long) - Method in class org.springframework.batch.core.Entity
 
setImportMetadata(AnnotationMetadata) - Method in class org.springframework.batch.core.configuration.annotation.AbstractBatchConfiguration
 
setIncrementerFactory(DataFieldMaxValueIncrementerFactory) - Method in class org.springframework.batch.core.repository.support.JobRepositoryFactoryBean
 
setInterruptionPolicy(StepInterruptionPolicy) - Method in class org.springframework.batch.core.step.tasklet.TaskletStep
Setter for the StepInterruptionPolicy.
setInterruptOnCancel(boolean) - Method in class org.springframework.batch.core.step.tasklet.SystemCommandTasklet
If true tasklet will attempt to interrupt the thread executing the system command if SystemCommandTasklet.setTimeout(long) has been exceeded or user interrupts the job.
setIsolation(Isolation) - Method in class org.springframework.batch.core.step.factory.SimpleStepFactoryBean
 
setIsolationLevelForCreate(String) - Method in class org.springframework.batch.core.repository.support.AbstractJobRepositoryFactoryBean
public setter for the isolation level to be used for the transaction when job execution entities are initially created.
setIsReaderTransactionalQueue(boolean) - Method in class org.springframework.batch.core.step.factory.SimpleStepFactoryBean
Flag to signal that the reader is transactional (usually a JMS consumer) so that items are re-presented after a rollback.
setItemProcessor(ItemProcessor<? super T, ? extends S>) - Method in class org.springframework.batch.core.step.factory.SimpleStepFactoryBean
 
setItemProcessor(ItemProcessor<? super I, ? extends O>) - Method in class org.springframework.batch.core.step.item.SimpleChunkProcessor
 
setItemReader(ItemReader<? extends T>) - Method in class org.springframework.batch.core.step.factory.SimpleStepFactoryBean
 
setItemReader(ItemReader<?>) - Method in class org.springframework.batch.core.step.item.ChunkMonitor
 
setItemWriter(ItemWriter<? super S>) - Method in class org.springframework.batch.core.step.factory.SimpleStepFactoryBean
 
setItemWriter(ItemWriter<? super O>) - Method in class org.springframework.batch.core.step.item.SimpleChunkProcessor
 
setJdbcTemplate(JdbcOperations) - Method in class org.springframework.batch.core.repository.dao.AbstractJdbcBatchMetadataDao
 
setJob(Job) - Method in class org.springframework.batch.core.step.job.JobStep
The Job to delegate to in this step.
setJobExecutionIncrementer(DataFieldMaxValueIncrementer) - Method in class org.springframework.batch.core.repository.dao.JdbcJobExecutionDao
Setter for DataFieldMaxValueIncrementer to be used when generating primary keys for JobExecution instances.
setJobExecutionListeners(JobExecutionListener[]) - Method in class org.springframework.batch.core.job.AbstractJob
Public setter for injecting JobExecutionListeners.
setJobExplorer(JobExplorer) - Method in class org.springframework.batch.core.launch.support.CommandLineJobRunner
Injection setter for JobExplorer.
setJobExplorer(JobExplorer) - Method in class org.springframework.batch.core.launch.support.SimpleJobOperator
Public setter for the JobExplorer.
setJobExplorer(JobExplorer) - Method in class org.springframework.batch.core.partition.support.RemoteStepExecutionAggregator
 
setJobFactoryRef(String) - Method in class org.springframework.batch.core.configuration.xml.AbstractFlowParser
Convenience method for subclasses to set the job factory reference if it is available (null is fine, but the quality of error reports is better if it is available).
setJobIncrementer(DataFieldMaxValueIncrementer) - Method in class org.springframework.batch.core.repository.dao.JdbcJobInstanceDao
Setter for DataFieldMaxValueIncrementer to be used when generating primary keys for JobInstance instances.
setJobInstance(JobInstance) - Method in class org.springframework.batch.core.JobExecution
 
setJobLauncher(JobLauncher) - Method in class org.springframework.batch.core.launch.support.SimpleJobOperator
Public setter for the JobLauncher.
setJobLauncher(JobLauncher) - Method in class org.springframework.batch.core.step.job.JobStep
A JobLauncher is required to be able to run the enclosed Job.
setJobLoader(JobLoader) - Method in class org.springframework.batch.core.configuration.support.AutomaticJobRegistrar
The job loader that will be used to load and manage jobs.
setJobLoader(JobLoader) - Method in class org.springframework.batch.core.launch.support.JobRegistryBackgroundJobRunner
A loader for the jobs that are going to be registered.
setJobLocator(JobLocator) - Method in class org.springframework.batch.core.launch.support.CommandLineJobRunner
JobLocator to find a job to run.
setJobParametersConverter(JobParametersConverter) - Method in class org.springframework.batch.core.launch.support.CommandLineJobRunner
Injection setter for JobParametersConverter.
setJobParametersConverter(JobParametersConverter) - Method in class org.springframework.batch.core.launch.support.SimpleJobOperator
Public setter for the JobParametersConverter.
setJobParametersExtractor(JobParametersExtractor) - Method in class org.springframework.batch.core.step.job.JobStep
The JobParametersExtractor is used to extract JobParametersExtractor from the StepExecution to run the Job.
setJobParametersIncrementer(JobParametersIncrementer) - Method in class org.springframework.batch.core.job.AbstractJob
Public setter for the JobParametersIncrementer.
setJobParametersIncrementer(JobParametersIncrementer) - Method in class org.springframework.batch.core.job.builder.JobBuilderHelper.CommonJobProperties
 
setJobParametersValidator(JobParametersValidator) - Method in class org.springframework.batch.core.job.AbstractJob
A validator for job parameters.
setJobParametersValidator(JobParametersValidator) - Method in class org.springframework.batch.core.job.builder.JobBuilderHelper.CommonJobProperties
 
setJobRegistry(JobRegistry) - Method in class org.springframework.batch.core.configuration.support.DefaultJobLoader
The JobRegistry to use for jobs created.
setJobRegistry(JobRegistry) - Method in class org.springframework.batch.core.configuration.support.JobFactoryRegistrationListener
Public setter for a JobRegistry to use for all the bind and unbind events.
setJobRegistry(JobRegistry) - Method in class org.springframework.batch.core.configuration.support.JobRegistryBeanPostProcessor
Injection setter for JobRegistry.
setJobRegistry(JobRegistry) - Method in class org.springframework.batch.core.launch.support.JobRegistryBackgroundJobRunner
A job registry that can be used to create a job loader (if none is provided).
setJobRegistry(ListableJobLocator) - Method in class org.springframework.batch.core.launch.support.SimpleJobOperator
Public setter for the ListableJobLocator.
setJobRepository(JobRepository) - Method in class org.springframework.batch.core.job.AbstractJob
Public setter for the JobRepository that is needed to manage the state of the batch meta domain (jobs, steps, executions) during the life of a job.
setJobRepository(JobRepository) - Method in class org.springframework.batch.core.job.builder.JobBuilderHelper.CommonJobProperties
 
setJobRepository(JobRepository) - Method in class org.springframework.batch.core.job.SimpleStepHandler
 
setJobRepository(JobRepository) - Method in class org.springframework.batch.core.launch.support.CommandLineJobRunner
 
setJobRepository(JobRepository) - Method in class org.springframework.batch.core.launch.support.SimpleJobLauncher
Set the JobRepsitory.
setJobRepository(JobRepository) - Method in class org.springframework.batch.core.launch.support.SimpleJobOperator
 
setJobRepository(JobRepository) - Method in class org.springframework.batch.core.partition.support.SimpleStepExecutionSplitter
The job repository that will be used to manage the persistence of the delegate step executions.
setJobRepository(JobRepository) - Method in class org.springframework.batch.core.step.AbstractStep
Public setter for JobRepository.
setJobRepository(JobRepository) - Method in class org.springframework.batch.core.step.builder.StepBuilderHelper.CommonStepProperties
 
setJobRepository(JobRepository) - Method in class org.springframework.batch.core.step.factory.SimpleStepFactoryBean
Public setter for JobRepository.
setKey(String) - Method in class org.springframework.batch.core.launch.support.RunIdIncrementer
The name of the run id in the job parameters.
setKeyGenerator(KeyGenerator) - Method in class org.springframework.batch.core.step.factory.FaultTolerantStepFactoryBean
The KeyGenerator to use to identify failed items across rollback.
setKeyGenerator(KeyGenerator) - Method in class org.springframework.batch.core.step.item.FaultTolerantChunkProcessor
The KeyGenerator to use to identify failed items across rollback.
setKeyName(String) - Method in class org.springframework.batch.core.partition.support.MultiResourcePartitioner
The name of the key for the file name in each ExecutionContext.
setKeyName(String) - Method in class org.springframework.batch.core.resource.StepExecutionSimpleCompletionPolicy
Public setter for the key name of a Long value in the JobParameters that will contain a commit interval.
setKeys(String[]) - Method in class org.springframework.batch.core.listener.ExecutionContextPromotionListener
 
setKeys(String[]) - Method in class org.springframework.batch.core.listener.JobParameterExecutionContextCopyListener
 
setKeys(String[]) - Method in class org.springframework.batch.core.step.job.DefaultJobParametersExtractor
The key names to pull out of the execution context or job parameters, if they exist.
setLastUpdated(Date) - Method in class org.springframework.batch.core.JobExecution
Set the last time this JobExecution was updated.
setLastUpdated(Date) - Method in class org.springframework.batch.core.StepExecution
Set the time when the StepExecution was last updated before persisting
setLauncher(JobLauncher) - Method in class org.springframework.batch.core.launch.support.CommandLineJobRunner
Injection setter for the JobLauncher.
setListeners(List<? extends ChunkListener>) - Method in class org.springframework.batch.core.listener.CompositeChunkListener
Public setter for the listeners.
setListeners(List<? extends ItemProcessListener<? super T, ? super S>>) - Method in class org.springframework.batch.core.listener.CompositeItemProcessListener
Public setter for the listeners.
setListeners(List<? extends ItemReadListener<? super T>>) - Method in class org.springframework.batch.core.listener.CompositeItemReadListener
Public setter for the listeners.
setListeners(List<? extends ItemWriteListener<? super S>>) - Method in class org.springframework.batch.core.listener.CompositeItemWriteListener
Public setter for the listeners.
setListeners(List<? extends JobExecutionListener>) - Method in class org.springframework.batch.core.listener.CompositeJobExecutionListener
Public setter for the listeners.
setListeners(List<? extends SkipListener<? super T, ? super S>>) - Method in class org.springframework.batch.core.listener.CompositeSkipListener
Public setter for the listeners.
setListeners(StepExecutionListener[]) - Method in class org.springframework.batch.core.listener.CompositeStepExecutionListener
Public setter for the listeners.
setListeners(List<? extends StepListener>) - Method in class org.springframework.batch.core.listener.MulticasterBatchListener
Register each of the objects as listeners.
setListeners(StepListener[]) - Method in class org.springframework.batch.core.step.factory.SimpleStepFactoryBean
The listeners to inject into the Step.
setListeners(RetryListener[]) - Method in class org.springframework.batch.core.step.item.BatchRetryTemplate
 
setListeners(List<? extends StepListener>) - Method in class org.springframework.batch.core.step.item.SimpleChunkProcessor
Register some StepListeners with the handler.
setListeners(List<? extends StepListener>) - Method in class org.springframework.batch.core.step.item.SimpleChunkProvider
Register some StepListeners with the handler.
setLobHandler(LobHandler) - Method in class org.springframework.batch.core.explore.support.JobExplorerFactoryBean
The lob handler to use when saving ExecutionContext instances.
setLobHandler(LobHandler) - Method in class org.springframework.batch.core.repository.dao.JdbcExecutionContextDao
 
setLobHandler(LobHandler) - Method in class org.springframework.batch.core.repository.support.JobRepositoryFactoryBean
A special handler for large objects.
setMapping(Map<String, Integer>) - Method in class org.springframework.batch.core.launch.support.SimpleJvmExitCodeMapper
Supply the ExitCodeMappings
setMappings(Map<Object, ExitStatus>) - Method in class org.springframework.batch.core.step.tasklet.ConfigurableSystemProcessExitCodeMapper
 
setMaxSkipsOnRead(int) - Method in class org.springframework.batch.core.step.item.FaultTolerantChunkProvider
 
setMaxVarCharLength(int) - Method in class org.springframework.batch.core.repository.support.JobRepositoryFactoryBean
Public setter for the length of long string columns in database.
setMetaDataMap(Map<String, String>) - Method in class org.springframework.batch.core.listener.AbstractListenerFactoryBean
 
setName(String) - Method in class org.springframework.batch.core.configuration.xml.SimpleFlowFactoryBean
The name of the flow that is created by this factory.
setName(String) - Method in class org.springframework.batch.core.job.AbstractJob
Set the name property.
setName(String) - Method in class org.springframework.batch.core.job.builder.JobBuilderHelper.CommonJobProperties
 
setName(String) - Method in class org.springframework.batch.core.scope.StepScope
Public setter for the name property.
setName(String) - Method in class org.springframework.batch.core.step.AbstractStep
Set the name property.
setName(String) - Method in class org.springframework.batch.core.step.builder.StepBuilderHelper.CommonStepProperties
 
setNoRollbackExceptionClasses(Collection<Class<? extends Throwable>>) - Method in class org.springframework.batch.core.step.factory.FaultTolerantStepFactoryBean
Exception classes that are candidates for no rollback.
setNumberFormat(NumberFormat) - Method in class org.springframework.batch.core.converter.DefaultJobParametersConverter
Public setter for the NumberFormat.
setOptionalKeys(String[]) - Method in class org.springframework.batch.core.job.DefaultJobParametersValidator
The keys that are optional in the parameters.
setOrder(int) - Method in class org.springframework.batch.core.configuration.support.AutomaticJobRegistrar
The order to start up and shutdown.
setOrder(int) - Method in class org.springframework.batch.core.scope.StepScope
 
setParameters(List<?>) - Method in class org.springframework.batch.core.resource.ListPreparedStatementSetter
The parameter values that will be set on the PreparedStatement.
setPartitioner(Partitioner) - Method in class org.springframework.batch.core.partition.support.SimpleStepExecutionSplitter
The Partitioner that will be used to generate step execution meta data for the target step.
setPartitionHandler(PartitionHandler) - Method in class org.springframework.batch.core.partition.support.PartitionStep
A PartitionHandler which can send out step executions for remote processing and bring back the results.
setPath(String) - Method in class org.springframework.batch.core.configuration.support.OsgiBundleXmlApplicationContextFactory
 
setPolicyMap(Map<Class<? extends Throwable>, SkipPolicy>) - Method in class org.springframework.batch.core.step.skip.ExceptionClassifierSkipPolicy
Setter for policy map.
setProcessorTransactional(boolean) - Method in class org.springframework.batch.core.step.factory.FaultTolerantStepFactoryBean
 
setProcessorTransactional(boolean) - Method in class org.springframework.batch.core.step.item.FaultTolerantChunkProcessor
Flag to say that the ItemProcessor is transactional (defaults to true).
setProcessSkipCount(int) - Method in class org.springframework.batch.core.StepExecution
Set the number of records skipped during processing.
setProcessSkipPolicy(SkipPolicy) - Method in class org.springframework.batch.core.step.item.FaultTolerantChunkProcessor
 
setPropagation(Propagation) - Method in class org.springframework.batch.core.step.factory.SimpleStepFactoryBean
 
setProxyTargetClass(boolean) - Method in class org.springframework.batch.core.scope.StepScope
Flag to indicate that proxies should use dynamic subclassing.
setReadCount(int) - Method in class org.springframework.batch.core.StepExecution
Sets the current number of read items for this execution
setReadSkipCount(int) - Method in class org.springframework.batch.core.StepExecution
Set the number of records skipped on read
setReflectionProvider(ReflectionProvider) - Method in class org.springframework.batch.core.repository.dao.XStreamExecutionContextStringSerializer
 
setRepositoryFactory(MapJobRepositoryFactoryBean) - Method in class org.springframework.batch.core.explore.support.MapJobExplorerFactoryBean
The repository factory that can be used to create daos for the explorer.
setRequiredKeys(String[]) - Method in class org.springframework.batch.core.job.DefaultJobParametersValidator
The keys that are required in the parameters.
setResources(Resource[]) - Method in class org.springframework.batch.core.configuration.support.ClasspathXmlApplicationContextsFactoryBean
A set of resources to load using a GenericApplicationContextFactory.
setResources(Resource[]) - Method in class org.springframework.batch.core.partition.support.MultiResourcePartitioner
The resources to assign to each partition.
setRestartable(boolean) - Method in class org.springframework.batch.core.job.AbstractJob
Boolean flag to prevent categorically a job from restarting, even if it has failed previously.
setRestartable(boolean) - Method in class org.springframework.batch.core.job.builder.JobBuilderHelper.CommonJobProperties
 
setRetryableExceptionClasses(Map<Class<? extends Throwable>, Boolean>) - Method in class org.springframework.batch.core.step.factory.FaultTolerantStepFactoryBean
Public setter for the retryable exceptions classifier map (from throwable class to boolean, true is retryable).
setRetryContextCache(RetryContextCache) - Method in class org.springframework.batch.core.step.factory.FaultTolerantStepFactoryBean
Override the default retry context cache for retry of chunk processing.
setRetryContextCache(RetryContextCache) - Method in class org.springframework.batch.core.step.item.BatchRetryTemplate
 
setRetryLimit(int) - Method in class org.springframework.batch.core.step.factory.FaultTolerantStepFactoryBean
Public setter for the retry limit.
setRetryListeners(RetryListener...) - Method in class org.springframework.batch.core.step.factory.FaultTolerantStepFactoryBean
Public setter for the RetryListeners.
setRetryPolicy(RetryPolicy) - Method in class org.springframework.batch.core.step.factory.FaultTolerantStepFactoryBean
Setter for the retry policy.
setRetryPolicy(RetryPolicy) - Method in class org.springframework.batch.core.step.item.BatchRetryTemplate
 
setRollbackClassifier(Classifier<Throwable, Boolean>) - Method in class org.springframework.batch.core.step.item.FaultTolerantChunkProcessor
A classifier that can distinguish between exceptions that cause rollback (return true) or not (return false).
setRollbackClassifier(Classifier<Throwable, Boolean>) - Method in class org.springframework.batch.core.step.item.FaultTolerantChunkProvider
Classifier to determine whether exceptions have been marked as no-rollback (as opposed to skippable).
setRollbackCount(int) - Method in class org.springframework.batch.core.StepExecution
Setter for number of rollbacks for this execution
setSerializer(ExecutionContextSerializer) - Method in class org.springframework.batch.core.explore.support.JobExplorerFactoryBean
A custom implementation of the ExecutionContextSerializer.
setSerializer(ExecutionContextSerializer) - Method in class org.springframework.batch.core.repository.dao.JdbcExecutionContextDao
Setter for Serializer implementation
setSerializer(ExecutionContextSerializer) - Method in class org.springframework.batch.core.repository.support.JobRepositoryFactoryBean
A custom implementation of the ExecutionContextSerializer.
setShortContextLength(int) - Method in class org.springframework.batch.core.repository.dao.JdbcExecutionContextDao
The maximum size that an execution context can have and still be stored completely in short form in the column SHORT_CONTEXT.
setSingleton(boolean) - Method in class org.springframework.batch.core.step.factory.SimpleStepFactoryBean
Public setter for the singleton flag.
setSkipLimit(int) - Method in class org.springframework.batch.core.step.factory.FaultTolerantStepFactoryBean
A limit that determines skip policy.
setSkipLimit(int) - Method in class org.springframework.batch.core.step.skip.LimitCheckingItemSkipPolicy
The absolute number of skips (of skippable exceptions) that can be tolerated before a failure.
setSkippableExceptionClasses(Map<Class<? extends Throwable>, Boolean>) - Method in class org.springframework.batch.core.step.factory.FaultTolerantStepFactoryBean
Exception classes that when raised won't crash the job but will result in the item which handling caused the exception being skipped.
setSkippableExceptionClassifier(Classifier<Throwable, Boolean>) - Method in class org.springframework.batch.core.step.skip.LimitCheckingItemSkipPolicy
The classifier that will be used to decide on skippability.
setSkippableExceptionMap(Map<Class<? extends Throwable>, Boolean>) - Method in class org.springframework.batch.core.step.skip.LimitCheckingItemSkipPolicy
Set up the classifier through a convenient map from throwable class to boolean (true if skippable).
setSkipPolicies(SkipPolicy[]) - Method in class org.springframework.batch.core.step.skip.CompositeSkipPolicy
 
setSkipPolicy(SkipPolicy) - Method in class org.springframework.batch.core.step.factory.FaultTolerantStepFactoryBean
A SkipPolicy that determines the outcome of an exception when processing an item.
setSkipPolicy(SkipPolicy) - Method in class org.springframework.batch.core.step.item.FaultTolerantChunkProvider
The policy that determines whether exceptions can be skipped on read.
setStartLimit(int) - Method in class org.springframework.batch.core.step.AbstractStep
Public setter for the startLimit.
setStartLimit(Integer) - Method in class org.springframework.batch.core.step.builder.StepBuilderHelper.CommonStepProperties
 
setStartLimit(int) - Method in class org.springframework.batch.core.step.factory.SimpleStepFactoryBean
Public setter for the start limit for the step.
setStartTime(Date) - Method in class org.springframework.batch.core.JobExecution
 
setStartTime(Date) - Method in class org.springframework.batch.core.StepExecution
Sets the time this execution started
setStateTransitions(List<StateTransition>) - Method in class org.springframework.batch.core.configuration.xml.SimpleFlowFactoryBean
The raw state transitions for the flow.
setStateTransitions(List<StateTransition>) - Method in class org.springframework.batch.core.job.flow.support.SimpleFlow
Public setter for the stateTransitions.
setStatus(BatchStatus) - Method in class org.springframework.batch.core.JobExecution
Set the value of the status field.
setStatus(BatchStatus) - Method in class org.springframework.batch.core.StepExecution
Sets the current status of this step
setStatuses(String[]) - Method in class org.springframework.batch.core.listener.ExecutionContextPromotionListener
 
setStep(Step) - Method in class org.springframework.batch.core.partition.support.TaskExecutorPartitionHandler
Setter for the Step that will be used to execute the partitioned StepExecution.
setStepExecutionAggregator(StepExecutionAggregator) - Method in class org.springframework.batch.core.partition.support.PartitionStep
A StepExecutionAggregator that can aggregate step executions when they come back from the handler.
setStepExecutionIncrementer(DataFieldMaxValueIncrementer) - Method in class org.springframework.batch.core.repository.dao.JdbcStepExecutionDao
 
setStepExecutionListeners(StepExecutionListener[]) - Method in class org.springframework.batch.core.step.AbstractStep
Register each of the objects as listeners.
setStepExecutionSplitter(StepExecutionSplitter) - Method in class org.springframework.batch.core.partition.support.PartitionStep
Public setter for mandatory property StepExecutionSplitter.
setStepLocator(StepLocator) - Method in class org.springframework.batch.core.step.StepLocatorStepFactoryBean
 
setStepName(String) - Method in class org.springframework.batch.core.partition.support.SimpleStepExecutionSplitter
The name of the target step that will be executed across the partitions.
setStepName(String) - Method in class org.springframework.batch.core.step.StepLocatorStepFactoryBean
 
setStepOperations(RepeatOperations) - Method in class org.springframework.batch.core.step.factory.SimpleStepFactoryBean
Public setter for the stepOperations.
setStepOperations(RepeatOperations) - Method in class org.springframework.batch.core.step.tasklet.TaskletStep
The RepeatOperations to use for the outer loop of the batch processing.
setStepRegistry(StepRegistry) - Method in class org.springframework.batch.core.configuration.support.DefaultJobLoader
The StepRegistry to use for the steps of created jobs.
setSteps(List<Step>) - Method in class org.springframework.batch.core.job.SimpleJob
Public setter for the steps in this job.
setStreams(ItemStream[]) - Method in class org.springframework.batch.core.step.factory.SimpleStepFactoryBean
The streams to inject into the Step.
setStreams(ItemStream[]) - Method in class org.springframework.batch.core.step.tasklet.TaskletStep
Register each of the streams for callbacks at the appropriate time in the step.
setStrict(boolean) - Method in class org.springframework.batch.core.listener.ExecutionContextPromotionListener
If set to TRUE, the listener will throw an exception if any 'key' is not found in the Step ExecutionContext.
setSystemExiter(SystemExiter) - Method in class org.springframework.batch.core.launch.support.CommandLineJobRunner
Injection setter for the SystemExiter.
setSystemProcessExitCodeMapper(SystemProcessExitCodeMapper) - Method in class org.springframework.batch.core.step.tasklet.SystemCommandTasklet
 
setTablePrefix(String) - Method in class org.springframework.batch.core.explore.support.JobExplorerFactoryBean
Sets the table prefix for all the batch meta-data tables.
setTablePrefix(String) - Method in class org.springframework.batch.core.repository.dao.AbstractJdbcBatchMetadataDao
Public setter for the table prefix property.
setTablePrefix(String) - Method in class org.springframework.batch.core.repository.support.JobRepositoryFactoryBean
Sets the table prefix for all the batch meta-data tables.
setTaskExecutor(TaskExecutor) - Method in class org.springframework.batch.core.job.flow.support.state.SplitState
Public setter for the taskExecutor.
setTaskExecutor(TaskExecutor) - Method in class org.springframework.batch.core.launch.support.SimpleJobLauncher
Set the TaskExecutor.
setTaskExecutor(TaskExecutor) - Method in class org.springframework.batch.core.partition.support.TaskExecutorPartitionHandler
Setter for the TaskExecutor that is used to farm out step executions to multiple threads.
setTaskExecutor(TaskExecutor) - Method in class org.springframework.batch.core.step.factory.SimpleStepFactoryBean
Public setter for the TaskExecutor.
setTaskExecutor(TaskExecutor) - Method in class org.springframework.batch.core.step.tasklet.SystemCommandTasklet
Sets the task executor that will be used to execute the system command NB! Avoid using a synchronous task executor
setTasklet(Tasklet) - Method in class org.springframework.batch.core.step.tasklet.TaskletStep
Public setter for the Tasklet.
setTerminateOnly() - Method in class org.springframework.batch.core.StepExecution
Set a flag that will signal to an execution environment that this execution (and its surrounding job) wishes to exit.
setTerminationCheckInterval(long) - Method in class org.springframework.batch.core.step.tasklet.SystemCommandTasklet
The time interval how often the tasklet will check for termination status.
setThrottleLimit(int) - Method in class org.springframework.batch.core.step.factory.SimpleStepFactoryBean
Public setter for the throttle limit.
setTimeout(long) - Method in class org.springframework.batch.core.step.tasklet.SystemCommandTasklet
Timeout in milliseconds.
setTransactionAttribute(TransactionAttribute) - Method in class org.springframework.batch.core.step.tasklet.TaskletStep
Public setter for the TransactionAttribute.
setTransactionManager(PlatformTransactionManager) - Method in class org.springframework.batch.core.repository.support.AbstractJobRepositoryFactoryBean
Public setter for the PlatformTransactionManager.
setTransactionManager(PlatformTransactionManager) - Method in class org.springframework.batch.core.step.builder.StepBuilderHelper.CommonStepProperties
 
setTransactionManager(PlatformTransactionManager) - Method in class org.springframework.batch.core.step.factory.SimpleStepFactoryBean
Public setter for the PlatformTransactionManager.
setTransactionManager(PlatformTransactionManager) - Method in class org.springframework.batch.core.step.tasklet.TaskletStep
Public setter for the PlatformTransactionManager.
setTransactionTimeout(int) - Method in class org.springframework.batch.core.step.factory.SimpleStepFactoryBean
The timeout for an individual transaction in the step.
setUserData(Object) - Method in class org.springframework.batch.core.step.item.Chunk
 
setValidateTransactionState(boolean) - Method in class org.springframework.batch.core.repository.support.AbstractJobRepositoryFactoryBean
Flag to determine whether to check for an existing transaction when a JobExecution is created.
setValidators(List<JobParametersValidator>) - Method in class org.springframework.batch.core.job.CompositeJobParametersValidator
Public setter for the validators
setValues(PreparedStatement) - Method in class org.springframework.batch.core.resource.ListPreparedStatementSetter
 
setVersion(Integer) - Method in class org.springframework.batch.core.Entity
Public setter for the version needed only by repository methods.
setWorkingDirectory(String) - Method in class org.springframework.batch.core.step.tasklet.SystemCommandTasklet
 
setWriteCount(int) - Method in class org.springframework.batch.core.StepExecution
Sets the current number of written items for this execution
setWriteSkipCount(int) - Method in class org.springframework.batch.core.StepExecution
Set the number of records skipped on write
setWriteSkipPolicy(SkipPolicy) - Method in class org.springframework.batch.core.step.item.FaultTolerantChunkProcessor
 
shouldSkip(Throwable, int) - Method in class org.springframework.batch.core.step.skip.AlwaysSkipItemSkipPolicy
 
shouldSkip(Throwable, int) - Method in class org.springframework.batch.core.step.skip.CompositeSkipPolicy
 
shouldSkip(Throwable, int) - Method in class org.springframework.batch.core.step.skip.ExceptionClassifierSkipPolicy
Consult the classifier and find a delegate policy, and then use that to determine the outcome.
shouldSkip(Throwable, int) - Method in class org.springframework.batch.core.step.skip.LimitCheckingItemSkipPolicy
Given the provided exception and skip count, determine whether or not processing should continue for the given exception.
shouldSkip(Throwable, int) - Method in class org.springframework.batch.core.step.skip.NeverSkipItemSkipPolicy
 
shouldSkip(Throwable, int) - Method in interface org.springframework.batch.core.step.skip.SkipPolicy
Returns true or false, indicating whether or not processing should continue with the given throwable.
SimpleBatchConfiguration - Class in org.springframework.batch.core.configuration.annotation
Base Configuration class providing common structure for enabling and using Spring Batch.
SimpleBatchConfiguration() - Constructor for class org.springframework.batch.core.configuration.annotation.SimpleBatchConfiguration
 
SimpleChunkProcessor<I,O> - Class in org.springframework.batch.core.step.item
Simple implementation of the ChunkProcessor interface that handles basic item writing and processing.
SimpleChunkProcessor(ItemProcessor<? super I, ? extends O>, ItemWriter<? super O>) - Constructor for class org.springframework.batch.core.step.item.SimpleChunkProcessor
 
SimpleChunkProvider<I> - Class in org.springframework.batch.core.step.item
Simple implementation of the ChunkProvider interface that does basic chunk providing from an ItemReader.
SimpleChunkProvider(ItemReader<? extends I>, RepeatOperations) - Constructor for class org.springframework.batch.core.step.item.SimpleChunkProvider
 
SimpleFlow - Class in org.springframework.batch.core.job.flow.support
A Flow that branches conditionally depending on the exit status of the last State.
SimpleFlow(String) - Constructor for class org.springframework.batch.core.job.flow.support.SimpleFlow
Create a flow with the given name.
SimpleFlowFactoryBean - Class in org.springframework.batch.core.configuration.xml
Convenience factory for SimpleFlow instances for use in XML namespace.
SimpleFlowFactoryBean() - Constructor for class org.springframework.batch.core.configuration.xml.SimpleFlowFactoryBean
 
SimpleJob - Class in org.springframework.batch.core.job
Simple implementation of Job interface providing the ability to run a JobExecution.
SimpleJob() - Constructor for class org.springframework.batch.core.job.SimpleJob
Default constructor for job with null name
SimpleJob(String) - Constructor for class org.springframework.batch.core.job.SimpleJob
 
SimpleJobBuilder - Class in org.springframework.batch.core.job.builder
 
SimpleJobBuilder(JobBuilderHelper<?>) - Constructor for class org.springframework.batch.core.job.builder.SimpleJobBuilder
Create a new builder initialized with any properties in the parent.
SimpleJobExplorer - Class in org.springframework.batch.core.explore.support
Implementation of JobExplorer using the injected DAOs.
SimpleJobExplorer(JobInstanceDao, JobExecutionDao, StepExecutionDao, ExecutionContextDao) - Constructor for class org.springframework.batch.core.explore.support.SimpleJobExplorer
 
SimpleJobLauncher - Class in org.springframework.batch.core.launch.support
Simple implementation of the JobLauncher interface.
SimpleJobLauncher() - Constructor for class org.springframework.batch.core.launch.support.SimpleJobLauncher
 
SimpleJobOperator - Class in org.springframework.batch.core.launch.support
Simple implementation of the JobOperator interface.
SimpleJobOperator() - Constructor for class org.springframework.batch.core.launch.support.SimpleJobOperator
 
SimpleJobRepository - Class in org.springframework.batch.core.repository.support
Implementation of JobRepository that stores JobInstances, JobExecutions, and StepExecutions using the injected DAOs.
SimpleJobRepository(JobInstanceDao, JobExecutionDao, StepExecutionDao, ExecutionContextDao) - Constructor for class org.springframework.batch.core.repository.support.SimpleJobRepository
 
SimpleJvmExitCodeMapper - Class in org.springframework.batch.core.launch.support
An implementation of ExitCodeMapper that can be configured through a map from batch exit codes (String) to integer results.
SimpleJvmExitCodeMapper() - Constructor for class org.springframework.batch.core.launch.support.SimpleJvmExitCodeMapper
 
SimplePartitioner - Class in org.springframework.batch.core.partition.support
Simplest possible implementation of Partitioner.
SimplePartitioner() - Constructor for class org.springframework.batch.core.partition.support.SimplePartitioner
 
SimpleRetryExceptionHandler - Class in org.springframework.batch.core.step.item
An ExceptionHandler that is aware of the retry context so that it can distinguish between a fatal exception and one that can be retried.
SimpleRetryExceptionHandler(RetryPolicy, ExceptionHandler, Collection<Class<? extends Throwable>>) - Constructor for class org.springframework.batch.core.step.item.SimpleRetryExceptionHandler
Create an exception handler from its mandatory properties.
SimpleStepBuilder<I,O> - Class in org.springframework.batch.core.step.builder
Step builder for simple item processing (chunk oriented) steps.
SimpleStepBuilder(StepBuilderHelper<?>) - Constructor for class org.springframework.batch.core.step.builder.SimpleStepBuilder
Create a new builder initialized with any properties in the parent.
SimpleStepBuilder(SimpleStepBuilder<I, O>) - Constructor for class org.springframework.batch.core.step.builder.SimpleStepBuilder
Create a new builder initialized with any properties in the parent.
SimpleStepExecutionSplitter - Class in org.springframework.batch.core.partition.support
Generic implementation of StepExecutionSplitter that delegates to a Partitioner to generate ExecutionContext instances.
SimpleStepExecutionSplitter() - Constructor for class org.springframework.batch.core.partition.support.SimpleStepExecutionSplitter
Default constructor for convenience in configuration.
SimpleStepExecutionSplitter(JobRepository, boolean, String, Partitioner) - Constructor for class org.springframework.batch.core.partition.support.SimpleStepExecutionSplitter
Construct a SimpleStepExecutionSplitter from its mandatory properties.
SimpleStepExecutionSplitter(JobRepository, Step, Partitioner) - Constructor for class org.springframework.batch.core.partition.support.SimpleStepExecutionSplitter
SimpleStepFactoryBean<T,S> - Class in org.springframework.batch.core.step.factory
Most common configuration options for simple steps should be found here.
SimpleStepFactoryBean() - Constructor for class org.springframework.batch.core.step.factory.SimpleStepFactoryBean
Default constructor for SimpleStepFactoryBean.
SimpleStepHandler - Class in org.springframework.batch.core.job
Implementation of StepHandler that manages repository and restart concerns.
SimpleStepHandler() - Constructor for class org.springframework.batch.core.job.SimpleStepHandler
Convenient default constructor for configuration usage.
SimpleStepHandler(JobRepository) - Constructor for class org.springframework.batch.core.job.SimpleStepHandler
 
SimpleStepHandler(JobRepository, ExecutionContext) - Constructor for class org.springframework.batch.core.job.SimpleStepHandler
 
SimpleSystemProcessExitCodeMapper - Class in org.springframework.batch.core.step.tasklet
Simple SystemProcessExitCodeMapper implementation that performs following mapping: 0 -> ExitStatus.FINISHED else -> ExitStatus.FAILED
SimpleSystemProcessExitCodeMapper() - Constructor for class org.springframework.batch.core.step.tasklet.SimpleSystemProcessExitCodeMapper
 
size() - Method in class org.springframework.batch.core.step.item.Chunk
 
skip(Class<? extends Throwable>) - Method in class org.springframework.batch.core.step.builder.FaultTolerantStepBuilder
Explicitly request certain exceptions (and subclasses) to be skipped.
skip(Exception) - Method in class org.springframework.batch.core.step.item.Chunk
Register an anonymous skip.
SkipException - Exception in org.springframework.batch.core.step.skip
Base exception indicating that the skip has failed or caused a failure.
SkipException(String, Throwable) - Constructor for exception org.springframework.batch.core.step.skip.SkipException
 
SkipException(String) - Constructor for exception org.springframework.batch.core.step.skip.SkipException
 
skipLimit(int) - Method in class org.springframework.batch.core.step.builder.FaultTolerantStepBuilder
Sets the maximium number of failed items to skip before the step fails.
SkipLimitExceededException - Exception in org.springframework.batch.core.step.skip
Exception indicating that the skip limit for a particular has been exceeded.
SkipLimitExceededException(int, Throwable) - Constructor for exception org.springframework.batch.core.step.skip.SkipLimitExceededException
 
SkipListener<T,S> - Interface in org.springframework.batch.core
Interface for listener to skipped items.
SkipListenerFailedException - Exception in org.springframework.batch.core.step.skip
Special exception to indicate a failure in a skip listener.
SkipListenerFailedException(String, RuntimeException, Throwable) - Constructor for exception org.springframework.batch.core.step.skip.SkipListenerFailedException
 
SkipListenerSupport<T,S> - Class in org.springframework.batch.core.listener
Basic no-op implementations of all SkipListener implementations.
SkipListenerSupport() - Constructor for class org.springframework.batch.core.listener.SkipListenerSupport
 
SkipOverflowException - Exception in org.springframework.batch.core.step.item
 
SkipOverflowException(String) - Constructor for exception org.springframework.batch.core.step.item.SkipOverflowException
 
skipPolicy(SkipPolicy) - Method in class org.springframework.batch.core.step.builder.FaultTolerantStepBuilder
Provide an explicit policy for managing skips.
SkipPolicy - Interface in org.springframework.batch.core.step.skip
Policy for determining whether or not some processing should be skipped.
SkipPolicyFailedException - Exception in org.springframework.batch.core.step.skip
Special exception to indicate a failure in a skip policy.
SkipPolicyFailedException(String, RuntimeException, Throwable) - Constructor for exception org.springframework.batch.core.step.skip.SkipPolicyFailedException
 
SkipWrapper<T> - Class in org.springframework.batch.core.step.item
Wrapper for an item and its exception if it failed processing.
SkipWrapper(T) - Constructor for class org.springframework.batch.core.step.item.SkipWrapper
 
SkipWrapper(Throwable) - Constructor for class org.springframework.batch.core.step.item.SkipWrapper
 
SkipWrapper(T, Throwable) - Constructor for class org.springframework.batch.core.step.item.SkipWrapper
 
split(TaskExecutor) - Method in class org.springframework.batch.core.job.builder.FlowBuilder
 
split(TaskExecutor) - Method in class org.springframework.batch.core.job.builder.SimpleJobBuilder
 
split(StepExecution, int) - Method in interface org.springframework.batch.core.partition.StepExecutionSplitter
Partition the provided StepExecution into a set of parallel executable instances with the same parent JobExecution.
split(StepExecution, int) - Method in class org.springframework.batch.core.partition.support.SimpleStepExecutionSplitter
 
SplitParser - Class in org.springframework.batch.core.configuration.xml
Internal parser for the <split/> elements inside a job.
SplitParser(String) - Constructor for class org.springframework.batch.core.configuration.xml.SplitParser
Construct a InlineFlowParser using the provided job repository ref.
SplitState - Class in org.springframework.batch.core.job.flow.support.state
A State implementation that splits a Flow into multiple parallel subflows.
SplitState(Collection<Flow>, String) - Constructor for class org.springframework.batch.core.job.flow.support.state.SplitState
 
splitter(StepExecutionSplitter) - Method in class org.springframework.batch.core.step.builder.PartitionStepBuilder
Provide an explicit StepExecutionSplitter instead of having one build from the PartitionStepBuilder.partitioner(String, Partitioner).
StandaloneStepParser - Class in org.springframework.batch.core.configuration.xml
Internal parser for the <step/> elements for a job.
StandaloneStepParser() - Constructor for class org.springframework.batch.core.configuration.xml.StandaloneStepParser
 
start() - Method in class org.springframework.batch.core.configuration.support.AutomaticJobRegistrar
Take all the contexts from the factories provided and pass them to the JobLoader.
start(Step) - Method in class org.springframework.batch.core.job.builder.FlowBuilder
Start a flow.
start(JobExecutionDecider) - Method in class org.springframework.batch.core.job.builder.FlowBuilder
If a flow should start with a decision use this as the first state.
start(Flow) - Method in class org.springframework.batch.core.job.builder.FlowBuilder
If a flow should start with a subflow use this as the first state.
start(Flow) - Method in class org.springframework.batch.core.job.builder.FlowJobBuilder
Start a job with this flow, but expect to transition from there to other flows or steps.
start(Step) - Method in class org.springframework.batch.core.job.builder.FlowJobBuilder
Start a job with this step, but expect to transition from there to other flows or steps.
start(Step) - Method in class org.springframework.batch.core.job.builder.JobBuilder
Create a new job builder that will execute a step or sequence of steps.
start(Flow) - Method in class org.springframework.batch.core.job.builder.JobBuilder
Create a new job builder that will execute a flow.
start(Step) - Method in class org.springframework.batch.core.job.builder.SimpleJobBuilder
Start the job with this step.
start(JobExecutionDecider) - Method in class org.springframework.batch.core.job.builder.SimpleJobBuilder
Start with this decider.
start(FlowExecutor) - Method in interface org.springframework.batch.core.job.flow.Flow
 
start(FlowExecutor) - Method in class org.springframework.batch.core.job.flow.support.SimpleFlow
 
start(String, String) - Method in interface org.springframework.batch.core.launch.JobOperator
Start a new instance of a job with the parameters specified.
start(String, String) - Method in class org.springframework.batch.core.launch.support.SimpleJobOperator
 
start(RepeatContext) - Method in class org.springframework.batch.core.resource.StepExecutionSimpleCompletionPolicy
 
startLimit(int) - Method in class org.springframework.batch.core.step.builder.StepBuilderHelper
 
StartLimitExceededException - Exception in org.springframework.batch.core
Indicates the step's start limit has been exceeded.
StartLimitExceededException(String) - Constructor for exception org.springframework.batch.core.StartLimitExceededException
 
startNextInstance(String) - Method in interface org.springframework.batch.core.launch.JobOperator
Launch the next in a sequence of JobInstance determined by the JobParametersIncrementer attached to the specified job.
startNextInstance(String) - Method in class org.springframework.batch.core.launch.support.SimpleJobOperator
 
State - Interface in org.springframework.batch.core.job.flow
 
StateTransition - Class in org.springframework.batch.core.job.flow.support
Value object representing a potential transition from one State to another.
Step - Interface in org.springframework.batch.core
Batch domain interface representing the configuration of a step.
step(Step) - Method in class org.springframework.batch.core.step.builder.PartitionStepBuilder
Provide an actual step instance to execute in parallel.
StepBuilder - Class in org.springframework.batch.core.step.builder
Convenient entry point for building all kinds of steps.
StepBuilder(String) - Constructor for class org.springframework.batch.core.step.builder.StepBuilder
Initialize a step builder for a step with the given name.
StepBuilderException - Exception in org.springframework.batch.core.step.builder
Utility exception thrown by builders when they encounter unexpected checked exceptions.
StepBuilderException(Exception) - Constructor for exception org.springframework.batch.core.step.builder.StepBuilderException
 
StepBuilderFactory - Class in org.springframework.batch.core.configuration.annotation
Convenient factory for a StepBuilder which sets the JobRepository and PlatformTransactionManager automatically.
StepBuilderFactory(JobRepository, PlatformTransactionManager) - Constructor for class org.springframework.batch.core.configuration.annotation.StepBuilderFactory
 
StepBuilderHelper<B extends StepBuilderHelper<B>> - Class in org.springframework.batch.core.step.builder
A base class and utility for other step builders providing access to common properties like job repository and transaction manager.
StepBuilderHelper(String) - Constructor for class org.springframework.batch.core.step.builder.StepBuilderHelper
 
StepBuilderHelper(StepBuilderHelper<?>) - Constructor for class org.springframework.batch.core.step.builder.StepBuilderHelper
Create a new builder initialized with any properties in the parent.
StepBuilderHelper.CommonStepProperties - Class in org.springframework.batch.core.step.builder
 
StepBuilderHelper.CommonStepProperties() - Constructor for class org.springframework.batch.core.step.builder.StepBuilderHelper.CommonStepProperties
 
StepBuilderHelper.CommonStepProperties(StepBuilderHelper.CommonStepProperties) - Constructor for class org.springframework.batch.core.step.builder.StepBuilderHelper.CommonStepProperties
 
stepBuilders() - Method in class org.springframework.batch.core.configuration.annotation.AbstractBatchConfiguration
 
StepContext - Class in org.springframework.batch.core.scope.context
A context object that can be used to interrogate the current StepExecution and some of its associated properties using expressions based on bean paths.
StepContext(StepExecution) - Constructor for class org.springframework.batch.core.scope.context.StepContext
Create a new instance of StepContext for this StepExecution.
StepContextRepeatCallback - Class in org.springframework.batch.core.scope.context
Convenient base class for clients who need to do something in a repeat callback inside a Step.
StepContextRepeatCallback(StepExecution) - Constructor for class org.springframework.batch.core.scope.context.StepContextRepeatCallback
 
StepContribution - Class in org.springframework.batch.core
Represents a contribution to a StepExecution, buffering changes until they can be applied at a chunk boundary.
StepContribution(StepExecution) - Constructor for class org.springframework.batch.core.StepContribution
 
StepExecution - Class in org.springframework.batch.core
Batch domain object representation the execution of a step.
StepExecution(String, JobExecution, Long) - Constructor for class org.springframework.batch.core.StepExecution
Constructor with mandatory properties.
StepExecution(String, JobExecution) - Constructor for class org.springframework.batch.core.StepExecution
Constructor that substitutes in null for the execution id
StepExecutionAggregator - Interface in org.springframework.batch.core.partition.support
Strategy for a aggregating step executions, usually when they are the result of partitioned or remote execution.
StepExecutionDao - Interface in org.springframework.batch.core.repository.dao
 
StepExecutionListener - Interface in org.springframework.batch.core
Listener interface for the lifecycle of a Step.
stepExecutionListenerMetaData() - Static method in enum org.springframework.batch.core.listener.StepListenerMetaData
 
StepExecutionListenerSupport - Class in org.springframework.batch.core.listener
 
StepExecutionListenerSupport() - Constructor for class org.springframework.batch.core.listener.StepExecutionListenerSupport
 
StepExecutionSimpleCompletionPolicy - Class in org.springframework.batch.core.resource
A CompletionPolicy that picks up a commit interval from JobParameters by listening to the start of a step.
StepExecutionSimpleCompletionPolicy() - Constructor for class org.springframework.batch.core.resource.StepExecutionSimpleCompletionPolicy
 
StepExecutionSplitter - Interface in org.springframework.batch.core.partition
Strategy interface for generating input contexts for a partitioned step execution independent from the fabric they are going to run on.
StepHandler - Interface in org.springframework.batch.core.job
Strategy interface for handling a Step on behalf of a Job.
StepHolder - Interface in org.springframework.batch.core.step
Interface for holders of a Step as a convenience for callers who need access to the underlying instance.
StepInterruptionPolicy - Interface in org.springframework.batch.core.step
Strategy interface for an interruption policy.
StepListener - Interface in org.springframework.batch.core
Marker interface that acts as a parent to all step domain listeners, such as: StepExecutionListener, ChunkListener, ItemReadListener and ItemWriteListener
StepListenerFactoryBean - Class in org.springframework.batch.core.listener
This AbstractListenerFactoryBean implementation is used to create a StepListener.
StepListenerFactoryBean() - Constructor for class org.springframework.batch.core.listener.StepListenerFactoryBean
 
StepListenerFailedException - Exception in org.springframework.batch.core.listener
Exception to indicate a problem in a step listener.
StepListenerFailedException(String, Throwable) - Constructor for exception org.springframework.batch.core.listener.StepListenerFailedException
 
StepListenerMetaData - Enum in org.springframework.batch.core.listener
Enumeration for StepListener meta data, which ties together the names of methods, their interfaces, annotation, and expected arguments.
StepListenerParser - Class in org.springframework.batch.core.configuration.xml
Parser for a step listener element.
StepListenerParser() - Constructor for class org.springframework.batch.core.configuration.xml.StepListenerParser
 
StepListenerParser(ListenerMetaData[]) - Constructor for class org.springframework.batch.core.configuration.xml.StepListenerParser
 
StepListenerSupport<T,S> - Class in org.springframework.batch.core.listener
Basic no-op implementations of all StepListener interfaces.
StepListenerSupport() - Constructor for class org.springframework.batch.core.listener.StepListenerSupport
 
StepLocator - Interface in org.springframework.batch.core.step
Interface for locating a Step instance by name.
stepLocator - Variable in class org.springframework.batch.core.step.StepLocatorStepFactoryBean
 
StepLocatorStepFactoryBean - Class in org.springframework.batch.core.step
Convenience factory for Step instances given a StepLocator.
StepLocatorStepFactoryBean() - Constructor for class org.springframework.batch.core.step.StepLocatorStepFactoryBean
 
stepName - Variable in class org.springframework.batch.core.step.StepLocatorStepFactoryBean
 
stepOperations(RepeatOperations) - Method in class org.springframework.batch.core.step.builder.AbstractTaskletStepBuilder
Sets the repeat template used for iterating the tasklet execution.
StepRegistry - Interface in org.springframework.batch.core.configuration
Registry keeping track of all the Step defined in a Job.
StepScope - Annotation Type in org.springframework.batch.core.configuration.annotation
Convenient annotation for step scoped beans that defaults the proxy mode, so that it doesn't have to be specified explicitly on every bean definition.
StepScope - Class in org.springframework.batch.core.scope
Scope for step context.
StepScope() - Constructor for class org.springframework.batch.core.scope.StepScope
 
StepScopeManager - Class in org.springframework.batch.core.scope.context
Convenient aspect to wrap a single threaded step execution, where the implementation of the Step is not step scope aware (i.e.
StepScopeManager() - Constructor for class org.springframework.batch.core.scope.context.StepScopeManager
 
StepState - Class in org.springframework.batch.core.job.flow.support.state
State implementation that delegates to a FlowExecutor to execute the specified Step.
StepState(Step) - Constructor for class org.springframework.batch.core.job.flow.support.state.StepState
 
StepState(String, Step) - Constructor for class org.springframework.batch.core.job.flow.support.state.StepState
 
StepSynchronizationManager - Class in org.springframework.batch.core.scope.context
Central convenience class for framework use in managing the step scope context.
StepSynchronizationManager() - Constructor for class org.springframework.batch.core.scope.context.StepSynchronizationManager
 
stop() - Method in class org.springframework.batch.core.configuration.support.AutomaticJobRegistrar
Delegates to JobLoader.clear().
stop() - Method in class org.springframework.batch.core.job.builder.FlowBuilder.TransitionBuilder
Signal the successful end of the flow.
stop() - Method in class org.springframework.batch.core.JobExecution
Signal the JobExecution to stop.
stop(long) - Method in interface org.springframework.batch.core.launch.JobOperator
Send a stop signal to the JobExecution with the supplied id.
stop() - Static method in class org.springframework.batch.core.launch.support.JobRegistryBackgroundJobRunner
If embedded in a JVM, call this method to terminate the main method.
stop(long) - Method in class org.springframework.batch.core.launch.support.SimpleJobOperator
 
stopAndRestart(Flow) - Method in class org.springframework.batch.core.job.builder.FlowBuilder.TransitionBuilder
Stop the flow and provide a flow to start with if the flow is restarted.
stopAndRestart(JobExecutionDecider) - Method in class org.springframework.batch.core.job.builder.FlowBuilder.TransitionBuilder
Stop the flow and provide a decider to start with if the flow is restarted.
stopAndRestart(Step) - Method in class org.springframework.batch.core.job.builder.FlowBuilder.TransitionBuilder
Stop the flow and provide a step to start with if the flow is restarted.
STOPPED - Static variable in class org.springframework.batch.core.ExitStatus
Convenient constant value representing finished processing with interrupted status.
STOPPED - Static variable in class org.springframework.batch.core.job.flow.FlowExecutionStatus
Special well-known status value.
stream(ItemStream) - Method in class org.springframework.batch.core.step.builder.AbstractTaskletStepBuilder
Register a stream for callbacks that manage restart data.
stream(ItemStream) - Method in class org.springframework.batch.core.step.builder.FaultTolerantStepBuilder
 
STRING_TYPE - Static variable in class org.springframework.batch.core.converter.DefaultJobParametersConverter
 
switchOriginAndDestination(StateTransition, State, String) - Static method in class org.springframework.batch.core.job.flow.support.StateTransition
Convenience method to switch the origin and destination of a transition, creating a new instance.
synchronizeStatus(JobExecution) - Method in class org.springframework.batch.core.repository.dao.JdbcJobExecutionDao
 
synchronizeStatus(JobExecution) - Method in interface org.springframework.batch.core.repository.dao.JobExecutionDao
Because it may be possible that the status of a JobExecution is updated while running, the following method will synchronize only the status and version fields.
synchronizeStatus(JobExecution) - Method in class org.springframework.batch.core.repository.dao.MapJobExecutionDao
 
SystemCommandException - Exception in org.springframework.batch.core.step.tasklet
Exception indicating failed execution of system command.
SystemCommandException(String) - Constructor for exception org.springframework.batch.core.step.tasklet.SystemCommandException
 
SystemCommandException(String, Throwable) - Constructor for exception org.springframework.batch.core.step.tasklet.SystemCommandException
 
SystemCommandTasklet - Class in org.springframework.batch.core.step.tasklet
Tasklet that executes a system command.
SystemCommandTasklet() - Constructor for class org.springframework.batch.core.step.tasklet.SystemCommandTasklet
 
SystemExiter - Interface in org.springframework.batch.core.launch.support
Interface for exiting the JVM.
SystemProcessExitCodeMapper - Interface in org.springframework.batch.core.step.tasklet
Maps the exit code of a system process to ExitStatus value returned by a system command.

T

taskExecutor(TaskExecutor) - Method in class org.springframework.batch.core.step.builder.AbstractTaskletStepBuilder
Provide a task executor to use when executing the tasklet.
taskExecutor(TaskExecutor) - Method in class org.springframework.batch.core.step.builder.PartitionStepBuilder
Provide a task executor to use when constructing a PartitionHandler from the PartitionStepBuilder.step(Step).
TaskExecutorPartitionHandler - Class in org.springframework.batch.core.partition.support
A PartitionHandler that uses a TaskExecutor to execute the partitioned Step locally in multiple threads.
TaskExecutorPartitionHandler() - Constructor for class org.springframework.batch.core.partition.support.TaskExecutorPartitionHandler
 
tasklet(Tasklet) - Method in class org.springframework.batch.core.step.builder.StepBuilder
Build a step with a custom tasklet, not necessarily item processing.
tasklet(Tasklet) - Method in class org.springframework.batch.core.step.builder.TaskletStepBuilder
 
Tasklet - Interface in org.springframework.batch.core.step.tasklet
Strategy for processing in a step.
taskletListenerMetaData() - Static method in enum org.springframework.batch.core.listener.StepListenerMetaData
 
TaskletParser - Class in org.springframework.batch.core.configuration.xml
Parse a tasklet element for a step.
TaskletParser() - Constructor for class org.springframework.batch.core.configuration.xml.TaskletParser
 
TaskletStep - Class in org.springframework.batch.core.step.tasklet
Simple implementation of executing the step as a call to a Tasklet, possibly repeated, and each call surrounded by a transaction.
TaskletStep() - Constructor for class org.springframework.batch.core.step.tasklet.TaskletStep
Default constructor.
TaskletStep(String) - Constructor for class org.springframework.batch.core.step.tasklet.TaskletStep
 
TaskletStepBuilder - Class in org.springframework.batch.core.step.builder
Builder for tasklet step based on a custom tasklet (not item oriented).
TaskletStepBuilder(StepBuilderHelper<?>) - Constructor for class org.springframework.batch.core.step.builder.TaskletStepBuilder
Create a new builder initialized with any properties in the parent.
testing - Static variable in class org.springframework.batch.core.launch.support.JobRegistryBackgroundJobRunner
 
ThreadStepInterruptionPolicy - Class in org.springframework.batch.core.step
Policy that checks the current thread to see if it has been interrupted.
ThreadStepInterruptionPolicy() - Constructor for class org.springframework.batch.core.step.ThreadStepInterruptionPolicy
 
throttleLimit(int) - Method in class org.springframework.batch.core.step.builder.AbstractTaskletStepBuilder
In the case of an asynchronous AbstractTaskletStepBuilder.taskExecutor(TaskExecutor) the number of concurrent tasklet executions can be throttled (beyond any throttling provided by a thread pool).
to(Step) - Method in class org.springframework.batch.core.job.builder.FlowBuilder.TransitionBuilder
Specify the next step.
to(Flow) - Method in class org.springframework.batch.core.job.builder.FlowBuilder.TransitionBuilder
Specify the next state as a complete flow.
to(JobExecutionDecider) - Method in class org.springframework.batch.core.job.builder.FlowBuilder.TransitionBuilder
Specify the next state as a decision.
toJobParameters() - Method in class org.springframework.batch.core.JobParametersBuilder
Conversion method that takes the current state of this builder and returns it as a JobruntimeParameters object.
TopLevelFlowParser - Class in org.springframework.batch.core.configuration.xml
 
TopLevelFlowParser() - Constructor for class org.springframework.batch.core.configuration.xml.TopLevelFlowParser
 
TopLevelJobListenerParser - Class in org.springframework.batch.core.configuration.xml
Parse <job-listener/> elements in the batch namespace.
TopLevelJobListenerParser() - Constructor for class org.springframework.batch.core.configuration.xml.TopLevelJobListenerParser
 
TopLevelStepListenerParser - Class in org.springframework.batch.core.configuration.xml
Parse <step-listener/> elements in the batch namespace.
TopLevelStepListenerParser() - Constructor for class org.springframework.batch.core.configuration.xml.TopLevelStepListenerParser
 
TopLevelStepParser - Class in org.springframework.batch.core.configuration.xml
Parser for the lt;step/gt; top level element in the Batch namespace.
TopLevelStepParser() - Constructor for class org.springframework.batch.core.configuration.xml.TopLevelStepParser
 
toString() - Method in class org.springframework.batch.core.configuration.support.AbstractApplicationContextFactory
 
toString() - Method in class org.springframework.batch.core.configuration.support.GroupAwareJob
 
toString() - Method in class org.springframework.batch.core.configuration.support.OsgiBundleXmlApplicationContextFactory
 
toString() - Method in class org.springframework.batch.core.Entity
 
toString() - Method in class org.springframework.batch.core.ExitStatus
 
toString() - Method in class org.springframework.batch.core.job.AbstractJob
 
toString() - Method in class org.springframework.batch.core.job.flow.FlowExecution
 
toString() - Method in class org.springframework.batch.core.job.flow.FlowExecutionStatus
 
toString() - Method in class org.springframework.batch.core.job.flow.support.state.AbstractState
 
toString() - Method in class org.springframework.batch.core.job.flow.support.state.EndState
 
toString() - Method in class org.springframework.batch.core.job.flow.support.StateTransition
 
toString() - Method in class org.springframework.batch.core.JobExecution
 
toString() - Method in class org.springframework.batch.core.JobInstance
 
toString() - Method in class org.springframework.batch.core.JobParameter
 
toString() - Method in class org.springframework.batch.core.JobParameters
 
toString() - Method in class org.springframework.batch.core.resource.StepExecutionSimpleCompletionPolicy
Delegates to the wrapped CompletionPolicy if set, otherwise returns the value of StepExecutionSimpleCompletionPolicy.setKeyName(String).
toString() - Method in class org.springframework.batch.core.scope.context.ChunkContext
 
toString() - Method in class org.springframework.batch.core.scope.context.StepContext
 
toString() - Method in class org.springframework.batch.core.step.AbstractStep
 
toString() - Method in class org.springframework.batch.core.step.item.Chunk.ChunkIterator
 
toString() - Method in class org.springframework.batch.core.step.item.Chunk
 
toString() - Method in class org.springframework.batch.core.step.item.SkipWrapper
 
toString() - Method in class org.springframework.batch.core.StepContribution
 
toString() - Method in class org.springframework.batch.core.StepExecution
 
transactionAttribute(TransactionAttribute) - Method in class org.springframework.batch.core.step.builder.AbstractTaskletStepBuilder
Sets the transaction attributes for the tasklet execution.
transactionAttribute(TransactionAttribute) - Method in class org.springframework.batch.core.step.builder.FaultTolerantStepBuilder
 
transactionManager() - Method in class org.springframework.batch.core.configuration.annotation.AbstractBatchConfiguration
 
transactionManager() - Method in class org.springframework.batch.core.configuration.annotation.ModularBatchConfiguration
 
transactionManager() - Method in class org.springframework.batch.core.configuration.annotation.SimpleBatchConfiguration
 
transactionManager(PlatformTransactionManager) - Method in class org.springframework.batch.core.step.builder.StepBuilderHelper
 
transform(StepContribution, Chunk<I>) - Method in class org.springframework.batch.core.step.item.FaultTolerantChunkProcessor
 
transform(StepContribution, Chunk<I>) - Method in class org.springframework.batch.core.step.item.SimpleChunkProcessor
 

U

unbind(JobFactory, Map<String, ?>) - Method in class org.springframework.batch.core.configuration.support.JobFactoryRegistrationListener
Take the JobFactory provided and unregister it with the JobRegistry.
UnexpectedJobExecutionException - Exception in org.springframework.batch.core
Indicates to the framework that a critical error has occurred and processing should immediately stop.
UnexpectedJobExecutionException(String) - Constructor for exception org.springframework.batch.core.UnexpectedJobExecutionException
Constructs a new instance with a message.
UnexpectedJobExecutionException(String, Throwable) - Constructor for exception org.springframework.batch.core.UnexpectedJobExecutionException
Constructs a new instance with a message.
UNKNOWN - Static variable in class org.springframework.batch.core.ExitStatus
Convenient constant value representing unknown state - assumed not continuable.
UNKNOWN - Static variable in class org.springframework.batch.core.job.flow.FlowExecutionStatus
Special well-known status value.
unregister(String) - Method in interface org.springframework.batch.core.configuration.JobRegistry
Unregisters a previously registered Job.
unregister(String) - Method in class org.springframework.batch.core.configuration.support.MapJobRegistry
 
unregisterStepsFromJob(String) - Method in interface org.springframework.batch.core.configuration.StepRegistry
Unregisters all the steps of the given job.
unregisterStepsFromJob(String) - Method in class org.springframework.batch.core.configuration.support.MapStepRegistry
 
update(JobExecution) - Method in interface org.springframework.batch.core.repository.JobRepository
Update the JobExecution (but not its ExecutionContext).
update(StepExecution) - Method in interface org.springframework.batch.core.repository.JobRepository
Update the StepExecution (but not its ExecutionContext).
update(JobExecution) - Method in class org.springframework.batch.core.repository.support.SimpleJobRepository
 
update(StepExecution) - Method in class org.springframework.batch.core.repository.support.SimpleJobRepository
 
update(RepeatContext) - Method in class org.springframework.batch.core.resource.StepExecutionSimpleCompletionPolicy
 
update(ExecutionContext) - Method in class org.springframework.batch.core.step.item.ChunkMonitor
 
updateExecutionContext(JobExecution) - Method in interface org.springframework.batch.core.repository.dao.ExecutionContextDao
Persist the updates of execution context associated with the given jobExecution.
updateExecutionContext(StepExecution) - Method in interface org.springframework.batch.core.repository.dao.ExecutionContextDao
Persist the updates of execution context associated with the given stepExecution.
updateExecutionContext(JobExecution) - Method in class org.springframework.batch.core.repository.dao.JdbcExecutionContextDao
 
updateExecutionContext(StepExecution) - Method in class org.springframework.batch.core.repository.dao.JdbcExecutionContextDao
 
updateExecutionContext(StepExecution) - Method in class org.springframework.batch.core.repository.dao.MapExecutionContextDao
 
updateExecutionContext(JobExecution) - Method in class org.springframework.batch.core.repository.dao.MapExecutionContextDao
 
updateExecutionContext(StepExecution) - Method in interface org.springframework.batch.core.repository.JobRepository
Persist the updated ExecutionContexts of the given StepExecution.
updateExecutionContext(JobExecution) - Method in interface org.springframework.batch.core.repository.JobRepository
Persist the updated ExecutionContext of the given JobExecution.
updateExecutionContext(StepExecution) - Method in class org.springframework.batch.core.repository.support.SimpleJobRepository
 
updateExecutionContext(JobExecution) - Method in class org.springframework.batch.core.repository.support.SimpleJobRepository
 
updateJobExecution(JobExecution) - Method in class org.springframework.batch.core.repository.dao.JdbcJobExecutionDao
Update given JobExecution using a SQL UPDATE statement.
updateJobExecution(JobExecution) - Method in interface org.springframework.batch.core.repository.dao.JobExecutionDao
Update and existing JobExecution.
updateJobExecution(JobExecution) - Method in class org.springframework.batch.core.repository.dao.MapJobExecutionDao
 
updateJobExecutionStatus(FlowExecutionStatus) - Method in interface org.springframework.batch.core.job.flow.FlowExecutor
Handle any status changes that might be needed in the JobExecution.
updateJobExecutionStatus(FlowExecutionStatus) - Method in class org.springframework.batch.core.job.flow.JobFlowExecutor
 
updateStepExecution(StepExecution) - Method in class org.springframework.batch.core.repository.dao.JdbcStepExecutionDao
 
updateStepExecution(StepExecution) - Method in class org.springframework.batch.core.repository.dao.MapStepExecutionDao
 
updateStepExecution(StepExecution) - Method in interface org.springframework.batch.core.repository.dao.StepExecutionDao
Update the given StepExecution Preconditions: Id must not be null.
upgradeStatus(BatchStatus) - Method in class org.springframework.batch.core.JobExecution
Upgrade the status field if the provided value is greater than the existing one.
upgradeStatus(BatchStatus) - Method in class org.springframework.batch.core.StepExecution
Upgrade the status field if the provided value is greater than the existing one.
upgradeTo(BatchStatus) - Method in enum org.springframework.batch.core.BatchStatus
Method used to move status values through their logical progression, and override less severe failures with more severe ones.

V

validate(JobParameters) - Method in class org.springframework.batch.core.job.CompositeJobParametersValidator
Validates the JobParameters according to the injected JobParameterValidators Validation stops and exception is thrown on first validation error
validate(JobParameters) - Method in class org.springframework.batch.core.job.DefaultJobParametersValidator
Check the parameters meet the specification provided.
validate(JobParameters) - Method in interface org.springframework.batch.core.JobParametersValidator
Check the parameters meet whatever requirements are appropriate, and throw an exception if not.
validator(JobParametersValidator) - Method in class org.springframework.batch.core.job.builder.JobBuilderHelper
Add a job parameters validator.
valueOf(String) - Static method in enum org.springframework.batch.core.BatchStatus
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.springframework.batch.core.JobParameter.ParameterType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.springframework.batch.core.listener.JobListenerMetaData
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.springframework.batch.core.listener.StepListenerMetaData
Returns the enum constant of this type with the specified name.
values() - Static method in enum org.springframework.batch.core.BatchStatus
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.springframework.batch.core.JobParameter.ParameterType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.springframework.batch.core.listener.JobListenerMetaData
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.springframework.batch.core.listener.StepListenerMetaData
Returns an array containing the constants of this enum type, in the order they are declared.

W

write(StepContribution, Chunk<I>, Chunk<O>) - Method in class org.springframework.batch.core.step.item.FaultTolerantChunkProcessor
 
write(StepContribution, Chunk<I>, Chunk<O>) - Method in class org.springframework.batch.core.step.item.SimpleChunkProcessor
Simple implementation delegates to the SimpleChunkProcessor.doWrite(List) method and increments the write count in the contribution.
writeItems(List<O>) - Method in class org.springframework.batch.core.step.item.SimpleChunkProcessor
 
writer(ItemWriter<? super O>) - Method in class org.springframework.batch.core.step.builder.SimpleStepBuilder
An item writer that writes a chunk of items.

X

XStreamExecutionContextStringSerializer - Class in org.springframework.batch.core.repository.dao
Implementation that uses XStream and Jettison to provide serialization.
XStreamExecutionContextStringSerializer() - Constructor for class org.springframework.batch.core.repository.dao.XStreamExecutionContextStringSerializer
 
A B C D E F G H I J K L M N O P R S T U V W X 

Copyright © 2014. All Rights Reserved.