Index

A B C D E F G H I J K L M N O P R S T U V W 
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form

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
 
ABANDONED - Enum constant in enum class org.springframework.batch.core.BatchStatus
Status of a batch job that did not stop properly and can not be restarted.
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.
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<T> - 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(AbstractTaskletStepBuilder<?>) - Constructor for class org.springframework.batch.core.step.builder.AbstractTaskletStepBuilder
Create a new builder initialized with any properties in the parent.
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
 
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 a single ApplicationContextFactory to the set that is 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 existing 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
Add a Throwable to failure exceptions.
addJobExecutionListener(JobExecutionListener) - Method in class org.springframework.batch.core.job.builder.JobBuilderHelper.CommonJobProperties
 
addJobParameter(String, JobParameter<?>) - Method in class org.springframework.batch.core.JobParametersBuilder
Add a new JobParameter for the given key.
addJobParameter(String, T, Class<T>) - Method in class org.springframework.batch.core.JobParametersBuilder
Add an identifying job parameter.
addJobParameter(String, T, Class<T>, boolean) - Method in class org.springframework.batch.core.JobParametersBuilder
Add a job parameter.
addJobParameters(JobParameters) - Method in class org.springframework.batch.core.JobParametersBuilder
Copy job parameters into the current state.
addLocalDate(String, LocalDate) - Method in class org.springframework.batch.core.JobParametersBuilder
Add a new identifying LocalDate parameter for the given key.
addLocalDate(String, LocalDate, boolean) - Method in class org.springframework.batch.core.JobParametersBuilder
Add a new LocalDate parameter for the given key.
addLocalDateTime(String, LocalDateTime) - Method in class org.springframework.batch.core.JobParametersBuilder
Add a new identifying LocalDateTime parameter for the given key.
addLocalDateTime(String, LocalDateTime, boolean) - Method in class org.springframework.batch.core.JobParametersBuilder
Add a new LocalDateTime parameter for the given key.
addLocalTime(String, LocalTime) - Method in class org.springframework.batch.core.JobParametersBuilder
Add a new identifying LocalTime parameter for the given key.
addLocalTime(String, LocalTime, boolean) - Method in class org.springframework.batch.core.JobParametersBuilder
Add a new LocalTime parameter for the given key.
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
Deprecated, for removal: This API element is subject to removal in a future version.
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 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.
AFTER_CHUNK - Enum constant in enum class org.springframework.batch.core.listener.StepListenerMetaData
 
AFTER_CHUNK_ERROR - Enum constant in enum class org.springframework.batch.core.listener.StepListenerMetaData
 
AFTER_JOB - Enum constant in enum class org.springframework.batch.core.listener.JobListenerMetaData
 
AFTER_PROCESS - Enum constant in enum class org.springframework.batch.core.listener.StepListenerMetaData
 
AFTER_READ - Enum constant in enum class org.springframework.batch.core.listener.StepListenerMetaData
 
AFTER_STEP - Enum constant in enum class org.springframework.batch.core.listener.StepListenerMetaData
 
AFTER_WRITE - Enum constant in enum class org.springframework.batch.core.listener.StepListenerMetaData
 
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
Deprecated.
 
afterChunk(ChunkContext) - Method in class org.springframework.batch.core.listener.CompositeChunkListener
Call the registered listeners in reverse order.
afterChunk(ChunkContext) - Method in class org.springframework.batch.core.listener.MulticasterBatchListener
 
AfterChunk - Annotation Interface in org.springframework.batch.core.annotation
Marks a method to be called after a chunk is executed.

Expected signature: void afterChunk(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
Deprecated.
 
afterChunkError(ChunkContext) - Method in class org.springframework.batch.core.listener.CompositeChunkListener
Call the registered listeners in reverse order.
afterChunkError(ChunkContext) - Method in class org.springframework.batch.core.listener.MulticasterBatchListener
 
AfterChunkError - Annotation Interface in org.springframework.batch.core.annotation
Marks a method to be called after a chunk has failed and been marked for rollback.

Expected signature: void afterFailedChunk(ChunkContext context)
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
Deprecated.
 
AfterJob - Annotation Interface in org.springframework.batch.core.annotation
Marks a method to be called after a Job has completed.
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(T, S) - Method in class org.springframework.batch.core.listener.MulticasterBatchListener
 
AfterProcess - Annotation Interface in org.springframework.batch.core.annotation
Marks a method to be called after an item is passed to an ItemProcessor.
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.support.JobRegistrySmartInitializingSingleton
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.AbstractJobExplorerFactoryBean
 
afterPropertiesSet() - Method in class org.springframework.batch.core.explore.support.JobExplorerFactoryBean
 
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.JobOperatorFactoryBean
 
afterPropertiesSet() - Method in class org.springframework.batch.core.launch.support.SimpleJobLauncher
Deprecated.
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.launch.support.TaskExecutorJobLauncher
 
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.support.AbstractJobRepositoryFactoryBean
 
afterPropertiesSet() - Method in class org.springframework.batch.core.repository.support.JobRepositoryFactoryBean
 
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(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(T) - Method in class org.springframework.batch.core.listener.MulticasterBatchListener
 
AfterRead - Annotation Interface 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)
afterSingletonsInstantiated() - Method in class org.springframework.batch.core.configuration.support.JobRegistrySmartInitializingSingleton
 
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
Deprecated.
 
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.
AfterStep - Annotation Interface in org.springframework.batch.core.annotation
Marks a method to be called after a Step has completed.
afterWrite(Chunk<? extends S>) - Method in interface org.springframework.batch.core.ItemWriteListener
afterWrite(Chunk<? 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(Chunk<? extends S>) - Method in class org.springframework.batch.core.listener.MulticasterBatchListener
 
AfterWrite - Annotation Interface in org.springframework.batch.core.annotation
Marks a method to be called after an item is passed to an ItemWriter.
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.
applicationContext - Variable in class org.springframework.batch.core.configuration.support.DefaultBatchConfiguration
 
ApplicationContextFactory - Interface in org.springframework.batch.core.configuration.support
Factory for the creation of ApplicationContext instances.
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
This method should be called on successful execution just before a chunk commit.
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
Create the beans based on the content of the source.

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.
BATCH_JOB_OBSERVATION - Enum constant in enum class org.springframework.batch.core.observability.BatchJobObservation
 
BATCH_STEP_OBSERVATION - Enum constant in enum class org.springframework.batch.core.observability.BatchStepObservation
 
BATCH_VERSION_KEY - Static variable in class org.springframework.batch.core.SpringBatchVersion
The key to use in the execution context for batch version.
BatchConfigurationException - Exception in org.springframework.batch.core.configuration
Represents that an error has occurred in the configuration of the base batch infrastructure (the creation of a JobRepository, for example).
BatchConfigurationException(String) - Constructor for exception org.springframework.batch.core.configuration.BatchConfigurationException
Create an exception with the given message.
BatchConfigurationException(String, Throwable) - Constructor for exception org.springframework.batch.core.configuration.BatchConfigurationException
Create an exception with the given message and Throwable.
BatchConfigurationException(Throwable) - Constructor for exception org.springframework.batch.core.configuration.BatchConfigurationException
Create an exception with the given Throwable.
BatchJobContext - Class in org.springframework.batch.core.observability
Observation context for batch jobs.
BatchJobContext(JobExecution) - Constructor for class org.springframework.batch.core.observability.BatchJobContext
 
BatchJobObservation - Enum Class in org.springframework.batch.core.observability
Observation created around a Job execution.
BatchJobObservationConvention - Interface in org.springframework.batch.core.observability
ObservationConvention for BatchJobContext.
BatchMetrics - Class in org.springframework.batch.core.observability
Central class for batch metrics.
BatchObservabilityBeanPostProcessor - Class in org.springframework.batch.core.configuration.annotation
Bean post processor that configures observable batch artifacts (jobs and steps) with Micrometer's observation registry.
BatchObservabilityBeanPostProcessor() - Constructor for class org.springframework.batch.core.configuration.annotation.BatchObservabilityBeanPostProcessor
 
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
 
BatchScopeSupport - Class in org.springframework.batch.core.scope
ScopeSupport.
BatchScopeSupport() - Constructor for class org.springframework.batch.core.scope.BatchScopeSupport
 
BatchScopeSupport.Scopifier - Class in org.springframework.batch.core.scope
Helper class to scan a bean definition hierarchy and force the use of auto-proxy for step scoped beans.
BatchStatus - Enum Class in org.springframework.batch.core
Enumeration representing the status of an execution.
BatchStepContext - Class in org.springframework.batch.core.observability
Observation context for batch steps.
BatchStepContext(StepExecution) - Constructor for class org.springframework.batch.core.observability.BatchStepContext
 
BatchStepObservation - Enum Class in org.springframework.batch.core.observability
Observation created around a step execution.
BatchStepObservationConvention - Interface in org.springframework.batch.core.observability
ObservationConvention for BatchStepContext.
BeanDefinitionUtils - Class in org.springframework.batch.core.configuration.xml
 
BeanDefinitionUtils() - Constructor for class org.springframework.batch.core.configuration.xml.BeanDefinitionUtils
 
BEFORE_CHUNK - Enum constant in enum class org.springframework.batch.core.listener.StepListenerMetaData
 
BEFORE_JOB - Enum constant in enum class org.springframework.batch.core.listener.JobListenerMetaData
 
BEFORE_PROCESS - Enum constant in enum class org.springframework.batch.core.listener.StepListenerMetaData
 
BEFORE_READ - Enum constant in enum class org.springframework.batch.core.listener.StepListenerMetaData
 
BEFORE_STEP - Enum constant in enum class org.springframework.batch.core.listener.StepListenerMetaData
 
BEFORE_WRITE - Enum constant in enum class org.springframework.batch.core.listener.StepListenerMetaData
 
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
Deprecated.
 
beforeChunk(ChunkContext) - Method in class org.springframework.batch.core.listener.CompositeChunkListener
Call the registered listeners in order, respecting and prioritizing those that implement Ordered.
beforeChunk(ChunkContext) - Method in class org.springframework.batch.core.listener.MulticasterBatchListener
 
BeforeChunk - Annotation Interface in org.springframework.batch.core.annotation
Marks a method to be called before a chunk 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
Deprecated.
 
BeforeJob - Annotation Interface 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.
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(T) - Method in class org.springframework.batch.core.listener.MulticasterBatchListener
 
BeforeProcess - Annotation Interface 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)
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.MulticasterBatchListener
 
BeforeRead - Annotation Interface in org.springframework.batch.core.annotation
Marks a method to be called before an item is read from an ItemReader

Expected signature: void beforeRead()
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
Deprecated.
 
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.
BeforeStep - Annotation Interface 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.
beforeWrite(Chunk<? extends S>) - Method in interface org.springframework.batch.core.ItemWriteListener
beforeWrite(Chunk<? 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(Chunk<? extends S>) - Method in class org.springframework.batch.core.listener.MulticasterBatchListener
 
BeforeWrite - Annotation Interface in org.springframework.batch.core.annotation
Marks a method to be called before a chunk is passed to an ItemWriter.
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

calculateDuration(LocalDateTime, LocalDateTime) - Static method in class org.springframework.batch.core.observability.BatchMetrics
Calculate the duration between two dates.
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
Create a new CallableTaskletAdapter instance.
CallableTaskletAdapter(Callable<RepeatStatus>) - Constructor for class org.springframework.batch.core.step.tasklet.CallableTaskletAdapter
Create a new CallableTaskletAdapter instance.
canRetry(RetryContext) - Method in class org.springframework.batch.core.step.item.BatchRetryTemplate
 
charset() - Element in annotation interface org.springframework.batch.core.configuration.annotation.EnableBatchProcessing
The charset to use in the job repository and job explorer
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(int) - Method in class org.springframework.batch.core.step.builder.StepBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
chunk(int, PlatformTransactionManager) - 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.SimpleStepBuilder
Sets a completion policy for the chunk processing.
chunk(CompletionPolicy) - Method in class org.springframework.batch.core.step.builder.StepBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
chunk(CompletionPolicy, PlatformTransactionManager) - Method in class org.springframework.batch.core.step.builder.StepBuilder
Build a step that processes items in chunks with the completion policy provided.
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
Deprecated.
as of 5.0, in favor of the default methods on the ChunkListener
ChunkListenerSupport() - Constructor for class org.springframework.batch.core.listener.ChunkListenerSupport
Deprecated.
 
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
 
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
 
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
 
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.
clobType() - Element in annotation interface org.springframework.batch.core.configuration.annotation.EnableBatchProcessing
The type of large objects.
close() - Method in class org.springframework.batch.core.scope.context.JobContext
Clean up the context at the end of a step execution.
close() - Static method in class org.springframework.batch.core.scope.context.JobSynchronizationManager
Method for unregistering the current context - should always and only be used by in conjunction with a matching JobSynchronizationManager.register(JobExecution) to ensure that JobSynchronizationManager.getContext() always returns the correct value.
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 unregistering 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() - Method in class org.springframework.batch.core.scope.context.SynchronizationManagerSupport
Method for unregistering the current context - should always and only be used by in conjunction with a matching SynchronizationManagerSupport.register(Object) to ensure that SynchronizationManagerSupport.getContext() always returns the correct value.
close() - Method in class org.springframework.batch.core.step.item.ChunkMonitor
 
close(C) - Method in class org.springframework.batch.core.scope.context.SynchronizationManagerSupport
 
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(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(ExecutionContext) - Method in class org.springframework.batch.core.step.tasklet.TaskletStep
 
close(RetryContext, RetryCallback<T, E>, 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.
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
 
CommandRunner - Interface in org.springframework.batch.core.step.tasklet
Strategy interface for executing commands.
CommonJobProperties() - Constructor for class org.springframework.batch.core.job.builder.JobBuilderHelper.CommonJobProperties
 
CommonJobProperties(JobBuilderHelper.CommonJobProperties) - Constructor for class org.springframework.batch.core.job.builder.JobBuilderHelper.CommonJobProperties
 
CommonStepProperties() - Constructor for class org.springframework.batch.core.step.builder.StepBuilderHelper.CommonStepProperties
 
CommonStepProperties(StepBuilderHelper.CommonStepProperties) - Constructor for class org.springframework.batch.core.step.builder.StepBuilderHelper.CommonStepProperties
 
compare(StateTransition, StateTransition) - Method in class org.springframework.batch.core.job.flow.support.DefaultStateTransitionComparator
 
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.
COMPLETED - Enum constant in enum class org.springframework.batch.core.BatchStatus
The batch job has successfully completed its execution.
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
Default constructor
CompositeChunkListener(List<? extends ChunkListener>) - Constructor for class org.springframework.batch.core.listener.CompositeChunkListener
Convenience constructor for setting the ChunkListeners.
CompositeChunkListener(ChunkListener...) - Constructor for class org.springframework.batch.core.listener.CompositeChunkListener
Convenience constructor for setting the ChunkListeners.
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
 
conversionService - Variable in class org.springframework.batch.core.converter.DefaultJobParametersConverter
 
conversionServiceRef() - Element in annotation interface org.springframework.batch.core.configuration.annotation.EnableBatchProcessing
Set the conversion service to use in the job repository and job explorer.
convert(String) - Method in class org.springframework.batch.core.converter.StringToDateConverter
 
convert(String) - Method in class org.springframework.batch.core.converter.StringToLocalDateConverter
 
convert(String) - Method in class org.springframework.batch.core.converter.StringToLocalDateTimeConverter
 
convert(String) - Method in class org.springframework.batch.core.converter.StringToLocalTimeConverter
 
convert(LocalDate) - Method in class org.springframework.batch.core.converter.LocalDateToStringConverter
 
convert(LocalDateTime) - Method in class org.springframework.batch.core.converter.LocalDateTimeToStringConverter
 
convert(LocalTime) - Method in class org.springframework.batch.core.converter.LocalTimeToStringConverter
 
convert(Date) - Method in class org.springframework.batch.core.converter.DateToStringConverter
 
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
 
CoreRuntimeHints - Class in org.springframework.batch.core.aot
RuntimeHintsRegistrar for Spring Batch core module.
CoreRuntimeHints() - Constructor for class org.springframework.batch.core.aot.CoreRuntimeHints
 
countStepExecutions(JobInstance, String) - Method in class org.springframework.batch.core.repository.dao.JdbcStepExecutionDao
 
countStepExecutions(JobInstance, String) - Method in interface org.springframework.batch.core.repository.dao.StepExecutionDao
Counts all the StepExecution for a given step name.
createApplicationContext() - Method in class org.springframework.batch.core.configuration.support.AbstractApplicationContextFactory
Creates an ApplicationContext from the provided path.
createApplicationContext() - Method in interface org.springframework.batch.core.configuration.support.ApplicationContextFactory
 
createApplicationContext(ConfigurableApplicationContext, Object...) - Method in class org.springframework.batch.core.configuration.support.AbstractApplicationContextFactory
 
createApplicationContext(ConfigurableApplicationContext, Object...) - Method in class org.springframework.batch.core.configuration.support.GenericApplicationContextFactory
 
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
 
createChunkProcessor() - Method in class org.springframework.batch.core.step.builder.FaultTolerantStepBuilder
 
createChunkProvider() - Method in class org.springframework.batch.core.step.builder.FaultTolerantStepBuilder
 
createCounter(MeterRegistry, String, String, Tag...) - Static method in class org.springframework.batch.core.observability.BatchMetrics
Create a Counter.
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
Creates an execution context instance data access object (DAO).
createExecutionContextDao() - Method in class org.springframework.batch.core.explore.support.JobExplorerFactoryBean
 
createExecutionContextDao() - Method in class org.springframework.batch.core.repository.support.AbstractJobRepositoryFactoryBean
 
createExecutionContextDao() - Method in class org.springframework.batch.core.repository.support.JobRepositoryFactoryBean
 
createFaultTolerantStep() - Method in class org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
Creates a fault tolerant Step.
createFlowStep() - Method in class org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
Create a new FlowStep.
createJob() - Method in interface org.springframework.batch.core.configuration.JobFactory
Create a new instance of Job.
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
Return the instance that was 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
Creates a job execution data access object (DAO).
createJobExecutionDao() - Method in class org.springframework.batch.core.explore.support.JobExplorerFactoryBean
 
createJobExecutionDao() - Method in class org.springframework.batch.core.repository.support.AbstractJobRepositoryFactoryBean
 
createJobExecutionDao() - Method in class org.springframework.batch.core.repository.support.JobRepositoryFactoryBean
 
createJobInstance(String, JobParameters) - Method in class org.springframework.batch.core.repository.dao.JdbcJobInstanceDao
In this JDBC implementation a job instance id is obtained by asking the jobInstanceIncrementer (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 interface org.springframework.batch.core.repository.JobRepository
Create a new JobInstance with the name and job parameters provided.
createJobInstance(String, JobParameters) - Method in class org.springframework.batch.core.repository.support.SimpleJobRepository
 
createJobInstanceDao() - Method in class org.springframework.batch.core.explore.support.AbstractJobExplorerFactoryBean
Creates a job instance data access object (DAO).
createJobInstanceDao() - Method in class org.springframework.batch.core.explore.support.JobExplorerFactoryBean
 
createJobInstanceDao() - Method in class org.springframework.batch.core.repository.support.AbstractJobRepositoryFactoryBean
 
createJobInstanceDao() - Method in class org.springframework.batch.core.repository.support.JobRepositoryFactoryBean
 
createLongTaskTimer(MeterRegistry, String, String, Tag...) - Static method in class org.springframework.batch.core.observability.BatchMetrics
Create a new LongTaskTimer.
createNewContext(E) - Method in class org.springframework.batch.core.scope.context.SynchronizationManagerSupport
 
createNewStepState(State, String, String) - Method in class org.springframework.batch.core.configuration.xml.SimpleFlowFactoryBean
Provides an extension point to provide alternative StepState implementations within a SimpleFlow.
createObservation(String, BatchJobContext, ObservationRegistry) - Static method in class org.springframework.batch.core.observability.BatchMetrics
Create a new Observation.
createObservation(String, BatchStepContext, ObservationRegistry) - Static method in class org.springframework.batch.core.observability.BatchMetrics
Create a new Observation.
createPartitionStep() - Method in class org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
Create a partition Step.
createRetryOperations() - Method in class org.springframework.batch.core.step.builder.FaultTolerantStepBuilder
 
createScopedProxy(String, BeanDefinition, BeanDefinitionRegistry, boolean) - Static method in class org.springframework.batch.core.scope.BatchScopeSupport
Wrap a target bean definition in a proxy that defers initialization until after the StepContext is available.
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.
createSimpleStep() - Method in class org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
Creates a new TaskletStep.
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
Creates a step execution data access object (DAO).
createStepExecutionDao() - Method in class org.springframework.batch.core.explore.support.JobExplorerFactoryBean
 
createStepExecutionDao() - Method in class org.springframework.batch.core.repository.support.AbstractJobRepositoryFactoryBean
 
createStepExecutionDao() - Method in class org.springframework.batch.core.repository.support.JobRepositoryFactoryBean
 
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
 
createTaskletStep() - Method in class org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
Create a new TaskletStep.
createTimer(MeterRegistry, String, String, Tag...) - Static method in class org.springframework.batch.core.observability.BatchMetrics
Create a Timer.
createTimerSample(MeterRegistry) - Static method in class org.springframework.batch.core.observability.BatchMetrics
Create a new Timer.Sample.
createTransition(FlowExecutionStatus, String, String, String, BeanDefinition, ParserContext, boolean) - Static method in class org.springframework.batch.core.configuration.xml.AbstractFlowParser
 

D

databaseType() - Element in annotation interface org.springframework.batch.core.configuration.annotation.EnableBatchProcessing
Set the type of the data source to use in the job repository.
DataFieldMaxValueJobParametersIncrementer - Class in org.springframework.batch.core.launch.support
This incrementer uses a DataFieldMaxValueIncrementer to generate the sequence of values to use as job instance discriminator.
DataFieldMaxValueJobParametersIncrementer(DataFieldMaxValueIncrementer) - Constructor for class org.springframework.batch.core.launch.support.DataFieldMaxValueJobParametersIncrementer
dataSourceRef() - Element in annotation interface org.springframework.batch.core.configuration.annotation.EnableBatchProcessing
Set the data source to use in the job repository and job explorer.
DateToStringConverter - Class in org.springframework.batch.core.converter
Converter implementation from Date to String.
DateToStringConverter() - Constructor for class org.springframework.batch.core.converter.DateToStringConverter
 
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.
DECISION_ELE - Static variable in class org.springframework.batch.core.configuration.xml.AbstractFlowParser
Establishes a Decision element.
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
 
decode(String) - Method in class org.springframework.batch.core.converter.DefaultJobParametersConverter
Decode a job parameter from a string.
decode(String) - Method in class org.springframework.batch.core.converter.JsonJobParametersConverter
 
DEFAULT_EXIT_MESSAGE_LENGTH - Static variable in class org.springframework.batch.core.repository.dao.AbstractJdbcBatchMetadataDao
 
DEFAULT_KEY - Static variable in class org.springframework.batch.core.launch.support.DataFieldMaxValueJobParametersIncrementer
Default key used as a job parameter.
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_SHORT_CONTEXT_LENGTH - Static variable in class org.springframework.batch.core.repository.dao.AbstractJdbcBatchMetadataDao
 
DEFAULT_TABLE_PREFIX - Static variable in class org.springframework.batch.core.repository.dao.AbstractJdbcBatchMetadataDao
Default value for the table prefix property.
DefaultBatchConfiguration - Class in org.springframework.batch.core.configuration.support
Base Configuration class that provides common JDBC-based infrastructure beans for enabling and using Spring Batch.
DefaultBatchConfiguration() - Constructor for class org.springframework.batch.core.configuration.support.DefaultBatchConfiguration
 
DefaultBatchJobObservationConvention - Class in org.springframework.batch.core.observability
Default BatchJobObservationConvention implementation.
DefaultBatchJobObservationConvention() - Constructor for class org.springframework.batch.core.observability.DefaultBatchJobObservationConvention
 
DefaultBatchStepObservationConvention - Class in org.springframework.batch.core.observability
Default BatchStepObservationConvention implementation.
DefaultBatchStepObservationConvention() - Constructor for class org.springframework.batch.core.observability.DefaultBatchStepObservationConvention
 
DefaultExecutionContextSerializer - Class in org.springframework.batch.core.repository.dao
An implementation of the ExecutionContextSerializer that produces/consumes Base64 content.
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.
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 that uses a simple naming convention for converting job parameters.
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.
DefaultStateTransitionComparator - Class in org.springframework.batch.core.job.flow.support
Sorts by decreasing specificity of pattern, based on just counting wildcards (with * taking precedence over ?).
DefaultStateTransitionComparator() - Constructor for class org.springframework.batch.core.job.flow.support.DefaultStateTransitionComparator
 
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
 
deleteExecutionContext(JobExecution) - Method in interface org.springframework.batch.core.repository.dao.ExecutionContextDao
Delete the execution context of the given JobExecution.
deleteExecutionContext(JobExecution) - Method in class org.springframework.batch.core.repository.dao.JdbcExecutionContextDao
Delete the execution context of the given JobExecution.
deleteExecutionContext(StepExecution) - Method in interface org.springframework.batch.core.repository.dao.ExecutionContextDao
Delete the execution context of the given StepExecution.
deleteExecutionContext(StepExecution) - Method in class org.springframework.batch.core.repository.dao.JdbcExecutionContextDao
Delete the execution context of the given StepExecution.
deleteJobExecution(JobExecution) - Method in class org.springframework.batch.core.repository.dao.JdbcJobExecutionDao
Delete the given job execution.
deleteJobExecution(JobExecution) - Method in interface org.springframework.batch.core.repository.dao.JobExecutionDao
Delete the given job execution.
deleteJobExecution(JobExecution) - Method in interface org.springframework.batch.core.repository.JobRepository
Delete the job execution object graph (ie the job execution with its execution context, all related step executions and their executions contexts, as well as associated job parameters)
deleteJobExecution(JobExecution) - Method in class org.springframework.batch.core.repository.support.SimpleJobRepository
 
deleteJobExecutionParameters(JobExecution) - Method in class org.springframework.batch.core.repository.dao.JdbcJobExecutionDao
Delete the parameters associated with the given job execution.
deleteJobExecutionParameters(JobExecution) - Method in interface org.springframework.batch.core.repository.dao.JobExecutionDao
Delete the parameters associated with the given job execution.
deleteJobInstance(JobInstance) - Method in class org.springframework.batch.core.repository.dao.JdbcJobInstanceDao
Delete the job instance.
deleteJobInstance(JobInstance) - Method in interface org.springframework.batch.core.repository.dao.JobInstanceDao
Delete the job instance.
deleteJobInstance(JobInstance) - Method in interface org.springframework.batch.core.repository.JobRepository
Delete the job instance object graph (ie the job instance with all associated job executions along with their respective object graphs as specified in JobRepository.deleteJobExecution(JobExecution)).
deleteJobInstance(JobInstance) - Method in class org.springframework.batch.core.repository.support.SimpleJobRepository
 
deleteStepExecution(StepExecution) - Method in class org.springframework.batch.core.repository.dao.JdbcStepExecutionDao
Delete the given step execution.
deleteStepExecution(StepExecution) - Method in interface org.springframework.batch.core.repository.dao.StepExecutionDao
Delete the given step execution.
deleteStepExecution(StepExecution) - Method in interface org.springframework.batch.core.repository.JobRepository
Delete the step execution along with its execution context.
deleteStepExecution(StepExecution) - Method in class org.springframework.batch.core.repository.support.SimpleJobRepository
 
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.Jackson2ExecutionContextStringSerializer
 
destroy() - Method in class org.springframework.batch.core.configuration.support.JobRegistryBeanPostProcessor
Unregister all the Job instances that were registered by this post processor.
destroy() - Method in class org.springframework.batch.core.configuration.support.JobRegistrySmartInitializingSingleton
Unregister all the Job instances that were registered by this smart initializing singleton.
detectStreamInReader() - Method in class org.springframework.batch.core.step.builder.FaultTolerantStepBuilder
 
doAfterWrite(Chunk<O>) - Method in class org.springframework.batch.core.step.item.SimpleChunkProcessor
Call the listener's after write method.
doAggregation(Collection<FlowExecution>, FlowExecutor) - Method in class org.springframework.batch.core.job.flow.support.state.SplitState
 
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(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.job.flow.FlowStep
Delegate to the flow provided for the execution of the step.
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.
doExecutionRegistration(StepExecution) - Method in class org.springframework.batch.core.step.AbstractStep
Registers the StepExecution for property resolution via StepScope
doExecutionRelease() - Method in class org.springframework.batch.core.step.AbstractStep
Releases the most recent StepExecution
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, Chunk<O>) - Method in class org.springframework.batch.core.step.item.SimpleChunkProcessor
Call listener's writerError method.
doParse(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.batch.core.configuration.xml.AbstractFlowParser
Performs the parsing for a flow definition.
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
Does the parsing.
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
Parse the flow.
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(Chunk<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
Create an exception with the given message and the given exception.

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
Deprecated.
System property key that switches the runner to "embedded" mode (returning immediately from the main method).
EnableBatchProcessing - Annotation Interface 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.
encode(JobParameter<?>) - Method in class org.springframework.batch.core.converter.DefaultJobParametersConverter
Encode a job parameter to a string.
encode(JobParameter<?>) - Method in class org.springframework.batch.core.converter.JsonJobParametersConverter
 
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.
END_ELE - Static variable in class org.springframework.batch.core.configuration.xml.AbstractFlowParser
Establishes an End element.
endCounter - Static variable in class org.springframework.batch.core.configuration.xml.AbstractFlowParser
Used as a suffix to generate unique state names for end transitions.
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(AbstractJob) - Method in class org.springframework.batch.core.job.builder.JobBuilderHelper
 
enhance(AbstractStep) - Method in class org.springframework.batch.core.step.builder.StepBuilderHelper
 
enhanceCommonStep(StepBuilderHelper<?>) - Method in class org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
Enhances a step with attributes from the provided StepBuilderHelper.
enhanceTaskletStepBuilder(AbstractTaskletStepBuilder<?>) - Method in class org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
Set the state of the AbstractTaskletStepBuilder using the values that were established for the factory bean.
Entity - Class in org.springframework.batch.core
Batch Domain Entity class.
Entity() - Constructor for class org.springframework.batch.core.Entity
Default constructor for Entity.
Entity(Long) - Constructor for class org.springframework.batch.core.Entity
The constructor for the Entity where the ID is established.
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 record class org.springframework.batch.core.converter.JsonJobParametersConverter.JobParameterDefinition
Indicates whether some other object is "equal to" this one.
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.JobContext
Extend the base class method to include the job execution itself as a key (i.e.
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
 
ExceptionElementParser - Class in org.springframework.batch.core.configuration.xml
 
ExceptionElementParser() - Constructor for class org.springframework.batch.core.configuration.xml.ExceptionElementParser
 
exceptionHandler(ExceptionHandler) - Method in class org.springframework.batch.core.step.builder.AbstractTaskletStepBuilder
Sets the exception handler to use in the case of tasklet failures.
exec(String[], String[], File) - Method in interface org.springframework.batch.core.step.tasklet.CommandRunner
Executes the specified string command in a separate process with the specified environment and working directory.
exec(String[], String[], File) - Method in class org.springframework.batch.core.step.tasklet.JvmCommandRunner
Delegate call to Runtime.exec(java.lang.String) with the arguments provided.
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, such as status and statistics, as necessary.
execute(Job, JobExecution) - Method in class org.springframework.batch.core.scope.context.JobScopeManager
 
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.
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(Step, StepExecution) - Method in class org.springframework.batch.core.scope.context.StepScopeManager
 
execute(RetryCallback<T, E>) - Method in class org.springframework.batch.core.step.item.BatchRetryTemplate
 
execute(RetryCallback<T, E>, Collection<RetryState>) - Method in class org.springframework.batch.core.step.item.BatchRetryTemplate
 
execute(RetryCallback<T, E>, RecoveryCallback<T>) - Method in class org.springframework.batch.core.step.item.BatchRetryTemplate
 
execute(RetryCallback<T, E>, RecoveryCallback<T>, Collection<RetryState>) - Method in class org.springframework.batch.core.step.item.BatchRetryTemplate
 
execute(RetryCallback<T, E>, RecoveryCallback<T>, RetryState) - Method in class org.springframework.batch.core.step.item.BatchRetryTemplate
 
execute(RetryCallback<T, E>, RetryState) - Method in class org.springframework.batch.core.step.item.BatchRetryTemplate
 
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.
executionContextSerializerRef() - Element in annotation interface org.springframework.batch.core.configuration.annotation.EnableBatchProcessing
Set the execution context serializer to use in the job repository and job explorer.
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.
EXIT_CODE_ATTR - Static variable in class org.springframework.batch.core.configuration.xml.AbstractFlowParser
Establishes a Exit Code element.
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 - Variable in class org.springframework.batch.core.job.flow.JobFlowExecutor
 
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
Constructor that accepts the exit code and sets the exit description to an empty String.
ExitStatus(String, String) - Constructor for class org.springframework.batch.core.ExitStatus
Constructor that establishes the exit code and the exit description for the ExitStatus.

F

fail() - Method in class org.springframework.batch.core.job.builder.FlowBuilder.TransitionBuilder
Signal the end of the flow with an error condition.
FAIL_ELE - Static variable in class org.springframework.batch.core.configuration.xml.AbstractFlowParser
Establishes a Fail element.
FAILED - Enum constant in enum class org.springframework.batch.core.BatchStatus
Status of a batch job that has failed during its execution.
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.FaultTolerantStepBuilder
Override parent method to prevent creation of a new FaultTolerantStepBuilder
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 ChunkProvider 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(SimpleStepBuilder<I, O>) - Constructor for class org.springframework.batch.core.step.builder.FaultTolerantStepBuilder
Create a new builder initialized with any properties in the parent.
FaultTolerantStepBuilder(StepBuilderHelper<?>) - 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
 
findAllReachableElements(String, Map<String, Set<String>>, Set<String>) - Method in class org.springframework.batch.core.configuration.xml.AbstractFlowParser
Find all of the elements that are reachable from the startElement.
findBatchStatus(FlowExecutionStatus) - Method in class org.springframework.batch.core.job.flow.JobFlowExecutor
 
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 JobExecutions for given JobInstance, sorted backwards by creation order (so the first element is the most recent).
findJobExecutions(JobInstance) - Method in interface org.springframework.batch.core.repository.JobRepository
Return all JobExecutions 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.support.SimpleJobRepository
 
findJobInstancesByJobName(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) with a 'like' or wildcard criteria.
findJobInstancesByJobName(String, int, int) - Method in class org.springframework.batch.core.explore.support.SimpleJobExplorer
 
findJobInstancesByName(String, int, int) - Method in class org.springframework.batch.core.repository.dao.JdbcJobInstanceDao
 
findJobInstancesByName(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, using a 'like' criteria
findJobInstancesByName(String, int, int) - Method in interface org.springframework.batch.core.repository.JobRepository
Fetch the last job instances with the provided name, sorted backwards by primary key, using a 'like' criteria
findJobInstancesByName(String, int, int) - Method in class org.springframework.batch.core.repository.support.SimpleJobRepository
 
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
 
flow - Variable in class org.springframework.batch.core.job.flow.FlowJob
 
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(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.
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_ELE - Static variable in class org.springframework.batch.core.configuration.xml.AbstractFlowParser
Establishes a Flow element.
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.TransitionBuilder<Q> - Class in org.springframework.batch.core.job.builder
A builder for transitions within a flow.
FlowBuilder.UnterminatedFlowBuilder<Q> - Class in org.springframework.batch.core.job.builder
A builder for continuing a flow from a decision state.
FlowBuilderException - Exception in org.springframework.batch.core.job.builder
 
FlowBuilderException(Exception) - Constructor for exception org.springframework.batch.core.job.builder.FlowBuilderException
 
FlowBuilderException(String) - Constructor for exception org.springframework.batch.core.job.builder.FlowBuilderException
 
FlowBuilderException(String, Exception) - 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
 
formatDuration(Duration) - Static method in class org.springframework.batch.core.observability.BatchMetrics
Format a duration in a human readable format like: 2h32m15s10ms.
from(Flow) - Method in class org.springframework.batch.core.job.builder.FlowBuilder
Start again from a subflow that was already registered.
from(JobExecutionDecider) - Method in class org.springframework.batch.core.job.builder.FlowBuilder
Start again from a decision that was already registered.
from(Step) - Method in class org.springframework.batch.core.job.builder.FlowBuilder
Go back to a previously registered step and start a new path.
fromPropertyName(String) - Static method in enum class org.springframework.batch.core.listener.JobListenerMetaData
Return the relevant meta data for the provided property name.
fromPropertyName(String) - Static method in enum class 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 specified resource.
get() - Method in class org.springframework.batch.core.observability.BatchJobContext
 
get() - Method in class org.springframework.batch.core.observability.BatchStepContext
 
get(String) - Method in class org.springframework.batch.core.configuration.annotation.JobBuilderFactory
Deprecated.
Creates a job builder and initializes its job repository.
get(String) - Method in class org.springframework.batch.core.configuration.annotation.StepBuilderFactory
Deprecated.
Creates a step builder and initializes its job repository.
get(String, ObjectFactory<?>) - Method in class org.springframework.batch.core.scope.JobScope
 
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.
getAggregator() - Method in class org.springframework.batch.core.step.builder.PartitionStepBuilder
 
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 class org.springframework.batch.core.listener.JobListenerMetaData
 
getAnnotation() - Method in interface org.springframework.batch.core.listener.ListenerMetaData
 
getAnnotation() - Method in enum class org.springframework.batch.core.listener.StepListenerMetaData
 
getAttribute(String, String, ConfigurableListableBeanFactory) - Static method in class org.springframework.batch.core.configuration.xml.BeanDefinitionUtils
 
getBatchStatusFromEndTransitionName(String) - Static method in class org.springframework.batch.core.configuration.xml.AbstractFlowParser
Gets the batch status from the end transition name by the element.
getBeanClass() - Method in class org.springframework.batch.core.configuration.xml.AbstractListenerParser
Gets the bean class.
getBeanClass() - Method in class org.springframework.batch.core.configuration.xml.JobExecutionListenerParser
 
getBeanClass() - Method in class org.springframework.batch.core.configuration.xml.StepListenerParser
 
getBeanClass(Element) - Method in class org.springframework.batch.core.configuration.xml.AbstractFlowParser
 
getBeanClass(Element) - Method in class org.springframework.batch.core.configuration.xml.JobParser
 
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.
getCharset() - Method in class org.springframework.batch.core.configuration.support.DefaultBatchConfiguration
Return the Charset to use when serializing/deserializing the execution context.
getChunkCompletionPolicy() - Method in class org.springframework.batch.core.step.builder.SimpleStepBuilder
 
getChunkMonitor() - Method in class org.springframework.batch.core.step.builder.FaultTolerantStepBuilder
 
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
 
getClobType() - Method in class org.springframework.batch.core.configuration.support.DefaultBatchConfiguration
Return the value from Types class to indicate the type to use for a CLOB
getClobTypeToUse() - Method in class org.springframework.batch.core.repository.dao.AbstractJdbcBatchMetadataDao
 
getCode() - Method in class org.springframework.batch.core.job.flow.support.state.EndState
 
getCommitCount() - Method in class org.springframework.batch.core.StepExecution
Returns the current number of commits for this execution.
getCommitInterval() - Method in class org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
 
getCompletionPolicy() - Method in class org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
 
getCompositeListener() - Method in class org.springframework.batch.core.step.AbstractStep
 
getContext() - Static method in class org.springframework.batch.core.scope.context.JobSynchronizationManager
Getter for the current context if there is one, otherwise returns null.
getContext() - Static method in class org.springframework.batch.core.scope.context.StepSynchronizationManager
Getter for the current context if there is one, otherwise returns null.
getContext() - Method in class org.springframework.batch.core.scope.context.SynchronizationManagerSupport
Getter for the current context if there is one, otherwise returns null.
getConversationId() - Method in class org.springframework.batch.core.scope.JobScope
 
getConversationId() - Method in class org.springframework.batch.core.scope.StepScope
 
getConversionService() - Method in class org.springframework.batch.core.configuration.support.DefaultBatchConfiguration
Return the conversion service to use in the job repository and job explorer.
getCreateTime() - Method in class org.springframework.batch.core.JobExecution
 
getCreateTime() - Method in class org.springframework.batch.core.StepExecution
Gets the time this execution was created
getCurrent() - Method in class org.springframework.batch.core.scope.context.SynchronizationManagerSupport
 
getDatabaseType() - Method in class org.springframework.batch.core.configuration.support.DefaultBatchConfiguration
Return the database type.
getDataFieldMaxValueIncrementer() - Method in class org.springframework.batch.core.launch.support.DataFieldMaxValueJobParametersIncrementer
Get the incrementer.
getDataSource() - Method in class org.springframework.batch.core.configuration.support.DefaultBatchConfiguration
Return the data source to use for Batch meta-data.
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.
getDefaultExitStatusForFailure(Throwable, JobExecution) - Method in class org.springframework.batch.core.job.AbstractJob
Default mapping from throwable to ExitStatus.
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 Double 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.
getEcDao() - Method in class org.springframework.batch.core.explore.support.SimpleJobExplorer
 
getEndTime() - Method in class org.springframework.batch.core.JobExecution
 
getEndTime() - Method in class org.springframework.batch.core.StepExecution
Returns the time when this execution ended or null if the step is running.
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
Deprecated.
Public getter for the startup errors encountered during parent context creation.
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() - Method in class org.springframework.batch.core.StepExecution
Returns the ExecutionContext for this execution.
getExecutionContext(JobExecution) - 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 interface org.springframework.batch.core.repository.dao.ExecutionContextDao
 
getExecutionContext(StepExecution) - Method in class org.springframework.batch.core.repository.dao.JdbcExecutionContextDao
 
getExecutionContextSerializer() - Method in class org.springframework.batch.core.configuration.support.DefaultBatchConfiguration
A custom implementation of the ExecutionContextSerializer.
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() - Method in class org.springframework.batch.core.StepContribution
Public getter for the ExitStatus.
getExitStatus() - Method in class org.springframework.batch.core.StepExecution
 
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
 
getFailureExceptions() - Method in class org.springframework.batch.core.JobExecution
Retrieve a list of exceptions.
getFailureExceptions() - Method in class org.springframework.batch.core.StepExecution
 
getFatalExceptionAwareProxy(SkipPolicy) - Method in class org.springframework.batch.core.step.builder.FaultTolerantStepBuilder
Wrap a SkipPolicy and make it consistent with known fatal exceptions.
getFaultTolerantStepBuilder(String) - Method in class org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
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.
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.
getFlows() - Method in class org.springframework.batch.core.configuration.xml.SimpleFlowFactoryBean.DelegateState
 
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.
getGridSize() - Method in class org.springframework.batch.core.step.builder.PartitionStepBuilder
 
getGroupName(BeanDefinition, Job) - Method in class org.springframework.batch.core.configuration.support.JobRegistryBeanPostProcessor
Determine a group name for the job to be registered.
getGroupName(BeanDefinition, Job) - Method in class org.springframework.batch.core.configuration.support.JobRegistrySmartInitializingSingleton
Determine a group name for the job to be registered.
getHighCardinalityKeyValues(BatchJobContext) - Method in class org.springframework.batch.core.observability.DefaultBatchJobObservationConvention
 
getHighCardinalityKeyValues(BatchStepContext) - Method in class org.springframework.batch.core.observability.DefaultBatchStepObservationConvention
 
getId() - Method in class org.springframework.batch.core.Entity
 
getId() - Method in class org.springframework.batch.core.scope.context.JobContext
 
getId() - Method in class org.springframework.batch.core.scope.context.StepContext
 
getIdentifyingParameters() - Method in class org.springframework.batch.core.JobParameters
Get a map of identifying parameters.
getIncrementerFactory() - Method in class org.springframework.batch.core.configuration.support.DefaultBatchConfiguration
Return the factory for creating DataFieldMaxValueIncrementer implementations used to increment entity IDs in meta-data tables.
getInstanceId() - Method in class org.springframework.batch.core.JobInstance
 
getIsolationLevelForCreate() - Method in class org.springframework.batch.core.configuration.support.DefaultBatchConfiguration
Return the transaction isolation level when creating job executions.
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.
getItemWriter() - Method in class org.springframework.batch.core.step.factory.SimpleStepFactoryBean
Protected getter for the ItemWriter for subclasses to use
getJdbcOperations() - Method in class org.springframework.batch.core.configuration.support.DefaultBatchConfiguration
Return the JdbcOperations.
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() - Method in interface org.springframework.batch.core.job.flow.FlowExecutor
 
getJobExecution() - Method in class org.springframework.batch.core.job.flow.JobFlowExecutor
 
getJobExecution() - Method in class org.springframework.batch.core.observability.BatchJobContext
 
getJobExecution() - Method in class org.springframework.batch.core.scope.context.JobContext
The current JobExecution that is active in this context.
getJobExecution() - Method in class org.springframework.batch.core.StepExecution
Accessor for the execution context information of the enclosing job.
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(Long) - Method in class org.springframework.batch.core.repository.dao.JdbcJobExecutionDao
 
getJobExecution(Long) - Method in interface org.springframework.batch.core.repository.dao.JobExecutionDao
 
getJobExecutionContext() - Method in class org.springframework.batch.core.scope.context.JobContext
 
getJobExecutionContext() - Method in class org.springframework.batch.core.scope.context.StepContext
 
getJobExecutionDao() - Method in class org.springframework.batch.core.explore.support.SimpleJobExplorer
 
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 the id of the enclosing job.
getJobInstance() - Method in class org.springframework.batch.core.JobExecution
 
getJobInstance(Long) - Method in interface org.springframework.batch.core.explore.JobExplorer
 
getJobInstance(Long) - Method in class org.springframework.batch.core.explore.support.SimpleJobExplorer
 
getJobInstance(Long) - Method in class org.springframework.batch.core.repository.dao.JdbcJobInstanceDao
 
getJobInstance(Long) - Method in interface org.springframework.batch.core.repository.dao.JobInstanceDao
Fetch the job instance with the provided identifier.
getJobInstance(String, JobParameters) - Method in interface org.springframework.batch.core.explore.JobExplorer
 
getJobInstance(String, JobParameters) - Method in class org.springframework.batch.core.explore.support.SimpleJobExplorer
 
getJobInstance(String, JobParameters) - Method in interface org.springframework.batch.core.launch.JobOperator
 
getJobInstance(String, JobParameters) - Method in class org.springframework.batch.core.launch.support.SimpleJobOperator
 
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(String, JobParameters) - Method in interface org.springframework.batch.core.repository.dao.JobInstanceDao
Find the job instance that matches the given name and parameters.
getJobInstance(String, JobParameters) - Method in interface org.springframework.batch.core.repository.JobRepository
 
getJobInstance(String, JobParameters) - Method in class org.springframework.batch.core.repository.support.SimpleJobRepository
 
getJobInstance(JobExecution) - Method in class org.springframework.batch.core.repository.dao.JdbcJobInstanceDao
 
getJobInstance(JobExecution) - Method in interface org.springframework.batch.core.repository.dao.JobInstanceDao
Fetch the JobInstance for the provided JobExecution.
getJobInstanceCount(String) - Method in interface org.springframework.batch.core.explore.JobExplorer
Query the repository for the number of unique JobInstance objects associated with the supplied job name.
getJobInstanceCount(String) - Method in class org.springframework.batch.core.explore.support.SimpleJobExplorer
 
getJobInstanceCount(String) - Method in class org.springframework.batch.core.repository.dao.JdbcJobInstanceDao
 
getJobInstanceCount(String) - Method in interface org.springframework.batch.core.repository.dao.JobInstanceDao
Query the repository for the number of unique JobInstances associated with the supplied job name.
getJobInstanceDao() - Method in class org.springframework.batch.core.explore.support.SimpleJobExplorer
 
getJobInstanceId() - Method in class org.springframework.batch.core.scope.context.StepContext
Convenient accessor for current JobInstance identifier.
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.
getJobKeyGenerator() - Method in class org.springframework.batch.core.configuration.support.DefaultBatchConfiguration
A custom implementation of the JobKeyGenerator.
getJobName() - Method in interface org.springframework.batch.core.configuration.JobFactory
 
getJobName() - Method in class org.springframework.batch.core.configuration.support.ApplicationContextJobFactory
Return the name of the instance passed in on initialization.
getJobName() - Method in class org.springframework.batch.core.configuration.support.ReferenceJobFactory
Return the name of the instance that was passed in on initialization.
getJobName() - Method in class org.springframework.batch.core.JobInstance
 
getJobName() - Method in class org.springframework.batch.core.scope.context.JobContext
Convenient accessor for current job name identifier.
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, Properties).
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 interface org.springframework.batch.core.repository.JobRepository
Retrieve the names of all job instances sorted alphabetically - i.e.
getJobNames() - Method in class org.springframework.batch.core.repository.support.SimpleJobRepository
 
getJobParameters() - Method in class org.springframework.batch.core.JobExecution
 
getJobParameters() - Method in class org.springframework.batch.core.scope.context.JobContext
 
getJobParameters() - Method in class org.springframework.batch.core.scope.context.StepContext
 
getJobParameters() - Method in class org.springframework.batch.core.StepExecution
Convenience method to get the current job parameters.
getJobParameters(Long) - Method in class org.springframework.batch.core.repository.dao.JdbcJobExecutionDao
 
getJobParameters(Properties) - Method in class org.springframework.batch.core.converter.DefaultJobParametersConverter
 
getJobParameters(Properties) - Method in interface org.springframework.batch.core.converter.JobParametersConverter
Get a new JobParameters instance.
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.
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 class org.springframework.batch.core.configuration.xml.JobParserJobFactoryBean
 
getJobRepository() - Method in class org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
 
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.job.SimpleStepHandler
 
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() - Method in class org.springframework.batch.core.launch.support.DataFieldMaxValueJobParametersIncrementer
Get the key.
getKey(Object) - Method in interface org.springframework.batch.core.step.item.KeyGenerator
 
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
 
getLastJobExecution(JobInstance) - Method in interface org.springframework.batch.core.explore.JobExplorer
Find the last JobExecution that has been created for a given JobInstance.
getLastJobExecution(JobInstance) - Method in class org.springframework.batch.core.explore.support.SimpleJobExplorer
 
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.
getLastJobInstance(String) - Method in interface org.springframework.batch.core.explore.JobExplorer
Find the last job instance, by ID, for the given job.
getLastJobInstance(String) - Method in class org.springframework.batch.core.explore.support.SimpleJobExplorer
 
getLastJobInstance(String) - Method in class org.springframework.batch.core.repository.dao.JdbcJobInstanceDao
 
getLastJobInstance(String) - Method in interface org.springframework.batch.core.repository.dao.JobInstanceDao
Fetch the last job instance by Id for the given job.
getLastStepExecution(JobInstance, String) - Method in class org.springframework.batch.core.repository.dao.JdbcStepExecutionDao
 
getLastStepExecution(JobInstance, String) - Method in interface org.springframework.batch.core.repository.dao.StepExecutionDao
Retrieve the last StepExecution for a given JobInstance ordered by creation time and then id.
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() - Method in class org.springframework.batch.core.step.item.SimpleChunkProcessor
 
getListener() - Method in class org.springframework.batch.core.step.item.SimpleChunkProvider
 
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.
getListenerInterface() - Method in enum class org.springframework.batch.core.listener.JobListenerMetaData
 
getListenerInterface() - Method in interface org.springframework.batch.core.listener.ListenerMetaData
 
getListenerInterface() - Method in enum class org.springframework.batch.core.listener.StepListenerMetaData
 
getListeners() - Method in class org.springframework.batch.core.step.factory.SimpleStepFactoryBean
Protected getter for the StepListeners.
getLobHandler() - Method in class org.springframework.batch.core.configuration.support.DefaultBatchConfiguration
A special handler for large objects.
getLocalDate(String) - Method in class org.springframework.batch.core.JobParameters
Typesafe getter for the LocalDate represented by the provided key.
getLocalDate(String, LocalDate) - Method in class org.springframework.batch.core.JobParameters
Typesafe getter for the LocalDate represented by the provided key.
getLocalDateTime(String) - Method in class org.springframework.batch.core.JobParameters
Typesafe getter for the LocalDateTime represented by the provided key.
getLocalDateTime(String, LocalDateTime) - Method in class org.springframework.batch.core.JobParameters
Typesafe getter for the LocalDateTime represented by the provided key.
getLocalTime(String) - Method in class org.springframework.batch.core.JobParameters
Typesafe getter for the LocalTime represented by the provided key.
getLocalTime(String, LocalTime) - Method in class org.springframework.batch.core.JobParameters
Typesafe getter for the LocalTime represented by the provided key.
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.
getLowCardinalityKeyValues(BatchJobContext) - Method in class org.springframework.batch.core.observability.DefaultBatchJobObservationConvention
 
getLowCardinalityKeyValues(BatchStepContext) - Method in class org.springframework.batch.core.observability.DefaultBatchStepObservationConvention
 
getMapping() - Method in class org.springframework.batch.core.launch.support.SimpleJvmExitCodeMapper
 
getMaxVarCharLength() - Method in class org.springframework.batch.core.configuration.support.DefaultBatchConfiguration
Return the length of long string columns in database.
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
Gets the metadata values.
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
 
getMeterRegistry() - Method in class org.springframework.batch.core.job.builder.JobBuilderHelper.CommonJobProperties
 
getMeterRegistry() - Method in class org.springframework.batch.core.step.builder.StepBuilderHelper.CommonStepProperties
 
getMethodInvokerByName(String, Object, Class<?>...) - Method in class org.springframework.batch.core.listener.AbstractListenerFactoryBean
 
getMethodName() - Method in enum class org.springframework.batch.core.listener.JobListenerMetaData
 
getMethodName() - Method in interface org.springframework.batch.core.listener.ListenerMetaData
 
getMethodName() - Method in enum class 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.configuration.xml.StepParserStepFactoryBean
 
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.scope.BatchScopeSupport
 
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
Increments the provided parameters.
getNext(JobParameters) - Method in class org.springframework.batch.core.launch.support.DataFieldMaxValueJobParametersIncrementer
 
getNext(JobParameters) - Method in class org.springframework.batch.core.launch.support.RunIdIncrementer
Increment the run.id parameter (starting with 1).
getNextElements(ParserContext, String, BeanDefinition, Element) - Static method in class org.springframework.batch.core.configuration.xml.AbstractFlowParser
Retrieve a list of StateTransition instances from a ParserContext.
getNextElements(ParserContext, BeanDefinition, Element) - Static method in class org.springframework.batch.core.configuration.xml.AbstractFlowParser
 
getNextJobParameters(Job) - Method in class org.springframework.batch.core.JobParametersBuilder
Initializes the JobParameters based on the state of the Job.
getObject() - Method in class org.springframework.batch.core.configuration.support.ClasspathXmlApplicationContextsFactoryBean
getObject() - Method in class org.springframework.batch.core.configuration.xml.JobParserJobFactoryBean
 
getObject() - Method in class org.springframework.batch.core.configuration.xml.SimpleFlowFactoryBean
 
getObject() - Method in class org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
Create a Step from the configuration provided.
getObject() - Method in class org.springframework.batch.core.explore.support.AbstractJobExplorerFactoryBean
 
getObject() - Method in class org.springframework.batch.core.launch.support.JobOperatorFactoryBean
 
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 as an array of ApplicationContextFactory.
getObjectType() - Method in class org.springframework.batch.core.configuration.xml.JobParserJobFactoryBean
 
getObjectType() - Method in class org.springframework.batch.core.configuration.xml.SimpleFlowFactoryBean
 
getObjectType() - Method in class org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
 
getObjectType() - Method in class org.springframework.batch.core.explore.support.AbstractJobExplorerFactoryBean
Returns the type of object to be returned from AbstractJobExplorerFactoryBean.getObject().
getObjectType() - Method in class org.springframework.batch.core.launch.support.JobOperatorFactoryBean
 
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.
getObservationConvention() - Method in class org.springframework.batch.core.job.builder.JobBuilderHelper.CommonJobProperties
 
getObservationConvention() - Method in class org.springframework.batch.core.step.builder.StepBuilderHelper.CommonStepProperties
 
getObservationRegistry() - Method in class org.springframework.batch.core.job.builder.JobBuilderHelper.CommonJobProperties
 
getObservationRegistry() - Method in class org.springframework.batch.core.step.builder.StepBuilderHelper.CommonStepProperties
 
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.BatchScopeSupport
 
getParameter(String) - Method in class org.springframework.batch.core.JobParameters
 
getParameters() - Method in class org.springframework.batch.core.JobParameters
Get a map of all parameters.
getParameters(long) - Method in interface org.springframework.batch.core.launch.JobOperator
Get the JobParameters as a human readable String (new line separated key=value pairs).
getParameters(long) - Method in class org.springframework.batch.core.launch.support.SimpleJobOperator
 
getParamTypes() - Method in enum class org.springframework.batch.core.listener.JobListenerMetaData
 
getParamTypes() - Method in interface org.springframework.batch.core.listener.ListenerMetaData
 
getParamTypes() - Method in enum class org.springframework.batch.core.listener.StepListenerMetaData
 
getPartitioner() - Method in class org.springframework.batch.core.step.builder.PartitionStepBuilder
 
getPartitionHandler() - Method in class org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
 
getPartitionHandler() - Method in class org.springframework.batch.core.partition.support.PartitionStep
 
getPartitionHandler() - Method in class org.springframework.batch.core.step.builder.PartitionStepBuilder
 
getPartitionNames(int) - Method in interface org.springframework.batch.core.partition.support.PartitionNameProvider
 
getPattern() - Method in class org.springframework.batch.core.job.flow.support.StateTransition
 
getPhase() - Method in class org.springframework.batch.core.configuration.support.AutomaticJobRegistrar
 
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
 
getProperties(JobParameters) - Method in interface org.springframework.batch.core.converter.JobParametersConverter
The inverse operation: get a Properties instance.
getPropertyName() - Method in enum class org.springframework.batch.core.listener.JobListenerMetaData
 
getPropertyName() - Method in interface org.springframework.batch.core.listener.ListenerMetaData
 
getPropertyName() - Method in enum class 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
Public getter for the read skip count.
getReadSkipCount() - Method in class org.springframework.batch.core.StepExecution
 
getRestartable() - Method in class org.springframework.batch.core.job.builder.JobBuilderHelper.CommonJobProperties
 
getRollbackClassifier() - Method in class org.springframework.batch.core.step.builder.FaultTolerantStepBuilder
Convenience method to get an exception classifier based on the provided transaction attributes.
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
 
getSimpleStepBuilder(String) - Method in class org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
 
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
 
getSkipListeners() - Method in class org.springframework.batch.core.step.builder.FaultTolerantStepBuilder
 
getSplitter() - Method in class org.springframework.batch.core.step.builder.PartitionStepBuilder
 
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
 
getStartState() - Method in class org.springframework.batch.core.job.flow.support.SimpleFlow
 
getStartTime() - Method in class org.springframework.batch.core.JobExecution
 
getStartTime() - Method in class org.springframework.batch.core.StepExecution
Gets the time when this execution started.
getState() - Method in class org.springframework.batch.core.configuration.xml.SimpleFlowFactoryBean.DelegateState
Gets the current state.
getState() - Method in class org.springframework.batch.core.job.flow.support.StateTransition
Public getter for the State.
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.
getStateMap() - Method in class org.springframework.batch.core.job.flow.support.SimpleFlow
 
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
Gets a reference to the state transition.
getStatus() - Method in class org.springframework.batch.core.job.flow.FlowExecution
 
getStatus() - Method in class org.springframework.batch.core.job.flow.support.state.EndState
 
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() - Method in class org.springframework.batch.core.job.flow.support.state.StepState
 
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 class org.springframework.batch.core.step.builder.PartitionStepBuilder
 
getStep() - Method in interface org.springframework.batch.core.step.StepHolder
 
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(String) - Method in class org.springframework.batch.core.job.flow.support.state.StepState
 
getStep(String) - Method in class org.springframework.batch.core.job.SimpleJob
 
getStep(String) - Method in interface org.springframework.batch.core.step.StepLocator
 
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
 
getStepContext() - Method in class org.springframework.batch.core.scope.context.ChunkContext
 
getStepExecution() - Method in interface org.springframework.batch.core.job.flow.FlowExecutor
 
getStepExecution() - Method in class org.springframework.batch.core.job.flow.JobFlowExecutor
 
getStepExecution() - Method in class org.springframework.batch.core.observability.BatchStepContext
 
getStepExecution() - Method in class org.springframework.batch.core.scope.context.StepContext
The current StepExecution that is active in this context.
getStepExecution() - Method in class org.springframework.batch.core.StepContribution
Public getter for the parent step execution of this contribution.
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(JobExecution, Long) - Method in class org.springframework.batch.core.repository.dao.JdbcStepExecutionDao
 
getStepExecution(JobExecution, Long) - Method in interface org.springframework.batch.core.repository.dao.StepExecutionDao
Retrieve a StepExecution from its id.
getStepExecutionAggergator() - Method in class org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
 
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.explore.support.SimpleJobExplorer
 
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.
getStepExecutionSplitter() - Method in class org.springframework.batch.core.partition.support.PartitionStep
 
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.step.builder.PartitionStepBuilder
 
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.flow.support.state.StepState
 
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
 
getStreams() - Method in class org.springframework.batch.core.step.builder.AbstractTaskletStepBuilder
 
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() - Method in class org.springframework.batch.core.StepExecution
 
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
 
getSystemProperties() - Method in class org.springframework.batch.core.scope.context.JobContext
Convenient accessor for System properties to make it easy to access them from placeholder expressions.
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.configuration.support.DefaultBatchConfiguration
Return the prefix of Batch meta-data tables.
getTablePrefix() - Method in class org.springframework.batch.core.repository.dao.AbstractJdbcBatchMetadataDao
 
getTargetNamePrefix() - Method in class org.springframework.batch.core.scope.BatchScopeSupport
 
getTargetNamePrefix() - Method in class org.springframework.batch.core.scope.JobScope
 
getTargetNamePrefix() - Method in class org.springframework.batch.core.scope.StepScope
 
getTaskExecutor() - Method in class org.springframework.batch.core.configuration.support.DefaultBatchConfiguration
Return the TaskExecutor to use in the the job launcher.
getTaskExecutor() - Method in class org.springframework.batch.core.step.builder.AbstractTaskletStepBuilder
 
getTaskExecutor() - Method in class org.springframework.batch.core.step.builder.PartitionStepBuilder
 
getTaskExecutor() - Method in class org.springframework.batch.core.step.factory.SimpleStepFactoryBean
Make the TaskExecutor available to subclasses
getTasklet() - Method in class org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
 
getTasklet() - Method in class org.springframework.batch.core.step.tasklet.TaskletStep
retrieve the tasklet - helper method for JobOperator
getThrottleLimit() - Method in class org.springframework.batch.core.step.builder.AbstractTaskletStepBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
getTransactionAttribute() - Method in class org.springframework.batch.core.step.builder.AbstractTaskletStepBuilder
 
getTransactionAttribute() - Method in class org.springframework.batch.core.step.factory.SimpleStepFactoryBean
Getter for the TransactionAttribute for subclasses only.
getTransactionManager() - Method in class org.springframework.batch.core.configuration.support.DefaultBatchConfiguration
Return the transaction manager to use for the job repository.
getTransactionManager() - Method in class org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
 
getTransactionManager() - Method in class org.springframework.batch.core.explore.support.AbstractJobExplorerFactoryBean
The transaction manager used in this factory.
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.AbstractTaskletStepBuilder
 
getTransitionMap() - Method in class org.springframework.batch.core.job.flow.support.SimpleFlow
 
getType() - Method in class org.springframework.batch.core.JobParameter
Return the type of the parameter.
getValidateTransactionState() - Method in class org.springframework.batch.core.configuration.support.DefaultBatchConfiguration
Return the value of the validateTransactionState parameter.
getValue() - Method in class org.springframework.batch.core.JobParameter
 
getVersion() - Method in class org.springframework.batch.core.Entity
 
getVersion() - Static method in class org.springframework.batch.core.SpringBatchVersion
Return the full version string of the present Spring Batch codebase, or "N/A" if it cannot be determined.
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
Public getter for the write skip count.
getWriteSkipCount() - Method in class org.springframework.batch.core.StepExecution
 
gridSize - Variable in class org.springframework.batch.core.partition.support.AbstractPartitionHandler
 
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(String, Job) - Constructor for class org.springframework.batch.core.configuration.support.GroupAwareJob
Create a new Job with the given group name and delegate.
GroupAwareJob(Job) - Constructor for class org.springframework.batch.core.configuration.support.GroupAwareJob
Create a new Job with the delegate and no group name.

H

handle(FlowExecutor) - Method in class org.springframework.batch.core.configuration.xml.SimpleFlowFactoryBean.DelegateState
 
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.
hasChunkElement() - Method in class org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
 
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 record class org.springframework.batch.core.converter.JsonJobParametersConverter.JobParameterDefinition
Returns a hash code value for this object.
hashCode() - Method in class org.springframework.batch.core.Entity
Use id, if it exists, to establish a hash code.
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.JobContext
Overrides the default behaviour to provide a hash code based only on the job execution.
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
 
hasPartitionElement() - Method in class org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
 
hasTasklet() - Method in class org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
 

I

ID_ATTR - Static variable in class org.springframework.batch.core.configuration.xml.AbstractFlowParser
Establishes the ID attribute.
ID_ATTR - Static variable in class org.springframework.batch.core.configuration.xml.AbstractStepParser
The ID attribute for the step parser.
ID_KEY - Static variable in class org.springframework.batch.core.scope.JobScope
Context key for clients to use for conversation identifier.
ID_KEY - Static variable in class org.springframework.batch.core.scope.StepScope
Context key for clients to use for conversation identifier.
identifying() - Method in record class org.springframework.batch.core.converter.JsonJobParametersConverter.JobParameterDefinition
Returns the value of the identifying record component.
increment() - Method in class org.springframework.batch.core.scope.context.SynchronizationManagerSupport
 
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.
incrementerFactoryRef() - Element in annotation interface org.springframework.batch.core.configuration.annotation.EnableBatchProcessing
The incrementer factory to use in various DAOs.
incrementFilterCount(long) - 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(long) - 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
Increments the rollback count.
incrementVersion() - Method in class org.springframework.batch.core.Entity
Increment the version number.
incrementWriteCount(long) - 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
 
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 reference.
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
 
instantFormatter - Variable in class org.springframework.batch.core.converter.StringToLocalDateConverter
 
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 exit code
invoke(MethodInvocation) - Method in class org.springframework.batch.core.launch.support.RuntimeExceptionTranslator
 
invoke(MethodInvocation) - Method in class org.springframework.batch.core.listener.MethodInvokerMethodInterceptor
 
isAbandon() - Method in class org.springframework.batch.core.job.flow.support.state.EndState
 
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
 
isAutoStartup() - Method in class org.springframework.batch.core.configuration.support.AutomaticJobRegistrar
 
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.
isComplete(RepeatContext) - Method in class org.springframework.batch.core.resource.StepExecutionSimpleCompletionPolicy
 
isComplete(RepeatContext, RepeatStatus) - Method in class org.springframework.batch.core.resource.StepExecutionSimpleCompletionPolicy
 
isCopyConfiguration() - Method in class org.springframework.batch.core.configuration.support.AbstractApplicationContextFactory
Protected access for subclasses to the flag that determines whether configuration should be copied from the parent context.
isEagerInit() - Method in class org.springframework.batch.core.configuration.xml.JobParserJobFactoryBean
 
isEmpty() - Method in class org.springframework.batch.core.JobParameters
 
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.
isEndState() - Method in class org.springframework.batch.core.configuration.xml.SimpleFlowFactoryBean.DelegateState
 
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
 
isFaultTolerant() - Method in class org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
Indicates whether the step has any components that require fault tolerance.
isFlowContinued(State, FlowExecutionStatus, StepExecution) - Method in class org.springframework.batch.core.job.flow.support.SimpleFlow
 
isGreaterThan(BatchStatus) - Method in enum class 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 class org.springframework.batch.core.BatchStatus
 
isLessThanOrEqualTo(BatchStatus) - Method in enum class org.springframework.batch.core.BatchStatus
 
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.
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.
isNonDefaultExitStatus(ExitStatus) - Static method in class org.springframework.batch.core.ExitStatus
 
isolationLevelForCreate() - Element in annotation interface org.springframework.batch.core.configuration.annotation.EnableBatchProcessing
Set the isolation level for create parameter value.
isPrototype() - Method in class org.springframework.batch.core.configuration.xml.JobParserJobFactoryBean
 
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 class org.springframework.batch.core.BatchStatus
Convenience method to decide if a status indicates that work is in progress.
isRunning() - Method in class org.springframework.batch.core.configuration.support.AutomaticJobRegistrar
Check whether 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.JobParserJobFactoryBean
 
isSingleton() - Method in class org.springframework.batch.core.configuration.xml.SimpleFlowFactoryBean
 
isSingleton() - Method in class org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
 
isSingleton() - Method in class org.springframework.batch.core.explore.support.AbstractJobExplorerFactoryBean
 
isSingleton() - Method in class org.springframework.batch.core.launch.support.JobOperatorFactoryBean
 
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.
isStartable(StepExecution, ExecutionContext) - Method in class org.springframework.batch.core.partition.support.SimpleStepExecutionSplitter
Check if a step execution is startable.
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, it may not have all properties.
isUnsuccessful() - Method in enum class org.springframework.batch.core.BatchStatus
Convenience method to decide if a status indicates execution was unsuccessful.
itemListenerMetaData() - Static method in enum class 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.

J

Jackson2ExecutionContextStringSerializer - Class in org.springframework.batch.core.repository.dao
Implementation that uses Jackson2 to provide (de)serialization.
Jackson2ExecutionContextStringSerializer(String...) - Constructor for class org.springframework.batch.core.repository.dao.Jackson2ExecutionContextStringSerializer
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(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 - Interface in org.springframework.batch.core
Batch domain object representing 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
Deprecated, for removal: This API element is subject to removal in a future version.
JobBuilder(String, JobRepository) - 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
Deprecated, for removal: This API element is subject to removal in a future version.
Deprecated as of v5.0 and scheduled for removal in v5.2 in favor of using the JobBuilder.
JobBuilderFactory(JobRepository) - Constructor for class org.springframework.batch.core.configuration.annotation.JobBuilderFactory
Deprecated.
 
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
Deprecated, for removal: This API element is subject to removal in a future version.
JobBuilderHelper(String, JobRepository) - Constructor for class org.springframework.batch.core.job.builder.JobBuilderHelper
Create a new 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
 
JobContext - Class in org.springframework.batch.core.scope.context
A context object that can be used to interrogate the current JobExecution and some of its associated properties using expressions based on bean paths.
JobContext(JobExecution) - Constructor for class org.springframework.batch.core.scope.context.JobContext
 
JobExecution - Class in org.springframework.batch.core
Batch domain object representing the execution of a job.
JobExecution(Long) - Constructor for class org.springframework.batch.core.JobExecution
Constructor that accepts the job execution id.
JobExecution(Long, JobParameters) - Constructor for class org.springframework.batch.core.JobExecution
Constructor that accepts the job execution id and JobParameters.
JobExecution(JobExecution) - Constructor for class org.springframework.batch.core.JobExecution
Constructor that sets the state of the instance to the JobExecution parameter.
JobExecution(JobInstance, Long, JobParameters) - Constructor for class org.springframework.batch.core.JobExecution
Because a JobExecution is not 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.
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
Deprecated.
as of 5.0, in favor of the default methods on the JobExecutionListener
JobExecutionListenerSupport() - Constructor for class org.springframework.batch.core.listener.JobExecutionListenerSupport
Deprecated.
 
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
Checked exception 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() - Method in class org.springframework.batch.core.configuration.support.DefaultBatchConfiguration
 
JobExplorer - Interface in org.springframework.batch.core.explore
Entry point for browsing the 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 by 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, Flow) - 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, Step) - 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
Constructor for 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 job has been interrupted.
JobInterruptedException(String) - Constructor for exception org.springframework.batch.core.JobInterruptedException
Constructor that sets the message for the exception.
JobInterruptedException(String, BatchStatus) - Constructor for exception org.springframework.batch.core.JobInterruptedException
Constructor that sets the message for the exception.
JobKeyGenerator<T> - Interface in org.springframework.batch.core
Strategy interface for the generation of the key used in identifying unique JobInstance objects.
jobKeyGeneratorRef() - Element in annotation interface org.springframework.batch.core.configuration.annotation.EnableBatchProcessing
The generator that determines a unique key for identifying job instance objects
jobLauncher() - Method in class org.springframework.batch.core.configuration.support.DefaultBatchConfiguration
 
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 Class 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() - Method in class org.springframework.batch.core.configuration.support.DefaultBatchConfiguration
 
JobOperator - Interface in org.springframework.batch.core.launch
Low level interface for inspecting and controlling jobs with access only to primitive and collection types.
JobOperatorFactoryBean - Class in org.springframework.batch.core.launch.support
Convenient factory bean that creates a transactional proxy around a JobOperator.
JobOperatorFactoryBean() - Constructor for class org.springframework.batch.core.launch.support.JobOperatorFactoryBean
 
JobParameter<T> - Class in org.springframework.batch.core
Domain representation of a parameter to a batch job.
JobParameter(T, Class<T>) - Constructor for class org.springframework.batch.core.JobParameter
Create a new identifying JobParameter.
JobParameter(T, Class<T>, boolean) - Constructor for class org.springframework.batch.core.JobParameter
Create a new JobParameter.
JobParameterDefinition(String, String, String) - Constructor for record class org.springframework.batch.core.converter.JsonJobParametersConverter.JobParameterDefinition
Creates an instance of a JobParameterDefinition record class.
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
Default constructor.
JobParameters(Map<String, JobParameter<?>>) - Constructor for class org.springframework.batch.core.JobParameters
Constructor that is initialized with the content of a Map that contains a String key and a JobParameter value.
JobParametersBuilder - Class in org.springframework.batch.core
Helper class for creating JobParameters.
JobParametersBuilder() - Constructor for class org.springframework.batch.core.JobParametersBuilder
Default constructor.
JobParametersBuilder(JobExplorer) - Constructor for class org.springframework.batch.core.JobParametersBuilder
 
JobParametersBuilder(JobParameters) - Constructor for class org.springframework.batch.core.JobParametersBuilder
Copy constructor.
JobParametersBuilder(JobParameters, JobExplorer) - Constructor for class org.springframework.batch.core.JobParametersBuilder
Copy constructor.
JobParametersConversionException - Exception in org.springframework.batch.core.converter
Exception to report an error when converting job parameters.
JobParametersConversionException(String) - Constructor for exception org.springframework.batch.core.converter.JobParametersConversionException
JobParametersConversionException(String, Throwable) - Constructor for exception org.springframework.batch.core.converter.JobParametersConversionException
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 object 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
Constructor that sets the message for the exception.
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 <job/> element in the Batch namespace.
JobParser() - Constructor for class org.springframework.batch.core.configuration.xml.JobParser
 
JobParserJobFactoryBean - Class in org.springframework.batch.core.configuration.xml
This FactoryBean is used by the batch namespace parser to create FlowJob objects.
JobParserJobFactoryBean(String) - Constructor for class org.springframework.batch.core.configuration.xml.JobParserJobFactoryBean
Constructor for the factory bean that initializes the name.
jobRegistry() - Method in class org.springframework.batch.core.configuration.support.DefaultBatchConfiguration
 
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
Deprecated, for removal: This API element is subject to removal in a future version.
since 5.0 with no replacement. Scheduled for removal in 5.2.
JobRegistryBackgroundJobRunner(String) - Constructor for class org.springframework.batch.core.launch.support.JobRegistryBackgroundJobRunner
Deprecated.
 
jobRegistryBeanPostProcessor() - Method in class org.springframework.batch.core.configuration.support.DefaultBatchConfiguration
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
 
JobRegistrySmartInitializingSingleton - Class in org.springframework.batch.core.configuration.support
A SmartInitializingSingleton that registers Job beans with a JobRegistry.
JobRegistrySmartInitializingSingleton() - Constructor for class org.springframework.batch.core.configuration.support.JobRegistrySmartInitializingSingleton
Default constructor.
JobRegistrySmartInitializingSingleton(JobRegistry) - Constructor for class org.springframework.batch.core.configuration.support.JobRegistrySmartInitializingSingleton
Convenience constructor for setting the JobRegistry.
jobRepository - Variable in class org.springframework.batch.core.step.factory.SimpleStepFactoryBean
 
jobRepository() - Method in class org.springframework.batch.core.configuration.support.DefaultBatchConfiguration
 
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 <job-repository/> 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
 
jobScope() - Static method in class org.springframework.batch.core.configuration.support.ScopeConfiguration
 
JobScope - Class in org.springframework.batch.core.scope
Scope for job context.
JobScope - Annotation Interface in org.springframework.batch.core.configuration.annotation
Convenient annotation for job-scoped beans that defaults the proxy mode, so that it does not have to be specified explicitly on every bean definition.
JobScope() - Constructor for class org.springframework.batch.core.scope.JobScope
 
JobScopeManager - Class in org.springframework.batch.core.scope.context
Convenient aspect to wrap a single threaded job execution, where the implementation of the Job is not job scope aware (i.e.
JobScopeManager() - Constructor for class org.springframework.batch.core.scope.context.JobScopeManager
 
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.
JobSynchronizationManager - Class in org.springframework.batch.core.scope.context
Central convenience class for framework use in managing the job scope context.
JobSynchronizationManager() - Constructor for class org.springframework.batch.core.scope.context.JobSynchronizationManager
 
JsonJobParametersConverter - Class in org.springframework.batch.core.converter
Converter for JobParameters instances that uses a JSON naming convention for converting job parameters.
JsonJobParametersConverter() - Constructor for class org.springframework.batch.core.converter.JsonJobParametersConverter
Create a new JsonJobParametersConverter with a default ObjectMapper.
JsonJobParametersConverter(ObjectMapper) - Constructor for class org.springframework.batch.core.converter.JsonJobParametersConverter
Create a new JsonJobParametersConverter with a custom ObjectMapper.
JsonJobParametersConverter.JobParameterDefinition - Record Class in org.springframework.batch.core.converter
 
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
 
JvmCommandRunner - Class in org.springframework.batch.core.step.tasklet
Implementation of the CommandRunner interface that calls the standard Runtime.exec(java.lang.String) method.
JvmCommandRunner() - Constructor for class org.springframework.batch.core.step.tasklet.JvmCommandRunner
 
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(Object) - Method in class org.springframework.batch.core.job.builder.JobBuilderHelper
Registers objects using the annotation based listener configuration.
listener(Object) - Method in class org.springframework.batch.core.step.builder.AbstractTaskletStepBuilder
Registers objects using the annotation based listener configuration.
listener(Object) - Method in class org.springframework.batch.core.step.builder.FaultTolerantStepBuilder
Registers objects using the annotation based listener configuration.
listener(Object) - Method in class org.springframework.batch.core.step.builder.SimpleStepBuilder
Registers objects using the annotation based listener configuration.
listener(Object) - Method in class org.springframework.batch.core.step.builder.StepBuilderHelper
Registers objects using the annotation based listener configuration.
listener(ChunkListener) - Method in class org.springframework.batch.core.step.builder.AbstractTaskletStepBuilder
Register a chunk listener.
listener(ChunkListener) - Method in class org.springframework.batch.core.step.builder.FaultTolerantStepBuilder
 
listener(ItemProcessListener<? super I, ? super O>) - Method in class org.springframework.batch.core.step.builder.SimpleStepBuilder
Register an item processor listener.
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(JobExecutionListener) - Method in class org.springframework.batch.core.job.builder.JobBuilderHelper
Register a job execution listener.
listener(SkipListener<? super I, ? super O>) - Method in class org.springframework.batch.core.step.builder.FaultTolerantStepBuilder
Register a skip listener.
listener(StepExecutionListener) - Method in class org.springframework.batch.core.step.builder.StepBuilderHelper
 
listener(RetryListener) - Method in class org.springframework.batch.core.step.builder.FaultTolerantStepBuilder
Register a retry listener.
ListenerMetaData - Interface in org.springframework.batch.core.listener
A common interface for listener meta data enumerations.
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.
lobHandlerRef() - Element in annotation interface org.springframework.batch.core.configuration.annotation.EnableBatchProcessing
The large object handler to use in job repository and job explorer.
localDateFormatter - Variable in class org.springframework.batch.core.converter.StringToLocalDateConverter
 
localDateTimeFormatter - Variable in class org.springframework.batch.core.converter.StringToLocalDateConverter
 
LocalDateTimeToStringConverter - Class in org.springframework.batch.core.converter
Converter implementation from LocalDateTime to String.
LocalDateTimeToStringConverter() - Constructor for class org.springframework.batch.core.converter.LocalDateTimeToStringConverter
 
LocalDateToStringConverter - Class in org.springframework.batch.core.converter
Converter implementation from LocalDate to String.
LocalDateToStringConverter() - Constructor for class org.springframework.batch.core.converter.LocalDateToStringConverter
 
localTimeFormatter - Variable in class org.springframework.batch.core.converter.StringToLocalDateConverter
 
LocalTimeToStringConverter - Class in org.springframework.batch.core.converter
Converter implementation from LocalTime to String.
LocalTimeToStringConverter() - Constructor for class org.springframework.batch.core.converter.LocalTimeToStringConverter
 
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
Deprecated.
 
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
 

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
Deprecated.
Supply a list of application context locations, starting with the parent context, and followed by the children.
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
 
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.
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 class 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 class org.springframework.batch.core.BatchStatus
Convenience method to return the higher value status of the statuses passed to the method.
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
 
maxVarCharLength() - Element in annotation interface org.springframework.batch.core.configuration.annotation.EnableBatchProcessing
The maximum length of exit messages in the database.
meterRegistry - Variable in class org.springframework.batch.core.step.item.SimpleChunkProcessor
 
meterRegistry(MeterRegistry) - Method in class org.springframework.batch.core.job.builder.JobBuilderHelper
Sets the meter registry for the job.
meterRegistry(MeterRegistry) - Method in class org.springframework.batch.core.step.builder.StepBuilderHelper
 
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
 
METRICS_PREFIX - Static variable in class org.springframework.batch.core.observability.BatchMetrics
 
modular() - Element in annotation interface org.springframework.batch.core.configuration.annotation.EnableBatchProcessing
Indicate whether the configuration is going to be modularized into multiple application contexts.
MulticasterBatchListener<T,S> - Class in org.springframework.batch.core.listener
 
MulticasterBatchListener() - Constructor for class org.springframework.batch.core.listener.MulticasterBatchListener
Initialize 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(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.FlowBuilder
Transition to the decider on successful completion of the current step.
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.FlowBuilder
Transition to the next step on successful completion of the current step.
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_ATTR - Static variable in class org.springframework.batch.core.configuration.xml.AbstractFlowParser
Establishes a Next attribute.
NEXT_ELE - Static variable in class org.springframework.batch.core.configuration.xml.AbstractFlowParser
Establishes a Next element.
nextState(String, FlowExecutionStatus, StepExecution) - Method in class org.springframework.batch.core.job.flow.support.SimpleFlow
 
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 a job that did no processing (for example, because it was already complete).
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

observationConvention(BatchJobObservationConvention) - Method in class org.springframework.batch.core.job.builder.JobBuilderHelper
Sets the job observation convention.
observationConvention(BatchStepObservationConvention) - Method in class org.springframework.batch.core.step.builder.StepBuilderHelper
Sets the step observation convention.
observationRegistry - Variable in class org.springframework.batch.core.step.factory.SimpleStepFactoryBean
 
observationRegistry(ObservationRegistry) - Method in class org.springframework.batch.core.job.builder.JobBuilderHelper
Sets the observation registry for the job.
observationRegistry(ObservationRegistry) - Method in class org.springframework.batch.core.step.builder.StepBuilderHelper
 
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.
ON_ATTR - Static variable in class org.springframework.batch.core.configuration.xml.AbstractFlowParser
Establishes an On element.
ON_PROCESS_ERROR - Enum constant in enum class org.springframework.batch.core.listener.StepListenerMetaData
 
ON_READ_ERROR - Enum constant in enum class org.springframework.batch.core.listener.StepListenerMetaData
 
ON_SKIP_IN_PROCESS - Enum constant in enum class org.springframework.batch.core.listener.StepListenerMetaData
 
ON_SKIP_IN_READ - Enum constant in enum class org.springframework.batch.core.listener.StepListenerMetaData
 
ON_SKIP_IN_WRITE - Enum constant in enum class org.springframework.batch.core.listener.StepListenerMetaData
 
ON_WRITE_ERROR - Enum constant in enum class org.springframework.batch.core.listener.StepListenerMetaData
 
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(T, Exception) - Method in class org.springframework.batch.core.listener.MulticasterBatchListener
 
OnProcessError - Annotation Interface in org.springframework.batch.core.annotation
Marks a method to be called if an exception is thrown by an ItemProcessor.
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.MulticasterBatchListener
 
onReadError(Exception) - Method in class org.springframework.batch.core.step.item.DefaultItemFailureHandler
 
OnReadError - Annotation Interface in org.springframework.batch.core.annotation
Marks a method to be called if an exception is thrown by an ItemReader.
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
Deprecated.
 
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.
OnSkipInProcess - Annotation Interface 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)
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
Deprecated.
 
onSkipInRead(Throwable) - Method in interface org.springframework.batch.core.SkipListener
Callback for a failure on read that is legal and, consequently, is not going to be re-thrown.
OnSkipInRead - Annotation Interface 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.
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
Deprecated.
 
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.
OnSkipInWrite - Annotation Interface 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)
onWriteError(Exception, Chunk<?>) - Method in class org.springframework.batch.core.step.item.DefaultItemFailureHandler
 
onWriteError(Exception, Chunk<? extends S>) - Method in interface org.springframework.batch.core.ItemWriteListener
Called if an error occurs while trying to write.
onWriteError(Exception, Chunk<? 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, Chunk<? extends S>) - Method in class org.springframework.batch.core.listener.MulticasterBatchListener
 
OnWriteError - Annotation Interface in org.springframework.batch.core.annotation
Marks a method to be called if an exception is thrown by an ItemWriter.
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
Annotations for java based configuration of listeners.
org.springframework.batch.core.aot - package org.springframework.batch.core.aot
 
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
Annotations and builder factories for java based configuration
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
Parsers for XML based configuration
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
Job and flow level builders for java based configuration of batch jobs
org.springframework.batch.core.job.flow - package org.springframework.batch.core.job.flow
Flow related constructs including Flow interface, executors, and related exceptions
org.springframework.batch.core.job.flow.support - package org.springframework.batch.core.job.flow.support
Basic implementations of flow constructs
org.springframework.batch.core.job.flow.support.state - package org.springframework.batch.core.job.flow.support.state
States used in defining the underlying Spring Batch state machine
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.observability - package org.springframework.batch.core.observability
This package contains APIs related to batch observability.
org.springframework.batch.core.partition - package org.springframework.batch.core.partition
Interfaces for partitioning components.
org.springframework.batch.core.partition.support - package org.springframework.batch.core.partition.support
Implementation of common partition components.
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
Implementation of Spring Batch specific bean scopes (Job and Step).
org.springframework.batch.core.scope.context - package org.springframework.batch.core.scope.context
Implementation of the contexts for each of the custom bean scopes in Spring Batch (Job and Step).
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
Step level builders for java based job configuration.
org.springframework.batch.core.step.factory - package org.springframework.batch.core.step.factory
Factories for step level components.
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
JobStep and related components.
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.

P

parametersExtractor(JobParametersExtractor) - Method in class org.springframework.batch.core.step.builder.JobStepBuilder
Provide a job parameters extractor.
parse(Element, AbstractBeanDefinition, ParserContext, boolean) - Method in class org.springframework.batch.core.configuration.xml.ChunkElementParser
Do the parsing.
parse(Element, ParserContext) - Method in class org.springframework.batch.core.configuration.xml.AbstractListenerParser
 
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) - 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.
parse(Element, ParserContext, String) - Method in class org.springframework.batch.core.configuration.xml.ExceptionElementParser
 
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.
parseBeanElement(Element, ParserContext) - Method in class org.springframework.batch.core.configuration.xml.JobParser
Parse the element to retrieve BeanMetadataElement.
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(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.
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.
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.
PartitionHandler - Interface in org.springframework.batch.core.partition
Interface defining the responsibilities of controlling the execution of a partitioned StepExecution.
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<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
 
postProcess(StepContribution, Chunk<T>) - Method in interface org.springframework.batch.core.step.item.ChunkProvider
 
postProcessAfterInitialization(Object, String) - Method in class org.springframework.batch.core.configuration.annotation.BatchObservabilityBeanPostProcessor
 
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.annotation.BatchObservabilityBeanPostProcessor
 
postProcessBeanFactory(ConfigurableListableBeanFactory) - Method in class org.springframework.batch.core.configuration.xml.CoreNamespacePostProcessor
 
postProcessBeanFactory(ConfigurableListableBeanFactory) - Method in class org.springframework.batch.core.scope.BatchScopeSupport
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 keeps a reference to a Job.
ReferenceJobFactory(Job) - Constructor for class org.springframework.batch.core.configuration.support.ReferenceJobFactory
 
register(E) - Method in class org.springframework.batch.core.scope.context.SynchronizationManagerSupport
Register a context with the current thread - always put a matching SynchronizationManagerSupport.close() call in a finally block to ensure that the correct context is available in the enclosing block.
register(String, Collection<Step>) - Method in interface org.springframework.batch.core.configuration.StepRegistry
Registers all the step instances of the given job.
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(JobFactory) - Method in interface org.springframework.batch.core.configuration.JobRegistry
Registers a Job at runtime.
register(JobFactory) - Method in class org.springframework.batch.core.configuration.support.MapJobRegistry
 
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(JobExecution) - Static method in class org.springframework.batch.core.scope.context.JobSynchronizationManager
Register a context with the current thread - always put a matching JobSynchronizationManager.close() call in a finally block to ensure that the correct context is available in the enclosing block.
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(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.
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.
registerAsStreamsAndListeners(ItemReader<? extends I>, ItemProcessor<? super I, ? extends O>, ItemWriter<? super O>) - Method in class org.springframework.batch.core.step.builder.SimpleStepBuilder
 
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.JobContext
Allow clients to register callbacks for clean up on close.
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.JobScope
 
registerDestructionCallback(String, Runnable) - Method in class org.springframework.batch.core.scope.StepScope
 
registerHints(RuntimeHints, ClassLoader) - Method in class org.springframework.batch.core.aot.CoreRuntimeHints
 
registerItemListeners(SimpleStepBuilder<I, O>) - Method in class org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
 
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(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.
registerListener(RetryListener) - Method in class org.springframework.batch.core.step.item.BatchRetryTemplate
 
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.
registerStepListenerAsChunkListener() - Method in class org.springframework.batch.core.step.builder.AbstractTaskletStepBuilder
 
registerStepListenerAsItemListener() - Method in class org.springframework.batch.core.step.builder.SimpleStepBuilder
 
registerStepListenerAsSkipListener() - Method in class org.springframework.batch.core.step.builder.FaultTolerantStepBuilder
 
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.JobSynchronizationManager
A convenient "deep" close operation.
release() - Static method in class org.springframework.batch.core.scope.context.StepSynchronizationManager
A convenient "deep" close operation.
release() - Method in class org.springframework.batch.core.scope.context.SynchronizationManagerSupport
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.JobScope
 
remove(String) - Method in class org.springframework.batch.core.scope.StepScope
 
removeAttribute(String) - Method in class org.springframework.batch.core.scope.context.JobContext
Override base class behaviour to ensure destruction callbacks are unregistered as well as the default behaviour.
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
Deprecated, for removal: This API element is subject to removal in a future version.
repository(JobRepository) - Method in class org.springframework.batch.core.step.builder.StepBuilderHelper
Deprecated, for removal: This API element is subject to removal in a future version.
requiresTransactionManager() - Method in class org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
Currently, all step implementations other than TaskletStep are instances of AbstractStep and do not require a transaction manager.
resetOffset() - Method in class org.springframework.batch.core.step.item.ChunkMonitor
 
resolveContextualObject(String) - Method in class org.springframework.batch.core.scope.JobScope
This will be used to resolve expressions in job-scoped beans.
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
 
resolveValue(Object) - Method in class org.springframework.batch.core.scope.BatchScopeSupport.Scopifier
 
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
 
RESTART_ATTR - Static variable in class org.springframework.batch.core.configuration.xml.AbstractFlowParser
Establishes a Restart attribute.
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
The key for retrieving the rollback exception.
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
Deprecated.
Run the provided job with the given JobParameters.
run(Job, JobParameters) - Method in class org.springframework.batch.core.launch.support.TaskExecutorJobLauncher
 
RunIdIncrementer - Class in org.springframework.batch.core.launch.support
This incrementer increments a "run.id" parameter of type Long from the given job parameters.
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(JobExecution) - Method in class org.springframework.batch.core.repository.dao.JdbcExecutionContextDao
 
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(StepExecution) - Method in class org.springframework.batch.core.repository.dao.JdbcExecutionContextDao
 
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
 
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.
saveStepExecution(StepExecution) - Method in class org.springframework.batch.core.repository.dao.JdbcStepExecutionDao
Save a StepExecution.
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 interface org.springframework.batch.core.repository.dao.StepExecutionDao
Save the given collection of StepExecution as a batch.
ScopeConfiguration - Class in org.springframework.batch.core.configuration.support
Configuration class that provides StepScope and JobScope.
ScopeConfiguration() - Constructor for class org.springframework.batch.core.configuration.support.ScopeConfiguration
 
Scopifier(BeanDefinitionRegistry, String, boolean, boolean) - Constructor for class org.springframework.batch.core.scope.BatchScopeSupport.Scopifier
 
self() - Method in class org.springframework.batch.core.step.builder.FlowStepBuilder
 
self() - Method in class org.springframework.batch.core.step.builder.JobStepBuilder
 
self() - Method in class org.springframework.batch.core.step.builder.PartitionStepBuilder
 
self() - Method in class org.springframework.batch.core.step.builder.SimpleStepBuilder
 
self() - Method in class org.springframework.batch.core.step.builder.StepBuilder
 
self() - Method in class org.springframework.batch.core.step.builder.StepBuilderHelper
 
self() - Method in class org.springframework.batch.core.step.builder.TaskletStepBuilder
 
serialize(Map<String, Object>, OutputStream) - Method in class org.springframework.batch.core.repository.dao.DefaultExecutionContextSerializer
Serializes an execution context to the provided OutputStream.
serialize(Map<String, Object>, OutputStream) - Method in class org.springframework.batch.core.repository.dao.Jackson2ExecutionContextStringSerializer
 
setAllowStartIfComplete(boolean) - Method in class org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
Public setter for the flag to indicate that the step should be replayed on a restart, even if successful the first time.
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.factory.SimpleStepFactoryBean
Public setter for the flag to indicate that the step should be replayed on a restart, even if successful the first time.
setAllowStartIfComplete(Boolean) - Method in class org.springframework.batch.core.step.builder.StepBuilderHelper.CommonStepProperties
 
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 you can use to check whether 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.DefaultBatchConfiguration
 
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 an array of ApplicationContextFactory instances to the set that is used to load contexts and jobs.
setAutoProxy(boolean) - Method in class org.springframework.batch.core.scope.BatchScopeSupport
Flag to indicate that bean definitions need not be auto proxied.
setAutoStartup(boolean) - Method in class org.springframework.batch.core.configuration.support.AutomaticJobRegistrar
 
setBackOffPolicy(BackOffPolicy) - Method in class org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
A backoff policy to be applied to the retry process.
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
 
setBeanFactory(BeanFactory) - Method in class org.springframework.batch.core.configuration.support.JobRegistrySmartInitializingSingleton
 
setBeanFactoryPostProcessorClasses(Class<? extends BeanFactoryPostProcessor>[]) - Method in class org.springframework.batch.core.configuration.support.AbstractApplicationContextFactory
Determines which bean factory post processors (such as 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 (such as property placeholders) should be copied from the parent context.
setBeanName(String) - Method in class org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
Set the bean name property, which will become the name of the Step when it is created.
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.
setCacheCapacity(int) - Method in class org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
Public setter for the capacity of the cache in the retry policy.
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.
setCharset(Charset) - Method in class org.springframework.batch.core.explore.support.JobExplorerFactoryBean
Sets the Charset to use when deserializing the execution context.
setCharset(Charset) - Method in class org.springframework.batch.core.repository.dao.JdbcExecutionContextDao
Set the Charset to use when serializing/deserializing the execution context.
setCharset(Charset) - Method in class org.springframework.batch.core.repository.support.JobRepositoryFactoryBean
Set the Charset to use when serializing/deserializing the execution context.
setChunk(SimpleStepBuilder<I, O>) - Method in class org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
 
setChunkCompletionPolicy(CompletionPolicy) - Method in class org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
Public setter for the CompletionPolicy that applies to the chunk level.
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
Set the command to execute along with its arguments.
setCommandRunner(CommandRunner) - Method in class org.springframework.batch.core.step.tasklet.SystemCommandTasklet
Injection setter for the CommandRunner.
setCommitCount(long) - 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.configuration.xml.StepParserStepFactoryBean
Set the commit interval.
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.
setConversionService(ConfigurableConversionService) - Method in class org.springframework.batch.core.converter.DefaultJobParametersConverter
Set the conversion service to use.
setConversionService(ConfigurableConversionService) - Method in class org.springframework.batch.core.explore.support.JobExplorerFactoryBean
Set the conversion service to use in the job explorer.
setConversionService(ConfigurableConversionService) - Method in class org.springframework.batch.core.repository.dao.JdbcJobExecutionDao
Set the conversion service to use to convert job parameters from String literals to typed values and vice versa.
setConversionService(ConfigurableConversionService) - Method in class org.springframework.batch.core.repository.support.JobRepositoryFactoryBean
Set the conversion service to use in the job repository.
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(LocalDateTime) - Method in class org.springframework.batch.core.JobExecution
 
setCreateTime(LocalDateTime) - Method in class org.springframework.batch.core.StepExecution
Sets the time this execution was created
setDatabaseType(String) - Method in class org.springframework.batch.core.repository.support.JobRepositoryFactoryBean
Sets the database type.
setDataFieldMaxValueIncrementer(DataFieldMaxValueIncrementer) - Method in class org.springframework.batch.core.launch.support.DataFieldMaxValueJobParametersIncrementer
The incrementer to generate the sequence of values.
setDataSource(DataSource) - Method in class org.springframework.batch.core.explore.support.JobExplorerFactoryBean
Sets the data source.
setDataSource(DataSource) - Method in class org.springframework.batch.core.repository.support.JobRepositoryFactoryBean
Public setter for the DataSource.
setDelegate(Object) - Method in class org.springframework.batch.core.listener.AbstractListenerFactoryBean
 
setDelegate(StepExecutionAggregator) - Method in class org.springframework.batch.core.partition.support.RemoteStepExecutionAggregator
 
setEndTime(LocalDateTime) - Method in class org.springframework.batch.core.JobExecution
Set the end time.
setEndTime(LocalDateTime) - Method in class org.springframework.batch.core.StepExecution
Sets the time when 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
 
setExitStatus(FlowExecutor, String) - Method in class org.springframework.batch.core.job.flow.support.state.EndState
Performs any logic to update the exit status for the current flow.
setFilterCount(long) - Method in class org.springframework.batch.core.StepExecution
Sets the number of items filtered out of this execution.
setFlow(Flow) - Method in class org.springframework.batch.core.configuration.xml.JobParserJobFactoryBean
Set the flow for the factory bean.
setFlow(Flow) - Method in class org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
 
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.
setFlowType(Class<SimpleFlow>) - Method in class org.springframework.batch.core.configuration.xml.SimpleFlowFactoryBean
 
setGridSize(int) - Method in class org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
 
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.
setGroupName(String) - Method in class org.springframework.batch.core.configuration.support.JobRegistrySmartInitializingSingleton
The group name for jobs registered by this component.
setHasChunkElement(boolean) - Method in class org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
 
setId(Long) - Method in class org.springframework.batch.core.Entity
 
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.configuration.xml.StepParserStepFactoryBean
 
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.
setIsolationLevelForCreateEnum(Isolation) - 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.configuration.xml.StepParserStepFactoryBean
Flag to signal that the reader is transactional (usually a JMS consumer) so that items are re-presented after a rollback.
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 I, ? extends O>) - Method in class org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
 
setItemProcessor(ItemProcessor<? super I, ? extends O>) - Method in class org.springframework.batch.core.step.item.SimpleChunkProcessor
 
setItemProcessor(ItemProcessor<? super T, ? extends S>) - Method in class org.springframework.batch.core.step.factory.SimpleStepFactoryBean
 
setItemReader(ItemReader<?>) - Method in class org.springframework.batch.core.step.item.ChunkMonitor
 
setItemReader(ItemReader<? extends I>) - Method in class org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
 
setItemReader(ItemReader<? extends T>) - Method in class org.springframework.batch.core.step.factory.SimpleStepFactoryBean
 
setItemWriter(ItemWriter<? super O>) - Method in class org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
 
setItemWriter(ItemWriter<? super O>) - Method in class org.springframework.batch.core.step.item.SimpleChunkProcessor
 
setItemWriter(ItemWriter<? super S>) - Method in class org.springframework.batch.core.step.factory.SimpleStepFactoryBean
 
setJdbcOperations(JdbcOperations) - Method in class org.springframework.batch.core.explore.support.JobExplorerFactoryBean
Public setter for the JdbcOperations.
setJdbcOperations(JdbcOperations) - Method in class org.springframework.batch.core.repository.support.JobRepositoryFactoryBean
Public setter for the JdbcOperations.
setJdbcTemplate(JdbcOperations) - Method in class org.springframework.batch.core.repository.dao.AbstractJdbcBatchMetadataDao
 
setJob(Job) - Method in class org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
 
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.configuration.xml.JobParserJobFactoryBean
 
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.JobOperatorFactoryBean
Setter for the job explorer.
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
 
setJobExplorer(JobExplorer) - Method in class org.springframework.batch.core.step.tasklet.SystemCommandTasklet
 
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
setJobInstance(JobInstance) - Method in class org.springframework.batch.core.JobExecution
Set the JobInstance used by the JobExecution.
setJobInstanceIncrementer(DataFieldMaxValueIncrementer) - Method in class org.springframework.batch.core.repository.dao.JdbcJobInstanceDao
Setter for DataFieldMaxValueIncrementer to be used when generating primary keys for JobInstance instances.
setJobKeyGenerator(JobKeyGenerator) - Method in class org.springframework.batch.core.explore.support.JobExplorerFactoryBean
* Sets the generator for creating the key used in identifying unique {link JobInstance} objects
setJobKeyGenerator(JobKeyGenerator) - Method in class org.springframework.batch.core.repository.dao.JdbcJobInstanceDao
Setter for JobKeyGenerator to be used when generating unique identifiers for JobInstance objects.
setJobKeyGenerator(JobKeyGenerator) - Method in class org.springframework.batch.core.repository.support.JobRepositoryFactoryBean
* Sets the generator for creating the key used in identifying unique {link JobInstance} objects
setJobLauncher(JobLauncher) - Method in class org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
 
setJobLauncher(JobLauncher) - Method in class org.springframework.batch.core.launch.support.JobOperatorFactoryBean
Setter for the job launcher.
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 is used to load and manage jobs.
setJobLoader(JobLoader) - Method in class org.springframework.batch.core.launch.support.JobRegistryBackgroundJobRunner
Deprecated.
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.JobOperatorFactoryBean
Setter for the job parameters converter.
setJobParametersConverter(JobParametersConverter) - Method in class org.springframework.batch.core.launch.support.SimpleJobOperator
Public setter for the JobParametersConverter.
setJobParametersConverter(JobParametersConverter) - Method in class org.springframework.batch.core.step.job.DefaultJobParametersExtractor
Set the JobParametersConverter to use.
setJobParametersExtractor(JobParametersExtractor) - Method in class org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
 
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.configuration.xml.JobParserJobFactoryBean
Set the JobParametersIncrementer for the factory bean.
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.configuration.xml.JobParserJobFactoryBean
Set the JobParametersValidator for the factory bean.
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.configuration.support.JobRegistrySmartInitializingSingleton
Injection setter for JobRegistry.
setJobRegistry(JobRegistry) - Method in class org.springframework.batch.core.launch.support.JobOperatorFactoryBean
Setter for the job registry.
setJobRegistry(JobRegistry) - Method in class org.springframework.batch.core.launch.support.JobRegistryBackgroundJobRunner
Deprecated.
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.configuration.xml.JobParserJobFactoryBean
Set the JobRepository for the factory bean.
setJobRepository(JobRepository) - Method in class org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
Public setter for JobRepository.
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.JobOperatorFactoryBean
Setter for the job repository.
setJobRepository(JobRepository) - Method in class org.springframework.batch.core.launch.support.SimpleJobLauncher
Deprecated.
Set the JobRepository.
setJobRepository(JobRepository) - Method in class org.springframework.batch.core.launch.support.SimpleJobOperator
 
setJobRepository(JobRepository) - Method in class org.springframework.batch.core.launch.support.TaskExecutorJobLauncher
 
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.DataFieldMaxValueJobParametersIncrementer
The name of the key to use as a job parameter.
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.configuration.xml.StepParserStepFactoryBean
A key generator that can be used to compare items with previously recorded items in a retry.
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(LocalDateTime) - Method in class org.springframework.batch.core.JobExecution
Set the last time this JobExecution was updated.
setLastUpdated(LocalDateTime) - Method in class org.springframework.batch.core.StepExecution
Sets 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(Object[]) - Method in class org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
The listeners to inject into the Step.
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(List<? extends StepListener>) - Method in class org.springframework.batch.core.listener.MulticasterBatchListener
Register each of the objects as listeners.
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.
setListeners(StepExecutionListener[]) - Method in class org.springframework.batch.core.listener.CompositeStepExecutionListener
Public setter for the 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
 
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.
setMaxVarCharLengthForExitMessage(int) - Method in class org.springframework.batch.core.repository.support.JobRepositoryFactoryBean
Public setter for the length of the exit message in both JdbcJobExecutionDao and JdbcStepExecutionDao.
setMaxVarCharLengthForShortContext(int) - Method in class org.springframework.batch.core.repository.support.JobRepositoryFactoryBean
Public setter for the length of short context string column in database.
setMetaDataMap(Map<String, String>) - Method in class org.springframework.batch.core.listener.AbstractListenerFactoryBean
 
setMeterRegistry(MeterRegistry) - Method in class org.springframework.batch.core.job.AbstractJob
 
setMeterRegistry(MeterRegistry) - Method in class org.springframework.batch.core.job.builder.JobBuilderHelper.CommonJobProperties
 
setMeterRegistry(MeterRegistry) - Method in class org.springframework.batch.core.launch.support.SimpleJobLauncher
Deprecated.
Set the meter registry to use for metrics.
setMeterRegistry(MeterRegistry) - Method in class org.springframework.batch.core.step.AbstractStep
 
setMeterRegistry(MeterRegistry) - Method in class org.springframework.batch.core.step.builder.StepBuilderHelper.CommonStepProperties
 
setMeterRegistry(MeterRegistry) - Method in class org.springframework.batch.core.step.item.SimpleChunkProcessor
Set the meter registry to use for metrics.
setMeterRegistry(MeterRegistry) - Method in class org.springframework.batch.core.step.item.SimpleChunkProvider
Set the meter registry to use for metrics.
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.configuration.xml.StepParserStepFactoryBean
 
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.BatchScopeSupport
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.configuration.xml.StepParserStepFactoryBean
Exception classes that may not cause a rollback if encountered in the right place.
setNoRollbackExceptionClasses(Collection<Class<? extends Throwable>>) - Method in class org.springframework.batch.core.step.factory.FaultTolerantStepFactoryBean
Exception classes that are candidates for no rollback.
setObjectMapper(ObjectMapper) - Method in class org.springframework.batch.core.repository.dao.Jackson2ExecutionContextStringSerializer
 
setObservationConvention(BatchJobObservationConvention) - Method in class org.springframework.batch.core.job.AbstractJob
 
setObservationConvention(BatchJobObservationConvention) - Method in class org.springframework.batch.core.job.builder.JobBuilderHelper.CommonJobProperties
 
setObservationConvention(BatchStepObservationConvention) - Method in class org.springframework.batch.core.step.AbstractStep
 
setObservationConvention(BatchStepObservationConvention) - Method in class org.springframework.batch.core.step.builder.StepBuilderHelper.CommonStepProperties
 
setObservationRegistry(ObservationRegistry) - Method in class org.springframework.batch.core.job.AbstractJob
 
setObservationRegistry(ObservationRegistry) - Method in class org.springframework.batch.core.job.builder.JobBuilderHelper.CommonJobProperties
 
setObservationRegistry(ObservationRegistry) - Method in class org.springframework.batch.core.step.AbstractStep
 
setObservationRegistry(ObservationRegistry) - Method in class org.springframework.batch.core.step.builder.StepBuilderHelper.CommonStepProperties
 
setObservationRegistry(ObservationRegistry) - Method in class org.springframework.batch.core.step.factory.SimpleStepFactoryBean
Public setter for ObservationRegistry.
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 in which to start up and shutdown.
setOrder(int) - Method in class org.springframework.batch.core.scope.BatchScopeSupport
 
setPartitioner(Partitioner) - Method in class org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
 
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.configuration.xml.StepParserStepFactoryBean
 
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.
setPhase(int) - Method in class org.springframework.batch.core.configuration.support.AutomaticJobRegistrar
 
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).
setProcessorTransactional(Boolean) - Method in class org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
Flag to signal that the processor is transactional -- in that case, it should be called for every item in every transaction.
setProcessSkipCount(long) - Method in class org.springframework.batch.core.StepExecution
Sets 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.configuration.xml.StepParserStepFactoryBean
 
setPropagation(Propagation) - Method in class org.springframework.batch.core.step.factory.SimpleStepFactoryBean
 
setProxyTargetClass(boolean) - Method in class org.springframework.batch.core.scope.BatchScopeSupport
Flag to indicate that proxies should use dynamic subclassing.
setReadCount(long) - Method in class org.springframework.batch.core.StepExecution
Sets the current number of read items for this execution.
setReadSkipCount(long) - Method in class org.springframework.batch.core.StepExecution
Set the number of records skipped on read.
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 by 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
 
setRestartable(Boolean) - Method in class org.springframework.batch.core.configuration.xml.JobParserJobFactoryBean
Set the restartable flag for the factory bean.
setRetryableExceptionClasses(Map<Class<? extends Throwable>, Boolean>) - Method in class org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
Public setter for exception classes that retries the item when raised.
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.configuration.xml.StepParserStepFactoryBean
 
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.configuration.xml.StepParserStepFactoryBean
Public setter for the retry limit.
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.configuration.xml.StepParserStepFactoryBean
Public setter for the RetryListener instances.
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.configuration.xml.StepParserStepFactoryBean
A retry policy to apply when exceptions occur.
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(long) - Method in class org.springframework.batch.core.StepExecution
Sets the number of rollbacks for this execution.
setSerializer(ExecutionContextSerializer) - Method in class org.springframework.batch.core.explore.support.JobExplorerFactoryBean
A custom implementation of 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.configuration.xml.StepParserStepFactoryBean
Public setter for a limit that determines skip policy.
setSkipLimit(int) - Method in class org.springframework.batch.core.step.factory.FaultTolerantStepFactoryBean
A limit that determines skip policy.
setSkipLimit(long) - 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.configuration.xml.StepParserStepFactoryBean
Public setter for exception classes that, when raised, do not crash the job but result in transaction rollback.
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.configuration.xml.StepParserStepFactoryBean
Public setter for a skip policy.
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.configuration.xml.StepParserStepFactoryBean
The number of times that the step should be allowed to start.
setStartLimit(int) - Method in class org.springframework.batch.core.step.AbstractStep
Public setter for the startLimit.
setStartLimit(int) - Method in class org.springframework.batch.core.step.factory.SimpleStepFactoryBean
Public setter for the start limit for the step.
setStartLimit(Integer) - Method in class org.springframework.batch.core.step.builder.StepBuilderHelper.CommonStepProperties
 
setStartTime(LocalDateTime) - Method in class org.springframework.batch.core.JobExecution
Set the start time.
setStartTime(LocalDateTime) - Method in class org.springframework.batch.core.StepExecution
Sets the time when this execution started.
setStateTransitionComparator(Comparator<StateTransition>) - Method in class org.springframework.batch.core.configuration.xml.SimpleFlowFactoryBean
 
setStateTransitionComparator(Comparator<StateTransition>) - Method in class org.springframework.batch.core.job.flow.support.SimpleFlow
 
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.configuration.xml.StepParserStepFactoryBean
 
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.configuration.xml.StepParserStepFactoryBean
 
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.configuration.xml.StepParserStepFactoryBean
The streams to inject into the Step.
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 metadata 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.configuration.xml.StepParserStepFactoryBean
Public setter for the TaskExecutor.
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
Deprecated.
Set the TaskExecutor.
setTaskExecutor(TaskExecutor) - Method in class org.springframework.batch.core.launch.support.TaskExecutorJobLauncher
 
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.configuration.xml.StepParserStepFactoryBean
A preconfigured Tasklet to use.
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
Sets a flag that signals 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
Deprecated, for removal: This API element is subject to removal in a future version.
since 5.0, scheduled for removal in 6.0. Use a pooled TaskExecutor implementation with a limited capacity of its task queue instead.
setThrottleLimit(Integer) - Method in class org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
Deprecated, for removal: This API element is subject to removal in a future version.
since 5.0, scheduled for removal in 6.0. This API is not intended for end users anyway. It is only used by the XML namespace parser.
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.
setTransactionAttributeSource(TransactionAttributeSource) - Method in class org.springframework.batch.core.explore.support.AbstractJobExplorerFactoryBean
Set the transaction attributes source to use in the created proxy.
setTransactionAttributeSource(TransactionAttributeSource) - Method in class org.springframework.batch.core.launch.support.JobOperatorFactoryBean
Set the transaction attributes source to use in the created proxy.
setTransactionAttributeSource(TransactionAttributeSource) - Method in class org.springframework.batch.core.repository.support.AbstractJobRepositoryFactoryBean
Set the transaction attributes source to use in the created proxy.
setTransactionManager(PlatformTransactionManager) - Method in class org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
 
setTransactionManager(PlatformTransactionManager) - Method in class org.springframework.batch.core.explore.support.AbstractJobExplorerFactoryBean
Public setter for the PlatformTransactionManager.
setTransactionManager(PlatformTransactionManager) - Method in class org.springframework.batch.core.launch.support.JobOperatorFactoryBean
Setter for the transaction manager.
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.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.configuration.xml.StepParserStepFactoryBean
 
setTransactionTimeout(int) - Method in class org.springframework.batch.core.step.factory.SimpleStepFactoryBean
The timeout for an individual transaction in the step.
setUseAllParentParameters(boolean) - Method in class org.springframework.batch.core.step.job.DefaultJobParametersExtractor
setter to support switching off all parent parameters
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
setVersion(Integer) - Method in class org.springframework.batch.core.Entity
Public setter for the version.
setWorkingDirectory(String) - Method in class org.springframework.batch.core.step.tasklet.SystemCommandTasklet
 
setWriteCount(long) - Method in class org.springframework.batch.core.StepExecution
Sets the current number of written items for this execution.
setWriteSkipCount(long) - 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
 
shouldGenerateId() - Method in class org.springframework.batch.core.configuration.xml.InlineFlowParser
 
shouldSkip(Throwable, long) - Method in class org.springframework.batch.core.step.skip.AlwaysSkipItemSkipPolicy
 
shouldSkip(Throwable, long) - Method in class org.springframework.batch.core.step.skip.CompositeSkipPolicy
 
shouldSkip(Throwable, long) - 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, long) - 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, long) - Method in class org.springframework.batch.core.step.skip.NeverSkipItemSkipPolicy
 
shouldSkip(Throwable, long) - 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.
shouldStart(StepExecution, JobExecution, Step) - Method in class org.springframework.batch.core.job.SimpleStepHandler
Given a step and configuration, return true if the step should start, false if it should not, and throw an exception if the job should finish.
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
 
SimpleChunkProcessor(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 the XML namespace.
SimpleFlowFactoryBean() - Constructor for class org.springframework.batch.core.configuration.xml.SimpleFlowFactoryBean
 
SimpleFlowFactoryBean.DelegateState - Class in org.springframework.batch.core.configuration.xml
A State that proxies a delegate and changes its name but leaves its behavior unchanged.
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 that uses the injected DAOs.
SimpleJobExplorer(JobInstanceDao, JobExecutionDao, StepExecutionDao, ExecutionContextDao) - Constructor for class org.springframework.batch.core.explore.support.SimpleJobExplorer
Constructor to initialize the job SimpleJobExplorer.
SimpleJobLauncher - Class in org.springframework.batch.core.launch.support
Deprecated, for removal: This API element is subject to removal in a future version.
Since v5.0.0 for removal in v5.2.0. Use TaskExecutorJobLauncher.
SimpleJobLauncher() - Constructor for class org.springframework.batch.core.launch.support.SimpleJobLauncher
Deprecated.
 
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 job instances, job executions, and step executions 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(SimpleStepBuilder<I, O>) - Constructor for class org.springframework.batch.core.step.builder.SimpleStepBuilder
Create a new builder initialized with any properties in the parent.
SimpleStepBuilder(StepBuilderHelper<?>) - 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.
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:
SimpleSystemProcessExitCodeMapper() - Constructor for class org.springframework.batch.core.step.tasklet.SimpleSystemProcessExitCodeMapper
 
skip(Class<? extends Throwable>) - Method in class org.springframework.batch.core.step.builder.FaultTolerantStepBuilder
Explicitly request certain exceptions (and subclasses) to be skipped.
SkipException - Exception in org.springframework.batch.core.step.skip
Base exception indicating that the skip has failed or caused a failure.
SkipException(String) - Constructor for exception org.springframework.batch.core.step.skip.SkipException
 
SkipException(String, Throwable) - Constructor for exception org.springframework.batch.core.step.skip.SkipException
 
skipLimit(int) - Method in class org.springframework.batch.core.step.builder.FaultTolerantStepBuilder
Sets the maximum 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 Step has been exceeded.
SkipLimitExceededException(long, 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
Deprecated.
as of v5.0 in favor of the default methods in SkipListener.
SkipListenerSupport() - Constructor for class org.springframework.batch.core.listener.SkipListenerSupport
Deprecated.
 
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
 
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
 
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_ELE - Static variable in class org.springframework.batch.core.configuration.xml.AbstractFlowParser
Establishes a Split element.
SplitBuilder(FlowBuilder<Q>, TaskExecutor) - Constructor for class org.springframework.batch.core.job.builder.FlowBuilder.SplitBuilder
 
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 by using the provided job repository reference.
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
 
SplitState(Collection<Flow>, String, SplitState) - 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).
SpringBatchVersion - Class in org.springframework.batch.core
Class that exposes the Spring Batch version.
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(String, String) - Method in interface org.springframework.batch.core.launch.JobOperator
Deprecated, for removal: This API element is subject to removal in a future version.
use JobOperator.start(String, Properties) instead. Will be removed in v5.2.
start(String, String) - Method in class org.springframework.batch.core.launch.support.SimpleJobOperator
Deprecated, for removal: This API element is subject to removal in a future version.
start(String, Properties) - Method in interface org.springframework.batch.core.launch.JobOperator
Start a new instance of a job with the parameters specified.
start(String, Properties) - Method in class org.springframework.batch.core.launch.support.SimpleJobOperator
 
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(Flow) - Method in class org.springframework.batch.core.job.builder.JobBuilder
Create a new job builder that will execute a flow.
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(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(JobExecutionDecider) - Method in class org.springframework.batch.core.job.builder.FlowJobBuilder
Start a job with this decider, but expect to transition from there to other flows or steps.
start(JobExecutionDecider) - Method in class org.springframework.batch.core.job.builder.JobBuilder
Create a new job builder that will start with a decider.
start(JobExecutionDecider) - Method in class org.springframework.batch.core.job.builder.SimpleJobBuilder
Start with this decider.
start(Step) - Method in class org.springframework.batch.core.job.builder.FlowBuilder
Start a flow.
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(Step) - Method in class org.springframework.batch.core.job.builder.SimpleJobBuilder
Start the job with this step.
start(RepeatContext) - Method in class org.springframework.batch.core.resource.StepExecutionSimpleCompletionPolicy
 
STARTED - Enum constant in enum class org.springframework.batch.core.BatchStatus
Status of a batch job that is running.
STARTING - Enum constant in enum class org.springframework.batch.core.BatchStatus
Status of a batch job prior to its execution.
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
Constructor that sets the message for the exception.
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
 
STATE_TRANSITION_COMPARATOR - Static variable in class org.springframework.batch.core.job.flow.support.DefaultStateTransitionComparator
 
StateTransition - Class in org.springframework.batch.core.job.flow.support
Value object representing a potential transition from one State to another.
STATUS_FAILURE - Static variable in class org.springframework.batch.core.observability.BatchMetrics
 
STATUS_SUCCESS - Static variable in class org.springframework.batch.core.observability.BatchMetrics
 
step(Step) - Method in class org.springframework.batch.core.step.builder.PartitionStepBuilder
Provide an actual step instance to execute in parallel.
Step - Interface in org.springframework.batch.core
Batch domain interface representing the configuration of a step.
STEP_ELE - Static variable in class org.springframework.batch.core.configuration.xml.AbstractFlowParser
Establishes a Step element.
STEP_TYPE_KEY - Static variable in interface org.springframework.batch.core.Step
The key to use when retrieving the batch step type.
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
Deprecated, for removal: This API element is subject to removal in a future version.
StepBuilder(String, JobRepository) - Constructor for class org.springframework.batch.core.step.builder.StepBuilder
Initialize a step builder for a step with the given name and job repository.
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
Deprecated, for removal: This API element is subject to removal in a future version.
Deprecated as of v5.0 and scheduled for removal in v5.2 in favor of using the StepBuilder.
StepBuilderFactory(JobRepository) - Constructor for class org.springframework.batch.core.configuration.annotation.StepBuilderFactory
Deprecated.
Constructor for the 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 listeners.
StepBuilderHelper(String) - Constructor for class org.springframework.batch.core.step.builder.StepBuilderHelper
Deprecated, for removal: This API element is subject to removal in a future version.
StepBuilderHelper(String, JobRepository) - Constructor for class org.springframework.batch.core.step.builder.StepBuilderHelper
Create a new 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
 
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 for the execution of a step.
StepExecution(String, JobExecution) - Constructor for class org.springframework.batch.core.StepExecution
Constructor that substitutes null for the execution ID.
StepExecution(String, JobExecution, Long) - Constructor for class org.springframework.batch.core.StepExecution
Constructor with mandatory properties.
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 class org.springframework.batch.core.listener.StepListenerMetaData
 
StepExecutionListenerSupport - Class in org.springframework.batch.core.listener
Deprecated.
as of 5.0, in favor of the default methods on the StepExecutionListener
StepExecutionListenerSupport() - Constructor for class org.springframework.batch.core.listener.StepExecutionListenerSupport
Deprecated.
 
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 Class 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 - Variable in class org.springframework.batch.core.step.StepLocatorStepFactoryBean
 
StepLocator - Interface in org.springframework.batch.core.step
Interface for locating a Step instance by name.
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.
StepParserStepFactoryBean<I,O> - Class in org.springframework.batch.core.configuration.xml
This FactoryBean is used by the batch namespace parser to create Step objects.
StepParserStepFactoryBean() - Constructor for class org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
 
StepRegistry - Interface in org.springframework.batch.core.configuration
Registry keeping track of all the Step instances defined in a Job.
stepScope() - Static method in class org.springframework.batch.core.configuration.support.ScopeConfiguration
 
StepScope - Class in org.springframework.batch.core.scope
Scope for step context.
StepScope - Annotation Interface in org.springframework.batch.core.configuration.annotation
Convenient annotation for step-scoped beans.
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(String, Step) - Constructor for class org.springframework.batch.core.job.flow.support.state.StepState
 
StepState(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() - Static method in class org.springframework.batch.core.launch.support.JobRegistryBackgroundJobRunner
Deprecated.
If embedded in a JVM, call this method to terminate the main method.
stop() - Method in interface org.springframework.batch.core.step.tasklet.StoppableTasklet
Used to signal that the job this Tasklet is executing within has been requested to stop.
stop() - Method in class org.springframework.batch.core.step.tasklet.SystemCommandTasklet
Will interrupt the thread executing the system command only if SystemCommandTasklet.setInterruptOnCancel(boolean) has been set to true.
stop(long) - Method in interface org.springframework.batch.core.launch.JobOperator
Send a stop signal to the JobExecution with the supplied id.
stop(long) - Method in class org.springframework.batch.core.launch.support.SimpleJobOperator
 
stop(Runnable) - Method in class org.springframework.batch.core.configuration.support.AutomaticJobRegistrar
 
stop(String) - Method in class org.springframework.batch.core.job.builder.FlowBuilder
 
stop(String, State) - Method in class org.springframework.batch.core.job.builder.FlowBuilder
 
STOP_ELE - Static variable in class org.springframework.batch.core.configuration.xml.AbstractFlowParser
Establishes a Stop element.
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.
StoppableTasklet - Interface in org.springframework.batch.core.step.tasklet
An extension to the Tasklet interface to allow users to add logic for stopping a tasklet.
STOPPED - Enum constant in enum class org.springframework.batch.core.BatchStatus
Status of a batch job that has been stopped by request.
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.
STOPPING - Enum constant in enum class org.springframework.batch.core.BatchStatus
Status of batch job waiting for a step to complete before stopping the batch job.
stopTimer(Timer.Sample, StepExecution, String, String, String) - Method in class org.springframework.batch.core.step.item.SimpleChunkProcessor
 
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
 
StringToDateConverter - Class in org.springframework.batch.core.converter
Converter implementation from String to Date.
StringToDateConverter() - Constructor for class org.springframework.batch.core.converter.StringToDateConverter
 
StringToLocalDateConverter - Class in org.springframework.batch.core.converter
Converter implementation from String to LocalDate.
StringToLocalDateConverter() - Constructor for class org.springframework.batch.core.converter.StringToLocalDateConverter
 
StringToLocalDateTimeConverter - Class in org.springframework.batch.core.converter
Converter implementation from String to LocalDateTime.
StringToLocalDateTimeConverter() - Constructor for class org.springframework.batch.core.converter.StringToLocalDateTimeConverter
 
StringToLocalTimeConverter - Class in org.springframework.batch.core.converter
Converter implementation from String to LocalTime.
StringToLocalTimeConverter() - Constructor for class org.springframework.batch.core.converter.StringToLocalTimeConverter
 
supportsContext(Observation.Context) - Method in interface org.springframework.batch.core.observability.BatchJobObservationConvention
 
supportsContext(Observation.Context) - Method in interface org.springframework.batch.core.observability.BatchStepObservationConvention
 
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.
SynchronizationManagerSupport<E,C> - Class in org.springframework.batch.core.scope.context
Central convenience class for framework use in managing the scope context.
SynchronizationManagerSupport() - Constructor for class org.springframework.batch.core.scope.context.SynchronizationManagerSupport
 
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.
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

tablePrefix() - Element in annotation interface org.springframework.batch.core.configuration.annotation.EnableBatchProcessing
The Batch tables prefix.
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).
TaskExecutorJobLauncher - Class in org.springframework.batch.core.launch.support
Implementation of the JobLauncher interface based on a TaskExecutor.
TaskExecutorJobLauncher() - Constructor for class org.springframework.batch.core.launch.support.TaskExecutorJobLauncher
 
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
 
taskExecutorRef() - Element in annotation interface org.springframework.batch.core.configuration.annotation.EnableBatchProcessing
Set the task executor to use in the job launcher.
tasklet(Tasklet) - Method in class org.springframework.batch.core.step.builder.StepBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
tasklet(Tasklet) - Method in class org.springframework.batch.core.step.builder.TaskletStepBuilder
Deprecated, for removal: This API element is subject to removal in a future version.
tasklet(Tasklet, PlatformTransactionManager) - Method in class org.springframework.batch.core.step.builder.StepBuilder
Build a step with a custom tasklet, not necessarily item processing.
tasklet(Tasklet, PlatformTransactionManager) - 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.
TASKLET_TYPE_KEY - Static variable in class org.springframework.batch.core.step.tasklet.TaskletStep
 
taskletListenerMetaData() - Static method in enum class 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
Deprecated.
 
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
Deprecated, for removal: This API element is subject to removal in a future version.
with no replacement since 5.0, scheduled for removal in 6.0. Use a custom RepeatOperations implementation (based on a TaskExecutor with a bounded task queue) and set it on the step with AbstractTaskletStepBuilder.stepOperations(RepeatOperations).
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.
to(Step) - Method in class org.springframework.batch.core.job.builder.FlowBuilder.TransitionBuilder
Specify the next step.
TO_ATTR - Static variable in class org.springframework.batch.core.configuration.xml.AbstractFlowParser
Establishes a To attribute.
toJobParameters() - Method in class org.springframework.batch.core.JobParametersBuilder
Conversion method that takes the current state of this builder and returns it as a JobParameters 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 <step/> top level element in the Batch namespace.
TopLevelStepParser() - Constructor for class org.springframework.batch.core.configuration.xml.TopLevelStepParser
 
toProperties() - Method in class org.springframework.batch.core.JobParameters
Deprecated, for removal: This API element is subject to removal in a future version.
since 5.0, scheduled for removal in 5.2. Use JobParametersConverter.getProperties(JobParameters)
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 record class org.springframework.batch.core.converter.JsonJobParametersConverter.JobParameterDefinition
Returns a string representation of this record class.
toString() - Method in class org.springframework.batch.core.Entity
Creates a string representation of the Entity, including the id, version, and class name.
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
Adds the job name to the string representation of the super class (Entity).
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.JobContext
 
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.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(PlatformTransactionManager) - Method in class org.springframework.batch.core.step.builder.AbstractTaskletStepBuilder
Set the transaction manager to use for the step.
transactionManagerRef() - Element in annotation interface org.springframework.batch.core.configuration.annotation.EnableBatchProcessing
Set the transaction manager to use in the job repository.
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
 
TransitionBuilder(FlowBuilder<Q>, String) - Constructor for class org.springframework.batch.core.job.builder.FlowBuilder.TransitionBuilder
 
type() - Method in record class org.springframework.batch.core.converter.JsonJobParametersConverter.JobParameterDefinition
Returns the value of the type record component.

U

unbind(JobFactory, Map<String, ?>) - Method in class org.springframework.batch.core.configuration.support.JobFactoryRegistrationListener
Take the provided JobFactory and unregister it with the JobRegistry.
UncheckedTransactionException - Exception in org.springframework.batch.core.step.tasklet
Convenience wrapper for a checked exception so that it can cause a rollback and be extracted afterwards.
UncheckedTransactionException(Exception) - Constructor for exception org.springframework.batch.core.step.tasklet.UncheckedTransactionException
 
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 - Enum constant in enum class org.springframework.batch.core.BatchStatus
Status of a batch job that is in an uncertain state.
UNKNOWN - Static variable in class org.springframework.batch.core.ExitStatus
Convenient constant value representing unknown state - assumed to not be 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 instances of the given job.
unregisterStepsFromJob(String) - Method in class org.springframework.batch.core.configuration.support.MapStepRegistry
 
UnterminatedFlowBuilder(FlowBuilder<Q>) - Constructor for class org.springframework.batch.core.job.builder.FlowBuilder.UnterminatedFlowBuilder
 
update(JobExecution) - Method in interface org.springframework.batch.core.repository.JobRepository
Update the JobExecution (but not its ExecutionContext).
update(JobExecution) - Method in class org.springframework.batch.core.repository.support.SimpleJobRepository
 
update(StepExecution) - Method in interface org.springframework.batch.core.repository.JobRepository
Update the StepExecution (but not its ExecutionContext).
update(StepExecution) - Method in class org.springframework.batch.core.repository.support.SimpleJobRepository
 
update(ExecutionContext) - Method in class org.springframework.batch.core.step.item.ChunkMonitor
 
update(RepeatContext) - Method in class org.springframework.batch.core.resource.StepExecutionSimpleCompletionPolicy
 
updateExecutionContext(JobExecution) - Method in interface org.springframework.batch.core.repository.dao.ExecutionContextDao
Persist the updates of execution context associated with the given jobExecution.
updateExecutionContext(JobExecution) - Method in class org.springframework.batch.core.repository.dao.JdbcExecutionContextDao
 
updateExecutionContext(JobExecution) - Method in interface org.springframework.batch.core.repository.JobRepository
Persist the updated ExecutionContext of the given JobExecution.
updateExecutionContext(JobExecution) - Method in class org.springframework.batch.core.repository.support.SimpleJobRepository
 
updateExecutionContext(StepExecution) - Method in interface org.springframework.batch.core.repository.dao.ExecutionContextDao
Persist the updates of execution context associated with the given stepExecution.
updateExecutionContext(StepExecution) - Method in class org.springframework.batch.core.repository.dao.JdbcExecutionContextDao
 
updateExecutionContext(StepExecution) - Method in interface org.springframework.batch.core.repository.JobRepository
Persist the updated ExecutionContexts of the given StepExecution.
updateExecutionContext(StepExecution) - 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.
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 interface org.springframework.batch.core.repository.dao.StepExecutionDao
Update the given StepExecution
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 class 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 that the parameters meet whatever requirements are appropriate, and throw an exception if not.
validateFaultTolerantSettings() - Method in class org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
Validates that all components required to build a fault tolerant step are set.
validator(JobParametersValidator) - Method in class org.springframework.batch.core.job.builder.JobBuilderHelper
Add a job parameters validator.
value() - Method in record class org.springframework.batch.core.converter.JsonJobParametersConverter.JobParameterDefinition
Returns the value of the value record component.
valueOf(String) - Static method in enum class org.springframework.batch.core.BatchStatus
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class org.springframework.batch.core.listener.JobListenerMetaData
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class org.springframework.batch.core.listener.StepListenerMetaData
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class org.springframework.batch.core.observability.BatchJobObservation
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class org.springframework.batch.core.observability.BatchStepObservation
Returns the enum constant of this class with the specified name.
values() - Static method in enum class org.springframework.batch.core.BatchStatus
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class org.springframework.batch.core.listener.JobListenerMetaData
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class org.springframework.batch.core.listener.StepListenerMetaData
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class org.springframework.batch.core.observability.BatchJobObservation
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class org.springframework.batch.core.observability.BatchStepObservation
Returns an array containing the constants of this enum class, in the order they are declared.
verifyUniquePattern(Element, List<String>, Element, ParserContext) - Static method in class org.springframework.batch.core.configuration.xml.AbstractFlowParser
Verifies that transitionElement is not in the list of state transition patterns.

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(Chunk) method and increments the write count in the contribution.
writeItems(Chunk<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.
A B C D E F G H I J K L M N O P R S T U V W 
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form