Skip navigation links
Spring Batch
A B C D E F G H I J K L M N O P Q R S T U V W X Z 

A

abandon(long) - Method in class org.springframework.batch.core.jsr.launch.JsrJobOperator
 
abandon(long) - Method in interface org.springframework.batch.core.launch.JobOperator
Mark the JobExecution as ABANDONED.
abandon(long) - Method in class org.springframework.batch.core.launch.support.SimpleJobOperator
 
abandonStepExecution() - Method in interface org.springframework.batch.core.job.flow.FlowExecutor
Handle any status changes that might be needed at the start of a state.
abandonStepExecution() - Method in class org.springframework.batch.core.job.flow.JobFlowExecutor
 
AbstractApplicationContextFactory - Class in org.springframework.batch.core.configuration.support
ApplicationContextFactory implementation that takes a parent context and a path to the context to create.
AbstractApplicationContextFactory(Object...) - Constructor for class org.springframework.batch.core.configuration.support.AbstractApplicationContextFactory
Create a factory instance with the resource specified.
AbstractBatchConfiguration - Class in org.springframework.batch.core.configuration.annotation
Base Configuration class providing common structure for enabling and using Spring Batch.
AbstractBatchConfiguration() - Constructor for class org.springframework.batch.core.configuration.annotation.AbstractBatchConfiguration
 
AbstractCursorItemReader<T> - Class in org.springframework.batch.item.database
Abstract base class for any simple item reader that opens a database cursor and continually retrieves the next row in the ResultSet.
AbstractCursorItemReader() - Constructor for class org.springframework.batch.item.database.AbstractCursorItemReader
 
AbstractFileItemWriter<T> - Class in org.springframework.batch.item.support
Base class for item writers that write data to a file or stream.
AbstractFileItemWriter() - Constructor for class org.springframework.batch.item.support.AbstractFileItemWriter
 
AbstractFileItemWriter.OutputState - Class in org.springframework.batch.item.support
Encapsulates the runtime state of the writer.
AbstractFlowParser - Class in org.springframework.batch.core.configuration.xml
 
AbstractFlowParser() - Constructor for class org.springframework.batch.core.configuration.xml.AbstractFlowParser
 
AbstractHibernateQueryProvider<T> - Class in org.springframework.batch.item.database.orm
Abstract Hibernate Query Provider to serve as a base class for all Hibernate Query providers.
AbstractHibernateQueryProvider() - Constructor for class org.springframework.batch.item.database.orm.AbstractHibernateQueryProvider
 
AbstractItemCountingItemStreamItemReader<T> - Class in org.springframework.batch.item.support
Abstract superclass for ItemReaders that supports restart by storing item count in the ExecutionContext (therefore requires item ordering to be preserved between runs).
AbstractItemCountingItemStreamItemReader() - Constructor for class org.springframework.batch.item.support.AbstractItemCountingItemStreamItemReader
 
AbstractItemStreamItemReader<T> - Class in org.springframework.batch.item.support
Base class for ItemReader implementations.
AbstractItemStreamItemReader() - Constructor for class org.springframework.batch.item.support.AbstractItemStreamItemReader
 
AbstractItemStreamItemWriter<T> - Class in org.springframework.batch.item.support
Base class for ItemWriter implementations.
AbstractItemStreamItemWriter() - Constructor for class org.springframework.batch.item.support.AbstractItemStreamItemWriter
 
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
 
AbstractJobTests - Class in org.springframework.batch.test
Deprecated.
(from 2.1) use JobLauncherTestUtils instead
AbstractJobTests() - Constructor for class org.springframework.batch.test.AbstractJobTests
Deprecated.
 
AbstractJpaQueryProvider - Class in org.springframework.batch.item.database.orm
Abstract JPA Query Provider to serve as a base class for all JPA Query providers.
AbstractJpaQueryProvider() - Constructor for class org.springframework.batch.item.database.orm.AbstractJpaQueryProvider
 
AbstractLineTokenizer - Class in org.springframework.batch.item.file.transform
Abstract class handling common concerns of various LineTokenizer implementations such as dealing with names and actual construction of FieldSet
AbstractLineTokenizer() - Constructor for class org.springframework.batch.item.file.transform.AbstractLineTokenizer
 
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
 
AbstractMethodInvokingDelegator<T> - Class in org.springframework.batch.item.adapter
Superclass for delegating classes which dynamically call a custom method of injected object.
AbstractMethodInvokingDelegator() - Constructor for class org.springframework.batch.item.adapter.AbstractMethodInvokingDelegator
 
AbstractMethodInvokingDelegator.InvocationTargetThrowableWrapper - Exception in org.springframework.batch.item.adapter
Used to wrap a Throwable (not an Exception) thrown by a reflectively-invoked delegate.
AbstractNeo4jItemReader<T> - Class in org.springframework.batch.item.data
Deprecated.
Extend Neo4jItemReader instead.
AbstractNeo4jItemReader() - Constructor for class org.springframework.batch.item.data.AbstractNeo4jItemReader
Deprecated.
 
AbstractPaginatedDataItemReader<T> - Class in org.springframework.batch.item.data
A base class that handles basic reading logic based on the paginated semantics of Spring Data's paginated facilities.
AbstractPaginatedDataItemReader() - Constructor for class org.springframework.batch.item.data.AbstractPaginatedDataItemReader
 
AbstractPagingItemReader<T> - Class in org.springframework.batch.item.database
Abstract ItemStreamReader for to extend when reading database records in a paging fashion.
AbstractPagingItemReader() - Constructor for class org.springframework.batch.item.database.AbstractPagingItemReader
 
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
 
AbstractSqlPagingQueryProvider - Class in org.springframework.batch.item.database.support
Abstract SQL Paging Query Provider to serve as a base class for all provided SQL paging query providers.
AbstractSqlPagingQueryProvider() - Constructor for class org.springframework.batch.item.database.support.AbstractSqlPagingQueryProvider
 
AbstractState - Class in org.springframework.batch.core.job.flow.support.state
 
AbstractState(String) - Constructor for class org.springframework.batch.core.job.flow.support.state.AbstractState
 
AbstractStep - Class in org.springframework.batch.core.step
A Step implementation that provides common behavior to subclasses, including registering and calling listeners.
AbstractStep() - Constructor for class org.springframework.batch.core.step.AbstractStep
Default constructor.
AbstractStep(String) - Constructor for class org.springframework.batch.core.step.AbstractStep
Convenient constructor for setting only the name property.
AbstractStepParser - Class in org.springframework.batch.core.configuration.xml
Internal parser for the <step/> elements inside a job.
AbstractStepParser() - Constructor for class org.springframework.batch.core.configuration.xml.AbstractStepParser
 
AbstractTaskletStepBuilder<B extends AbstractTaskletStepBuilder<B>> - Class in org.springframework.batch.core.step.builder
Base class for step builders that want to build a TaskletStep.
AbstractTaskletStepBuilder(StepBuilderHelper<?>) - Constructor for class org.springframework.batch.core.step.builder.AbstractTaskletStepBuilder
 
add(Flow...) - Method in class org.springframework.batch.core.job.builder.FlowBuilder.SplitBuilder
Add flows to the split, in addition to the current state already present in the parent builder.
add(StepExecution) - Method in interface org.springframework.batch.core.repository.JobRepository
add(StepExecution) - Method in class org.springframework.batch.core.repository.support.SimpleJobRepository
 
add(W) - Method in class org.springframework.batch.core.step.item.Chunk
Add the item to the chunk.
add(XMLEvent) - Method in class org.springframework.batch.item.xml.stax.NoStartEndDocumentStreamWriter
 
add(XMLEvent) - Method in class org.springframework.batch.item.xml.stax.UnclosedElementCollectingEventWriter
 
add(XMLEvent) - Method in class org.springframework.batch.item.xml.stax.UnopenedElementClosingEventWriter
 
addAll(Collection<StepExecution>) - Method in interface org.springframework.batch.core.repository.JobRepository
Save a collection of StepExecutions and each ExecutionContext.
addAll(Collection<StepExecution>) - Method in class org.springframework.batch.core.repository.support.SimpleJobRepository
 
addApplicationContextFactory(ApplicationContextFactory) - Method in class org.springframework.batch.core.configuration.support.AutomaticJobRegistrar
Add some factories to the set that will be used to load contexts and jobs.
addColumns(Range) - Method in class org.springframework.batch.item.file.builder.FlatFileItemReaderBuilder.FixedLengthBuilder
Add a column range to the existing list
addColumns(Range, int) - Method in class org.springframework.batch.item.file.builder.FlatFileItemReaderBuilder.FixedLengthBuilder
Insert a column range to the existing list
addComment(String) - Method in class org.springframework.batch.item.file.builder.FlatFileItemReaderBuilder
Add a string to the list of Strings that indicate commented lines.
addDate(String, Date) - Method in class org.springframework.batch.core.JobParametersBuilder
Add a new identifying Date parameter for the given key.
addDate(String, Date, boolean) - Method in class org.springframework.batch.core.JobParametersBuilder
Add a new Date parameter for the given key.
addDouble(String, Double) - Method in class org.springframework.batch.core.JobParametersBuilder
Add a new identifying Double parameter for the given key.
addDouble(String, Double, boolean) - Method in class org.springframework.batch.core.JobParametersBuilder
Add a new Double parameter for the given key.
addExitDescription(String) - Method in class org.springframework.batch.core.ExitStatus
Add an exit description to an existing ExitStatus.
addExitDescription(Throwable) - Method in class org.springframework.batch.core.ExitStatus
Extract the stack trace from the throwable provided and append it to the exist description.
addExitStatus(String) - Method in interface org.springframework.batch.core.job.flow.FlowExecutor
 
addExitStatus(String) - Method in class org.springframework.batch.core.job.flow.JobFlowExecutor
 
addExitStatus(String) - Method in class org.springframework.batch.core.jsr.job.flow.JsrFlowExecutor
 
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
 
addFragmentRootElements(String...) - Method in class org.springframework.batch.item.xml.builder.StaxEventItemReaderBuilder
Adds the list of fragments to be used as the root of each chunk to the configuration.
addFragmentRootElements(List<String>) - Method in class org.springframework.batch.item.xml.builder.StaxEventItemReaderBuilder
Adds the list of fragments to be used as the root of each chunk to the configuration.
addIncludedField(int) - Method in class org.springframework.batch.item.file.builder.FlatFileItemReaderBuilder.DelimitedBuilder
Add an index to the list of fields to be included from the file
addJobExecutionListener(JobExecutionListener) - Method in class org.springframework.batch.core.job.builder.JobBuilderHelper.CommonJobProperties
 
addJobParameters(JobParameters) - Method in class org.springframework.batch.core.JobParametersBuilder
Copy job parameters into the current state.
addLong(String, Long) - Method in class org.springframework.batch.core.JobParametersBuilder
Add a new identifying Long parameter for the given key.
addLong(String, Long, boolean) - Method in class org.springframework.batch.core.JobParametersBuilder
Add a new Long parameter for the given key.
addParameter(String, JobParameter) - Method in class org.springframework.batch.core.JobParametersBuilder
Add a new JobParameter for the given key.
addStep(Step) - Method in class org.springframework.batch.core.job.SimpleJob
Convenience method for adding a single step to the job.
addStepExecutionListener(StepExecutionListener) - Method in class org.springframework.batch.core.step.builder.StepBuilderHelper.CommonStepProperties
 
addStepExecutionListeners(List<JobExecutionListener>) - Method in class org.springframework.batch.core.job.builder.JobBuilderHelper.CommonJobProperties
 
addStepExecutionListeners(List<StepExecutionListener>) - Method in class org.springframework.batch.core.step.builder.StepBuilderHelper.CommonStepProperties
 
addStepExecutions(List<StepExecution>) - Method in class org.springframework.batch.core.JobExecution
Add some step executions.
addStepExecutions(JobExecution) - Method in class org.springframework.batch.core.repository.dao.JdbcStepExecutionDao
 
addStepExecutions(JobExecution) - Method in class org.springframework.batch.core.repository.dao.MapStepExecutionDao
Deprecated.
 
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(RepeatContext, RepeatStatus) - Method in class org.springframework.batch.repeat.listener.CompositeRepeatListener
 
after(RepeatContext, RepeatStatus) - Method in class org.springframework.batch.repeat.listener.RepeatListenerSupport
 
after(RepeatContext, RepeatStatus) - Method in interface org.springframework.batch.repeat.RepeatListener
Called by the framework after each item has been processed, unless the item processing results in an exception.
AfterChunk - Annotation Type in org.springframework.batch.core.annotation
Marks a method to be called after a chunk is executed.

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

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

Expected signature: void afterProcess(T item, S result)
afterProcess(T, S) - Method in interface org.springframework.batch.core.ItemProcessListener
Called after ItemProcessor.process(Object) returns.
afterProcess(T, S) - Method in class org.springframework.batch.core.jsr.ItemProcessListenerAdapter
 
afterProcess(T, S) - Method in class org.springframework.batch.core.listener.CompositeItemProcessListener
Call the registered listeners in reverse order, respecting and prioritising those that implement Ordered.
afterProcess(I, O) - Method in class org.springframework.batch.core.listener.ItemListenerSupport
 
afterProcess(T, S) - Method in class org.springframework.batch.core.listener.MulticasterBatchListener
 
afterProcess(T, S) - Method in class org.springframework.batch.core.listener.StepListenerSupport
 
afterPropertiesSet() - Method in class org.springframework.batch.core.configuration.annotation.AbstractBatchConfiguration
 
afterPropertiesSet() - Method in class org.springframework.batch.core.configuration.support.AutomaticJobRegistrar
 
afterPropertiesSet() - Method in class org.springframework.batch.core.configuration.support.DefaultJobLoader
 
afterPropertiesSet() - Method in class org.springframework.batch.core.configuration.support.JobRegistryBeanPostProcessor
Make sure the registry is set before use.
afterPropertiesSet() - Method in class org.springframework.batch.core.configuration.xml.SimpleFlowFactoryBean
Check mandatory properties (name).
afterPropertiesSet() - Method in class org.springframework.batch.core.explore.support.JobExplorerFactoryBean
 
afterPropertiesSet() - Method in class org.springframework.batch.core.explore.support.MapJobExplorerFactoryBean
Deprecated.
 
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.jsr.configuration.xml.DecisionStepFactoryBean
 
afterPropertiesSet() - Method in class org.springframework.batch.core.jsr.job.JsrStepHandler
 
afterPropertiesSet() - Method in class org.springframework.batch.core.jsr.JsrJobParametersConverter
 
afterPropertiesSet() - Method in class org.springframework.batch.core.jsr.JsrStepContextFactoryBean
 
afterPropertiesSet() - Method in class org.springframework.batch.core.jsr.launch.JsrJobOperator
 
afterPropertiesSet() - Method in class org.springframework.batch.core.jsr.partition.JsrPartitionHandler
 
afterPropertiesSet() - Method in class org.springframework.batch.core.launch.support.SimpleJobLauncher
Ensure the required dependencies of a JobRepository have been set.
afterPropertiesSet() - Method in class org.springframework.batch.core.launch.support.SimpleJobOperator
Check mandatory properties.
afterPropertiesSet() - Method in class org.springframework.batch.core.listener.AbstractListenerFactoryBean
 
afterPropertiesSet() - Method in class org.springframework.batch.core.listener.ExecutionContextPromotionListener
 
afterPropertiesSet() - Method in class org.springframework.batch.core.partition.support.PartitionStep
Assert that mandatory properties are set (stepExecutionSplitter, partitionHandler) and delegate top superclass.
afterPropertiesSet() - Method in class org.springframework.batch.core.partition.support.RemoteStepExecutionAggregator
 
afterPropertiesSet() - Method in class org.springframework.batch.core.partition.support.SimpleStepExecutionSplitter
Check mandatory properties (step name, job repository and partitioner).
afterPropertiesSet() - Method in class org.springframework.batch.core.partition.support.TaskExecutorPartitionHandler
 
afterPropertiesSet() - Method in class org.springframework.batch.core.repository.dao.AbstractJdbcBatchMetadataDao
 
afterPropertiesSet() - Method in class org.springframework.batch.core.repository.dao.JdbcExecutionContextDao
 
afterPropertiesSet() - Method in class org.springframework.batch.core.repository.dao.JdbcJobExecutionDao
 
afterPropertiesSet() - Method in class org.springframework.batch.core.repository.dao.JdbcJobInstanceDao
 
afterPropertiesSet() - Method in class org.springframework.batch.core.repository.dao.JdbcStepExecutionDao
 
afterPropertiesSet() - Method in class org.springframework.batch.core.repository.dao.XStreamExecutionContextStringSerializer
Deprecated.
 
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
 
afterPropertiesSet() - Method in class org.springframework.batch.integration.async.AsyncItemProcessor
Check mandatory properties (the AsyncItemProcessor.setDelegate(ItemProcessor)).
afterPropertiesSet() - Method in class org.springframework.batch.integration.async.AsyncItemWriter
 
afterPropertiesSet() - Method in class org.springframework.batch.integration.chunk.ChunkProcessorChunkHandler
 
afterPropertiesSet() - Method in class org.springframework.batch.integration.chunk.MessageSourcePollerInterceptor
Asserts that mandatory properties are set.
afterPropertiesSet() - Method in class org.springframework.batch.integration.config.annotation.BatchIntegrationConfiguration
 
afterPropertiesSet() - Method in class org.springframework.batch.integration.partition.MessageChannelPartitionHandler
 
afterPropertiesSet() - Method in class org.springframework.batch.integration.step.DelegateStep
Check mandatory properties (delegate).
afterPropertiesSet() - Method in class org.springframework.batch.item.adapter.AbstractMethodInvokingDelegator
 
afterPropertiesSet() - Method in class org.springframework.batch.item.adapter.PropertyExtractingDelegatingItemWriter
 
afterPropertiesSet() - Method in class org.springframework.batch.item.data.AbstractNeo4jItemReader
Deprecated.
Checks mandatory properties
afterPropertiesSet() - Method in class org.springframework.batch.item.data.MongoItemReader
Checks mandatory properties
afterPropertiesSet() - Method in class org.springframework.batch.item.data.MongoItemWriter
 
afterPropertiesSet() - Method in class org.springframework.batch.item.data.Neo4jItemWriter
Checks mandatory properties
afterPropertiesSet() - Method in class org.springframework.batch.item.data.RepositoryItemReader
 
afterPropertiesSet() - Method in class org.springframework.batch.item.data.RepositoryItemWriter
Check mandatory properties - there must be a repository.
afterPropertiesSet() - Method in class org.springframework.batch.item.database.AbstractCursorItemReader
Assert that mandatory properties are set.
afterPropertiesSet() - Method in class org.springframework.batch.item.database.AbstractPagingItemReader
Check mandatory properties.
afterPropertiesSet() - Method in class org.springframework.batch.item.database.ExtendedConnectionDataSourceProxy
 
afterPropertiesSet() - Method in class org.springframework.batch.item.database.HibernateCursorItemReader
 
afterPropertiesSet() - Method in class org.springframework.batch.item.database.HibernateItemReaderHelper
 
afterPropertiesSet() - Method in class org.springframework.batch.item.database.HibernateItemWriter
Check mandatory properties - there must be a sessionFactory.
afterPropertiesSet() - Method in class org.springframework.batch.item.database.HibernatePagingItemReader
 
afterPropertiesSet() - Method in class org.springframework.batch.item.database.JdbcBatchItemWriter
Check mandatory properties - there must be a NamedParameterJdbcOperations and an SQL statement plus a parameter source.
afterPropertiesSet() - Method in class org.springframework.batch.item.database.JdbcCursorItemReader
Assert that mandatory properties are set.
afterPropertiesSet() - Method in class org.springframework.batch.item.database.JdbcPagingItemReader
Check mandatory properties.
afterPropertiesSet() - Method in class org.springframework.batch.item.database.JpaCursorItemReader
 
afterPropertiesSet() - Method in class org.springframework.batch.item.database.JpaItemWriter
Check mandatory properties - there must be an entityManagerFactory.
afterPropertiesSet() - Method in class org.springframework.batch.item.database.JpaPagingItemReader
 
afterPropertiesSet() - Method in class org.springframework.batch.item.database.orm.HibernateNativeQueryProvider
 
afterPropertiesSet() - Method in class org.springframework.batch.item.database.orm.JpaNamedQueryProvider
 
afterPropertiesSet() - Method in class org.springframework.batch.item.database.orm.JpaNativeQueryProvider
 
afterPropertiesSet() - Method in class org.springframework.batch.item.database.StoredProcedureItemReader
Assert that mandatory properties are set.
afterPropertiesSet() - Method in class org.springframework.batch.item.database.support.ListPreparedStatementSetter
Deprecated.
 
afterPropertiesSet() - Method in class org.springframework.batch.item.file.FlatFileItemReader
 
afterPropertiesSet() - Method in class org.springframework.batch.item.file.FlatFileItemWriter
Assert that mandatory properties (lineAggregator) are set.
afterPropertiesSet() - Method in class org.springframework.batch.item.file.mapping.BeanWrapperFieldSetMapper
Check that precisely one of type or prototype bean name is specified.
afterPropertiesSet() - Method in class org.springframework.batch.item.file.mapping.DefaultLineMapper
 
afterPropertiesSet() - Method in class org.springframework.batch.item.file.mapping.PatternMatchingCompositeLineMapper
 
afterPropertiesSet() - Method in class org.springframework.batch.item.file.transform.BeanWrapperFieldExtractor
 
afterPropertiesSet() - Method in class org.springframework.batch.item.file.transform.DelimitedLineTokenizer
 
afterPropertiesSet() - Method in class org.springframework.batch.item.file.transform.PatternMatchingCompositeLineTokenizer
 
afterPropertiesSet() - Method in class org.springframework.batch.item.jms.JmsItemReader
 
afterPropertiesSet() - Method in class org.springframework.batch.item.json.JsonFileItemWriter
Assert that mandatory properties (jsonObjectMarshaller) are set.
afterPropertiesSet() - Method in class org.springframework.batch.item.KeyValueItemWriter
 
afterPropertiesSet() - Method in class org.springframework.batch.item.ldif.LdifReader
 
afterPropertiesSet() - Method in class org.springframework.batch.item.ldif.MappingLdifReader
 
afterPropertiesSet() - Method in class org.springframework.batch.item.mail.javamail.MimeMessageItemWriter
Check mandatory properties (mailSender).
afterPropertiesSet() - Method in class org.springframework.batch.item.mail.SimpleMailMessageItemWriter
Check mandatory properties (mailSender).
afterPropertiesSet() - Method in class org.springframework.batch.item.support.CompositeItemProcessor
 
afterPropertiesSet() - Method in class org.springframework.batch.item.support.CompositeItemWriter
 
afterPropertiesSet() - Method in class org.springframework.batch.item.support.ScriptItemProcessor
 
afterPropertiesSet() - Method in class org.springframework.batch.item.support.SynchronizedItemStreamReader
 
afterPropertiesSet() - Method in class org.springframework.batch.item.support.SynchronizedItemStreamWriter
 
afterPropertiesSet() - Method in class org.springframework.batch.item.validator.BeanValidatingItemProcessor
 
afterPropertiesSet() - Method in class org.springframework.batch.item.validator.SpringValidator
 
afterPropertiesSet() - Method in class org.springframework.batch.item.validator.ValidatingItemProcessor
 
afterPropertiesSet() - Method in class org.springframework.batch.item.xml.StaxEventItemReader
Ensure that all required dependencies for the ItemReader to run are provided after all properties have been set.
afterPropertiesSet() - Method in class org.springframework.batch.item.xml.StaxEventItemWriter
 
afterPropertiesSet() - Method in class org.springframework.batch.repeat.exception.SimpleLimitExceptionHandler
Apply the provided properties to create a delegate handler.
afterPropertiesSet() - Method in class org.springframework.batch.support.SystemPropertyInitializer
Sets the System property with the provided name and default value.
afterPropertiesSet() - Method in class org.springframework.batch.test.DataSourceInitializer
 
afterPropertiesSet() - Method in class org.springframework.batch.test.JobRepositoryTestUtils
 
AfterRead - Annotation Type in org.springframework.batch.core.annotation
Marks a method to be called after an item is read from an ItemReader

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

Expected signature: void afterWrite(List<? extends S> items)
afterWrite(List<? extends S>) - Method in interface org.springframework.batch.core.ItemWriteListener
Called after ItemWriter.write(java.util.List) This will be called before any transaction is committed, and before ChunkListener.afterChunk(ChunkContext)
afterWrite(List<? extends S>) - Method in class org.springframework.batch.core.jsr.ItemWriteListenerAdapter
 
afterWrite(List<? extends S>) - Method in class org.springframework.batch.core.listener.CompositeItemWriteListener
Call the registered listeners in reverse order, respecting and prioritising those that implement Ordered.
afterWrite(List<? extends O>) - Method in class org.springframework.batch.core.listener.ItemListenerSupport
 
afterWrite(List<? extends S>) - Method in class org.springframework.batch.core.listener.MulticasterBatchListener
 
afterWrite(List<? extends S>) - Method in class org.springframework.batch.core.listener.StepListenerSupport
 
aggregate(Collection<FlowExecution>) - Method in interface org.springframework.batch.core.job.flow.support.state.FlowExecutionAggregator
 
aggregate(Collection<FlowExecution>) - Method in class org.springframework.batch.core.job.flow.support.state.MaxValueFlowExecutionAggregator
Aggregate all of the FlowExecutionStatuses of the FlowExecutions into one status.
aggregate(StepExecution, Collection<StepExecution>) - Method in class org.springframework.batch.core.jsr.partition.support.JsrStepExecutionAggregator
 
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.
aggregate(List<?>) - Method in class org.springframework.batch.integration.partition.MessageChannelPartitionHandler
 
aggregate(T) - Method in class org.springframework.batch.item.file.transform.ExtractorLineAggregator
Extract fields from the given item using the FieldExtractor and then aggregate them.
aggregate(T) - Method in interface org.springframework.batch.item.file.transform.LineAggregator
Create a string from the value provided.
aggregate(T) - Method in class org.springframework.batch.item.file.transform.PassThroughLineAggregator
Simply convert to a String with toString().
aggregate(Collection<T>) - Method in class org.springframework.batch.item.file.transform.RecursiveCollectionLineAggregator
 
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.
aggregator(StepExecutionAggregator) - Method in class org.springframework.batch.integration.partition.RemotePartitioningManagerStepBuilder
 
aggregator(StepExecutionAggregator) - Method in class org.springframework.batch.integration.partition.RemotePartitioningMasterStepBuilder
Deprecated.
 
Alignment - Enum in org.springframework.batch.item.file.transform
Deprecated.
Use FormatterLineAggregator.setFormat(java.lang.String) for alignment (See examples in FormatterLineAggregatorTests)
allowStartIfComplete(boolean) - Method in class org.springframework.batch.core.step.builder.StepBuilderHelper
 
allowStartIfComplete(boolean) - Method in class org.springframework.batch.integration.chunk.RemoteChunkingManagerStepBuilder
 
allowStartIfComplete(boolean) - Method in class org.springframework.batch.integration.chunk.RemoteChunkingMasterStepBuilder
Deprecated.
 
allowStartIfComplete(boolean) - Method in class org.springframework.batch.integration.partition.RemotePartitioningManagerStepBuilder
 
allowStartIfComplete(boolean) - Method in class org.springframework.batch.integration.partition.RemotePartitioningMasterStepBuilder
Deprecated.
 
allowStartIfComplete(boolean) - Method in class org.springframework.batch.integration.partition.RemotePartitioningWorkerStepBuilder
 
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
 
AmqpItemReader<T> - Class in org.springframework.batch.item.amqp
AMQP ItemReader implementation using an AmqpTemplate to receive and/or convert messages.
AmqpItemReader(AmqpTemplate) - Constructor for class org.springframework.batch.item.amqp.AmqpItemReader
Initialize the AmqpItemReader.
AmqpItemReaderBuilder<T> - Class in org.springframework.batch.item.amqp.builder
A builder implementation for the AmqpItemReader
AmqpItemReaderBuilder() - Constructor for class org.springframework.batch.item.amqp.builder.AmqpItemReaderBuilder
 
AmqpItemWriter<T> - Class in org.springframework.batch.item.amqp
AMQP ItemWriter implementation using an AmqpTemplate to send messages.
AmqpItemWriter(AmqpTemplate) - Constructor for class org.springframework.batch.item.amqp.AmqpItemWriter
 
AmqpItemWriterBuilder<T> - Class in org.springframework.batch.item.amqp.builder
A builder implementation for the AmqpItemWriter
AmqpItemWriterBuilder() - Constructor for class org.springframework.batch.item.amqp.builder.AmqpItemWriterBuilder
 
amqpTemplate(AmqpTemplate) - Method in class org.springframework.batch.item.amqp.builder.AmqpItemReaderBuilder
Establish the amqpTemplate to be used by the AmqpItemReader.
amqpTemplate(AmqpTemplate) - Method in class org.springframework.batch.item.amqp.builder.AmqpItemWriterBuilder
Establish the amqpTemplate to be used by the AmqpItemWriter.
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.
and(boolean) - Method in enum org.springframework.batch.repeat.RepeatStatus
 
AnnotationMethodResolver - Class in org.springframework.batch.support
MethodResolver implementation that finds a single Method on the given Class that contains the specified annotation type.
AnnotationMethodResolver(Class<? extends Annotation>) - Constructor for class org.springframework.batch.support.AnnotationMethodResolver
Create a MethodResolver for the specified Method-level annotation type.
append(boolean) - Method in class org.springframework.batch.item.file.builder.FlatFileItemWriterBuilder
If set to true and the file exists, the output will be appended to the existing file.
append(boolean) - Method in class org.springframework.batch.item.json.builder.JsonFileItemWriterBuilder
If set to true and the file exists, the output will be appended to the existing file.
append - Variable in class org.springframework.batch.item.support.AbstractFileItemWriter
 
ApplicationContextFactory - Interface in org.springframework.batch.core.configuration.support
Factory for the creation of ApplicationContexts.
ApplicationContextJobFactory - Class in org.springframework.batch.core.configuration.support
A JobFactory that creates its own ApplicationContext and pulls a bean out when asked to create a Job.
ApplicationContextJobFactory(String, ApplicationContextFactory) - Constructor for class org.springframework.batch.core.configuration.support.ApplicationContextJobFactory
 
apply(StepContribution) - Method in class org.springframework.batch.core.StepExecution
On successful execution just before a chunk commit, this method should be called.
applyConfiguration(SimpleStepBuilder<T, S>) - Method in class org.springframework.batch.core.step.factory.FaultTolerantStepFactoryBean
 
applyConfiguration(SimpleStepBuilder<T, S>) - Method in class org.springframework.batch.core.step.factory.SimpleStepFactoryBean
 
applyListenerScope(String, BeanDefinitionRegistry) - Method in class org.springframework.batch.core.jsr.configuration.xml.ListenerParser
 
applyStatementSettings(PreparedStatement) - Method in class org.springframework.batch.item.database.AbstractCursorItemReader
Prepare the given JDBC Statement (or PreparedStatement or CallableStatement), applying statement settings such as fetch size, max rows, and query timeout.
arguments(List<?>) - Method in class org.springframework.batch.item.data.builder.RepositoryItemReaderBuilder
Arguments to be passed to the data providing method.
arguments(Object...) - Method in class org.springframework.batch.item.data.builder.RepositoryItemReaderBuilder
Arguments to be passed to the data providing method.
ArrayFieldSetMapper - Class in org.springframework.batch.item.file.mapping
A basic array mapper, returning the values backing a fieldset.
ArrayFieldSetMapper() - Constructor for class org.springframework.batch.item.file.mapping.ArrayFieldSetMapper
 
AssertFile - Class in org.springframework.batch.test
This class can be used to assert that two files are the same.
AssertFile() - Constructor for class org.springframework.batch.test.AssertFile
 
assertFileEquals(File, File) - Static method in class org.springframework.batch.test.AssertFile
 
assertFileEquals(Resource, Resource) - Static method in class org.springframework.batch.test.AssertFile
 
assertLineCount(int, File) - Static method in class org.springframework.batch.test.AssertFile
 
assertLineCount(int, Resource) - Static method in class org.springframework.batch.test.AssertFile
 
assertUpdates(boolean) - Method in class org.springframework.batch.item.database.builder.JdbcBatchItemWriterBuilder
If set to true, confirms that every insert results in the update of at least one row in the database.
assertUpdates - Variable in class org.springframework.batch.item.database.JdbcBatchItemWriter
 
AsynchronousFailureException - Exception in org.springframework.batch.integration.chunk
Exception indicating that a failure or early completion condition was detected in a remote worker.
AsynchronousFailureException(String, Throwable) - Constructor for exception org.springframework.batch.integration.chunk.AsynchronousFailureException
Create a new AsynchronousFailureException based on a message and another exception.
AsynchronousFailureException(String) - Constructor for exception org.springframework.batch.integration.chunk.AsynchronousFailureException
Create a new AsynchronousFailureException based on a message.
AsyncItemProcessor<I,O> - Class in org.springframework.batch.integration.async
An ItemProcessor that delegates to a nested processor and in the background.
AsyncItemProcessor() - Constructor for class org.springframework.batch.integration.async.AsyncItemProcessor
 
AsyncItemWriter<T> - Class in org.springframework.batch.integration.async
 
AsyncItemWriter() - Constructor for class org.springframework.batch.integration.async.AsyncItemWriter
 
attributeNames() - Method in class org.springframework.batch.repeat.context.SynchronizedAttributeAccessor
 
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
 
AvroItemReader<T> - Class in org.springframework.batch.item.avro
An ItemReader that deserializes data from a Resource containing serialized Avro objects.
AvroItemReader(Resource, Class<T>) - Constructor for class org.springframework.batch.item.avro.AvroItemReader
 
AvroItemReader(Resource, Resource) - Constructor for class org.springframework.batch.item.avro.AvroItemReader
 
AvroItemReaderBuilder<T> - Class in org.springframework.batch.item.avro.builder
A builder implementation for the AvroItemReader.
AvroItemReaderBuilder() - Constructor for class org.springframework.batch.item.avro.builder.AvroItemReaderBuilder
 
AvroItemWriter<T> - Class in org.springframework.batch.item.avro
An ItemWriter that serializes data to an WritableResource using Avro.
AvroItemWriter(WritableResource, Resource, Class<T>) - Constructor for class org.springframework.batch.item.avro.AvroItemWriter
 
AvroItemWriter(WritableResource, Class<T>) - Constructor for class org.springframework.batch.item.avro.AvroItemWriter
This constructor will create an ItemWriter that does not embedded Avro schema.
AvroItemWriterBuilder<T> - Class in org.springframework.batch.item.avro.builder
A builder implementation for the AvroItemWriter.
AvroItemWriterBuilder() - Constructor for class org.springframework.batch.item.avro.builder.AvroItemWriterBuilder
 

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.
backOffPolicy(BackOffPolicy) - Method in class org.springframework.batch.integration.chunk.RemoteChunkingManagerStepBuilder
 
backOffPolicy(BackOffPolicy) - Method in class org.springframework.batch.integration.chunk.RemoteChunkingMasterStepBuilder
Deprecated.
 
BaseContextListFactoryBean - Class in org.springframework.batch.core.jsr.configuration.support
A simple factory bean that consolidates the list of locations to look for the base context for the JSR-352 functionality
BaseContextListFactoryBean() - Constructor for class org.springframework.batch.core.jsr.configuration.support.BaseContextListFactoryBean
 
BatchArtifactType - Enum in org.springframework.batch.core.jsr.configuration.support
Enum to identify batch artifact types.
BatchConfigurationException - Exception in org.springframework.batch.core.configuration
Represents an error has occurred in the configuration of base batch infrastructure (creation of a JobRepository for example.
BatchConfigurationException(Throwable) - Constructor for exception org.springframework.batch.core.configuration.BatchConfigurationException
 
BatchConfigurationSelector - Class in org.springframework.batch.core.configuration.annotation
Base Configuration class providing common structure for enabling and using Spring Batch.
BatchConfigurationSelector() - Constructor for class org.springframework.batch.core.configuration.annotation.BatchConfigurationSelector
 
BatchConfigurer - Interface in org.springframework.batch.core.configuration.annotation
Strategy interface for users to provide as a factory for custom components needed by a Batch system.
BatchIntegrationConfiguration - Class in org.springframework.batch.integration.config.annotation
Base configuration class for Spring Batch Integration factory beans.
BatchIntegrationConfiguration(JobRepository, JobExplorer, PlatformTransactionManager) - Constructor for class org.springframework.batch.integration.config.annotation.BatchIntegrationConfiguration
 
BatchIntegrationNamespaceHandler - Class in org.springframework.batch.integration.config.xml
The namespace handler for the Spring Batch Integration namespace.
BatchIntegrationNamespaceHandler() - Constructor for class org.springframework.batch.integration.config.xml.BatchIntegrationNamespaceHandler
 
BatchletAdapter - Class in org.springframework.batch.core.jsr.step.batchlet
 
BatchletAdapter(Batchlet) - Constructor for class org.springframework.batch.core.jsr.step.batchlet.BatchletAdapter
 
BatchletParser - Class in org.springframework.batch.core.jsr.configuration.xml
Parser for the <batchlet /> tag defined in JSR-352.
BatchletParser() - Constructor for class org.springframework.batch.core.jsr.configuration.xml.BatchletParser
 
BatchletStep - Class in org.springframework.batch.core.jsr.step
Special sub class of the TaskletStep for use with JSR-352 jobs.
BatchletStep(String, BatchPropertyContext) - Constructor for class org.springframework.batch.core.jsr.step.BatchletStep
 
BatchMetrics - Class in org.springframework.batch.core.metrics
Central class for batch metrics.
BatchParser - Class in org.springframework.batch.core.jsr.configuration.xml
Parser used to parse the batch.xml file as defined in JSR-352.
BatchParser() - Constructor for class org.springframework.batch.core.jsr.configuration.xml.BatchParser
 
BatchPropertyBeanPostProcessor - Class in org.springframework.batch.core.jsr.launch.support
BeanPostProcessor implementation used to inject JSR-352 String properties into batch artifact fields that are marked with the BatchProperty annotation.
BatchPropertyBeanPostProcessor() - Constructor for class org.springframework.batch.core.jsr.launch.support.BatchPropertyBeanPostProcessor
 
BatchPropertyContext - Class in org.springframework.batch.core.jsr.configuration.support
Context object to hold parsed JSR-352 batch properties, mapping properties to beans / "batch artifacts".
BatchPropertyContext() - Constructor for class org.springframework.batch.core.jsr.configuration.support.BatchPropertyContext
 
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 in org.springframework.batch.core
Enumeration representing the status of an Execution.
BatchTestContextCustomizer - Class in org.springframework.batch.test.context
ContextCustomizer implementation that adds batch test utility classes (JobLauncherTestUtils and JobRepositoryTestUtils) as beans in the test context.
BatchTestContextCustomizer() - Constructor for class org.springframework.batch.test.context.BatchTestContextCustomizer
 
BatchTestContextCustomizerFactory - Class in org.springframework.batch.test.context
BatchTestContextCustomizerFactory() - Constructor for class org.springframework.batch.test.context.BatchTestContextCustomizerFactory
 
BeanDefinitionUtils - Class in org.springframework.batch.core.configuration.xml
 
BeanDefinitionUtils() - Constructor for class org.springframework.batch.core.configuration.xml.BeanDefinitionUtils
 
beanFactory(BeanFactory) - Method in class org.springframework.batch.integration.partition.RemotePartitioningManagerStepBuilder
Set the bean factory.
beanFactory(BeanFactory) - Method in class org.springframework.batch.integration.partition.RemotePartitioningMasterStepBuilder
Deprecated.
Set the bean factory.
beanFactory(BeanFactory) - Method in class org.springframework.batch.integration.partition.RemotePartitioningWorkerStepBuilder
Set the bean factory.
beanFactory(BeanFactory) - Method in class org.springframework.batch.item.file.builder.FlatFileItemReaderBuilder
Configures the BeanFactory used to create the beans that are returned as items.
BeanFactoryStepLocator - Class in org.springframework.batch.integration.partition
A StepLocator implementation that just looks in its enclosing bean factory for components of type Step.
BeanFactoryStepLocator() - Constructor for class org.springframework.batch.integration.partition.BeanFactoryStepLocator
 
beanMapped() - Method in class org.springframework.batch.item.database.builder.JdbcBatchItemWriterBuilder
beanMapperStrict(boolean) - Method in class org.springframework.batch.item.file.builder.FlatFileItemReaderBuilder
If set to true, mapping will fail if the FieldSet contains fields that cannot be mapped to the bean.
BeanPropertyItemSqlParameterSourceProvider<T> - Class in org.springframework.batch.item.database
A convenient implementation for providing BeanPropertySqlParameterSource when the item has JavaBean properties that correspond to names used for parameters in the SQL statement.
BeanPropertyItemSqlParameterSourceProvider() - Constructor for class org.springframework.batch.item.database.BeanPropertyItemSqlParameterSourceProvider
 
beanRowMapper(Class<T>) - Method in class org.springframework.batch.item.database.builder.JdbcCursorItemReaderBuilder
Creates a BeanPropertyRowMapper to be used as your RowMapper.
beanRowMapper(Class<T>) - Method in class org.springframework.batch.item.database.builder.JdbcPagingItemReaderBuilder
Creates a BeanPropertyRowMapper to be used as your RowMapper.
BeanValidatingItemProcessor<T> - Class in org.springframework.batch.item.validator
A ValidatingItemProcessor that uses the Bean Validation API (JSR-303) to validate items.
BeanValidatingItemProcessor() - Constructor for class org.springframework.batch.item.validator.BeanValidatingItemProcessor
Create a new instance of BeanValidatingItemProcessor with the default configuration.
BeanValidatingItemProcessor(LocalValidatorFactoryBean) - Constructor for class org.springframework.batch.item.validator.BeanValidatingItemProcessor
Create a new instance of BeanValidatingItemProcessor.
BeanWrapperFieldExtractor<T> - Class in org.springframework.batch.item.file.transform
This is a field extractor for a java bean.
BeanWrapperFieldExtractor() - Constructor for class org.springframework.batch.item.file.transform.BeanWrapperFieldExtractor
 
BeanWrapperFieldSetMapper<T> - Class in org.springframework.batch.item.file.mapping
FieldSetMapper implementation based on bean property paths.
BeanWrapperFieldSetMapper() - Constructor for class org.springframework.batch.item.file.mapping.BeanWrapperFieldSetMapper
 
before(RepeatContext) - Method in class org.springframework.batch.repeat.listener.CompositeRepeatListener
 
before(RepeatContext) - Method in class org.springframework.batch.repeat.listener.RepeatListenerSupport
 
before(RepeatContext) - Method in interface org.springframework.batch.repeat.RepeatListener
Called by the framework before each batch item.
BeforeChunk - Annotation Type in org.springframework.batch.core.annotation
Marks a method to be called before a chunk is executed.
beforeChunk(ChunkContext) - Method in interface org.springframework.batch.core.ChunkListener
Callback before the chunk is executed, but inside the transaction.
beforeChunk(ChunkContext) - Method in class org.springframework.batch.core.jsr.ChunkListenerAdapter
 
beforeChunk(ChunkContext) - Method in class org.springframework.batch.core.jsr.partition.PartitionCollectorAdapter
 
beforeChunk(ChunkContext) - Method in class org.springframework.batch.core.listener.ChunkListenerSupport
 
beforeChunk(ChunkContext) - Method in class org.springframework.batch.core.listener.CompositeChunkListener
Call the registered listeners in order, respecting and prioritizing those that implement Ordered.
beforeChunk(ChunkContext) - Method in class org.springframework.batch.core.listener.MulticasterBatchListener
 
beforeChunk(ChunkContext) - Method in class org.springframework.batch.core.listener.StepListenerSupport
 
BeforeJob - Annotation Type in org.springframework.batch.core.annotation
Marks a method to be called before a Job is executed, which comes after a JobExecution is created and persisted, but before the first Step is executed.
beforeJob(JobExecution) - Method in interface org.springframework.batch.core.JobExecutionListener
Callback before a job executes.
beforeJob(JobExecution) - Method in class org.springframework.batch.core.jsr.JobListenerAdapter
 
beforeJob(JobExecution) - Method in class org.springframework.batch.core.listener.CompositeJobExecutionListener
Call the registered listeners in order, respecting and prioritising those that implement Ordered.
beforeJob(JobExecution) - Method in class org.springframework.batch.core.listener.JobExecutionListenerSupport
 
BeforeProcess - Annotation Type in org.springframework.batch.core.annotation
Marks a method to be called before an item is passed to an ItemProcessor

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

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

Expected signature: void beforeWrite(List<? extends S> items)
beforeWrite(List<? extends S>) - Method in interface org.springframework.batch.core.ItemWriteListener
beforeWrite(List<? extends S>) - Method in class org.springframework.batch.core.jsr.ItemWriteListenerAdapter
 
beforeWrite(List<? extends S>) - Method in class org.springframework.batch.core.listener.CompositeItemWriteListener
Call the registered listeners in order, respecting and prioritising those that implement Ordered.
beforeWrite(List<? extends O>) - Method in class org.springframework.batch.core.listener.ItemListenerSupport
 
beforeWrite(List<? extends S>) - Method in class org.springframework.batch.core.listener.MulticasterBatchListener
 
beforeWrite(List<? extends S>) - Method in class org.springframework.batch.core.listener.StepListenerSupport
 
begin(T) - Method in class org.springframework.batch.support.transaction.TransactionAwareProxyFactory
Make a copy of the target that can be used inside a transaction to isolate changes from the original.
bind(JobFactory, Map<String, ?>) - Method in class org.springframework.batch.core.configuration.support.JobFactoryRegistrationListener
Take the JobFactory provided and register it with the JobRegistry.
BufferedReaderFactory - Interface in org.springframework.batch.item.file
A factory strategy for custom extensions of BufferedReader allowing customisation of the standard behaviour of the java.io variety.
bufferedReaderFactory(BufferedReaderFactory) - Method in class org.springframework.batch.item.file.builder.FlatFileItemReaderBuilder
Configure a custom BufferedReaderFactory for the reader.
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.jsr.step.builder.JsrBatchletStepBuilder
Build the step from the components collected by the fluent setters.
build() - Method in class org.springframework.batch.core.jsr.step.builder.JsrFaultTolerantStepBuilder
Build the step from the components collected by the fluent setters.
build() - Method in class org.springframework.batch.core.jsr.step.builder.JsrPartitionStepBuilder
 
build() - Method in class org.springframework.batch.core.jsr.step.builder.JsrSimpleStepBuilder
Build the step from the components collected by the fluent setters.
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.
build() - Method in class org.springframework.batch.integration.chunk.RemoteChunkingManagerStepBuilder
Build a manager TaskletStep.
build() - Method in class org.springframework.batch.integration.chunk.RemoteChunkingMasterStepBuilder
Deprecated.
Build a master TaskletStep.
build() - Method in class org.springframework.batch.integration.chunk.RemoteChunkingWorkerBuilder
Create an IntegrationFlow with a ChunkProcessorChunkHandler configured as a service activator listening to the input channel and replying on the output channel.
build() - Method in class org.springframework.batch.integration.partition.RemotePartitioningManagerStepBuilder
 
build() - Method in class org.springframework.batch.integration.partition.RemotePartitioningMasterStepBuilder
Deprecated.
 
build() - Method in class org.springframework.batch.item.amqp.builder.AmqpItemReaderBuilder
Validates and builds a AmqpItemReader.
build() - Method in class org.springframework.batch.item.amqp.builder.AmqpItemWriterBuilder
Validates and builds a AmqpItemWriter.
build() - Method in class org.springframework.batch.item.avro.builder.AvroItemReaderBuilder
Build an instance of AvroItemReader.
build() - Method in class org.springframework.batch.item.avro.builder.AvroItemWriterBuilder
Build an instance of AvroItemWriter.
build() - Method in class org.springframework.batch.item.data.builder.GemfireItemWriterBuilder
Validates and builds a GemfireItemWriter.
build() - Method in class org.springframework.batch.item.data.builder.MongoItemReaderBuilder
Validates and builds a MongoItemReader.
build() - Method in class org.springframework.batch.item.data.builder.MongoItemWriterBuilder
Validates and builds a MongoItemWriter.
build() - Method in class org.springframework.batch.item.data.builder.Neo4jItemReaderBuilder
Returns a fully constructed Neo4jItemReader.
build() - Method in class org.springframework.batch.item.data.builder.Neo4jItemWriterBuilder
Validates and builds a Neo4jItemWriter.
build() - Method in class org.springframework.batch.item.data.builder.RepositoryItemReaderBuilder
build() - Method in class org.springframework.batch.item.data.builder.RepositoryItemWriterBuilder
build() - Method in class org.springframework.batch.item.database.builder.HibernateCursorItemReaderBuilder
Returns a fully constructed HibernateCursorItemReader.
build() - Method in class org.springframework.batch.item.database.builder.HibernateItemWriterBuilder
Returns a fully built HibernateItemWriter
build() - Method in class org.springframework.batch.item.database.builder.HibernatePagingItemReaderBuilder
Returns a fully constructed HibernatePagingItemReader.
build() - Method in class org.springframework.batch.item.database.builder.JdbcBatchItemWriterBuilder
Validates configuration and builds the JdbcBatchItemWriter.
build() - Method in class org.springframework.batch.item.database.builder.JdbcCursorItemReaderBuilder
Validates configuration and builds a new reader instance.
build() - Method in class org.springframework.batch.item.database.builder.JdbcPagingItemReaderBuilder
Provides a completely built instance of the JdbcPagingItemReader
build() - Method in class org.springframework.batch.item.database.builder.JpaCursorItemReaderBuilder
Returns a fully constructed JpaCursorItemReader.
build() - Method in class org.springframework.batch.item.database.builder.JpaItemWriterBuilder
Returns a fully built JpaItemWriter.
build() - Method in class org.springframework.batch.item.database.builder.JpaPagingItemReaderBuilder
Returns a fully constructed JpaPagingItemReader.
build() - Method in class org.springframework.batch.item.database.builder.StoredProcedureItemReaderBuilder
Validates configuration and builds a new reader instance
build() - Method in class org.springframework.batch.item.file.builder.FlatFileItemReaderBuilder
Builds the FlatFileItemReader.
build() - Method in class org.springframework.batch.item.file.builder.FlatFileItemReaderBuilder.DelimitedBuilder
build() - Method in class org.springframework.batch.item.file.builder.FlatFileItemReaderBuilder.FixedLengthBuilder
build() - Method in class org.springframework.batch.item.file.builder.FlatFileItemWriterBuilder
Validates and builds a FlatFileItemWriter.
build() - Method in class org.springframework.batch.item.file.builder.FlatFileItemWriterBuilder.DelimitedBuilder
 
build() - Method in class org.springframework.batch.item.file.builder.FlatFileItemWriterBuilder.FormattedBuilder
 
build() - Method in class org.springframework.batch.item.file.builder.MultiResourceItemReaderBuilder
build() - Method in class org.springframework.batch.item.file.builder.MultiResourceItemWriterBuilder
build() - Method in class org.springframework.batch.item.jms.builder.JmsItemReaderBuilder
Returns a fully constructed JmsItemReader.
build() - Method in class org.springframework.batch.item.jms.builder.JmsItemWriterBuilder
Returns a fully constructed JmsItemWriter.
build() - Method in class org.springframework.batch.item.json.builder.JsonFileItemWriterBuilder
Validate the configuration and build a new JsonFileItemWriter.
build() - Method in class org.springframework.batch.item.json.builder.JsonItemReaderBuilder
Validate the configuration and build a new JsonItemReader.
build() - Method in class org.springframework.batch.item.kafka.builder.KafkaItemReaderBuilder
 
build() - Method in class org.springframework.batch.item.kafka.builder.KafkaItemWriterBuilder
Validates and builds a KafkaItemWriter.
build() - Method in class org.springframework.batch.item.ldif.builder.LdifReaderBuilder
Returns a fully constructed LdifReader.
build() - Method in class org.springframework.batch.item.ldif.builder.MappingLdifReaderBuilder
Returns a fully constructed MappingLdifReader.
build() - Method in class org.springframework.batch.item.mail.builder.SimpleMailMessageItemWriterBuilder
Returns a fully constructed SimpleMailMessageItemWriter.
build() - Method in class org.springframework.batch.item.support.builder.ClassifierCompositeItemProcessorBuilder
Returns a fully constructed ClassifierCompositeItemProcessor.
build() - Method in class org.springframework.batch.item.support.builder.ClassifierCompositeItemWriterBuilder
Returns a fully constructed ClassifierCompositeItemWriter.
build() - Method in class org.springframework.batch.item.support.builder.CompositeItemProcessorBuilder
Returns a fully constructed CompositeItemProcessor.
build() - Method in class org.springframework.batch.item.support.builder.CompositeItemWriterBuilder
Returns a fully constructed CompositeItemWriter.
build() - Method in class org.springframework.batch.item.support.builder.ScriptItemProcessorBuilder
Returns a fully constructed ScriptItemProcessor.
build() - Method in class org.springframework.batch.item.support.builder.SingleItemPeekableItemReaderBuilder
Returns a fully constructed SingleItemPeekableItemReader.
build() - Method in class org.springframework.batch.item.support.builder.SynchronizedItemStreamReaderBuilder
Returns a fully constructed SynchronizedItemStreamReader.
build() - Method in class org.springframework.batch.item.support.builder.SynchronizedItemStreamWriterBuilder
Returns a fully constructed SynchronizedItemStreamWriter.
build() - Method in class org.springframework.batch.item.xml.builder.StaxEventItemReaderBuilder
Validates the configuration and builds a new StaxEventItemReader
build() - Method in class org.springframework.batch.item.xml.builder.StaxEventItemWriterBuilder
Returns a configured StaxEventItemWriter
buildSortClause(AbstractSqlPagingQueryProvider) - Static method in class org.springframework.batch.item.database.support.SqlPagingQueryUtils
Generates ORDER BY attributes based on the sort keys.
buildSortClause(Map<String, Order>) - Static method in class org.springframework.batch.item.database.support.SqlPagingQueryUtils
Generates ORDER BY attributes based on the sort keys.
buildSortConditions(AbstractSqlPagingQueryProvider, StringBuilder) - Static method in class org.springframework.batch.item.database.support.SqlPagingQueryUtils
Appends the where conditions required to query for the subsequent pages.

C

calculateDuration(Date, Date) - Static method in class org.springframework.batch.core.metrics.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
 
canContinue(RepeatStatus) - Method in class org.springframework.batch.repeat.support.RepeatTemplate
Check return value from batch operation.
canRetry(RetryContext) - Method in class org.springframework.batch.core.step.item.BatchRetryTemplate
 
checkInterrupted(StepExecution) - Method in interface org.springframework.batch.core.step.StepInterruptionPolicy
Has the job been interrupted? If so then throw a JobInterruptedException.
checkInterrupted(StepExecution) - Method in class org.springframework.batch.core.step.ThreadStepInterruptionPolicy
Returns if the current job lifecycle has been interrupted by checking if the current thread is interrupted.
CheckpointAlgorithmAdapter - Class in org.springframework.batch.jsr.repeat
Wrapper for the CheckpointAlgorithm to be used via the rest of the framework.
CheckpointAlgorithmAdapter(CheckpointAlgorithm) - Constructor for class org.springframework.batch.jsr.repeat.CheckpointAlgorithmAdapter
 
CheckpointSupport - Class in org.springframework.batch.jsr.item
Provides support for JSR-352 checkpointing.
CheckpointSupport(String) - Constructor for class org.springframework.batch.jsr.item.CheckpointSupport
 
chunk(int) - Method in class org.springframework.batch.core.step.builder.SimpleStepBuilder
Sets the chunk size or commit interval for this step.
chunk(CompletionPolicy) - Method in class org.springframework.batch.core.step.builder.SimpleStepBuilder
Sets a completion policy for the chunk processing.
chunk(int) - Method in class org.springframework.batch.core.step.builder.StepBuilder
Build a step that processes items in chunks with the size provided.
chunk(CompletionPolicy) - Method in class org.springframework.batch.core.step.builder.StepBuilder
Build a step that processes items in chunks with the completion policy provided.
Chunk<W> - Class in org.springframework.batch.core.step.item
Encapsulation of a list of items to be processed and possibly a list of failed items to be skipped.
Chunk() - Constructor for class org.springframework.batch.core.step.item.Chunk
 
Chunk(Collection<? extends W>) - Constructor for class org.springframework.batch.core.step.item.Chunk
 
Chunk(Collection<? extends W>, List<SkipWrapper<W>>) - Constructor for class org.springframework.batch.core.step.item.Chunk
 
chunk(int) - Method in class org.springframework.batch.integration.chunk.RemoteChunkingManagerStepBuilder
 
chunk(CompletionPolicy) - Method in class org.springframework.batch.integration.chunk.RemoteChunkingManagerStepBuilder
 
chunk(int) - Method in class org.springframework.batch.integration.chunk.RemoteChunkingMasterStepBuilder
Deprecated.
 
chunk(CompletionPolicy) - Method in class org.springframework.batch.integration.chunk.RemoteChunkingMasterStepBuilder
Deprecated.
 
chunk(int) - Method in class org.springframework.batch.integration.partition.RemotePartitioningWorkerStepBuilder
 
chunk(CompletionPolicy) - Method in class org.springframework.batch.integration.partition.RemotePartitioningWorkerStepBuilder
 
Chunk.ChunkIterator - Class in org.springframework.batch.core.step.item
Special iterator for a chunk providing the Chunk.ChunkIterator.remove(Throwable) method for dynamically removing an item and adding it to the skips.
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
 
ChunkHandler<T> - Interface in org.springframework.batch.integration.chunk
Interface for a remote worker in the Remote Chunking pattern.
ChunkIterator(List<W>) - Constructor for class org.springframework.batch.core.step.item.Chunk.ChunkIterator
 
ChunkListener - Interface in org.springframework.batch.core
Listener interface for the lifecycle of a chunk.
ChunkListenerAdapter - Class in org.springframework.batch.core.jsr
Wrapper class to adapt the ChunkListener to a ChunkListener.
ChunkListenerAdapter(ChunkListener) - Constructor for class org.springframework.batch.core.jsr.ChunkListenerAdapter
 
chunkListeners - Variable in class org.springframework.batch.core.step.builder.AbstractTaskletStepBuilder
 
ChunkListenerSupport - Class in org.springframework.batch.core.listener
Basic support implementation of ChunkListener
ChunkListenerSupport() - Constructor for class org.springframework.batch.core.listener.ChunkListenerSupport
 
ChunkMessageChannelItemWriter<T> - Class in org.springframework.batch.integration.chunk
 
ChunkMessageChannelItemWriter() - Constructor for class org.springframework.batch.integration.chunk.ChunkMessageChannelItemWriter
 
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.
chunkOperations(RepeatOperations) - Method in class org.springframework.batch.integration.chunk.RemoteChunkingManagerStepBuilder
 
chunkOperations(RepeatOperations) - Method in class org.springframework.batch.integration.chunk.RemoteChunkingMasterStepBuilder
Deprecated.
 
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
 
ChunkParser - Class in org.springframework.batch.core.jsr.configuration.xml
Parser for the <chunk /> element as specified in JSR-352.
ChunkParser() - Constructor for class org.springframework.batch.core.jsr.configuration.xml.ChunkParser
 
ChunkProcessor<I> - Interface in org.springframework.batch.core.step.item
Interface defined for processing Chunks.
ChunkProcessorChunkHandler<S> - Class in org.springframework.batch.integration.chunk
ChunkProcessorChunkHandler() - Constructor for class org.springframework.batch.integration.chunk.ChunkProcessorChunkHandler
 
ChunkProvider<T> - Interface in org.springframework.batch.core.step.item
Interface for providing Chunks to be processed, used by the ChunkOrientedTasklet
ChunkRequest<T> - Class in org.springframework.batch.integration.chunk
Encapsulation of a chunk of items to be processed remotely as part of a step execution.
ChunkRequest(int, Collection<? extends T>, long, StepContribution) - Constructor for class org.springframework.batch.integration.chunk.ChunkRequest
 
ChunkResponse - Class in org.springframework.batch.integration.chunk
Encapsulates a response to processing a chunk of items, summarising the result as a StepContribution.
ChunkResponse(int, Long, StepContribution) - Constructor for class org.springframework.batch.integration.chunk.ChunkResponse
 
ChunkResponse(boolean, int, Long, StepContribution) - Constructor for class org.springframework.batch.integration.chunk.ChunkResponse
 
ChunkResponse(boolean, int, Long, StepContribution, String) - Constructor for class org.springframework.batch.integration.chunk.ChunkResponse
 
ChunkResponse(ChunkResponse, boolean) - Constructor for class org.springframework.batch.integration.chunk.ChunkResponse
 
ChunkResponse(boolean, int, Long, StepContribution, String, boolean) - Constructor for class org.springframework.batch.integration.chunk.ChunkResponse
 
chunkSize - Variable in class org.springframework.batch.core.step.item.ChunkMonitor.ChunkMonitorData
 
classifier(Classifier<? super I, ItemProcessor<?, ? extends O>>) - Method in class org.springframework.batch.item.support.builder.ClassifierCompositeItemProcessorBuilder
Establishes the classifier that will determine which ItemProcessor to use.
classifier(Classifier<T, ItemWriter<? super T>>) - Method in class org.springframework.batch.item.support.builder.ClassifierCompositeItemWriterBuilder
Establish the classifier to be used for the selection of which ItemWriter to use.
Classifier - Annotation Type in org.springframework.batch.support.annotation
Mark a method as capable of classifying its input to an instance of its output.
ClassifierCompositeItemProcessor<I,O> - Class in org.springframework.batch.item.support
Calls one of a collection of ItemProcessors, based on a router pattern implemented through the provided Classifier.
ClassifierCompositeItemProcessor() - Constructor for class org.springframework.batch.item.support.ClassifierCompositeItemProcessor
 
ClassifierCompositeItemProcessorBuilder<I,O> - Class in org.springframework.batch.item.support.builder
Creates a fully qualified ClassifierCompositeItemProcessor.
ClassifierCompositeItemProcessorBuilder() - Constructor for class org.springframework.batch.item.support.builder.ClassifierCompositeItemProcessorBuilder
 
ClassifierCompositeItemWriter<T> - Class in org.springframework.batch.item.support
Calls one of a collection of ItemWriters for each item, based on a router pattern implemented through the provided Classifier.
ClassifierCompositeItemWriter() - Constructor for class org.springframework.batch.item.support.ClassifierCompositeItemWriter
 
ClassifierCompositeItemWriterBuilder<T> - Class in org.springframework.batch.item.support.builder
Creates a fully qualified ClassifierCompositeItemWriter.
ClassifierCompositeItemWriterBuilder() - Constructor for class org.springframework.batch.item.support.builder.ClassifierCompositeItemWriterBuilder
 
ClassPathXmlApplicationContextFactory - Class in org.springframework.batch.core.configuration.support
Deprecated.
ClassPathXmlApplicationContextFactory(Resource) - Constructor for class org.springframework.batch.core.configuration.support.ClassPathXmlApplicationContextFactory
Deprecated.
Create an application context factory for the resource specified.
ClasspathXmlApplicationContextsFactoryBean - Class in org.springframework.batch.core.configuration.support
A convenient factory for creating a set of ApplicationContextFactory components from a set of resources.
ClasspathXmlApplicationContextsFactoryBean() - Constructor for class org.springframework.batch.core.configuration.support.ClasspathXmlApplicationContextsFactoryBean
 
ClassPathXmlJobRegistry - Class in org.springframework.batch.core.configuration.support
Deprecated.
in version 2.1, please us AutomaticJobRegistrar instead
ClassPathXmlJobRegistry() - Constructor for class org.springframework.batch.core.configuration.support.ClassPathXmlJobRegistry
Deprecated.
 
cleanupOnClose() - Method in class org.springframework.batch.item.database.AbstractCursorItemReader
Deprecated.
This method is deprecated in favor of AbstractCursorItemReader.cleanupOnClose(java.sql.Connection) and will be removed in a future release
cleanupOnClose(Connection) - Method in class org.springframework.batch.item.database.AbstractCursorItemReader
Clean up resources.
cleanupOnClose() - Method in class org.springframework.batch.item.database.JdbcCursorItemReader
Deprecated.
This method is deprecated in favor of JdbcCursorItemReader.cleanupOnClose(java.sql.Connection) and will be removed in a future release
cleanupOnClose(Connection) - Method in class org.springframework.batch.item.database.JdbcCursorItemReader
Close the cursor and database connection.
cleanupOnClose() - Method in class org.springframework.batch.item.database.StoredProcedureItemReader
Deprecated.
This method is deprecated in favor of StoredProcedureItemReader.cleanupOnClose(java.sql.Connection) and will be removed in a future release
cleanupOnClose(Connection) - Method in class org.springframework.batch.item.database.StoredProcedureItemReader
Close the cursor and database connection.
clear() - Method in class org.springframework.batch.core.configuration.support.DefaultJobLoader
Unregister all the jobs and close all the contexts created by this loader.
clear() - Method in interface org.springframework.batch.core.configuration.support.JobLoader
Unregister all the jobs and close all the contexts created by this loader.
clear() - Method in class org.springframework.batch.core.repository.dao.MapExecutionContextDao
Deprecated.
 
clear() - Method in class org.springframework.batch.core.repository.dao.MapJobExecutionDao
Deprecated.
 
clear() - Method in class org.springframework.batch.core.repository.dao.MapJobInstanceDao
Deprecated.
 
clear() - Method in class org.springframework.batch.core.repository.dao.MapStepExecutionDao
Deprecated.
 
clear() - Method in class org.springframework.batch.core.repository.support.MapJobRepositoryFactoryBean
Deprecated.
Convenience method to clear all the map DAOs globally, removing all entities.
clear() - Method in class org.springframework.batch.core.step.item.Chunk
Clear the items down to signal that we are done.
clear() - Method in class org.springframework.batch.item.database.HibernateItemReaderHelper
Clear the session if stateful.
clear() - Static method in class org.springframework.batch.repeat.support.RepeatSynchronizationManager
Clear the current context at the end of a batch - should only be used by RepeatOperations implementations.
clearDirtyFlag() - Method in class org.springframework.batch.item.ExecutionContext
Clears the dirty flag.
clearSession(boolean) - Method in class org.springframework.batch.item.database.builder.HibernateItemWriterBuilder
If set to false, the Session will not be cleared at the end of the chunk.
clearSkips() - Method in class org.springframework.batch.core.step.item.Chunk
Clear only the skips list.
close(FlowExecution) - Method in interface org.springframework.batch.core.job.flow.FlowExecutor
Chance to clean up resources at the end of a flow (whether it completed successfully or not).
close(FlowExecution) - Method in class org.springframework.batch.core.job.flow.JobFlowExecutor
 
close() - Method in class org.springframework.batch.core.jsr.JsrJobContextFactoryBean
Used to remove the JobContext for the current thread.
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(C) - Method in class org.springframework.batch.core.scope.context.SynchronizationManagerSupport
 
close(ExecutionContext) - Method in class org.springframework.batch.core.step.AbstractStep
Extension point for subclasses to provide callbacks to their collaborators at the end of a step (right at the end of the finally block), to close or release resources.
close() - Method in class org.springframework.batch.core.step.item.ChunkMonitor
 
close(RetryContext, RetryCallback<T, 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.
close(ExecutionContext) - Method in class org.springframework.batch.core.step.tasklet.TaskletStep
 
close() - Method in class org.springframework.batch.integration.async.AsyncItemWriter
 
close() - Method in class org.springframework.batch.integration.chunk.ChunkMessageChannelItemWriter
 
close() - Method in class org.springframework.batch.item.avro.AvroItemWriter
 
close() - Method in class org.springframework.batch.item.database.HibernateItemReaderHelper
Close the open session (stateful or otherwise).
close() - Method in class org.springframework.batch.item.file.MultiResourceItemReader
Close the MultiResourceItemReader.setDelegate(ResourceAwareItemReaderItemStream) reader and reset instance variable values.
close() - Method in class org.springframework.batch.item.file.MultiResourceItemWriter
 
close() - Method in interface org.springframework.batch.item.ItemStream
If any resources are needed for the stream to operate they need to be destroyed here.
close() - Method in class org.springframework.batch.item.ItemStreamSupport
No-op.
close() - Method in class org.springframework.batch.item.json.GsonJsonObjectReader
 
close() - Method in class org.springframework.batch.item.json.JacksonJsonObjectReader
 
close() - Method in interface org.springframework.batch.item.json.JsonObjectReader
Close the input resource.
close() - Method in class org.springframework.batch.item.kafka.KafkaItemReader
 
close() - Method in class org.springframework.batch.item.support.AbstractFileItemWriter
 
close() - Method in class org.springframework.batch.item.support.AbstractFileItemWriter.OutputState
Close the open resource and reset counters.
close() - Method in class org.springframework.batch.item.support.AbstractItemCountingItemStreamItemReader
 
close() - Method in class org.springframework.batch.item.support.CompositeItemStream
Broadcast the call to close.
close() - Method in class org.springframework.batch.item.support.CompositeItemWriter
 
close() - Method in class org.springframework.batch.item.support.SingleItemPeekableItemReader
If the delegate is an ItemStream, just pass the call on, otherwise reset the peek cache.
close() - Method in class org.springframework.batch.item.support.SynchronizedItemStreamReader
 
close() - Method in class org.springframework.batch.item.support.SynchronizedItemStreamWriter
 
close() - Method in class org.springframework.batch.item.xml.stax.NoStartEndDocumentStreamWriter
 
close() - Method in class org.springframework.batch.item.xml.StaxEventItemWriter
Flush and close the output source.
close() - Method in class org.springframework.batch.jsr.item.CheckpointSupport
 
close() - Method in class org.springframework.batch.repeat.context.RepeatContextSupport
 
close(RepeatContext) - Method in class org.springframework.batch.repeat.listener.CompositeRepeatListener
 
close(RepeatContext) - Method in class org.springframework.batch.repeat.listener.RepeatListenerSupport
 
close() - Method in interface org.springframework.batch.repeat.RepeatContext
Allow resources to be cleared, especially in destruction callbacks.
close(RepeatContext) - Method in interface org.springframework.batch.repeat.RepeatListener
Called once at the end of a complete batch, after normal or abnormal completion (i.e.
close() - Method in class org.springframework.batch.support.transaction.TransactionAwareBufferedWriter
 
collection(String) - Method in class org.springframework.batch.item.data.builder.MongoItemReaderBuilder
Establish an optional collection that can be queried.
collection(String) - Method in class org.springframework.batch.item.data.builder.MongoItemWriterBuilder
Set the name of the Mongo collection to be written to.
ColumnMapItemPreparedStatementSetter - Class in org.springframework.batch.item.database.support
Implementation of the ItemPreparedStatementSetter interface that assumes all keys are contained within a Map with the column name as the key.
ColumnMapItemPreparedStatementSetter() - Constructor for class org.springframework.batch.item.database.support.ColumnMapItemPreparedStatementSetter
 
columnMapped() - Method in class org.springframework.batch.item.database.builder.JdbcBatchItemWriterBuilder
columns(Range...) - Method in class org.springframework.batch.item.file.builder.FlatFileItemReaderBuilder.FixedLengthBuilder
The column ranges for each field
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
 
comments(String...) - Method in class org.springframework.batch.item.file.builder.FlatFileItemReaderBuilder
Set an array of Strings that indicate lines that are comments (and therefore skipped by the reader).
comments - Variable in class org.springframework.batch.item.file.FlatFileItemReader
 
commit(T, T) - Method in class org.springframework.batch.support.transaction.TransactionAwareProxyFactory
Take the working copy state and commit it back to the original target.
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
 
comparator(Comparator<Resource>) - Method in class org.springframework.batch.item.file.builder.MultiResourceItemReaderBuilder
Used to order the injected resources, by default compares Resource.getFilename() values.
compare(StateTransition, StateTransition) - Method in class org.springframework.batch.core.job.flow.support.DefaultStateTransitionComparator
 
compare(Resource, Resource) - Method in class org.springframework.batch.support.LastModifiedResourceComparator
Compare the two resources by last modified time, so that a sorted list of resources will have oldest first.
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 - 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.
CompletionPolicy - Interface in org.springframework.batch.repeat
Interface for batch completion policies, to enable batch operations to strategise normal completion conditions.
CompletionPolicySupport - Class in org.springframework.batch.repeat.policy
Very simple base class for CompletionPolicy implementations.
CompletionPolicySupport() - Constructor for class org.springframework.batch.repeat.policy.CompletionPolicySupport
 
CompositeBatchContext(RepeatContext, List<RepeatContext>) - Constructor for class org.springframework.batch.repeat.policy.CompositeCompletionPolicy.CompositeBatchContext
 
CompositeChunkListener - Class in org.springframework.batch.core.listener
 
CompositeChunkListener() - Constructor for class org.springframework.batch.core.listener.CompositeChunkListener
 
CompositeCompletionPolicy - Class in org.springframework.batch.repeat.policy
Composite policy that loops through a list of delegate policies and answers calls by a consensus.
CompositeCompletionPolicy() - Constructor for class org.springframework.batch.repeat.policy.CompositeCompletionPolicy
 
CompositeCompletionPolicy.CompositeBatchContext - Class in org.springframework.batch.repeat.policy
Composite context that knows about the policies and contexts is was created with.
CompositeExceptionHandler - Class in org.springframework.batch.repeat.exception
Composite ExceptionHandler that loops though a list of delegates.
CompositeExceptionHandler() - Constructor for class org.springframework.batch.repeat.exception.CompositeExceptionHandler
 
CompositeItemProcessListener<T,S> - Class in org.springframework.batch.core.listener
 
CompositeItemProcessListener() - Constructor for class org.springframework.batch.core.listener.CompositeItemProcessListener
 
CompositeItemProcessor<I,O> - Class in org.springframework.batch.item.support
Composite ItemProcessor that passes the item through a sequence of injected ItemTransformers (return value of previous transformation is the entry value of the next).

Note the user is responsible for injecting a chain of ItemProcessors that conforms to declared input and output types.
CompositeItemProcessor() - Constructor for class org.springframework.batch.item.support.CompositeItemProcessor
 
CompositeItemProcessorBuilder<I,O> - Class in org.springframework.batch.item.support.builder
Creates a fully qualified CompositeItemProcessorBuilder.
CompositeItemProcessorBuilder() - Constructor for class org.springframework.batch.item.support.builder.CompositeItemProcessorBuilder
 
CompositeItemReadListener<T> - Class in org.springframework.batch.core.listener
 
CompositeItemReadListener() - Constructor for class org.springframework.batch.core.listener.CompositeItemReadListener
 
CompositeItemStream - Class in org.springframework.batch.item.support
Simple ItemStream that delegates to a list of other streams.
CompositeItemStream() - Constructor for class org.springframework.batch.item.support.CompositeItemStream
 
CompositeItemWriteListener<S> - Class in org.springframework.batch.core.listener
 
CompositeItemWriteListener() - Constructor for class org.springframework.batch.core.listener.CompositeItemWriteListener
 
CompositeItemWriter<T> - Class in org.springframework.batch.item.support
Calls a collection of ItemWriters in fixed-order sequence.

The implementation is thread-safe if all delegates are thread-safe.
CompositeItemWriter() - Constructor for class org.springframework.batch.item.support.CompositeItemWriter
 
CompositeItemWriterBuilder<T> - Class in org.springframework.batch.item.support.builder
Creates a fully qualified CompositeItemWriter.
CompositeItemWriterBuilder() - Constructor for class org.springframework.batch.item.support.builder.CompositeItemWriterBuilder
 
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
 
CompositeRepeatListener - Class in org.springframework.batch.repeat.listener
Allows a user to register one or more RepeatListeners to be notified on batch events.
CompositeRepeatListener() - Constructor for class org.springframework.batch.repeat.listener.CompositeRepeatListener
 
CompositeRetryProcessListener - Class in org.springframework.batch.core.listener
Composite class holding RetryProcessListener's.
CompositeRetryProcessListener() - Constructor for class org.springframework.batch.core.listener.CompositeRetryProcessListener
 
CompositeRetryReadListener - Class in org.springframework.batch.core.listener
Composite class holding RetryReadListener's.
CompositeRetryReadListener() - Constructor for class org.springframework.batch.core.listener.CompositeRetryReadListener
 
CompositeRetryWriteListener - Class in org.springframework.batch.core.listener
Composite class holding RetryWriteListener's.
CompositeRetryWriteListener() - Constructor for class org.springframework.batch.core.listener.CompositeRetryWriteListener
 
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
 
connectionAutoCommit(boolean) - Method in class org.springframework.batch.item.database.builder.JdbcCursorItemReaderBuilder
Set whether "autoCommit" should be overridden for the connection used by the cursor.
consumerProperties(Properties) - Method in class org.springframework.batch.item.kafka.builder.KafkaItemReaderBuilder
Configure the underlying consumer properties.
containsKey(String) - Method in class org.springframework.batch.item.ExecutionContext
Indicates whether or not a key is represented in this context.
containsValue(Object) - Method in class org.springframework.batch.item.ExecutionContext
Indicates whether or not a value is represented in this context.
continueIf(boolean) - Static method in enum org.springframework.batch.repeat.RepeatStatus
 
ConversionException - Exception in org.springframework.batch.item.file.transform
 
ConversionException(String) - Constructor for exception org.springframework.batch.item.file.transform.ConversionException
 
convert(V) - Method in class org.springframework.batch.item.SpELItemKeyMapper
 
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
 
COUNT - Static variable in class org.springframework.batch.repeat.policy.CountingCompletionPolicy
Session key for global counter.
CountingBatchContext(RepeatContext) - Constructor for class org.springframework.batch.repeat.policy.CountingCompletionPolicy.CountingBatchContext
 
CountingCompletionPolicy - Class in org.springframework.batch.repeat.policy
Abstract base class for policies that need to count the number of occurrences of some event (e.g.
CountingCompletionPolicy() - Constructor for class org.springframework.batch.repeat.policy.CountingCompletionPolicy
 
CountingCompletionPolicy.CountingBatchContext - Class in org.springframework.batch.repeat.policy
 
countParameterPlaceholders(String, List<String>) - Static method in class org.springframework.batch.item.database.JdbcParameterUtils
Count the occurrences of the character placeholder in an SQL string sql.
countStepExecutions(JobInstance, String) - Method in class org.springframework.batch.core.repository.dao.JdbcStepExecutionDao
 
countStepExecutions(JobInstance, String) - Method in class org.springframework.batch.core.repository.dao.MapStepExecutionDao
Deprecated.
 
countStepExecutions(JobInstance, String) - Method in interface org.springframework.batch.core.repository.dao.StepExecutionDao
Counts all the StepExecution for a given step name.
create(Resource, String) - Method in interface org.springframework.batch.item.file.BufferedReaderFactory
Create a BufferedReader for reading String items from the provided resource.
create(Resource, String) - Method in class org.springframework.batch.item.file.DefaultBufferedReaderFactory
 
create(Resource, String) - Method in class org.springframework.batch.item.file.SimpleBinaryBufferedReaderFactory
 
create(String[], String[]) - Method in class org.springframework.batch.item.file.transform.DefaultFieldSetFactory
Create a FieldSet with named tokens.
create(String[]) - Method in class org.springframework.batch.item.file.transform.DefaultFieldSetFactory
Create a FieldSet with anonymous tokens.
create(String[], String[]) - Method in interface org.springframework.batch.item.file.transform.FieldSetFactory
Create a FieldSet with named tokens.
create(String[]) - Method in interface org.springframework.batch.item.file.transform.FieldSetFactory
Create a FieldSet with anonymous tokens.
createAppendOnlyTransactionalList() - Static method in class org.springframework.batch.support.transaction.TransactionAwareProxyFactory
 
createAppendOnlyTransactionalMap() - Static method in class org.springframework.batch.support.transaction.TransactionAwareProxyFactory
 
createAppendOnlyTransactionalSet() - Static method in class org.springframework.batch.support.transaction.TransactionAwareProxyFactory
 
createApplicationContext() - Method in class org.springframework.batch.core.configuration.support.AbstractApplicationContextFactory
Creates an ApplicationContext from the provided path.
createApplicationContext(ConfigurableApplicationContext, Object...) - Method in class org.springframework.batch.core.configuration.support.AbstractApplicationContextFactory
 
createApplicationContext() - Method in interface org.springframework.batch.core.configuration.support.ApplicationContextFactory
 
createApplicationContext(ConfigurableApplicationContext, Object...) - Method in class org.springframework.batch.core.configuration.support.GenericApplicationContextFactory
 
createBinder(Object) - Method in class org.springframework.batch.item.file.mapping.BeanWrapperFieldSetMapper
Create a binder for the target object.
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.jsr.step.builder.JsrFaultTolerantStepBuilder
Provides a JSR-352 specific implementation of a ChunkProcessor for use within the ChunkOrientedTasklet
createChunkProcessor() - Method in class org.springframework.batch.core.step.builder.FaultTolerantStepBuilder
 
createChunkProvider() - Method in class org.springframework.batch.core.jsr.step.builder.JsrFaultTolerantStepBuilder
 
createChunkProvider() - Method in class org.springframework.batch.core.step.builder.FaultTolerantStepBuilder
 
createContextCustomizer(Class<?>, List<ContextConfigurationAttributes>) - Method in class org.springframework.batch.test.context.BatchTestContextCustomizerFactory
 
createEndStateTransition(State) - Static method in class org.springframework.batch.core.job.flow.support.StateTransition
Create a new end state StateTransition specification.
createEndStateTransition(State, String) - Static method in class org.springframework.batch.core.job.flow.support.StateTransition
Create a new end state StateTransition specification.
createExecutionContextDao() - Method in class org.springframework.batch.core.explore.support.AbstractJobExplorerFactoryBean
 
createExecutionContextDao() - Method in class org.springframework.batch.core.explore.support.JobExplorerFactoryBean
 
createExecutionContextDao() - Method in class org.springframework.batch.core.explore.support.MapJobExplorerFactoryBean
Deprecated.
 
createExecutionContextDao() - Method in class org.springframework.batch.core.repository.support.AbstractJobRepositoryFactoryBean
 
createExecutionContextDao() - Method in class org.springframework.batch.core.repository.support.JobRepositoryFactoryBean
 
createExecutionContextDao() - Method in class org.springframework.batch.core.repository.support.MapJobRepositoryFactoryBean
Deprecated.
 
createFaultTolerantStep() - Method in class org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
 
createFlowStep() - Method in class org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
 
createInternalState(RepeatContext) - Method in class org.springframework.batch.repeat.support.RepeatTemplate
Create an internal state object that is used to store data needed internally in the scope of an iteration.
createInternalState(RepeatContext) - Method in class org.springframework.batch.repeat.support.TaskExecutorRepeatTemplate
 
createJob() - Method in interface org.springframework.batch.core.configuration.JobFactory
 
createJob() - Method in class org.springframework.batch.core.configuration.support.ApplicationContextJobFactory
Create an ApplicationContext from the factory provided and pull out a bean with the name given during initialization.
createJob() - Method in class org.springframework.batch.core.configuration.support.ReferenceJobFactory
Just return the instance passed in on initialization.
createJobExecution(JobInstance, JobParameters, String) - Method in interface org.springframework.batch.core.repository.JobRepository
Create a new JobExecution based upon the JobInstance it's associated with, the JobParameters used to execute it with and the location of the configuration file that defines the job.
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
 
createJobExecution(JobInstance, JobParameters, String) - Method in class org.springframework.batch.core.repository.support.SimpleJobRepository
 
createJobExecution() - Static method in class org.springframework.batch.test.MetaDataInstanceFactory
Create a JobExecution with default parameters.
createJobExecution(Long) - Static method in class org.springframework.batch.test.MetaDataInstanceFactory
Create a JobExecution with the parameters provided.
createJobExecution(String, Long, Long) - Static method in class org.springframework.batch.test.MetaDataInstanceFactory
Create a JobExecution with the parameters provided.
createJobExecution(String, Long, Long, String) - Static method in class org.springframework.batch.test.MetaDataInstanceFactory
Create a JobExecution with the parameters provided.
createJobExecution(String, Long, Long, JobParameters) - Static method in class org.springframework.batch.test.MetaDataInstanceFactory
Create a JobExecution with the parameters provided.
createJobExecutionDao() - Method in class org.springframework.batch.core.explore.support.AbstractJobExplorerFactoryBean
 
createJobExecutionDao() - Method in class org.springframework.batch.core.explore.support.JobExplorerFactoryBean
 
createJobExecutionDao() - Method in class org.springframework.batch.core.explore.support.MapJobExplorerFactoryBean
Deprecated.
 
createJobExecutionDao() - Method in class org.springframework.batch.core.repository.support.AbstractJobRepositoryFactoryBean
 
createJobExecutionDao() - Method in class org.springframework.batch.core.repository.support.JobRepositoryFactoryBean
 
createJobExecutionDao() - Method in class org.springframework.batch.core.repository.support.MapJobRepositoryFactoryBean
Deprecated.
 
createJobExecutions(String, String[], int) - Method in class org.springframework.batch.test.JobRepositoryTestUtils
Use the JobRepository to create some JobExecution instances each with the given job name and each having step executions with the given step names.
createJobExecutions(int) - Method in class org.springframework.batch.test.JobRepositoryTestUtils
Use the JobRepository to create some JobExecution instances each with a single step execution.
createJobExecutionWithStepExecutions(Long, Collection<String>) - Static method in class org.springframework.batch.test.MetaDataInstanceFactory
Create a JobExecution with the parameters provided with attached step executions.
createJobExplorer() - Method in class org.springframework.batch.core.configuration.annotation.DefaultBatchConfigurer
 
createJobInstance(String, JobParameters) - Method in class org.springframework.batch.core.repository.dao.JdbcJobInstanceDao
In this JDBC implementation a job id is obtained by asking the jobIncrementer (which is likely a sequence) for the next long value, and then passing the Id and parameter values into an INSERT statement.
createJobInstance(String, JobParameters) - Method in interface org.springframework.batch.core.repository.dao.JobInstanceDao
Create a JobInstance with given name and parameters.
createJobInstance(String, JobParameters) - Method in class org.springframework.batch.core.repository.dao.MapJobInstanceDao
Deprecated.
 
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
 
createJobInstance(String, Long) - Static method in class org.springframework.batch.test.MetaDataInstanceFactory
Create a JobInstance with the parameters provided.
createJobInstance() - Static method in class org.springframework.batch.test.MetaDataInstanceFactory
Create a JobInstance with default parameters.
createJobInstanceDao() - Method in class org.springframework.batch.core.explore.support.AbstractJobExplorerFactoryBean
 
createJobInstanceDao() - Method in class org.springframework.batch.core.explore.support.JobExplorerFactoryBean
 
createJobInstanceDao() - Method in class org.springframework.batch.core.explore.support.MapJobExplorerFactoryBean
Deprecated.
 
createJobInstanceDao() - Method in class org.springframework.batch.core.repository.support.AbstractJobRepositoryFactoryBean
 
createJobInstanceDao() - Method in class org.springframework.batch.core.repository.support.JobRepositoryFactoryBean
 
createJobInstanceDao() - Method in class org.springframework.batch.core.repository.support.MapJobRepositoryFactoryBean
Deprecated.
 
createJobLauncher() - Method in class org.springframework.batch.core.configuration.annotation.DefaultBatchConfigurer
 
createJobRepository() - Method in class org.springframework.batch.core.configuration.annotation.DefaultBatchConfigurer
 
createLongTaskTimer(String, String, Tag...) - Static method in class org.springframework.batch.core.metrics.BatchMetrics
Create a new LongTaskTimer.
createNewContext(E, BatchPropertyContext) - Method in class org.springframework.batch.core.scope.context.SynchronizationManagerSupport
 
createNewFile(File) - Static method in class org.springframework.batch.item.util.FileUtils
Create a new file if it doesn't already exist.
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
createNewStepState(State, String, String) - Method in class org.springframework.batch.core.jsr.configuration.xml.JsrFlowFactoryBean
 
createPartitionStep() - Method in class org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
 
createPartitionStep() - Method in class org.springframework.batch.core.jsr.configuration.xml.StepFactoryBean
 
createQuery() - Method in class org.springframework.batch.item.database.HibernateItemReaderHelper
Open appropriate type of hibernate session and create the query.
createQuery() - Method in class org.springframework.batch.item.database.orm.HibernateNativeQueryProvider
Create an NativeQuery from the session provided (preferring stateless if both are available).
createQuery() - Method in interface org.springframework.batch.item.database.orm.HibernateQueryProvider
Create the query object which type will be determined by the underline implementation (e.g.
createQuery() - Method in class org.springframework.batch.item.database.orm.JpaNamedQueryProvider
 
createQuery() - Method in class org.springframework.batch.item.database.orm.JpaNativeQueryProvider
 
createQuery() - Method in interface org.springframework.batch.item.database.orm.JpaQueryProvider
Create the query object.
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
 
createSkipPolicy() - Method in class org.springframework.batch.core.step.builder.FaultTolerantStepBuilder
 
createSqlParameterSource(T) - Method in class org.springframework.batch.item.database.BeanPropertyItemSqlParameterSourceProvider
Provide parameter values in an BeanPropertySqlParameterSource based on values from the provided item.
createSqlParameterSource(T) - Method in interface org.springframework.batch.item.database.ItemSqlParameterSourceProvider
Provide parameter values in an SqlParameterSource based on values from the provided item.
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).
createStaxResult() - Method in class org.springframework.batch.item.xml.StaxEventItemWriter
Subclasses can override to customize the STAX result.
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.
createStepExecution() - Static method in class org.springframework.batch.test.MetaDataInstanceFactory
Create a StepExecution with default parameters.
createStepExecution(String, Long) - Static method in class org.springframework.batch.test.MetaDataInstanceFactory
Create a StepExecution with the parameters provided.
createStepExecution(JobExecution, String, Long) - Static method in class org.springframework.batch.test.MetaDataInstanceFactory
Create a StepExecution with the parameters provided.
createStepExecution(JobParameters, ExecutionContext) - Static method in class org.springframework.batch.test.MetaDataInstanceFactory
Create a StepExecution and all its parent entities with default values, but using the ExecutionContext and JobParameters provided.
createStepExecution(JobParameters) - Static method in class org.springframework.batch.test.MetaDataInstanceFactory
Create a StepExecution and all its parent entities with default values, but using the JobParameters provided.
createStepExecution(ExecutionContext) - Static method in class org.springframework.batch.test.MetaDataInstanceFactory
Create a StepExecution and all its parent entities with default values, but using the ExecutionContext provided.
createStepExecutionDao() - Method in class org.springframework.batch.core.explore.support.AbstractJobExplorerFactoryBean
 
createStepExecutionDao() - Method in class org.springframework.batch.core.explore.support.JobExplorerFactoryBean
 
createStepExecutionDao() - Method in class org.springframework.batch.core.explore.support.MapJobExplorerFactoryBean
Deprecated.
 
createStepExecutionDao() - Method in class org.springframework.batch.core.repository.support.AbstractJobRepositoryFactoryBean
 
createStepExecutionDao() - Method in class org.springframework.batch.core.repository.support.JobRepositoryFactoryBean
 
createStepExecutionDao() - Method in class org.springframework.batch.core.repository.support.MapJobRepositoryFactoryBean
Deprecated.
 
createTask(Step, StepExecution) - Method in class org.springframework.batch.core.jsr.partition.JsrPartitionHandler
Creates the task executing the given step in the context of the given execution.
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.jsr.step.builder.JsrSimpleStepBuilder
 
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
 
createTaskletStep() - Method in class org.springframework.batch.core.jsr.configuration.xml.StepFactoryBean
 
createTimer(String, String, Tag...) - Static method in class org.springframework.batch.core.metrics.BatchMetrics
Create a Timer.
createTimerSample() - Static method in class org.springframework.batch.core.metrics.BatchMetrics
Create a new Timer.Sample.
createTransactionalList() - Static method in class org.springframework.batch.support.transaction.TransactionAwareProxyFactory
 
createTransactionalList(List<T>) - Static method in class org.springframework.batch.support.transaction.TransactionAwareProxyFactory
 
createTransactionalMap() - Static method in class org.springframework.batch.support.transaction.TransactionAwareProxyFactory
 
createTransactionalMap(Map<K, V>) - Static method in class org.springframework.batch.support.transaction.TransactionAwareProxyFactory
 
createTransactionalSet() - Static method in class org.springframework.batch.support.transaction.TransactionAwareProxyFactory
 
createTransactionalSet(Set<T>) - Static method in class org.springframework.batch.support.transaction.TransactionAwareProxyFactory
 
createTransition(FlowExecutionStatus, String, String, String, BeanDefinition, ParserContext, boolean) - Static method in class org.springframework.batch.core.configuration.xml.AbstractFlowParser
 
createTransition(FlowExecutionStatus, String, String, String, String, BeanDefinition, ParserContext, boolean) - Static method in class org.springframework.batch.core.jsr.configuration.xml.FlowParser
 
createXmlEventFactory() - Method in class org.springframework.batch.item.xml.StaxEventItemWriter
Subclasses can override to customize the event factory.
createXmlEventWriter(XMLOutputFactory, Writer) - Method in class org.springframework.batch.item.xml.StaxEventItemWriter
Subclasses can override to customize the writer.
createXmlInputFactory() - Static method in class org.springframework.batch.item.xml.StaxUtils
Deprecated.
 
createXmlOutputFactory() - Method in class org.springframework.batch.item.xml.StaxEventItemWriter
Subclasses can override to customize the factory.
currentItemCount(int) - Method in class org.springframework.batch.item.avro.builder.AvroItemReaderBuilder
Index for the current item.
currentItemCount(int) - Method in class org.springframework.batch.item.data.builder.MongoItemReaderBuilder
Index for the current item.
currentItemCount(int) - Method in class org.springframework.batch.item.data.builder.Neo4jItemReaderBuilder
Index for the current item.
currentItemCount(int) - Method in class org.springframework.batch.item.data.builder.RepositoryItemReaderBuilder
Index for the current item.
currentItemCount(int) - Method in class org.springframework.batch.item.database.builder.HibernateCursorItemReaderBuilder
Index for the current item.
currentItemCount(int) - Method in class org.springframework.batch.item.database.builder.HibernatePagingItemReaderBuilder
Index for the current item.
currentItemCount(int) - Method in class org.springframework.batch.item.database.builder.JdbcCursorItemReaderBuilder
Index for the current item.
currentItemCount(int) - Method in class org.springframework.batch.item.database.builder.JdbcPagingItemReaderBuilder
Index for the current item.
currentItemCount(int) - Method in class org.springframework.batch.item.database.builder.JpaCursorItemReaderBuilder
Index for the current item.
currentItemCount(int) - Method in class org.springframework.batch.item.database.builder.JpaPagingItemReaderBuilder
Index for the current item.
currentItemCount(int) - Method in class org.springframework.batch.item.database.builder.StoredProcedureItemReaderBuilder
Index for the current item.
currentItemCount(int) - Method in class org.springframework.batch.item.file.builder.FlatFileItemReaderBuilder
Index for the current item.
currentItemCount(int) - Method in class org.springframework.batch.item.json.builder.JsonItemReaderBuilder
Index for the current item.
currentItemCount(int) - Method in class org.springframework.batch.item.ldif.builder.LdifReaderBuilder
Index for the current item.
currentItemCount(int) - Method in class org.springframework.batch.item.ldif.builder.MappingLdifReaderBuilder
Index for the current item.
currentItemCount(int) - Method in class org.springframework.batch.item.xml.builder.StaxEventItemReaderBuilder
Index for the current item.
customEditors(Map<Class<?>, PropertyEditor>) - Method in class org.springframework.batch.item.file.builder.FlatFileItemReaderBuilder
Register custom type converters for beans being mapped.
customizeContext(ConfigurableApplicationContext, MergedContextConfiguration) - Method in class org.springframework.batch.test.context.BatchTestContextCustomizer
 

D

DatabaseType - Enum in org.springframework.batch.support
Enum representing a database type, such as DB2 or oracle.
DataFieldMaxValueIncrementerFactory - Interface in org.springframework.batch.item.database.support
Factory for creating DataFieldMaxValueIncrementer implementations based upon a provided string.
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
dataSource - Variable in class org.springframework.batch.core.jsr.JsrJobParametersConverter
 
dataSource(DataSource) - Method in class org.springframework.batch.item.database.builder.JdbcBatchItemWriterBuilder
Configure the DataSource to be used.
dataSource(DataSource) - Method in class org.springframework.batch.item.database.builder.JdbcCursorItemReaderBuilder
The DataSource to read from
dataSource(DataSource) - Method in class org.springframework.batch.item.database.builder.JdbcPagingItemReaderBuilder
The DataSource to query against.
dataSource(DataSource) - Method in class org.springframework.batch.item.database.builder.StoredProcedureItemReaderBuilder
The DataSource to read from
DataSourceInitializer - Class in org.springframework.batch.test
Wrapper for a DataSource that can run scripts on start up and shut down.
DataSourceInitializer() - Constructor for class org.springframework.batch.test.DataSourceInitializer
 
DATE_TYPE - Static variable in class org.springframework.batch.core.converter.DefaultJobParametersConverter
 
Db2PagingQueryProvider - Class in org.springframework.batch.item.database.support
DB2 implementation of a PagingQueryProvider using database specific features.
Db2PagingQueryProvider() - Constructor for class org.springframework.batch.item.database.support.Db2PagingQueryProvider
 
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
 
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
 
DecisionStep - Class in org.springframework.batch.core.jsr.step
Implements a Step to follow the rules for a decision state as defined by JSR-352.
DecisionStep(Decider) - Constructor for class org.springframework.batch.core.jsr.step.DecisionStep
 
DecisionStepFactoryBean - Class in org.springframework.batch.core.jsr.configuration.xml
FactoryBean for creating a DecisionStep.
DecisionStepFactoryBean() - Constructor for class org.springframework.batch.core.jsr.configuration.xml.DecisionStepFactoryBean
 
DEFAULT_CHARSET - Static variable in class org.springframework.batch.item.file.FlatFileItemReader
 
DEFAULT_CHARSET - Static variable in class org.springframework.batch.item.support.AbstractFileItemWriter
 
DEFAULT_CHUNK_SIZE - Static variable in class org.springframework.batch.repeat.policy.SimpleCompletionPolicy
 
DEFAULT_COMMENT_PREFIXES - Static variable in class org.springframework.batch.item.file.FlatFileItemReader
 
DEFAULT_ENCODING - Static variable in class org.springframework.batch.item.xml.StaxEventItemReader
 
DEFAULT_ENCODING - Static variable in class org.springframework.batch.item.xml.StaxEventItemWriter
 
DEFAULT_EXIT_MESSAGE_LENGTH - Static variable in class org.springframework.batch.core.repository.dao.AbstractJdbcBatchMetadataDao
 
DEFAULT_JOB_EXECUTION_ID - Static variable in class org.springframework.batch.test.MetaDataInstanceFactory
The default id for a job execution (123L)
DEFAULT_JOB_INSTANCE_ID - Static variable in class org.springframework.batch.test.MetaDataInstanceFactory
The default id for a job instance (12L)
DEFAULT_JOB_NAME - Static variable in class org.springframework.batch.test.MetaDataInstanceFactory
The default name for a job ("job")
DEFAULT_KEY - Static variable in class org.springframework.batch.core.launch.support.DataFieldMaxValueJobParametersIncrementer
Default key used as a job parameter.
DEFAULT_LINE_SEPARATOR - Static variable in class org.springframework.batch.item.support.AbstractFileItemWriter
 
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_QUOTE_CHARACTER - Static variable in class org.springframework.batch.item.file.transform.DelimitedLineTokenizer
Convenient constant for the common case of a " character used to escape delimiters or line endings.
DEFAULT_ROOT_TAG_NAME - Static variable in class org.springframework.batch.item.xml.StaxEventItemWriter
 
DEFAULT_STANDALONE_DOCUMENT - Static variable in class org.springframework.batch.item.xml.StaxEventItemWriter
 
DEFAULT_STEP_EXECUTION_ID - Static variable in class org.springframework.batch.test.MetaDataInstanceFactory
The default id for a step execution (1234L)
DEFAULT_STEP_NAME - Static variable in class org.springframework.batch.test.MetaDataInstanceFactory
The default name for a step ("step")
DEFAULT_SUFFIX - Static variable in class org.springframework.batch.item.file.separator.SuffixRecordSeparatorPolicy
Default value for record terminator suffix.
DEFAULT_TABLE_PREFIX - Static variable in class org.springframework.batch.core.repository.dao.AbstractJdbcBatchMetadataDao
Default value for the table prefix property.
DEFAULT_THROTTLE_LIMIT - Static variable in class org.springframework.batch.repeat.support.TaskExecutorRepeatTemplate
Default limit for maximum number of concurrent unfinished results allowed by the template.
DEFAULT_TIMEOUT - Static variable in class org.springframework.batch.repeat.policy.TimeoutTerminationPolicy
Default timeout value in milliseconds (the value equivalent to 30 seconds).
DEFAULT_TRANSACTIONAL - Static variable in class org.springframework.batch.item.support.AbstractFileItemWriter
 
DEFAULT_XML_VERSION - Static variable in class org.springframework.batch.item.xml.StaxEventItemWriter
 
DefaultBatchConfigurer - Class in org.springframework.batch.core.configuration.annotation
 
DefaultBatchConfigurer() - Constructor for class org.springframework.batch.core.configuration.annotation.DefaultBatchConfigurer
 
DefaultBatchConfigurer(DataSource) - Constructor for class org.springframework.batch.core.configuration.annotation.DefaultBatchConfigurer
 
DefaultBufferedReaderFactory - Class in org.springframework.batch.item.file
 
DefaultBufferedReaderFactory() - Constructor for class org.springframework.batch.item.file.DefaultBufferedReaderFactory
 
DefaultDataFieldMaxValueIncrementerFactory - Class in org.springframework.batch.item.database.support
Default implementation of the DataFieldMaxValueIncrementerFactory interface.
DefaultDataFieldMaxValueIncrementerFactory(DataSource) - Constructor for class org.springframework.batch.item.database.support.DefaultDataFieldMaxValueIncrementerFactory
 
DefaultExceptionHandler - Class in org.springframework.batch.repeat.exception
Default implementation of ExceptionHandler - just re-throws the exception it encounters.
DefaultExceptionHandler() - Constructor for class org.springframework.batch.repeat.exception.DefaultExceptionHandler
 
DefaultExecutionContextSerializer - Class in org.springframework.batch.core.repository.dao
An implementation of the ExecutionContextSerializer using the default serialization implementations from Spring (DefaultSerializer and DefaultDeserializer).
DefaultExecutionContextSerializer() - Constructor for class org.springframework.batch.core.repository.dao.DefaultExecutionContextSerializer
 
DefaultFieldSet - Class in org.springframework.batch.item.file.transform
Default implementation of FieldSet using Java primitive and standard types and utilities.
DefaultFieldSet(String[]) - Constructor for class org.springframework.batch.item.file.transform.DefaultFieldSet
Create a FieldSet with anonymous tokens.
DefaultFieldSet(String[], String[]) - Constructor for class org.springframework.batch.item.file.transform.DefaultFieldSet
Create a FieldSet with named tokens.
DefaultFieldSetFactory - Class in org.springframework.batch.item.file.transform
Default implementation of FieldSetFactory with no special knowledge of the FieldSet required.
DefaultFieldSetFactory() - Constructor for class org.springframework.batch.item.file.transform.DefaultFieldSetFactory
 
DefaultFragmentEventReader - Class in org.springframework.batch.item.xml.stax
Default implementation of FragmentEventReader
DefaultFragmentEventReader(XMLEventReader) - Constructor for class org.springframework.batch.item.xml.stax.DefaultFragmentEventReader
Caches the StartDocument event for later use.
DefaultItemFailureHandler - Class in org.springframework.batch.core.step.item
Default implementation of the ItemListenerSupport class that writes all exceptions via commons logging.
DefaultItemFailureHandler() - Constructor for class org.springframework.batch.core.step.item.DefaultItemFailureHandler
 
DefaultJobKeyGenerator - Class in org.springframework.batch.core
Default implementation of the JobKeyGenerator interface.
DefaultJobKeyGenerator() - Constructor for class org.springframework.batch.core.DefaultJobKeyGenerator
 
DefaultJobLoader - Class in org.springframework.batch.core.configuration.support
Default implementation of JobLoader.
DefaultJobLoader() - Constructor for class org.springframework.batch.core.configuration.support.DefaultJobLoader
Default constructor useful for declarative configuration.
DefaultJobLoader(JobRegistry) - Constructor for class org.springframework.batch.core.configuration.support.DefaultJobLoader
Creates a job loader with the job registry provided.
DefaultJobLoader(JobRegistry, StepRegistry) - Constructor for class org.springframework.batch.core.configuration.support.DefaultJobLoader
Creates a job loader with the job and step registries provided.
DefaultJobParametersConverter - Class in org.springframework.batch.core.converter
Converter for JobParameters instances using a simple naming convention for property keys.
DefaultJobParametersConverter() - Constructor for class org.springframework.batch.core.converter.DefaultJobParametersConverter
 
DefaultJobParametersExtractor - Class in org.springframework.batch.core.step.job
Simple implementation of JobParametersExtractor which pulls parameters with named keys out of the step execution context and the job parameters of the surrounding job.
DefaultJobParametersExtractor() - Constructor for class org.springframework.batch.core.step.job.DefaultJobParametersExtractor
 
DefaultJobParametersValidator - Class in org.springframework.batch.core.job
Default implementation of JobParametersValidator.
DefaultJobParametersValidator() - Constructor for class org.springframework.batch.core.job.DefaultJobParametersValidator
Convenient default constructor for unconstrained validation.
DefaultJobParametersValidator(String[], String[]) - Constructor for class org.springframework.batch.core.job.DefaultJobParametersValidator
Create a new validator with the required and optional job parameter keys provided.
DefaultLineMapper<T> - Class in org.springframework.batch.item.file.mapping
Two-phase LineMapper implementation consisting of tokenization of the line into FieldSet followed by mapping to item.
DefaultLineMapper() - Constructor for class org.springframework.batch.item.file.mapping.DefaultLineMapper
 
DefaultMailErrorHandler - Class in org.springframework.batch.item.mail
This MailErrorHandler implementation simply rethrows the exception it receives.
DefaultMailErrorHandler() - Constructor for class org.springframework.batch.item.mail.DefaultMailErrorHandler
 
DefaultPropertyEditorRegistrar - Class in org.springframework.batch.support
A re-usable PropertyEditorRegistrar that can be used wherever one needs to register custom PropertyEditor instances with a PropertyEditorRegistry (like a bean wrapper, or a type converter).
DefaultPropertyEditorRegistrar() - Constructor for class org.springframework.batch.support.DefaultPropertyEditorRegistrar
 
DefaultRecordSeparatorPolicy - Class in org.springframework.batch.item.file.separator
A RecordSeparatorPolicy that treats all lines as record endings, as long as they do not have unterminated quotes, and do not end in a continuation marker.
DefaultRecordSeparatorPolicy() - Constructor for class org.springframework.batch.item.file.separator.DefaultRecordSeparatorPolicy
Default constructor.
DefaultRecordSeparatorPolicy(String) - Constructor for class org.springframework.batch.item.file.separator.DefaultRecordSeparatorPolicy
Convenient constructor with quote character as parameter.
DefaultRecordSeparatorPolicy(String, String) - Constructor for class org.springframework.batch.item.file.separator.DefaultRecordSeparatorPolicy
Convenient constructor with quote character and continuation marker as parameters.
DefaultResultCompletionPolicy - Class in org.springframework.batch.repeat.policy
Very simple CompletionPolicy that bases its decision on the result of a batch operation.
DefaultResultCompletionPolicy() - Constructor for class org.springframework.batch.repeat.policy.DefaultResultCompletionPolicy
 
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
 
delegate(ResourceAwareItemReaderItemStream<? extends T>) - Method in class org.springframework.batch.item.file.builder.MultiResourceItemReaderBuilder
Establishes the delegate to use for reading the resources provided.
delegate(ResourceAwareItemWriterItemStream<? super T>) - Method in class org.springframework.batch.item.file.builder.MultiResourceItemWriterBuilder
Delegate used for actual writing of the output.
delegate(ItemReader<T>) - Method in class org.springframework.batch.item.support.builder.SingleItemPeekableItemReaderBuilder
The item reader to use as a delegate.
delegate(ItemStreamReader<T>) - Method in class org.springframework.batch.item.support.builder.SynchronizedItemStreamReaderBuilder
The item stream reader to use as a delegate.
delegate(ItemStreamWriter<T>) - Method in class org.springframework.batch.item.support.builder.SynchronizedItemStreamWriterBuilder
Set the delegate ItemStreamWriter.
delegates(List<? extends ItemProcessor<?, ?>>) - Method in class org.springframework.batch.item.support.builder.CompositeItemProcessorBuilder
Establishes the ItemProcessor delegates that will work on the item to be processed.
delegates(ItemProcessor<?, ?>...) - Method in class org.springframework.batch.item.support.builder.CompositeItemProcessorBuilder
Establishes the ItemProcessor delegates that will work on the item to be processed.
delegates(List<ItemWriter<? super T>>) - Method in class org.springframework.batch.item.support.builder.CompositeItemWriterBuilder
The list of item writers to use as delegates.
delegates(ItemWriter<? super T>...) - Method in class org.springframework.batch.item.support.builder.CompositeItemWriterBuilder
The item writers to use as delegates.
DelegateStep - Class in org.springframework.batch.integration.step
Provides a wrapper for an existing Step, delegating execution to it, but serving all other operations locally.
DelegateStep() - Constructor for class org.springframework.batch.integration.step.DelegateStep
 
delete(boolean) - Method in class org.springframework.batch.item.data.builder.GemfireItemWriterBuilder
Indicates if the items being passed to the writer are to be saved or removed from the data store.
delete(boolean) - Method in class org.springframework.batch.item.data.builder.MongoItemWriterBuilder
Indicates if the items being passed to the writer are to be saved or removed from the data store.
delete(boolean) - Method in class org.springframework.batch.item.data.builder.Neo4jItemWriterBuilder
Boolean flag indicating whether the writer should save or delete the item at write time.
delete(boolean) - Method in class org.springframework.batch.item.kafka.builder.KafkaItemWriterBuilder
Indicate if the items being passed to the writer are all to be sent as delete events to the topic.
delete - Variable in class org.springframework.batch.item.KeyValueItemWriter
 
delimited() - Method in class org.springframework.batch.item.file.builder.FlatFileItemReaderBuilder
delimited() - Method in class org.springframework.batch.item.file.builder.FlatFileItemWriterBuilder
DelimitedBuilder(FlatFileItemReaderBuilder<T>) - Constructor for class org.springframework.batch.item.file.builder.FlatFileItemReaderBuilder.DelimitedBuilder
 
DelimitedBuilder(FlatFileItemWriterBuilder<T>) - Constructor for class org.springframework.batch.item.file.builder.FlatFileItemWriterBuilder.DelimitedBuilder
 
DelimitedLineAggregator<T> - Class in org.springframework.batch.item.file.transform
A LineAggregator implementation that converts an object into a delimited list of strings.
DelimitedLineAggregator() - Constructor for class org.springframework.batch.item.file.transform.DelimitedLineAggregator
 
DelimitedLineTokenizer - Class in org.springframework.batch.item.file.transform
A LineTokenizer implementation that splits the input String on a configurable delimiter.
DelimitedLineTokenizer() - Constructor for class org.springframework.batch.item.file.transform.DelimitedLineTokenizer
Create a new instance of the DelimitedLineTokenizer class for the common case where the delimiter is a comma.
DelimitedLineTokenizer(String) - Constructor for class org.springframework.batch.item.file.transform.DelimitedLineTokenizer
Create a new instance of the DelimitedLineTokenizer class.
delimiter(String) - Method in class org.springframework.batch.item.file.builder.FlatFileItemReaderBuilder.DelimitedBuilder
Define the delimiter for the file.
delimiter(String) - Method in class org.springframework.batch.item.file.builder.FlatFileItemWriterBuilder.DelimitedBuilder
Define the delimiter for the file.
DELIMITER_COMMA - Static variable in class org.springframework.batch.item.file.transform.DelimitedLineTokenizer
Convenient constant for the common case of a comma delimiter.
DELIMITER_TAB - Static variable in class org.springframework.batch.item.file.transform.DelimitedLineTokenizer
Convenient constant for the common case of a tab delimiter.
DerbyPagingQueryProvider - Class in org.springframework.batch.item.database.support
Derby implementation of a PagingQueryProvider using standard SQL:2003 windowing functions.
DerbyPagingQueryProvider() - Constructor for class org.springframework.batch.item.database.support.DerbyPagingQueryProvider
 
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
 
deserialize(InputStream) - Method in class org.springframework.batch.core.repository.dao.XStreamExecutionContextStringSerializer
Deprecated.
Deserializes the supplied input stream into a new execution context.
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.test.DataSourceInitializer
 
detectStreamInReader() - Method in class org.springframework.batch.core.step.builder.FaultTolerantStepBuilder
 
DirectPoller<S> - Class in org.springframework.batch.poller
A Poller that uses the callers thread to poll for a result as soon as it is asked for.
DirectPoller(long) - Constructor for class org.springframework.batch.poller.DirectPoller
 
distanceLimit(int) - Method in class org.springframework.batch.item.file.builder.FlatFileItemReaderBuilder
Configures the maximum tolerance between the actual spelling of a field's name and the property's name.
doAfterWrite(List<O>) - Method in class org.springframework.batch.core.step.item.SimpleChunkProcessor
Call the listener's after write method.
doAggregate(Object[]) - Method in class org.springframework.batch.item.file.transform.DelimitedLineAggregator
 
doAggregate(Object[]) - Method in class org.springframework.batch.item.file.transform.ExtractorLineAggregator
Aggregate provided fields into single String.
doAggregate(Object[]) - Method in class org.springframework.batch.item.file.transform.FormatterLineAggregator
 
doAggregation(Collection<FlowExecution>, FlowExecutor) - Method in class org.springframework.batch.core.job.flow.support.state.SplitState
 
doAggregation(Collection<FlowExecution>, FlowExecutor) - Method in class org.springframework.batch.core.jsr.job.flow.support.state.JsrSplitState
Resets the JobExecution's exit status before aggregating the results of the flows within the split.
doBegin(Object, TransactionDefinition) - Method in class org.springframework.batch.support.transaction.ResourcelessTransactionManager
 
doCheckpoint() - Method in class org.springframework.batch.jsr.item.CheckpointSupport
Used to provide a Serializable representing the current state of the batch artifact.
doCheckpoint() - Method in class org.springframework.batch.jsr.item.ItemReaderAdapter
 
doCheckpoint() - Method in class org.springframework.batch.jsr.item.ItemWriterAdapter
 
doCleanupAfterCompletion(Object) - Method in class org.springframework.batch.support.transaction.ResourcelessTransactionManager
 
doClose() - Method in class org.springframework.batch.item.avro.AvroItemReader
 
doClose() - Method in class org.springframework.batch.item.data.AbstractPaginatedDataItemReader
 
doClose() - Method in class org.springframework.batch.item.data.RepositoryItemReader
 
doClose() - Method in class org.springframework.batch.item.database.AbstractCursorItemReader
Close the cursor and database connection.
doClose() - Method in class org.springframework.batch.item.database.AbstractPagingItemReader
 
doClose() - Method in class org.springframework.batch.item.database.HibernateCursorItemReader
Close the cursor and hibernate session.
doClose() - Method in class org.springframework.batch.item.database.HibernatePagingItemReader
 
doClose() - Method in class org.springframework.batch.item.database.JpaCursorItemReader
 
doClose() - Method in class org.springframework.batch.item.database.JpaPagingItemReader
 
doClose() - Method in class org.springframework.batch.item.file.FlatFileItemReader
 
doClose() - Method in class org.springframework.batch.item.json.JsonItemReader
 
doClose() - Method in class org.springframework.batch.item.ldif.LdifReader
 
doClose() - Method in class org.springframework.batch.item.ldif.MappingLdifReader
 
doClose() - Method in class org.springframework.batch.item.support.AbstractItemCountingItemStreamItemReader
doClose() - Method in class org.springframework.batch.item.xml.StaxEventItemReader
 
doClose() - Method in class org.springframework.batch.jsr.item.CheckpointSupport
Used to close the underlying batch artifact
doClose() - Method in class org.springframework.batch.jsr.item.ItemReaderAdapter
 
doClose() - Method in class org.springframework.batch.jsr.item.ItemWriterAdapter
 
doCommit(DefaultTransactionStatus) - Method in class org.springframework.batch.support.transaction.ResourcelessTransactionManager
 
doExecute(JobExecution) - Method in class org.springframework.batch.core.job.AbstractJob
Extension point for subclasses allowing them to concentrate on processing logic and ignore listeners and repository calls.
doExecute(JobExecution) - Method in class org.springframework.batch.core.job.flow.FlowJob
 
doExecute(StepExecution) - Method in class org.springframework.batch.core.job.flow.FlowStep
Delegate to the flow provided for the execution of the step.
doExecute(JobExecution) - Method in class org.springframework.batch.core.job.SimpleJob
Handler of steps sequentially as provided, checking each one for success before moving to the next.
doExecute(JobExecution) - Method in class org.springframework.batch.core.jsr.job.flow.JsrFlowJob
 
doExecute(StepExecution) - Method in class org.springframework.batch.core.jsr.step.DecisionStep
 
doExecute(StepExecution) - Method in class org.springframework.batch.core.jsr.step.PartitionStep
Delegate execution to the PartitionHandler provided.
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.
doExecute(StepExecution) - Method in class org.springframework.batch.integration.step.DelegateStep
 
doExecutionRegistration(StepExecution) - Method in class org.springframework.batch.core.jsr.step.BatchletStep
 
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
doGetTransaction() - Method in class org.springframework.batch.support.transaction.ResourcelessTransactionManager
 
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.
doInIteration(RepeatContext) - Method in class org.springframework.batch.repeat.callback.NestedRepeatCallback
Simply calls template.execute(callback).
doInIteration(RepeatContext) - Method in interface org.springframework.batch.repeat.RepeatCallback
Implementations return true if they can continue processing - e.g.
doInJobScope(JobExecution, Callable<T>) - Static method in class org.springframework.batch.test.JobScopeTestUtils
 
doInStepScope(StepExecution, Callable<T>) - Static method in class org.springframework.batch.test.StepScopeTestUtils
 
doJumpToPage(int) - Method in class org.springframework.batch.item.database.AbstractPagingItemReader
 
doJumpToPage(int) - Method in class org.springframework.batch.item.database.HibernatePagingItemReader
 
doJumpToPage(int) - Method in class org.springframework.batch.item.database.JdbcPagingItemReader
 
doJumpToPage(int) - Method in class org.springframework.batch.item.database.JpaPagingItemReader
 
doOnWriteError(Exception, List<O>) - Method in class org.springframework.batch.core.step.item.SimpleChunkProcessor
Call listener's writerError method.
doOpen() - Method in class org.springframework.batch.item.avro.AvroItemReader
 
doOpen() - Method in class org.springframework.batch.item.data.AbstractPaginatedDataItemReader
 
doOpen() - Method in class org.springframework.batch.item.data.RepositoryItemReader
 
doOpen() - Method in class org.springframework.batch.item.database.AbstractCursorItemReader
Execute the statement to open the cursor.
doOpen() - Method in class org.springframework.batch.item.database.AbstractPagingItemReader
 
doOpen() - Method in class org.springframework.batch.item.database.HibernateCursorItemReader
Open hibernate session and create a forward-only cursor for the query.
doOpen() - Method in class org.springframework.batch.item.database.HibernatePagingItemReader
 
doOpen() - Method in class org.springframework.batch.item.database.JpaCursorItemReader
 
doOpen() - Method in class org.springframework.batch.item.database.JpaPagingItemReader
 
doOpen() - Method in class org.springframework.batch.item.file.FlatFileItemReader
 
doOpen() - Method in class org.springframework.batch.item.json.JsonItemReader
 
doOpen() - Method in class org.springframework.batch.item.ldif.LdifReader
 
doOpen() - Method in class org.springframework.batch.item.ldif.MappingLdifReader
 
doOpen() - Method in class org.springframework.batch.item.support.AbstractItemCountingItemStreamItemReader
Open resources necessary to start reading input.
doOpen() - Method in class org.springframework.batch.item.xml.StaxEventItemReader
 
doOpen(Serializable) - Method in class org.springframework.batch.jsr.item.CheckpointSupport
Used to open a batch artifact with previously saved checkpoint information.
doOpen(Serializable) - Method in class org.springframework.batch.jsr.item.ItemReaderAdapter
 
doOpen(Serializable) - Method in class org.springframework.batch.jsr.item.ItemWriterAdapter
 
doPageRead() - Method in class org.springframework.batch.item.data.AbstractPaginatedDataItemReader
Method this ItemStreamReader delegates to for the actual work of reading a page.
doPageRead() - Method in class org.springframework.batch.item.data.MongoItemReader
 
doPageRead() - Method in class org.springframework.batch.item.data.Neo4jItemReader
 
doPageRead() - Method in class org.springframework.batch.item.data.RepositoryItemReader
Performs the actual reading of a page via the repository.
doParse(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.batch.core.configuration.xml.AbstractFlowParser
 
doParse(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.batch.core.configuration.xml.AbstractListenerParser
 
doParse(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.batch.core.configuration.xml.InlineFlowParser
 
doParse(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.batch.core.configuration.xml.JobParser
Create a bean definition for a FlowJob.
doParse(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.batch.core.configuration.xml.JobRepositoryParser
Parse and create a bean definition for a JobRepositoryFactoryBean .
doParse(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.batch.core.configuration.xml.TopLevelFlowParser
 
doParse(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.batch.core.configuration.xml.TopLevelJobListenerParser
 
doParse(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.batch.core.configuration.xml.TopLevelStepListenerParser
 
doParse(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.batch.core.jsr.configuration.xml.FlowParser
 
doParse(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.batch.core.jsr.configuration.xml.JsrJobParser
 
doPersist(StepContribution, Chunk<O>) - Method in class org.springframework.batch.core.jsr.step.item.JsrChunkProcessor
Implements writing and all related listener calls
doProcess(I) - Method in class org.springframework.batch.core.step.item.SimpleChunkProcessor
 
doProvide(StepContribution, Chunk<I>) - Method in class org.springframework.batch.core.jsr.step.item.JsrChunkProcessor
Implements reading as well as any related listener calls required.
doRead() - Method in class org.springframework.batch.core.step.item.SimpleChunkProvider
Surrounds the read call with listener callbacks.
doRead() - Method in class org.springframework.batch.item.avro.AvroItemReader
 
doRead() - Method in class org.springframework.batch.item.data.AbstractPaginatedDataItemReader
 
doRead() - Method in class org.springframework.batch.item.data.RepositoryItemReader
 
doRead() - Method in class org.springframework.batch.item.database.AbstractCursorItemReader
Read next row and map it to item, verify cursor position if AbstractCursorItemReader.setVerifyCursorPosition(boolean) is true.
doRead() - Method in class org.springframework.batch.item.database.AbstractPagingItemReader
 
doRead() - Method in class org.springframework.batch.item.database.HibernateCursorItemReader
 
doRead() - Method in class org.springframework.batch.item.database.JpaCursorItemReader
 
doRead() - Method in class org.springframework.batch.item.file.FlatFileItemReader
 
doRead() - Method in class org.springframework.batch.item.json.JsonItemReader
 
doRead() - Method in class org.springframework.batch.item.ldif.LdifReader
 
doRead() - Method in class org.springframework.batch.item.ldif.MappingLdifReader
 
doRead() - Method in class org.springframework.batch.item.support.AbstractItemCountingItemStreamItemReader
Read next item from input.
doRead() - Method in class org.springframework.batch.item.xml.StaxEventItemReader
Move to next fragment and map it to item.
doReadPage() - Method in class org.springframework.batch.item.database.AbstractPagingItemReader
 
doReadPage() - Method in class org.springframework.batch.item.database.HibernatePagingItemReader
 
doReadPage() - Method in class org.springframework.batch.item.database.JdbcPagingItemReader
 
doReadPage() - Method in class org.springframework.batch.item.database.JpaPagingItemReader
 
doRollback(DefaultTransactionStatus) - Method in class org.springframework.batch.support.transaction.ResourcelessTransactionManager
 
doSetRollbackOnly(DefaultTransactionStatus) - Method in class org.springframework.batch.support.transaction.ResourcelessTransactionManager
 
doTokenize(String) - Method in class org.springframework.batch.item.file.transform.AbstractLineTokenizer
 
doTokenize(String) - Method in class org.springframework.batch.item.file.transform.DelimitedLineTokenizer
Yields the tokens resulting from the splitting of the supplied line.
doTokenize(String) - Method in class org.springframework.batch.item.file.transform.FixedLengthTokenizer
Yields the tokens resulting from the splitting of the supplied line.
doTokenize(String) - Method in class org.springframework.batch.item.file.transform.RegexLineTokenizer
 
doTransform(I) - Method in class org.springframework.batch.core.jsr.step.item.JsrChunkProcessor
Implements processing and all related listener calls.
doUpdate(RepeatContext) - Method in class org.springframework.batch.repeat.policy.CountingCompletionPolicy
Extension point for subclasses.
doWrite(List<O>) - Method in class org.springframework.batch.core.step.item.SimpleChunkProcessor
Surrounds the actual write call with listener callbacks.
doWrite(List<? extends T>) - Method in class org.springframework.batch.item.data.MongoItemWriter
Performs the actual write to the store via the template.
doWrite(List<? extends T>) - Method in class org.springframework.batch.item.data.Neo4jItemWriter
Performs the actual write using the template.
doWrite(List<? extends T>) - Method in class org.springframework.batch.item.data.RepositoryItemWriter
Performs the actual write to the repository.
doWrite(SessionFactory, List<? extends T>) - Method in class org.springframework.batch.item.database.HibernateItemWriter
Do perform the actual write operation using Hibernate's API.
doWrite(HibernateOperations, List<? extends T>) - Method in class org.springframework.batch.item.database.HibernateItemWriter
Deprecated.
As of 2.2 in favor of using Hibernate's session management APIs directly
doWrite(EntityManager, List<? extends T>) - Method in class org.springframework.batch.item.database.JpaItemWriter
Do perform the actual write operation.
doWrite(List<? extends T>) - Method in class org.springframework.batch.item.file.FlatFileItemWriter
 
doWrite(List<? extends T>) - Method in class org.springframework.batch.item.json.JsonFileItemWriter
 
doWrite(List<? extends T>) - Method in class org.springframework.batch.item.support.AbstractFileItemWriter
Write out a string of items followed by a "new line", where the format of the new line separator is determined by the underlying operating system.
driverSupportsAbsolute(boolean) - Method in class org.springframework.batch.item.database.builder.JdbcCursorItemReaderBuilder
Indicates if the JDBC driver supports setting the absolute row on the ResultSet.
driverSupportsAbsolute(boolean) - Method in class org.springframework.batch.item.database.builder.StoredProcedureItemReaderBuilder
Indicates if the JDBC driver supports setting the absolute row on the ResultSet.
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
 
DynamicMethodInvocationException - Exception in org.springframework.batch.item.adapter
Indicates an error has been encountered while trying to dynamically invoke a method e.g.
DynamicMethodInvocationException(Throwable) - Constructor for exception org.springframework.batch.item.adapter.DynamicMethodInvocationException
 
DynamicMethodInvocationException(String, Throwable) - Constructor for exception org.springframework.batch.item.adapter.DynamicMethodInvocationException
 

E

ELSE_KEY - Static variable in class org.springframework.batch.core.step.tasklet.ConfigurableSystemProcessExitCodeMapper
 
EMBEDDED - Static variable in class org.springframework.batch.core.launch.support.JobRegistryBackgroundJobRunner
System property key that switches the runner to "embedded" mode (returning immediately from the main method).
embeddedSchema(boolean) - Method in class org.springframework.batch.item.avro.builder.AvroItemReaderBuilder
Disable or enable reading an embedded Avro schema.
EnableBatchIntegration - Annotation Type in org.springframework.batch.integration.config.annotation
Enable Spring Batch Integration features and provide a base configuration for setting up remote chunking or partitioning infrastructure beans.
EnableBatchProcessing - Annotation Type in org.springframework.batch.core.configuration.annotation
Enable Spring Batch features and provide a base configuration for setting up batch jobs in an @Configuration class, roughly equivalent to using the <batch:*> XML namespace.
encoding(String) - Method in class org.springframework.batch.item.file.builder.FlatFileItemReaderBuilder
Configure the encoding used by the reader to read the input source.
encoding(String) - Method in class org.springframework.batch.item.file.builder.FlatFileItemWriterBuilder
Encoding used for output.
encoding(String) - Method in class org.springframework.batch.item.json.builder.JsonFileItemWriterBuilder
Encoding used for output.
encoding(String) - Method in class org.springframework.batch.item.xml.builder.StaxEventItemReaderBuilder
Encoding for the input file.
encoding(String) - Method in class org.springframework.batch.item.xml.builder.StaxEventItemWriterBuilder
Encoding for the file.
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
 
endCounter - Static variable in class org.springframework.batch.core.configuration.xml.AbstractFlowParser
 
endDocument(XMLEventWriter) - Method in class org.springframework.batch.item.xml.StaxEventItemWriter
Writes the EndDocument tag manually.
EndState - Class in org.springframework.batch.core.job.flow.support.state
State implementation for ending a job if it is in progress and continuing if just starting.
EndState(FlowExecutionStatus, String) - Constructor for class org.springframework.batch.core.job.flow.support.state.EndState
 
EndState(FlowExecutionStatus, String, String) - Constructor for class org.springframework.batch.core.job.flow.support.state.EndState
 
EndState(FlowExecutionStatus, String, String, boolean) - Constructor for class org.springframework.batch.core.job.flow.support.state.EndState
 
enhance(Job) - Method in class org.springframework.batch.core.job.builder.JobBuilderHelper
 
enhance(Step) - Method in class org.springframework.batch.core.step.builder.StepBuilderHelper
 
enhanceCommonStep(StepBuilderHelper<?>) - Method in class org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
 
enhanceTaskletStepBuilder(AbstractTaskletStepBuilder<?>) - Method in class org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
 
Entity - Class in org.springframework.batch.core
Batch Domain Entity class.
Entity() - Constructor for class org.springframework.batch.core.Entity
 
Entity(Long) - Constructor for class org.springframework.batch.core.Entity
 
entityClass(Class<T>) - Method in class org.springframework.batch.item.database.builder.HibernateCursorItemReaderBuilder
 
entityManagerFactory(EntityManagerFactory) - Method in class org.springframework.batch.item.database.builder.JpaCursorItemReaderBuilder
The EntityManagerFactory to be used for executing the configured JpaCursorItemReaderBuilder.queryString.
entityManagerFactory(EntityManagerFactory) - Method in class org.springframework.batch.item.database.builder.JpaItemWriterBuilder
The JPA EntityManagerFactory to obtain an entity manager from.
entityManagerFactory(EntityManagerFactory) - Method in class org.springframework.batch.item.database.builder.JpaPagingItemReaderBuilder
The EntityManagerFactory to be used for executing the configured JpaPagingItemReaderBuilder.queryString.
entrySet() - Method in class org.springframework.batch.item.ExecutionContext
Returns the entry set containing the contents of this context.
ENVIRONMENT - Static variable in class org.springframework.batch.support.SystemPropertyInitializer
Name of system property used by default.
equals(Object) - Method in class org.springframework.batch.core.configuration.support.AbstractApplicationContextFactory
 
equals(Object) - Method in class org.springframework.batch.core.configuration.support.GroupAwareJob
 
equals(Object) - Method in class org.springframework.batch.core.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
 
equals(Object) - Method in class org.springframework.batch.item.ExecutionContext
 
equals(Object) - Method in class org.springframework.batch.item.file.transform.DefaultFieldSet
 
equals(Object) - Method in class org.springframework.batch.repeat.context.SynchronizedAttributeAccessor
 
equals(Object) - Method in class org.springframework.batch.support.SimpleMethodInvoker
 
equals(Object) - Method in class org.springframework.batch.test.context.BatchTestContextCustomizer
 
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.
exceptionHandler(ExceptionHandler) - Method in class org.springframework.batch.integration.chunk.RemoteChunkingManagerStepBuilder
 
exceptionHandler(ExceptionHandler) - Method in class org.springframework.batch.integration.chunk.RemoteChunkingMasterStepBuilder
Deprecated.
 
ExceptionHandler - Interface in org.springframework.batch.repeat.exception
Handler to allow strategies for re-throwing exceptions.
execute(JobExecution) - Method in class org.springframework.batch.core.configuration.support.GroupAwareJob
 
execute(JobExecution) - Method in class org.springframework.batch.core.job.AbstractJob
Run the specified job, handling all listener and repository calls, and delegating the actual processing to AbstractJob.doExecute(JobExecution).
execute(JobExecution) - Method in interface org.springframework.batch.core.Job
Run the JobExecution and update the meta information like status and statistics as necessary.
execute(StepContribution, ChunkContext) - Method in class org.springframework.batch.core.jsr.step.batchlet.BatchletAdapter
 
execute(Job, JobExecution) - Method in class org.springframework.batch.core.scope.context.JobScopeManager
 
execute(Step, StepExecution) - Method in class org.springframework.batch.core.scope.context.StepScopeManager
 
execute(StepExecution) - Method in class org.springframework.batch.core.step.AbstractStep
Template method for step execution logic - calls abstract methods for resource initialization ( AbstractStep.open(ExecutionContext)), execution logic (AbstractStep.doExecute(StepExecution)) and resource closing ( AbstractStep.close(ExecutionContext)).
execute(StepExecution) - Method in interface org.springframework.batch.core.Step
Process the step and assign progress and status meta information to the StepExecution provided.
execute(RetryCallback<T, E>, Collection<RetryState>) - 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>, RecoveryCallback<T>) - 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
 
execute(RetryCallback<T, E>) - Method in class org.springframework.batch.core.step.item.BatchRetryTemplate
 
execute(StepContribution, ChunkContext) - Method in class org.springframework.batch.core.step.item.ChunkOrientedTasklet
 
execute(StepContribution, ChunkContext) - Method in class org.springframework.batch.core.step.tasklet.CallableTaskletAdapter
Execute the provided Callable and return its RepeatStatus.
execute(StepContribution, ChunkContext) - Method in class org.springframework.batch.core.step.tasklet.MethodInvokingTaskletAdapter
Delegate execution to the target object and translate the return value to an ExitStatus by invoking a method in the delegate POJO.
execute(StepContribution, ChunkContext) - Method in class org.springframework.batch.core.step.tasklet.SystemCommandTasklet
Execute system command and map its exit code to ExitStatus using SystemProcessExitCodeMapper.
execute(StepContribution, ChunkContext) - Method in interface org.springframework.batch.core.step.tasklet.Tasklet
Given the current context in the form of a step contribution, do whatever is necessary to process this unit inside a transaction.
executeAfterInterceptors(RepeatContext, RepeatStatus) - Method in class org.springframework.batch.repeat.support.RepeatTemplate
Convenience method to execute after interceptors on a callback result.
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.
ExecutionContext - Class in org.springframework.batch.item
Object representing a context for an ItemStream.
ExecutionContext() - Constructor for class org.springframework.batch.item.ExecutionContext
Default constructor.
ExecutionContext(Map<String, Object>) - Constructor for class org.springframework.batch.item.ExecutionContext
Initializes a new execution context with the contents of another map.
ExecutionContext(ExecutionContext) - Constructor for class org.springframework.batch.item.ExecutionContext
Initializes a new ExecutionContext with the contents of another ExecutionContext.
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.
ExecutionContextTestUtils - Class in org.springframework.batch.test
Convenience class for accessing ExecutionContext values from job and step executions.
ExecutionContextTestUtils() - Constructor for class org.springframework.batch.test.ExecutionContextTestUtils
 
ExecutionContextUserSupport - Class in org.springframework.batch.item.util
Facilitates assigning names to objects persisting data in ExecutionContext and generating keys for ExecutionContext based on the name.
ExecutionContextUserSupport() - Constructor for class org.springframework.batch.item.util.ExecutionContextUserSupport
 
ExecutionContextUserSupport(String) - Constructor for class org.springframework.batch.item.util.ExecutionContextUserSupport
 
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
 
ExitCodeMapper - Interface in org.springframework.batch.core.launch.support
This interface should be implemented when an environment calling the batch framework has specific requirements regarding the operating system process return status.
ExitStatus - Class in org.springframework.batch.core
Value object used to carry information about the status of a job or step execution.
ExitStatus(String) - Constructor for class org.springframework.batch.core.ExitStatus
 
ExitStatus(String, String) - Constructor for class org.springframework.batch.core.ExitStatus
 
exitStatus - Variable in class org.springframework.batch.core.job.flow.JobFlowExecutor
 
expect() - Method in class org.springframework.batch.repeat.support.ResultHolderResultQueue
Tell the queue to expect one more result.
expect() - Method in class org.springframework.batch.repeat.support.ThrottleLimitResultQueue
Tell the queue to expect one more result.
ExtendedConnectionDataSourceProxy - Class in org.springframework.batch.item.database
Implementation of SmartDataSource that is capable of keeping a single JDBC Connection which is NOT closed after each use even if Connection.close() is called.
ExtendedConnectionDataSourceProxy() - Constructor for class org.springframework.batch.item.database.ExtendedConnectionDataSourceProxy
No arg constructor for use when configured using JavaBean style.
ExtendedConnectionDataSourceProxy(DataSource) - Constructor for class org.springframework.batch.item.database.ExtendedConnectionDataSourceProxy
Constructor that takes as a parameter with the DataSource to be wrapped.
extract(ChunkResponse, boolean) - Method in class org.springframework.batch.integration.chunk.JmsRedeliveredExtractor
 
extract(T) - Method in class org.springframework.batch.item.file.transform.BeanWrapperFieldExtractor
 
extract(T) - Method in interface org.springframework.batch.item.file.transform.FieldExtractor
 
extract(T) - Method in class org.springframework.batch.item.file.transform.PassThroughFieldExtractor
Get an array of fields as close as possible to the input.
ExtractorLineAggregator<T> - Class in org.springframework.batch.item.file.transform
An abstract LineAggregator implementation that utilizes a FieldExtractor to convert the incoming object to an array of its parts.
ExtractorLineAggregator() - Constructor for class org.springframework.batch.item.file.transform.ExtractorLineAggregator
 
extractTableAlias() - Method in class org.springframework.batch.item.database.support.SqlWindowingPagingQueryProvider
 

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
 
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.jsr.step.builder.JsrFaultTolerantStepBuilder
 
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(StepBuilderHelper<?>) - Constructor for class org.springframework.batch.core.step.builder.FaultTolerantStepBuilder
Create a new builder initialized with any properties in the parent.
FaultTolerantStepBuilder(SimpleStepBuilder<I, O>) - Constructor for class org.springframework.batch.core.step.builder.FaultTolerantStepBuilder
Create a new builder initialized with any properties in the parent.
FaultTolerantStepFactoryBean<T,S> - Class in org.springframework.batch.core.step.factory
Factory bean for step that provides options for configuring skip behavior.
FaultTolerantStepFactoryBean() - Constructor for class org.springframework.batch.core.step.factory.FaultTolerantStepFactoryBean
 
fetchSize(int) - Method in class org.springframework.batch.item.database.builder.HibernateCursorItemReaderBuilder
The number of items to be returned with each round trip to the database.
fetchSize(int) - Method in class org.springframework.batch.item.database.builder.HibernatePagingItemReaderBuilder
Fetch size used internally by Hibernate to limit amount of data fetched from database per round trip.
fetchSize(int) - Method in class org.springframework.batch.item.database.builder.JdbcCursorItemReaderBuilder
A hint to the driver as to how many rows to return with each fetch.
fetchSize(int) - Method in class org.springframework.batch.item.database.builder.JdbcPagingItemReaderBuilder
A hint to the underlying RDBMS as to how many records to return with each fetch.
fetchSize(int) - Method in class org.springframework.batch.item.database.builder.StoredProcedureItemReaderBuilder
A hint to the driver as to how many rows to return with each fetch.
fieldExtractor(FieldExtractor<T>) - Method in class org.springframework.batch.item.file.builder.FlatFileItemWriterBuilder.DelimitedBuilder
Set the FieldExtractor to use to extract fields from each item.
fieldExtractor(FieldExtractor<T>) - Method in class org.springframework.batch.item.file.builder.FlatFileItemWriterBuilder.FormattedBuilder
Set the FieldExtractor to use to extract fields from each item.
FieldExtractor<T> - Interface in org.springframework.batch.item.file.transform
This class will convert an object to an array of its parts.
fields(String) - Method in class org.springframework.batch.item.data.builder.MongoItemReaderBuilder
JSON defining the fields to be returned from the matching documents by MongoDB.
FieldSet - Interface in org.springframework.batch.item.file.transform
Interface used by flat file input sources to encapsulate concerns of converting an array of Strings to Java native types.
fieldSetFactory(FieldSetFactory) - Method in class org.springframework.batch.item.file.builder.FlatFileItemReaderBuilder.DelimitedBuilder
A factory for creating the resulting FieldSet.
fieldSetFactory(FieldSetFactory) - Method in class org.springframework.batch.item.file.builder.FlatFileItemReaderBuilder.FixedLengthBuilder
A factory for creating the resulting FieldSet.
FieldSetFactory - Interface in org.springframework.batch.item.file.transform
Factory interface for creating FieldSet instances.
fieldSetMapper(FieldSetMapper<T>) - Method in class org.springframework.batch.item.file.builder.FlatFileItemReaderBuilder
A FieldSetMapper implementation to be used.
FieldSetMapper<T> - Interface in org.springframework.batch.item.file.mapping
Interface that is used to map data obtained from a FieldSet into an object.
FileUtils - Class in org.springframework.batch.item.util
Utility methods for files used in batch processing.
findAllReachableElements(String, Map<String, Set<String>>, Set<String>) - Method in class org.springframework.batch.core.configuration.xml.AbstractFlowParser
Find all of the elements reachable from the startElement.
findAutowiredAnnotation(AccessibleObject) - Method in class org.springframework.batch.core.jsr.configuration.support.JsrAutowiredAnnotationBeanPostProcessor
 
findAutowiringMetadata(Class<?>) - Method in class org.springframework.batch.core.jsr.configuration.support.JsrAutowiredAnnotationBeanPostProcessor
 
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 class org.springframework.batch.core.repository.dao.MapJobExecutionDao
Deprecated.
 
findJobInstancesByJobName(String, int, int) - Method in interface org.springframework.batch.core.explore.JobExplorer
Fetch JobInstance values in descending order of creation (and there for usually of first execution) with a 'like'/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 class org.springframework.batch.core.repository.dao.MapJobInstanceDao
Deprecated.
 
findMatchingMethod() - Method in class org.springframework.batch.item.adapter.HippyMethodInvoker
 
findMethod(Object) - Method in class org.springframework.batch.support.AnnotationMethodResolver
Find a single Method on the Class of the given candidate object that contains the annotation type for which this resolver is searching.
findMethod(Class<?>) - Method in class org.springframework.batch.support.AnnotationMethodResolver
Find a single Method on the given Class that contains the annotation type for which this resolver is searching.
findMethod(Object) - Method in interface org.springframework.batch.support.MethodResolver
Find a single Method on the provided Object that matches this resolver's criteria.
findMethod(Class<?>) - Method in interface org.springframework.batch.support.MethodResolver
Find a single Method on the given Class that matches this resolver's criteria.
findMethod(Class, Class<? extends Annotation>) - Static method in class org.springframework.batch.support.ReflectionUtils
Returns a Set of Method instances that are annotated with the annotation provided.
findRunningJobExecutions(String) - Method in interface org.springframework.batch.core.explore.JobExplorer
Retrieve running job executions.
findRunningJobExecutions(String) - Method in class org.springframework.batch.core.explore.support.SimpleJobExplorer
 
findRunningJobExecutions(String) - Method in class org.springframework.batch.core.repository.dao.JdbcJobExecutionDao
 
findRunningJobExecutions(String) - Method in interface org.springframework.batch.core.repository.dao.JobExecutionDao
 
findRunningJobExecutions(String) - Method in class org.springframework.batch.core.repository.dao.MapJobExecutionDao
Deprecated.
 
fixedLength() - Method in class org.springframework.batch.item.file.builder.FlatFileItemReaderBuilder
FixedLengthBuilder(FlatFileItemReaderBuilder<T>) - Constructor for class org.springframework.batch.item.file.builder.FlatFileItemReaderBuilder.FixedLengthBuilder
 
FixedLengthTokenizer - Class in org.springframework.batch.item.file.transform
Tokenizer used to process data obtained from files with fixed-length format.
FixedLengthTokenizer() - Constructor for class org.springframework.batch.item.file.transform.FixedLengthTokenizer
 
FlatFileFooterCallback - Interface in org.springframework.batch.item.file
Callback interface for writing a footer to a file.
FlatFileFormatException - Exception in org.springframework.batch.item.file.transform
Exception indicating that some type of error has occurred while attempting to parse a line of input into tokens.
FlatFileFormatException(String, String) - Constructor for exception org.springframework.batch.item.file.transform.FlatFileFormatException
Create a new FlatFileFormatException based on a message.
FlatFileFormatException(String) - Constructor for exception org.springframework.batch.item.file.transform.FlatFileFormatException
Create a new FlatFileFormatException based on a message.
FlatFileFormatException(String, Throwable) - Constructor for exception org.springframework.batch.item.file.transform.FlatFileFormatException
Create a new FlatFileFormatException based on a message and another exception.
FlatFileHeaderCallback - Interface in org.springframework.batch.item.file
Callback interface for writing a header to a file.
FlatFileItemReader<T> - Class in org.springframework.batch.item.file
Restartable ItemReader that reads lines from input FlatFileItemReader.setResource(Resource).
FlatFileItemReader() - Constructor for class org.springframework.batch.item.file.FlatFileItemReader
 
FlatFileItemReaderBuilder<T> - Class in org.springframework.batch.item.file.builder
A builder implementation for the FlatFileItemReader.
FlatFileItemReaderBuilder() - Constructor for class org.springframework.batch.item.file.builder.FlatFileItemReaderBuilder
 
FlatFileItemReaderBuilder.DelimitedBuilder<T> - Class in org.springframework.batch.item.file.builder
A builder for constructing a DelimitedLineTokenizer
FlatFileItemReaderBuilder.FixedLengthBuilder<T> - Class in org.springframework.batch.item.file.builder
A builder for constructing a FixedLengthTokenizer
FlatFileItemWriter<T> - Class in org.springframework.batch.item.file
This class is an item writer that writes data to a file or stream.
FlatFileItemWriter() - Constructor for class org.springframework.batch.item.file.FlatFileItemWriter
 
FlatFileItemWriterBuilder<T> - Class in org.springframework.batch.item.file.builder
A builder implementation for the FlatFileItemWriter
FlatFileItemWriterBuilder() - Constructor for class org.springframework.batch.item.file.builder.FlatFileItemWriterBuilder
 
FlatFileItemWriterBuilder.DelimitedBuilder<T> - Class in org.springframework.batch.item.file.builder
A builder for constructing a DelimitedLineAggregator
FlatFileItemWriterBuilder.FormattedBuilder<T> - Class in org.springframework.batch.item.file.builder
A builder for constructing a FormatterLineAggregator.
FlatFileParseException - Exception in org.springframework.batch.item.file
Exception thrown when errors are encountered parsing flat files.
FlatFileParseException(String, String) - Constructor for exception org.springframework.batch.item.file.FlatFileParseException
 
FlatFileParseException(String, String, int) - Constructor for exception org.springframework.batch.item.file.FlatFileParseException
 
FlatFileParseException(String, Throwable, String, int) - Constructor for exception org.springframework.batch.item.file.FlatFileParseException
 
flow() - Method in class org.springframework.batch.core.job.builder.FlowBuilder
 
flow(Flow) - Method in class org.springframework.batch.core.job.builder.FlowJobBuilder
Provide a single flow to execute as the job.
flow(Step) - Method in class org.springframework.batch.core.job.builder.JobBuilder
Create a new job builder that will execute a step or sequence of steps.
Flow - Interface in org.springframework.batch.core.job.flow
 
flow - Variable in class org.springframework.batch.core.job.flow.FlowJob
 
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(Flow) - Method in class org.springframework.batch.integration.partition.RemotePartitioningWorkerStepBuilder
 
FLOW_ELE - Static variable in class org.springframework.batch.core.configuration.xml.AbstractFlowParser
 
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(String, Exception) - Constructor for exception org.springframework.batch.core.job.builder.FlowBuilderException
 
FlowBuilderException(Exception) - Constructor for exception org.springframework.batch.core.job.builder.FlowBuilderException
 
FlowBuilderException(String) - Constructor for exception org.springframework.batch.core.job.builder.FlowBuilderException
 
FlowElementParser - Class in org.springframework.batch.core.configuration.xml
Internal parser for the <flow/> elements inside a job.
FlowElementParser() - Constructor for class org.springframework.batch.core.configuration.xml.FlowElementParser
 
FlowExecution - Class in org.springframework.batch.core.job.flow
 
FlowExecution(String, FlowExecutionStatus) - Constructor for class org.springframework.batch.core.job.flow.FlowExecution
 
FlowExecutionAggregator - Interface in org.springframework.batch.core.job.flow.support.state
Strategy interface for aggregating FlowExecution instances into a single exit status.
FlowExecutionException - Exception in org.springframework.batch.core.job.flow
 
FlowExecutionException(String) - Constructor for exception org.springframework.batch.core.job.flow.FlowExecutionException
 
FlowExecutionException(String, Throwable) - Constructor for exception org.springframework.batch.core.job.flow.FlowExecutionException
 
FlowExecutionStatus - Class in org.springframework.batch.core.job.flow
Represents the status of FlowExecution.
FlowExecutionStatus(String) - Constructor for class org.springframework.batch.core.job.flow.FlowExecutionStatus
 
FlowExecutor - Interface in org.springframework.batch.core.job.flow
Context and execution strategy for FlowJob to allow it to delegate its execution step by step.
FlowHolder - Interface in org.springframework.batch.core.job.flow
Convenient interface for components that contain nested flows.
FlowJob - Class in org.springframework.batch.core.job.flow
Implementation of the Job interface that allows for complex flows of steps, rather than requiring sequential execution.
FlowJob() - Constructor for class org.springframework.batch.core.job.flow.FlowJob
Create a FlowJob with null name and no flow (invalid state).
FlowJob(String) - Constructor for class org.springframework.batch.core.job.flow.FlowJob
Create a FlowJob with provided name and no flow (invalid state).
FlowJobBuilder - Class in org.springframework.batch.core.job.builder
A job builder for FlowJob instances.
FlowJobBuilder(JobBuilderHelper<?>) - Constructor for class org.springframework.batch.core.job.builder.FlowJobBuilder
Create a new builder initialized with any properties in the parent.
FlowParser - Class in org.springframework.batch.core.jsr.configuration.xml
Parses flows as defined in JSR-352.
FlowParser(String, String) - Constructor for class org.springframework.batch.core.jsr.configuration.xml.FlowParser
 
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.
flush() - Method in class org.springframework.batch.item.kafka.KafkaItemWriter
 
flush() - Method in class org.springframework.batch.item.KeyValueItemWriter
Flush items to the key/value store.
flush() - Method in class org.springframework.batch.support.transaction.TransactionAwareBufferedWriter
 
FlushFailedException - Exception in org.springframework.batch.support.transaction
Unchecked exception indicating that an error has occurred while trying to flush a buffer.
FlushFailedException(String, Throwable) - Constructor for exception org.springframework.batch.support.transaction.FlushFailedException
Create a new FlushFailedException based on a message and another exception.
FlushFailedException(String) - Constructor for exception org.springframework.batch.support.transaction.FlushFailedException
Create a new FlushFailedException based on a message.
footerCallback(FlatFileFooterCallback) - Method in class org.springframework.batch.item.file.builder.FlatFileItemWriterBuilder
A callback for footer processing
footerCallback(FlatFileFooterCallback) - Method in class org.springframework.batch.item.json.builder.JsonFileItemWriterBuilder
A callback for footer processing.
footerCallback(StaxWriterCallback) - Method in class org.springframework.batch.item.xml.builder.StaxEventItemWriterBuilder
A StaxWriterCallback to provide any footer elements
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
 
forceSync(boolean) - Method in class org.springframework.batch.item.file.builder.FlatFileItemWriterBuilder
A flag indicating that changes should be force-synced to disk on flush.
forceSync(boolean) - Method in class org.springframework.batch.item.json.builder.JsonFileItemWriterBuilder
A flag indicating that changes should be force-synced to disk on flush.
forceSync(boolean) - Method in class org.springframework.batch.item.xml.builder.StaxEventItemWriterBuilder
Flag to indicate that changes should be force-synced to disk on flush.
format(String) - Method in class org.springframework.batch.item.file.builder.FlatFileItemWriterBuilder.FormattedBuilder
Set the format string used to aggregate items
formatDuration(Duration) - Static method in class org.springframework.batch.core.metrics.BatchMetrics
Format a duration in a human readable format like: 2h32m15s10ms.
formatted() - Method in class org.springframework.batch.item.file.builder.FlatFileItemWriterBuilder
FormattedBuilder(FlatFileItemWriterBuilder<T>) - Constructor for class org.springframework.batch.item.file.builder.FlatFileItemWriterBuilder.FormattedBuilder
 
FormatterLineAggregator<T> - Class in org.springframework.batch.item.file.transform
A LineAggregator implementation which produces a String by aggregating the provided item via the Formatter syntax.
FormatterLineAggregator() - Constructor for class org.springframework.batch.item.file.transform.FormatterLineAggregator
 
FragmentEventReader - Interface in org.springframework.batch.item.xml.stax
Interface for event readers which support treating XML fragments as standalone XML documents by wrapping the fragments with StartDocument and EndDocument events.
from(Step) - Method in class org.springframework.batch.core.job.builder.FlowBuilder
Go back to a previously registered step and start a new path.
from(JobExecutionDecider) - Method in class org.springframework.batch.core.job.builder.FlowBuilder
Start again from a decision that was already registered.
from(Flow) - Method in class org.springframework.batch.core.job.builder.FlowBuilder
Start again from a subflow that was already registered.
fromClause(String) - Method in class org.springframework.batch.item.database.builder.JdbcPagingItemReaderBuilder
The SQL FROM clause for a db specific PagingQueryProvider.
fromMetaData(DataSource) - Static method in enum org.springframework.batch.support.DatabaseType
Convenience method that pulls a database product name from the DataSource's metadata.
fromProductName(String) - Static method in enum org.springframework.batch.support.DatabaseType
Static method to obtain a DatabaseType from the provided product name.
fromPropertyName(String) - Static method in enum org.springframework.batch.core.jsr.JsrJobListenerMetaData
Return the relevant meta data for the provided property name.
fromPropertyName(String) - Static method in enum org.springframework.batch.core.jsr.JsrStepListenerMetaData
Return the relevant meta data for the provided property name.
fromPropertyName(String) - Static method in enum org.springframework.batch.core.listener.JobListenerMetaData
Return the relevant meta data for the provided property name.
fromPropertyName(String) - Static method in enum org.springframework.batch.core.listener.StepListenerMetaData
Return the relevant meta data for the provided property name.
function() - Method in class org.springframework.batch.item.database.builder.StoredProcedureItemReaderBuilder
Indicates the stored procedure is a function
FunctionItemProcessor<I,O> - Class in org.springframework.batch.item.function
An ItemProcessor implementation that delegates to a Function
FunctionItemProcessor(Function<I, O>) - Constructor for class org.springframework.batch.item.function.FunctionItemProcessor
 

G

GemfireItemWriter<K,V> - Class in org.springframework.batch.item.data
An ItemWriter that stores items in GemFire
GemfireItemWriter() - Constructor for class org.springframework.batch.item.data.GemfireItemWriter
 
GemfireItemWriterBuilder<K,V> - Class in org.springframework.batch.item.data.builder
A builder implementation for the GemfireItemWriter
GemfireItemWriterBuilder() - Constructor for class org.springframework.batch.item.data.builder.GemfireItemWriterBuilder
 
generateFirstPageQuery(int) - Method in interface org.springframework.batch.item.database.PagingQueryProvider
Generate the query that will provide the first page, limited by the page size.
generateFirstPageQuery(int) - Method in class org.springframework.batch.item.database.support.AbstractSqlPagingQueryProvider
Method generating the query string to be used for retrieving the first page.
generateFirstPageQuery(int) - Method in class org.springframework.batch.item.database.support.Db2PagingQueryProvider
 
generateFirstPageQuery(int) - Method in class org.springframework.batch.item.database.support.H2PagingQueryProvider
 
generateFirstPageQuery(int) - Method in class org.springframework.batch.item.database.support.HsqlPagingQueryProvider
 
generateFirstPageQuery(int) - Method in class org.springframework.batch.item.database.support.MySqlPagingQueryProvider
 
generateFirstPageQuery(int) - Method in class org.springframework.batch.item.database.support.OraclePagingQueryProvider
 
generateFirstPageQuery(int) - Method in class org.springframework.batch.item.database.support.PostgresPagingQueryProvider
 
generateFirstPageQuery(int) - Method in class org.springframework.batch.item.database.support.SqlitePagingQueryProvider
 
generateFirstPageQuery(int) - Method in class org.springframework.batch.item.database.support.SqlServerPagingQueryProvider
 
generateFirstPageQuery(int) - Method in class org.springframework.batch.item.database.support.SqlWindowingPagingQueryProvider
 
generateFirstPageQuery(int) - Method in class org.springframework.batch.item.database.support.SybasePagingQueryProvider
 
generateGroupedTopSqlQuery(AbstractSqlPagingQueryProvider, boolean, String) - Static method in class org.springframework.batch.item.database.support.SqlPagingQueryUtils
Generate SQL query string using a TOP clause
generateJumpToItemQuery(int, int) - Method in interface org.springframework.batch.item.database.PagingQueryProvider
Generate the query that will provide the jump to item query.
generateJumpToItemQuery(int, int) - Method in class org.springframework.batch.item.database.support.AbstractSqlPagingQueryProvider
Method generating the query string to be used for jumping to a specific item position.
generateJumpToItemQuery(int, int) - Method in class org.springframework.batch.item.database.support.H2PagingQueryProvider
 
generateJumpToItemQuery(int, int) - Method in class org.springframework.batch.item.database.support.HsqlPagingQueryProvider
 
generateJumpToItemQuery(int, int) - Method in class org.springframework.batch.item.database.support.MySqlPagingQueryProvider
 
generateJumpToItemQuery(int, int) - Method in class org.springframework.batch.item.database.support.OraclePagingQueryProvider
 
generateJumpToItemQuery(int, int) - Method in class org.springframework.batch.item.database.support.PostgresPagingQueryProvider
 
generateJumpToItemQuery(int, int) - Method in class org.springframework.batch.item.database.support.SqlitePagingQueryProvider
 
generateJumpToItemQuery(int, int) - Method in class org.springframework.batch.item.database.support.SqlWindowingPagingQueryProvider
 
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.
generateLimitCypherQuery() - Method in class org.springframework.batch.item.data.AbstractNeo4jItemReader
Deprecated.
 
generateLimitGroupedSqlQuery(AbstractSqlPagingQueryProvider, boolean, String) - Static method in class org.springframework.batch.item.database.support.SqlPagingQueryUtils
Generate SQL query string using a LIMIT clause
generateLimitJumpToQuery(AbstractSqlPagingQueryProvider, String) - Static method in class org.springframework.batch.item.database.support.SqlPagingQueryUtils
Generate SQL query string using a LIMIT clause
generateLimitSqlQuery(AbstractSqlPagingQueryProvider, boolean, String) - Static method in class org.springframework.batch.item.database.support.SqlPagingQueryUtils
Generate SQL query string using a LIMIT clause
generateRemainingPagesQuery(int) - Method in interface org.springframework.batch.item.database.PagingQueryProvider
Generate the query that will provide the first page, limited by the page size.
generateRemainingPagesQuery(int) - Method in class org.springframework.batch.item.database.support.AbstractSqlPagingQueryProvider
Method generating the query string to be used for retrieving the pages following the first page.
generateRemainingPagesQuery(int) - Method in class org.springframework.batch.item.database.support.Db2PagingQueryProvider
 
generateRemainingPagesQuery(int) - Method in class org.springframework.batch.item.database.support.H2PagingQueryProvider
 
generateRemainingPagesQuery(int) - Method in class org.springframework.batch.item.database.support.HsqlPagingQueryProvider
 
generateRemainingPagesQuery(int) - Method in class org.springframework.batch.item.database.support.MySqlPagingQueryProvider
 
generateRemainingPagesQuery(int) - Method in class org.springframework.batch.item.database.support.OraclePagingQueryProvider
 
generateRemainingPagesQuery(int) - Method in class org.springframework.batch.item.database.support.PostgresPagingQueryProvider
 
generateRemainingPagesQuery(int) - Method in class org.springframework.batch.item.database.support.SqlitePagingQueryProvider
 
generateRemainingPagesQuery(int) - Method in class org.springframework.batch.item.database.support.SqlServerPagingQueryProvider
 
generateRemainingPagesQuery(int) - Method in class org.springframework.batch.item.database.support.SqlWindowingPagingQueryProvider
 
generateRemainingPagesQuery(int) - Method in class org.springframework.batch.item.database.support.SybasePagingQueryProvider
 
generateRowNumSqlQuery(AbstractSqlPagingQueryProvider, boolean, String) - Static method in class org.springframework.batch.item.database.support.SqlPagingQueryUtils
Generate SQL query string using a ROW_NUM condition
generateRowNumSqlQuery(AbstractSqlPagingQueryProvider, String, boolean, String) - Static method in class org.springframework.batch.item.database.support.SqlPagingQueryUtils
Generate SQL query string using a ROW_NUM condition
generateRowNumSqlQueryWithNesting(AbstractSqlPagingQueryProvider, String, boolean, String) - Static method in class org.springframework.batch.item.database.support.SqlPagingQueryUtils
 
generateRowNumSqlQueryWithNesting(AbstractSqlPagingQueryProvider, String, String, boolean, String) - Static method in class org.springframework.batch.item.database.support.SqlPagingQueryUtils
 
generateTopJumpToQuery(AbstractSqlPagingQueryProvider, String) - Static method in class org.springframework.batch.item.database.support.SqlPagingQueryUtils
Generate SQL query string using a TOP clause
generateTopSqlQuery(AbstractSqlPagingQueryProvider, boolean, String) - Static method in class org.springframework.batch.item.database.support.SqlPagingQueryUtils
Generate SQL query string using a TOP clause
GenericApplicationContextFactory - Class in org.springframework.batch.core.configuration.support
ApplicationContextFactory implementation that takes a parent context and a path to the context to create.
GenericApplicationContextFactory(Object...) - Constructor for class org.springframework.batch.core.configuration.support.GenericApplicationContextFactory
Create an application context factory for the resource specified.
get(String) - Method in class org.springframework.batch.core.configuration.annotation.JobBuilderFactory
Creates a job builder and initializes its job repository.
get(String) - Method in class org.springframework.batch.core.configuration.annotation.StepBuilderFactory
Creates a step builder and initializes its job repository and transaction manager.
get(String, ObjectFactory<?>) - Method in class org.springframework.batch.core.scope.JobScope
 
get(String, ObjectFactory<?>) - Method in class org.springframework.batch.core.scope.StepScope
 
get(String) - Method in class org.springframework.batch.integration.chunk.RemoteChunkingManagerStepBuilderFactory
Creates a RemoteChunkingManagerStepBuilder and initializes its job repository and transaction manager.
get(String) - Method in class org.springframework.batch.integration.chunk.RemoteChunkingMasterStepBuilderFactory
Deprecated.
Creates a RemoteChunkingMasterStepBuilder and initializes its job repository and transaction manager.
get(String) - Method in class org.springframework.batch.integration.partition.RemotePartitioningManagerStepBuilderFactory
Creates a RemotePartitioningManagerStepBuilder and initializes its job repository, job explorer, bean factory and transaction manager.
get(String) - Method in class org.springframework.batch.integration.partition.RemotePartitioningMasterStepBuilderFactory
Deprecated.
Creates a RemotePartitioningMasterStepBuilder and initializes its job repository, job explorer, bean factory and transaction manager.
get(String) - Method in class org.springframework.batch.integration.partition.RemotePartitioningWorkerStepBuilderFactory
Creates a RemotePartitioningWorkerStepBuilder and initializes its job repository, job explorer, bean factory and transaction manager.
get(String) - Method in class org.springframework.batch.item.ExecutionContext
Getter for the value represented by the provided key.
getActualCount() - Method in exception org.springframework.batch.item.file.transform.IncorrectTokenCountException
 
getActualLength() - Method in exception org.springframework.batch.item.file.transform.IncorrectLineLengthException
Retrieves the actual length that was recorded for this exception.
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 org.springframework.batch.core.jsr.JsrJobListenerMetaData
 
getAnnotation() - Method in enum org.springframework.batch.core.jsr.JsrStepListenerMetaData
 
getAnnotation() - Method in enum org.springframework.batch.core.listener.JobListenerMetaData
 
getAnnotation() - Method in interface org.springframework.batch.core.listener.ListenerMetaData
 
getAnnotation() - Method in enum org.springframework.batch.core.listener.StepListenerMetaData
 
getApplicationContext() - Method in class org.springframework.batch.test.AbstractJobTests
Deprecated.
 
getArguments() - Method in class org.springframework.batch.item.adapter.AbstractMethodInvokingDelegator
Return arguments.
getArtifactProperties(String) - Method in class org.springframework.batch.core.jsr.configuration.support.BatchPropertyContext
Obtains the batch Properties for the provided artifact name.
getAsText() - Method in class org.springframework.batch.item.file.transform.RangeArrayPropertyEditor
 
getAttribute(String, String, ConfigurableListableBeanFactory) - Static method in class org.springframework.batch.core.configuration.xml.BeanDefinitionUtils
 
getAttribute(String) - Method in class org.springframework.batch.repeat.context.SynchronizedAttributeAccessor
 
getBatchStatus() - Method in enum org.springframework.batch.core.BatchStatus
Converts the current status to the JSR-352 equivalent
getBatchStatus() - Method in class org.springframework.batch.core.jsr.JsrJobContext
 
getBatchStatus() - Method in class org.springframework.batch.core.jsr.JsrJobExecution
 
getBatchStatus() - Method in class org.springframework.batch.core.jsr.JsrStepContext
 
getBatchStatus() - Method in class org.springframework.batch.core.jsr.JsrStepExecution
 
getBatchStatusFromEndTransitionName(String) - Static method in class org.springframework.batch.core.configuration.xml.AbstractFlowParser
 
getBeanClass(Element) - Method in class org.springframework.batch.core.configuration.xml.AbstractFlowParser
 
getBeanClass() - Method in class org.springframework.batch.core.configuration.xml.AbstractListenerParser
 
getBeanClass() - Method in class org.springframework.batch.core.configuration.xml.JobExecutionListenerParser
 
getBeanClass(Element) - Method in class org.springframework.batch.core.configuration.xml.JobParser
 
getBeanClass() - Method in class org.springframework.batch.core.configuration.xml.StepListenerParser
 
getBeanClass(Element) - Method in class org.springframework.batch.core.configuration.xml.TopLevelJobListenerParser
 
getBeanClass(Element) - Method in class org.springframework.batch.core.configuration.xml.TopLevelStepListenerParser
 
getBeanClass(Element) - Method in class org.springframework.batch.core.jsr.configuration.xml.FlowParser
 
getBeanClass(Element) - Method in class org.springframework.batch.core.jsr.configuration.xml.JsrJobParser
 
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.
getBufferSize() - Method in class org.springframework.batch.support.transaction.TransactionAwareBufferedWriter
Convenience method for clients to determine if there is any unflushed data.
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
 
getChunkSize() - Method in class org.springframework.batch.repeat.policy.SimpleCompletionPolicy
 
getClobTypeToUse() - Method in class org.springframework.batch.core.repository.dao.AbstractJdbcBatchMetadataDao
 
getCloseSuppressingConnectionProxy(Connection) - Method in class org.springframework.batch.item.database.ExtendedConnectionDataSourceProxy
Wrap the given Connection with a proxy that delegates every method call to it but suppresses close calls.
getCode() - Method in class org.springframework.batch.core.job.flow.support.state.EndState
 
getCode() - Method in enum org.springframework.batch.item.file.transform.Alignment
Deprecated.
 
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
 
getConfigurer(Collection<BatchConfigurer>) - Method in class org.springframework.batch.core.configuration.annotation.AbstractBatchConfiguration
 
getConnection() - Method in class org.springframework.batch.item.database.ExtendedConnectionDataSourceProxy
 
getConnection(String, String) - Method in class org.springframework.batch.item.database.ExtendedConnectionDataSourceProxy
 
getContext() - Method in class org.springframework.batch.core.jsr.launch.JsrJobOperator.BaseContextHolder
 
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.
getContext() - Static method in class org.springframework.batch.repeat.support.RepeatSynchronizationManager
Getter for the current context.
getConversationId() - Method in class org.springframework.batch.core.scope.JobScope
 
getConversationId() - Method in class org.springframework.batch.core.scope.StepScope
 
getCount() - Method in class org.springframework.batch.repeat.context.RepeatContextCounter
 
getCount(RepeatContext) - Method in class org.springframework.batch.repeat.policy.CountingCompletionPolicy
Extension point for subclasses.
getCounter() - Method in class org.springframework.batch.repeat.policy.CountingCompletionPolicy.CountingBatchContext
 
getCreateTime() - Method in class org.springframework.batch.core.JobExecution
 
getCreateTime() - Method in class org.springframework.batch.core.jsr.JsrJobExecution
 
getCurrent() - Method in class org.springframework.batch.core.scope.context.SynchronizationManagerSupport
 
getCurrentItemCount() - Method in class org.springframework.batch.item.support.AbstractItemCountingItemStreamItemReader
 
getCurrentResource() - Method in class org.springframework.batch.item.file.MultiResourceItemReader
Deprecated.
In favor of using ResourceAware instead.
getDataFieldMaxValueIncrementer() - Method in class org.springframework.batch.core.launch.support.DataFieldMaxValueJobParametersIncrementer
Get the incrementer.
getDataSource() - Method in class org.springframework.batch.item.database.AbstractCursorItemReader
Public getter for the data source.
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.
getDefaultExitStatusForFailure(Throwable, JobExecution) - Method in class org.springframework.batch.core.jsr.job.flow.JsrFlowJob
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 Long represented by the provided key.
getDouble(String, double) - Method in class org.springframework.batch.core.JobParameters
Deprecated.
Use JobParameters.getDouble(java.lang.String, java.lang.Double) instead. This method will be removed in a future release.
getDouble(String, Double) - Method in class org.springframework.batch.core.JobParameters
Typesafe Getter for the Double represented by the provided key.
getDouble(String) - Method in class org.springframework.batch.item.ExecutionContext
Typesafe Getter for the Double represented by the provided key.
getDouble(String, double) - Method in class org.springframework.batch.item.ExecutionContext
Typesafe Getter for the Double represented by the provided key with default value to return if key is not represented.
getEncoding() - Method in class org.springframework.batch.item.xml.StaxEventItemWriter
Get used encoding.
getEndTime() - Method in class org.springframework.batch.core.JobExecution
 
getEndTime() - Method in class org.springframework.batch.core.jsr.JsrJobExecution
 
getEndTime() - Method in class org.springframework.batch.core.jsr.JsrStepExecution
 
getEndTime() - Method in class org.springframework.batch.core.StepExecution
Returns the time that this execution ended or null if the step is running.
getEntityManager() - Method in class org.springframework.batch.item.database.orm.AbstractJpaQueryProvider
Getter for EntityManager
getErrorMessage() - Static method in class org.springframework.batch.core.launch.support.CommandLineJobRunner
Retrieve the error message set by an instance of CommandLineJobRunner as it exits.
getErrors() - Static method in class org.springframework.batch.core.launch.support.JobRegistryBackgroundJobRunner
Public getter for the startup errors encountered during parent context creation.
getErrors() - Method in class org.springframework.batch.core.step.item.Chunk
 
getException() - Method in class org.springframework.batch.core.jsr.JsrStepContext
To support both JSR-352's requirement to return the most recent exception and Spring Batch's support for Throwable, this implementation will return the most recent exception in the underlying StepExecution's failure exceptions list.
getException() - Method in class org.springframework.batch.core.step.item.SkipWrapper
Public getter for the exception.
getExceptionHandler() - Method in class org.springframework.batch.core.step.builder.AbstractTaskletStepBuilder
Convenience method for subclasses to access the exception handler that was injected by user.
getExceptionHandler() - Method in class org.springframework.batch.core.step.factory.SimpleStepFactoryBean
Protected getter for the ExceptionHandler.
getExceptionTranslator() - Method in class org.springframework.batch.item.database.AbstractCursorItemReader
Creates a default SQLErrorCodeSQLExceptionTranslator for the specified DataSource if none is set.
getExecutionContext() - Method in class org.springframework.batch.core.JobExecution
Returns the ExecutionContext for this execution.
getExecutionContext(JobExecution) - Method in interface org.springframework.batch.core.repository.dao.ExecutionContextDao
 
getExecutionContext(StepExecution) - Method in interface org.springframework.batch.core.repository.dao.ExecutionContextDao
 
getExecutionContext(JobExecution) - Method in class org.springframework.batch.core.repository.dao.JdbcExecutionContextDao
 
getExecutionContext(StepExecution) - Method in class org.springframework.batch.core.repository.dao.JdbcExecutionContextDao
 
getExecutionContext(StepExecution) - Method in class org.springframework.batch.core.repository.dao.MapExecutionContextDao
Deprecated.
 
getExecutionContext(JobExecution) - Method in class org.springframework.batch.core.repository.dao.MapExecutionContextDao
Deprecated.
 
getExecutionContext() - Method in class org.springframework.batch.core.StepExecution
Returns the ExecutionContext for this execution
getExecutionContextDao() - Method in class org.springframework.batch.core.repository.support.MapJobRepositoryFactoryBean
Deprecated.
 
getExecutionContextKey(String) - Method in class org.springframework.batch.item.ItemStreamSupport
 
getExecutionId() - Method in class org.springframework.batch.core.jsr.JsrJobContext
 
getExecutionId() - Method in class org.springframework.batch.core.jsr.JsrJobExecution
 
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.jsr.JsrJobContext
 
getExitStatus() - Method in class org.springframework.batch.core.jsr.JsrJobExecution
 
getExitStatus() - Method in class org.springframework.batch.core.jsr.JsrStepContext
 
getExitStatus() - Method in class org.springframework.batch.core.jsr.JsrStepExecution
 
getExitStatus(int) - Method in class org.springframework.batch.core.step.tasklet.ConfigurableSystemProcessExitCodeMapper
 
getExitStatus(int) - Method in class org.springframework.batch.core.step.tasklet.SimpleSystemProcessExitCodeMapper
 
getExitStatus(int) - Method in interface org.springframework.batch.core.step.tasklet.SystemProcessExitCodeMapper
 
getExitStatus() - Method in class org.springframework.batch.core.StepContribution
Public getter for the status.
getExitStatus() - Method in class org.springframework.batch.core.StepExecution
 
getExpectedCount() - Method in exception org.springframework.batch.item.file.transform.IncorrectTokenCountException
 
getExpectedLength() - Method in exception org.springframework.batch.item.file.transform.IncorrectLineLengthException
Retrieves the expected length that was recorded for this exception.
getFailureExceptions() - Method in class org.springframework.batch.core.JobExecution
 
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
 
getFaultTolerantStepBuilder(String) - Method in class org.springframework.batch.core.jsr.configuration.xml.StepFactoryBean
 
getFieldCount() - Method in class org.springframework.batch.item.file.transform.DefaultFieldSet
 
getFieldCount() - Method in interface org.springframework.batch.item.file.transform.FieldSet
Return the number of fields in this 'FieldSet'.
getFilterCount(Chunk<I>, Chunk<O>) - Method in class org.springframework.batch.core.step.item.FaultTolerantChunkProcessor
 
getFilterCount(Chunk<I>, Chunk<O>) - Method in class org.springframework.batch.core.step.item.SimpleChunkProcessor
Extension point for subclasses to calculate the filter count.
getFilterCount() - Method in class org.springframework.batch.core.StepContribution
Public getter for the filter counter.
getFilterCount() - Method in class org.springframework.batch.core.StepExecution
Returns the current number of items filtered out of this execution
getFlows() - Method in 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
 
getForwardOnlyCursor(int, Map<String, Object>) - Method in class org.springframework.batch.item.database.HibernateItemReaderHelper
Get a cursor over all of the results, with the forward-only flag set.
getFromClause() - Method in class org.springframework.batch.item.database.support.AbstractSqlPagingQueryProvider
 
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
 
getGroupClause() - Method in class org.springframework.batch.item.database.support.AbstractSqlPagingQueryProvider
The getter for the group by clause
getGroupName(BeanDefinition, Job) - Method in class org.springframework.batch.core.configuration.support.JobRegistryBeanPostProcessor
Determine a group name for the job to be registered.
getId() - Method in class org.springframework.batch.core.Entity
 
getId() - Method in class org.springframework.batch.core.scope.context.JobContext
 
getId() - Method in class org.springframework.batch.core.scope.context.StepContext
 
getIncrementer(String, String) - Method in interface org.springframework.batch.item.database.support.DataFieldMaxValueIncrementerFactory
Return the DataFieldMaxValueIncrementer for the provided database type.
getIncrementer(String, String) - Method in class org.springframework.batch.item.database.support.DefaultDataFieldMaxValueIncrementerFactory
 
getInput() - Method in exception org.springframework.batch.item.file.FlatFileParseException
 
getInput() - Method in exception org.springframework.batch.item.file.NonTransientFlatFileException
 
getInput() - Method in exception org.springframework.batch.item.file.transform.FlatFileFormatException
Retrieve the input that caused this exception.
getInput() - Method in exception org.springframework.batch.item.file.transform.IncorrectTokenCountException
 
getInputChannelAttributeName() - Method in class org.springframework.batch.integration.config.xml.JobLaunchingGatewayParser
 
getInstance() - Static method in class org.springframework.batch.core.jsr.launch.JsrJobOperator.BaseContextHolder
 
getInstanceId() - Method in class org.springframework.batch.core.JobInstance
 
getInstanceId() - Method in class org.springframework.batch.core.jsr.JsrJobContext
 
getInt(String) - Method in class org.springframework.batch.item.ExecutionContext
Typesafe Getter for the Integer represented by the provided key.
getInt(String, int) - Method in class org.springframework.batch.item.ExecutionContext
Typesafe Getter for the Integer represented by the provided key with default value to return if key is not represented.
getItem() - Method in class org.springframework.batch.core.step.item.SkipWrapper
Public getter for the item.
getItemListeners() - Method in class org.springframework.batch.core.step.builder.SimpleStepBuilder
 
getItemProcessor() - Method in class org.springframework.batch.core.step.factory.SimpleStepFactoryBean
Protected getter for the ItemProcessor for subclasses to use
getItemReader() - Method in class org.springframework.batch.core.step.factory.SimpleStepFactoryBean
Protected getter for the ItemReader for subclasses to use.
getItems() - Method in class org.springframework.batch.core.step.item.Chunk
 
getItems() - Method in class org.springframework.batch.integration.chunk.ChunkRequest
 
getItemWriter() - Method in class org.springframework.batch.core.step.factory.SimpleStepFactoryBean
Protected getter for the ItemWriter for subclasses to use
getJdbcTemplate() - Method in class org.springframework.batch.core.repository.dao.AbstractJdbcBatchMetadataDao
 
getJob(String) - Method in interface org.springframework.batch.core.configuration.JobLocator
Locates a Job at runtime.
getJob(String) - Method in class org.springframework.batch.core.configuration.support.MapJobRegistry
 
getJob() - Method in class org.springframework.batch.integration.launch.JobLaunchRequest
 
getJob() - Method in class org.springframework.batch.test.AbstractJobTests
Deprecated.
 
getJob() - Method in class org.springframework.batch.test.JobLauncherTestUtils
 
getJobConfigurationName() - Method in class org.springframework.batch.core.JobExecution
 
getJobExecution(Long) - Method in interface org.springframework.batch.core.explore.JobExplorer
Retrieve a JobExecution by its id.
getJobExecution(Long) - Method in class org.springframework.batch.core.explore.support.SimpleJobExplorer
 
getJobExecution() - Method in interface org.springframework.batch.core.job.flow.FlowExecutor
 
getJobExecution() - Method in class org.springframework.batch.core.job.flow.JobFlowExecutor
 
getJobExecution(long) - Method in class org.springframework.batch.core.jsr.launch.JsrJobOperator
 
getJobExecution(Long) - Method in class org.springframework.batch.core.repository.dao.JdbcJobExecutionDao
 
getJobExecution(Long) - Method in interface org.springframework.batch.core.repository.dao.JobExecutionDao
 
getJobExecution(Long) - Method in class org.springframework.batch.core.repository.dao.MapJobExecutionDao
Deprecated.
 
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(TestContext) - Method in class org.springframework.batch.test.JobScopeTestExecutionListener
Discover a JobExecution as a field in the test case or create one if none is available.
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.repository.support.MapJobRepositoryFactoryBean
Deprecated.
 
getJobExecutionId() - Method in class org.springframework.batch.core.StepExecution
Accessor for the job execution id.
getJobExecutionId() - Method in class org.springframework.batch.integration.partition.StepExecutionRequest
 
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
 
getJobExecutions(JobInstance) - Method in class org.springframework.batch.core.jsr.launch.JsrJobOperator
 
getJobExplorer() - Method in interface org.springframework.batch.core.configuration.annotation.BatchConfigurer
 
getJobExplorer() - Method in class org.springframework.batch.core.configuration.annotation.DefaultBatchConfigurer
 
getJobId() - Method in class org.springframework.batch.core.JobExecution
Convenience getter for for the id of the enclosing job.
getJobId() - Method in class org.springframework.batch.integration.chunk.ChunkRequest
 
getJobId() - Method in class org.springframework.batch.integration.chunk.ChunkResponse
 
getJobInstance(Long) - Method in interface org.springframework.batch.core.explore.JobExplorer
 
getJobInstance(Long) - Method in class org.springframework.batch.core.explore.support.SimpleJobExplorer
 
getJobInstance() - Method in class org.springframework.batch.core.JobExecution
 
getJobInstance(long) - Method in class org.springframework.batch.core.jsr.launch.JsrJobOperator
 
getJobInstance(String, JobParameters) - Method in class org.springframework.batch.core.repository.dao.JdbcJobInstanceDao
The job table is queried for any jobs that match the given identifier, adding them to a list via the RowMapper callback.
getJobInstance(Long) - Method in class org.springframework.batch.core.repository.dao.JdbcJobInstanceDao
 
getJobInstance(JobExecution) - Method in class org.springframework.batch.core.repository.dao.JdbcJobInstanceDao
 
getJobInstance(String, JobParameters) - Method in interface org.springframework.batch.core.repository.dao.JobInstanceDao
Find the job instance that matches the given name and parameters.
getJobInstance(Long) - Method in interface org.springframework.batch.core.repository.dao.JobInstanceDao
Fetch the job instance with the provided identifier.
getJobInstance(JobExecution) - Method in interface org.springframework.batch.core.repository.dao.JobInstanceDao
Fetch the JobInstance for the provided JobExecution.
getJobInstance(String, JobParameters) - Method in class org.springframework.batch.core.repository.dao.MapJobInstanceDao
Deprecated.
 
getJobInstance(Long) - Method in class org.springframework.batch.core.repository.dao.MapJobInstanceDao
Deprecated.
 
getJobInstance(JobExecution) - Method in class org.springframework.batch.core.repository.dao.MapJobInstanceDao
Deprecated.
 
getJobInstanceCount(String) - Method in interface org.springframework.batch.core.explore.JobExplorer
Query the repository for the number of unique JobInstances 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.jsr.launch.JsrJobOperator
 
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.
getJobInstanceCount(String) - Method in class org.springframework.batch.core.repository.dao.MapJobInstanceDao
Deprecated.
 
getJobInstanceDao() - Method in class org.springframework.batch.core.repository.support.MapJobRepositoryFactoryBean
Deprecated.
 
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 class org.springframework.batch.core.jsr.launch.JsrJobOperator
 
getJobInstances(String, int, int) - Method in interface org.springframework.batch.core.launch.JobOperator
List the JobInstances for a given job name, in reverse order of creation (and therefore usually of first execution).
getJobInstances(String, int, int) - Method in class org.springframework.batch.core.launch.support.SimpleJobOperator
 
getJobInstances(String, int, int) - Method in class org.springframework.batch.core.repository.dao.JdbcJobInstanceDao
 
getJobInstances(String, int, int) - Method in interface org.springframework.batch.core.repository.dao.JobInstanceDao
Fetch the last job instances with the provided name, sorted backwards by primary key.
getJobInstances(String, int, int) - Method in class org.springframework.batch.core.repository.dao.MapJobInstanceDao
Deprecated.
 
getJobLauncher() - Method in interface org.springframework.batch.core.configuration.annotation.BatchConfigurer
 
getJobLauncher() - Method in class org.springframework.batch.core.configuration.annotation.DefaultBatchConfigurer
 
getJobLauncher() - Method in class org.springframework.batch.test.AbstractJobTests
Deprecated.
 
getJobLauncher() - Method in class org.springframework.batch.test.JobLauncherTestUtils
 
getJobName() - Method in interface org.springframework.batch.core.configuration.JobFactory
 
getJobName() - Method in class org.springframework.batch.core.configuration.support.ApplicationContextJobFactory
Just return the name of instance passed in on initialization.
getJobName() - Method in class org.springframework.batch.core.configuration.support.ReferenceJobFactory
Just return the name of instance passed in on initialization.
getJobName() - Method in class org.springframework.batch.core.JobInstance
 
getJobName() - Method in class org.springframework.batch.core.jsr.JsrJobContext
 
getJobName() - Method in class org.springframework.batch.core.jsr.JsrJobExecution
 
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 class org.springframework.batch.core.jsr.launch.JsrJobOperator
 
getJobNames() - Method in interface org.springframework.batch.core.launch.JobOperator
List the available job names that can be launched with JobOperator.start(String, String).
getJobNames() - Method in class org.springframework.batch.core.launch.support.SimpleJobOperator
 
getJobNames() - Method in class org.springframework.batch.core.repository.dao.JdbcJobInstanceDao
 
getJobNames() - Method in interface org.springframework.batch.core.repository.dao.JobInstanceDao
Retrieve the names of all job instances sorted alphabetically - i.e.
getJobNames() - Method in class org.springframework.batch.core.repository.dao.MapJobInstanceDao
Deprecated.
 
getJobParameters(Properties) - Method in class org.springframework.batch.core.converter.DefaultJobParametersConverter
Check for suffix on keys and use those to decide how to convert the value.
getJobParameters(Properties) - Method in interface org.springframework.batch.core.converter.JobParametersConverter
Get a new JobParameters instance.
getJobParameters() - Method in class org.springframework.batch.core.JobExecution
 
getJobParameters() - Method in class org.springframework.batch.core.jsr.configuration.xml.JsrBeanDefinitionDocumentReader
 
getJobParameters() - Method in class org.springframework.batch.core.jsr.JsrJobExecution
 
getJobParameters(Properties) - Method in class org.springframework.batch.core.jsr.JsrJobParametersConverter
 
getJobParameters(Properties) - Method in class org.springframework.batch.core.launch.support.ScheduledJobParametersFactory
Deprecated.
 
getJobParameters(Long) - Method in class org.springframework.batch.core.repository.dao.JdbcJobExecutionDao
 
getJobParameters() - Method in class org.springframework.batch.core.scope.context.JobContext
 
getJobParameters() - Method in class org.springframework.batch.core.scope.context.StepContext
 
getJobParameters(Job, StepExecution) - Method in class org.springframework.batch.core.step.job.DefaultJobParametersExtractor
 
getJobParameters(Job, StepExecution) - Method in interface org.springframework.batch.core.step.job.JobParametersExtractor
Extract job parameters from the step execution, for example from the execution context or other properties.
getJobParameters() - Method in class org.springframework.batch.core.StepExecution
Convenience method to get the current job parameters.
getJobParameters() - Method in class org.springframework.batch.integration.launch.JobLaunchRequest
 
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.
getJobProperties() - Method in class org.springframework.batch.core.jsr.configuration.support.BatchPropertyContext
Obtains the Job level properties.
getJobProperties() - Method in class org.springframework.batch.core.jsr.configuration.xml.JsrBeanDefinitionDocumentReader
 
getJobRepository() - Method in interface org.springframework.batch.core.configuration.annotation.BatchConfigurer
 
getJobRepository() - Method in class org.springframework.batch.core.configuration.annotation.DefaultBatchConfigurer
 
getJobRepository() - Method in class org.springframework.batch.core.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.jsr.configuration.xml.JobFactoryBean
 
getJobRepository() - Method in class org.springframework.batch.core.repository.support.AbstractJobRepositoryFactoryBean
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
 
getJobRepository() - Method in class org.springframework.batch.test.AbstractJobTests
Deprecated.
 
getJobRepository() - Method in class org.springframework.batch.test.JobLauncherTestUtils
 
getJobRestartProperties(Properties, JobExecution) - Method in class org.springframework.batch.core.jsr.launch.JsrJobOperator
 
getJsrRetryListeners() - Method in class org.springframework.batch.core.step.builder.FaultTolerantStepBuilder
 
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
 
getKey(Object[]) - Method in class org.springframework.batch.item.jms.JmsMethodArgumentsKeyGenerator
If the message is a Message then returns the JMS message ID.
getKey(String) - Method in class org.springframework.batch.item.util.ExecutionContextUserSupport
Prefix the argument with ExecutionContextUserSupport.getName() to create a unique key that can be safely used to identify data stored in ExecutionContext.
getLabel() - Method in enum org.springframework.batch.item.file.transform.Alignment
Deprecated.
 
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.
getLastJobExecution(JobInstance) - Method in class org.springframework.batch.core.repository.dao.MapJobExecutionDao
Deprecated.
 
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
 
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.
getLastJobInstance(String) - Method in class org.springframework.batch.core.repository.dao.MapJobInstanceDao
Deprecated.
 
getLastStepExecution(JobInstance, String) - Method in class org.springframework.batch.core.repository.dao.JdbcStepExecutionDao
 
getLastStepExecution(JobInstance, String) - Method in class org.springframework.batch.core.repository.dao.MapStepExecutionDao
Deprecated.
 
getLastStepExecution(JobInstance, String) - Method in interface org.springframework.batch.core.repository.dao.StepExecutionDao
Retrieve the last StepExecution for a given JobInstance ordered by starting 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
 
getLastUpdatedTime() - Method in class org.springframework.batch.core.jsr.JsrJobExecution
 
getLineNumber() - Method in exception org.springframework.batch.item.file.FlatFileParseException
 
getLineNumber() - Method in exception org.springframework.batch.item.file.NonTransientFlatFileException
 
getLinesWritten() - Method in class org.springframework.batch.item.support.AbstractFileItemWriter.OutputState
 
getListener() - Method in class org.springframework.batch.core.jsr.step.item.JsrChunkProcessor
 
getListener(Object) - Static method in class org.springframework.batch.core.listener.JobListenerFactoryBean
Convenience method to wrap any object and expose the appropriate JobExecutionListener interfaces.
getListener(Object) - Static method in class org.springframework.batch.core.listener.StepListenerFactoryBean
Convenience method to wrap any object and expose the appropriate StepListener interfaces.
getListener() - Method in class org.springframework.batch.core.step.item.SimpleChunkProcessor
 
getListener() - Method in class org.springframework.batch.core.step.item.SimpleChunkProvider
 
getListenerInterface() - Method in enum org.springframework.batch.core.jsr.JsrJobListenerMetaData
 
getListenerInterface() - Method in enum org.springframework.batch.core.jsr.JsrStepListenerMetaData
 
getListenerInterface() - Method in enum org.springframework.batch.core.listener.JobListenerMetaData
 
getListenerInterface() - Method in interface org.springframework.batch.core.listener.ListenerMetaData
 
getListenerInterface() - Method in enum org.springframework.batch.core.listener.StepListenerMetaData
 
getListeners() - Method in class org.springframework.batch.core.step.factory.SimpleStepFactoryBean
Protected getter for the StepListeners.
getLoginTimeout() - Method in class org.springframework.batch.item.database.ExtendedConnectionDataSourceProxy
 
getLogWriter() - Method in class org.springframework.batch.item.database.ExtendedConnectionDataSourceProxy
 
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
Deprecated.
Use JobParameters.getLong(java.lang.String, java.lang.Long) instead. This method will be removed in a future release.
getLong(String, Long) - Method in class org.springframework.batch.core.JobParameters
Typesafe Getter for the Long represented by the provided key.
getLong(String) - Method in class org.springframework.batch.item.ExecutionContext
Typesafe Getter for the Long represented by the provided key.
getLong(String, long) - Method in class org.springframework.batch.item.ExecutionContext
Typesafe Getter for the Long represented by the provided key with default value to return if key is not represented.
getMapping() - Method in class org.springframework.batch.core.launch.support.SimpleJvmExitCodeMapper
 
getMax() - Method in class org.springframework.batch.item.file.transform.Range
 
getMessage() - Method in class org.springframework.batch.integration.chunk.ChunkResponse
 
getMetaDataFromPropertyName(String) - Method in class org.springframework.batch.core.jsr.configuration.xml.JsrJobListenerFactoryBean
 
getMetaDataFromPropertyName(String) - Method in class org.springframework.batch.core.jsr.configuration.xml.JsrStepListenerFactoryBean
 
getMetaDataFromPropertyName(String) - Method in class org.springframework.batch.core.listener.AbstractListenerFactoryBean
 
getMetaDataFromPropertyName(String) - Method in class org.springframework.batch.core.listener.JobListenerFactoryBean
 
getMetaDataFromPropertyName(String) - Method in class org.springframework.batch.core.listener.StepListenerFactoryBean
 
getMetaDataValues() - Method in class org.springframework.batch.core.configuration.xml.AbstractListenerParser
 
getMetaDataValues() - Method in class org.springframework.batch.core.configuration.xml.JobExecutionListenerParser
 
getMetaDataValues() - Method in class org.springframework.batch.core.configuration.xml.StepListenerParser
 
getMetaDataValues() - Method in class org.springframework.batch.core.jsr.configuration.xml.JsrJobListenerFactoryBean
 
getMetaDataValues() - Method in class org.springframework.batch.core.jsr.configuration.xml.JsrStepListenerFactoryBean
 
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
 
getMethodInvokerByAnnotation(Class<? extends Annotation>, Object, Class<?>...) - Static method in class org.springframework.batch.support.MethodInvokerUtils
Create a MethodInvoker from the delegate based on the annotationType.
getMethodInvokerByAnnotation(Class<? extends Annotation>, Object) - Static method in class org.springframework.batch.support.MethodInvokerUtils
Create MethodInvoker for the method with the provided annotation on the provided object.
getMethodInvokerByName(String, Object, Class<?>...) - Method in class org.springframework.batch.core.listener.AbstractListenerFactoryBean
 
getMethodInvokerByName(Object, String, boolean, Class<?>...) - Static method in class org.springframework.batch.support.MethodInvokerUtils
Create a MethodInvoker using the provided method name to search.
getMethodInvokerForInterface(Class<?>, String, Object, Class<?>...) - Static method in class org.springframework.batch.support.MethodInvokerUtils
Create a MethodInvoker using the provided interface, and method name from that interface.
getMethodInvokerForSingleArgument(Object) - Static method in class org.springframework.batch.support.MethodInvokerUtils
Create a MethodInvoker for the delegate from a single public method.
getMethodName() - Method in enum org.springframework.batch.core.jsr.JsrJobListenerMetaData
 
getMethodName() - Method in enum org.springframework.batch.core.jsr.JsrStepListenerMetaData
 
getMethodName() - Method in enum org.springframework.batch.core.listener.JobListenerMetaData
 
getMethodName() - Method in interface org.springframework.batch.core.listener.ListenerMetaData
 
getMethodName() - Method in enum org.springframework.batch.core.listener.StepListenerMetaData
 
getMetric(StepExecution, Metric.MetricType) - Static method in class org.springframework.batch.test.JsrTestUtils
 
getMetrics() - Method in class org.springframework.batch.core.jsr.JsrStepContext
 
getMetrics() - Method in class org.springframework.batch.core.jsr.JsrStepExecution
 
getMin() - Method in class org.springframework.batch.item.file.transform.Range
 
getMostRecentStepName() - Method in class org.springframework.batch.core.jsr.job.flow.support.JsrFlow
 
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
 
getName() - Method in class org.springframework.batch.item.ItemStreamSupport
Get the name of the component
getName() - Method in class org.springframework.batch.item.util.ExecutionContextUserSupport
 
getNames() - Method in class org.springframework.batch.item.file.transform.DefaultFieldSet
 
getNames() - Method in interface org.springframework.batch.item.file.transform.FieldSet
Accessor for the names of the fields.
getNext() - Method in class org.springframework.batch.core.job.flow.support.StateTransition
Public getter for the next State name.
getNext(JobParameters) - Method in interface org.springframework.batch.core.JobParametersIncrementer
Increment the provided parameters.
getNext(JobParameters) - Method in class org.springframework.batch.core.launch.support.DataFieldMaxValueJobParametersIncrementer
 
getNext(JobParameters) - Method in class org.springframework.batch.core.launch.support.RunIdIncrementer
Increment the run.id parameter (starting with 1).
getNextElements(ParserContext, BeanDefinition, Element) - Static method in class org.springframework.batch.core.configuration.xml.AbstractFlowParser
 
getNextElements(ParserContext, String, BeanDefinition, Element) - Static method in class org.springframework.batch.core.configuration.xml.AbstractFlowParser
 
getNextElements(ParserContext, BeanDefinition, Element) - Static method in class org.springframework.batch.core.jsr.configuration.xml.FlowParser
 
getNextElements(ParserContext, String, BeanDefinition, Element) - Static method in class org.springframework.batch.core.jsr.configuration.xml.FlowParser
 
getNextJobParameters(Job) - Method in class org.springframework.batch.core.JobParametersBuilder
Initializes the JobParameters based on the state of the Job.
getNextResult(RepeatContext, RepeatCallback, RepeatInternalState) - Method in class org.springframework.batch.repeat.support.RepeatTemplate
Get the next completed result, possibly executing several callbacks until one finally finishes.
getNextResult(RepeatContext, RepeatCallback, RepeatInternalState) - Method in class org.springframework.batch.repeat.support.TaskExecutorRepeatTemplate
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.JobExplorerFactoryBean
 
getObject() - Method in class org.springframework.batch.core.explore.support.MapJobExplorerFactoryBean
Deprecated.
 
getObject() - Method in class org.springframework.batch.core.jsr.configuration.support.BaseContextListFactoryBean
 
getObject() - Method in class org.springframework.batch.core.jsr.configuration.xml.DecisionStepFactoryBean
 
getObject() - Method in class org.springframework.batch.core.jsr.configuration.xml.JobFactoryBean
 
getObject() - Method in class org.springframework.batch.core.jsr.configuration.xml.StepFactoryBean
Create a Step from the configuration provided.
getObject() - Method in class org.springframework.batch.core.jsr.JsrJobContextFactoryBean
 
getObject() - Method in class org.springframework.batch.core.jsr.JsrStepContextFactoryBean
 
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
 
getObject() - Method in class org.springframework.batch.integration.chunk.RemoteChunkHandlerFactoryBean
Builds a ChunkHandler from the ChunkProcessor extracted from the step provided.
getObject() - Method in class org.springframework.batch.item.database.support.SqlPagingQueryProviderFactoryBean
Get a PagingQueryProvider instance using the provided properties and appropriate for the given database type.
getObjectType() - Method in class org.springframework.batch.core.configuration.support.ClasspathXmlApplicationContextsFactoryBean
The type of object returned by this factory - an array of ApplicationContextFactory.
getObjectType() - Method in class org.springframework.batch.core.configuration.xml.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
The type of object to be returned from FactoryBean.getObject().
getObjectType() - Method in class org.springframework.batch.core.jsr.configuration.support.BaseContextListFactoryBean
 
getObjectType() - Method in class org.springframework.batch.core.jsr.configuration.xml.DecisionStepFactoryBean
 
getObjectType() - Method in class org.springframework.batch.core.jsr.configuration.xml.JobFactoryBean
 
getObjectType() - Method in class org.springframework.batch.core.jsr.configuration.xml.JsrJobListenerFactoryBean
 
getObjectType() - Method in class org.springframework.batch.core.jsr.JsrJobContextFactoryBean
 
getObjectType() - Method in class org.springframework.batch.core.jsr.JsrStepContextFactoryBean
 
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.
getObjectType() - Method in class org.springframework.batch.integration.chunk.RemoteChunkHandlerFactoryBean
The type of object created by this factory.
getObjectType() - Method in class org.springframework.batch.item.database.support.SqlPagingQueryProviderFactoryBean
Always returns PagingQueryProvider.
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.jsr.configuration.support.ThreadLocalClassloaderBeanPostProcessor
Sets this BeanFactoryPostProcessor to the lowest precedence so that it is executed as late as possible in the chain of BeanFactoryPostProcessors
getOrder() - Method in class org.springframework.batch.core.scope.BatchScopeSupport
 
getOrderedQueryAlias() - Method in class org.springframework.batch.item.database.support.DerbyPagingQueryProvider
 
getOrderedQueryAlias() - Method in class org.springframework.batch.item.database.support.SqlWindowingPagingQueryProvider
 
getOutputState() - Method in class org.springframework.batch.item.support.AbstractFileItemWriter
 
getOverClause() - Method in class org.springframework.batch.item.database.support.DerbyPagingQueryProvider
 
getOverClause() - Method in class org.springframework.batch.item.database.support.SqlWindowingPagingQueryProvider
 
getOverSubstituteClauseEnd() - Method in class org.springframework.batch.item.database.support.DerbyPagingQueryProvider
 
getOverSubstituteClauseEnd() - Method in class org.springframework.batch.item.database.support.SqlWindowingPagingQueryProvider
 
getOverSubstituteClauseStart() - Method in class org.springframework.batch.item.database.support.DerbyPagingQueryProvider
 
getOverSubstituteClauseStart() - Method in class org.springframework.batch.item.database.support.SqlWindowingPagingQueryProvider
 
getPage() - Method in class org.springframework.batch.item.database.AbstractPagingItemReader
The current page number.
getPageSize() - Method in class org.springframework.batch.item.database.AbstractPagingItemReader
The page size configured for this reader.
getParameterCount() - Method in interface org.springframework.batch.item.database.PagingQueryProvider
The number of parameters that are declared in the query
getParameterCount() - Method in class org.springframework.batch.item.database.support.AbstractSqlPagingQueryProvider
 
getParameters() - Method in class org.springframework.batch.core.JobParameters
Get a map of all parameters, including string, long, and date.
getParameters(long) - Method in class org.springframework.batch.core.jsr.launch.JsrJobOperator
 
getParameters(long) - Method in interface org.springframework.batch.core.launch.JobOperator
Get the JobParameters as an easily readable String.
getParameters(long) - Method in class org.springframework.batch.core.launch.support.SimpleJobOperator
 
getParameterValues() - Method in class org.springframework.batch.item.data.AbstractNeo4jItemReader
Deprecated.
 
getParamTypes() - Method in enum org.springframework.batch.core.jsr.JsrJobListenerMetaData
 
getParamTypes() - Method in enum org.springframework.batch.core.jsr.JsrStepListenerMetaData
 
getParamTypes() - Method in enum org.springframework.batch.core.listener.JobListenerMetaData
 
getParamTypes() - Method in interface org.springframework.batch.core.listener.ListenerMetaData
 
getParamTypes() - Method in enum org.springframework.batch.core.listener.StepListenerMetaData
 
getParamTypesString(Class<?>...) - Static method in class org.springframework.batch.support.MethodInvokerUtils
Create a String representation of the array of parameter types.
getParent() - Method in class org.springframework.batch.repeat.context.RepeatContextSupport
 
getParent() - Method in interface org.springframework.batch.repeat.RepeatContext
If batches are nested, then the inner batch will be created with the outer one as a parent.
getParentLogger() - Method in class org.springframework.batch.item.database.ExtendedConnectionDataSourceProxy
Added due to JDK 7 compatibility.
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
 
getPartitionPlan() - Method in class org.springframework.batch.core.scope.context.StepContext
 
getPartitionProperties() - Method in class org.springframework.batch.core.jsr.partition.JsrPartitionHandler.PartitionPlanState
 
getPartitions() - Method in class org.springframework.batch.core.jsr.partition.JsrPartitionHandler.PartitionPlanState
 
getPartitionsOverride() - Method in class org.springframework.batch.core.jsr.partition.JsrPartitionHandler.PartitionPlanState
 
getPartitionStepNames() - Method in class org.springframework.batch.core.jsr.partition.JsrPartitionHandler
 
getPattern() - Method in class org.springframework.batch.core.job.flow.support.StateTransition
 
getPersistentUserData() - Method in class org.springframework.batch.core.jsr.JsrStepContext
 
getPersistentUserData() - Method in class org.springframework.batch.core.jsr.JsrStepExecution
 
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
 
getProductName() - Method in enum org.springframework.batch.support.DatabaseType
 
getProperties(JobParameters) - Method in class org.springframework.batch.core.converter.DefaultJobParametersConverter
Use the same suffixes to create properties (omitting the string suffix because it is the default).
getProperties(JobParameters) - Method in interface org.springframework.batch.core.converter.JobParametersConverter
The inverse operation: get a Properties instance.
getProperties() - Method in class org.springframework.batch.core.jsr.JsrJobContext
 
getProperties(JobParameters) - Method in class org.springframework.batch.core.jsr.JsrJobParametersConverter
 
getProperties() - Method in class org.springframework.batch.core.jsr.JsrStepContext
 
getProperties(JobParameters) - Method in class org.springframework.batch.core.launch.support.ScheduledJobParametersFactory
Deprecated.
Convert schedule date to Date, and assume all other parameters can be represented by their default string value.
getProperties() - Method in class org.springframework.batch.item.file.transform.DefaultFieldSet
 
getProperties() - Method in interface org.springframework.batch.item.file.transform.FieldSet
Construct name-value pairs from the field names and string values.
getPropertyName() - Method in enum org.springframework.batch.core.jsr.JsrJobListenerMetaData
 
getPropertyName() - Method in enum org.springframework.batch.core.jsr.JsrStepListenerMetaData
 
getPropertyName() - Method in enum org.springframework.batch.core.listener.JobListenerMetaData
 
getPropertyName() - Method in interface org.springframework.batch.core.listener.ListenerMetaData
 
getPropertyName() - Method in enum org.springframework.batch.core.listener.StepListenerMetaData
 
getPropertyValue(String, String, ConfigurableListableBeanFactory) - Static method in class org.springframework.batch.core.configuration.xml.BeanDefinitionUtils
 
getQuery(String) - Method in class org.springframework.batch.core.repository.dao.AbstractJdbcBatchMetadataDao
 
getReadCount() - Method in class org.springframework.batch.core.StepContribution
Public access to the read counter.
getReadCount() - Method in class org.springframework.batch.core.StepExecution
Returns the current number of items read for this execution
getReader() - Method in class org.springframework.batch.core.jsr.configuration.xml.JsrXmlApplicationContext
 
getReader() - Method in class org.springframework.batch.core.step.builder.SimpleStepBuilder
 
getReadSkipCount() - Method in class org.springframework.batch.core.StepContribution
 
getReadSkipCount() - Method in class org.springframework.batch.core.StepExecution
 
getRestartable() - Method in class org.springframework.batch.core.job.builder.JobBuilderHelper.CommonJobProperties
 
getResult(XMLEventWriter) - Static method in class org.springframework.batch.item.xml.StaxUtils
Deprecated.
 
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
getRootElementAttributes() - Method in class org.springframework.batch.item.xml.StaxEventItemWriter
Get attributes of the root element.
getRootTagName() - Method in class org.springframework.batch.item.xml.StaxEventItemWriter
Get the tag name of the root element.
getRootTagNamespace() - Method in class org.springframework.batch.item.xml.StaxEventItemWriter
Get the namespace of the root element.
getRootTagNamespacePrefix() - Method in class org.springframework.batch.item.xml.StaxEventItemWriter
Get the namespace prefix of the root element.
getRunningExecutions(String) - Method in class org.springframework.batch.core.jsr.launch.JsrJobOperator
 
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
 
getSelectClause() - Method in class org.springframework.batch.item.database.support.AbstractSqlPagingQueryProvider
 
getSequence() - Method in class org.springframework.batch.integration.chunk.ChunkRequest
 
getSequence() - Method in class org.springframework.batch.integration.chunk.ChunkResponse
 
getSessionFactory() - Method in class org.springframework.batch.item.data.AbstractNeo4jItemReader
Deprecated.
 
getSimpleStepBuilder(String) - Method in class org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
 
getSimpleStepBuilder(String) - Method in class org.springframework.batch.core.jsr.configuration.xml.StepFactoryBean
 
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
 
getSkips() - Method in class org.springframework.batch.core.step.item.Chunk
 
getSortKeyPlaceHolder(String) - Method in interface org.springframework.batch.item.database.PagingQueryProvider
Returns either a String to be used as the named placeholder for a sort key value (based on the column name) or a ? for unnamed parameters.
getSortKeyPlaceHolder(String) - Method in class org.springframework.batch.item.database.support.AbstractSqlPagingQueryProvider
The sort key placeholder will vary depending on whether named parameters or traditional placeholders are used in query strings.
getSortKeys() - Method in interface org.springframework.batch.item.database.PagingQueryProvider
The sort keys.
getSortKeys() - Method in class org.springframework.batch.item.database.support.AbstractSqlPagingQueryProvider
A Map<String, Boolean> of sort columns as the key and boolean for ascending/descending (ascending = true).
getSortKeysWithoutAliases() - Method in interface org.springframework.batch.item.database.PagingQueryProvider
The sort key (unique single column name) without alias.
getSortKeysWithoutAliases() - Method in class org.springframework.batch.item.database.support.AbstractSqlPagingQueryProvider
 
getSource(XMLEventReader) - Static method in class org.springframework.batch.item.xml.StaxUtils
Deprecated.
 
getSplitTaskExecutorPropertyValue(BeanDefinitionRegistry) - Method in class org.springframework.batch.core.jsr.configuration.xml.JsrSplitParser
 
getSplitter() - Method in class org.springframework.batch.core.step.builder.PartitionStepBuilder
 
getSql() - Method in class org.springframework.batch.item.database.AbstractCursorItemReader
 
getSql() - Method in class org.springframework.batch.item.database.JdbcCursorItemReader
 
getSql() - Method in class org.springframework.batch.item.database.StoredProcedureItemReader
 
getStandalone() - Method in class org.springframework.batch.item.xml.StaxEventItemWriter
Get used standalone document declaration.
getStartable(StepExecution, ExecutionContext) - Method in class org.springframework.batch.core.partition.support.SimpleStepExecutionSplitter
Deprecated.
getStartedCount() - Method in class org.springframework.batch.repeat.context.RepeatContextSupport
 
getStartedCount() - Method in interface org.springframework.batch.repeat.RepeatContext
Public access to a counter for the number of operations attempted.
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.jsr.JsrJobExecution
 
getStartTime() - Method in class org.springframework.batch.core.jsr.JsrStepExecution
 
getStartTime() - Method in class org.springframework.batch.core.StepExecution
Gets the time this execution started
getState() - Method in class org.springframework.batch.core.configuration.xml.SimpleFlowFactoryBean.DelegateState
 
getState(String) - Method in interface org.springframework.batch.core.job.flow.Flow
Retrieve the State with the given name.
getState(String) - Method in class org.springframework.batch.core.job.flow.support.SimpleFlow
Retrieve the State with the given name.
getState() - Method in class org.springframework.batch.core.job.flow.support.StateTransition
Public getter for the State.
getStatefulSession() - Method in class org.springframework.batch.item.database.orm.AbstractHibernateQueryProvider
 
getStatelessSession() - Method in class org.springframework.batch.item.database.orm.AbstractHibernateQueryProvider
 
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
 
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(String, String) - Method in interface org.springframework.batch.core.configuration.StepRegistry
Returns the Step of the specified job based on its name.
getStep(String, String) - Method in class org.springframework.batch.core.configuration.support.MapStepRegistry
 
getStep(String) - Method in class org.springframework.batch.core.job.AbstractJob
Retrieve the step with the given name.
getStep(String) - Method in class org.springframework.batch.core.job.flow.FlowJob
Retrieve the step with the given name.
getStep() - Method in class org.springframework.batch.core.job.flow.support.state.StepState
 
getStep(String) - Method in class org.springframework.batch.core.job.flow.support.state.StepState
 
getStep(String) - Method in class org.springframework.batch.core.job.SimpleJob
 
getStep() - Method in class org.springframework.batch.core.jsr.partition.JsrPartitionHandler
 
getStep(String) - Method in class org.springframework.batch.core.jsr.step.PartitionStep
 
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 interface org.springframework.batch.core.step.StepLocator
 
getStep(String) - Method in class org.springframework.batch.integration.partition.BeanFactoryStepLocator
Look up a bean with the provided name of type Step.
getStepArtifactProperties(String, String) - Method in class org.springframework.batch.core.jsr.configuration.support.BatchPropertyContext
Obtains the batch Properties for the provided Step and artifact name.
getStepContext() - Method in class org.springframework.batch.core.scope.context.ChunkContext
 
getStepContribution() - Method in class org.springframework.batch.integration.chunk.ChunkRequest
 
getStepContribution() - Method in class org.springframework.batch.integration.chunk.ChunkResponse
 
getStepContributions() - Method in class org.springframework.batch.integration.chunk.ChunkMessageChannelItemWriter
 
getStepContributions() - Method in interface org.springframework.batch.integration.chunk.StepContributionSource
Get the currently available contributions and drain the source.
getStepExecution(Long, Long) - Method in interface org.springframework.batch.core.explore.JobExplorer
Retrieve a StepExecution by its id and parent JobExecution id.
getStepExecution(Long, Long) - Method in class org.springframework.batch.core.explore.support.SimpleJobExplorer
 
getStepExecution() - Method in interface org.springframework.batch.core.job.flow.FlowExecutor
 
getStepExecution() - Method in class org.springframework.batch.core.job.flow.JobFlowExecutor
 
getStepExecution(JobExecution, Long) - Method in class org.springframework.batch.core.repository.dao.JdbcStepExecutionDao
 
getStepExecution(JobExecution, Long) - Method in class org.springframework.batch.core.repository.dao.MapStepExecutionDao
Deprecated.
 
getStepExecution(JobExecution, Long) - Method in interface org.springframework.batch.core.repository.dao.StepExecutionDao
Retrieve a StepExecution from its id.
getStepExecution() - Method in class org.springframework.batch.core.scope.context.StepContext
The current StepExecution that is active in this context.
getStepExecution() - Method in class org.springframework.batch.core.StepContribution
Public getter for the parent step execution of this contribution.
getStepExecution(TestContext) - Method in class org.springframework.batch.test.StepScopeTestExecutionListener
Discover a StepExecution as a field in the test case or create one if none is available.
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.repository.support.MapJobRepositoryFactoryBean
Deprecated.
 
getStepExecutionId() - Method in class org.springframework.batch.core.jsr.JsrStepContext
 
getStepExecutionId() - Method in class org.springframework.batch.core.jsr.JsrStepExecution
 
getStepExecutionId() - Method in class org.springframework.batch.integration.partition.StepExecutionRequest
 
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.
getStepExecutions(long) - Method in class org.springframework.batch.core.jsr.launch.JsrJobOperator
 
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 class org.springframework.batch.core.jsr.JsrStepContext
 
getStepName() - Method in class org.springframework.batch.core.jsr.JsrStepExecution
 
getStepName() - Method in class org.springframework.batch.core.jsr.partition.JsrStepExecutionSplitter
 
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
 
getStepName() - Method in class org.springframework.batch.integration.partition.StepExecutionRequest
 
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 class org.springframework.batch.core.jsr.step.PartitionStep
 
getStepNames() - Method in interface org.springframework.batch.core.step.StepLocator
 
getStepNames() - Method in class org.springframework.batch.integration.partition.BeanFactoryStepLocator
Look in the bean factory for all beans of type Step.
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.
getStepProperties(String) - Method in class org.springframework.batch.core.jsr.configuration.support.BatchPropertyContext
Obtains the Step level properties for the provided Step name.
getStepRunner() - Method in class org.springframework.batch.test.AbstractJobTests
Deprecated.
Convenient method for subclasses to grab a StepRunner for running steps by name.
getStepRunner() - Method in class org.springframework.batch.test.JobLauncherTestUtils
Convenient method for subclasses to grab a StepRunner for running steps by name.
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.
getString(String) - Method in class org.springframework.batch.item.ExecutionContext
Typesafe Getter for the String represented by the provided key.
getString(String, String) - Method in class org.springframework.batch.item.ExecutionContext
Typesafe Getter for the String represented by the provided key with default value to return if key is not represented.
getStringCode() - Method in enum org.springframework.batch.item.file.transform.Alignment
Deprecated.
 
getSubQueryAlias() - Method in class org.springframework.batch.item.database.support.Db2PagingQueryProvider
 
getSubQueryAlias() - Method in class org.springframework.batch.item.database.support.SqlServerPagingQueryProvider
 
getSubQueryAlias() - Method in class org.springframework.batch.item.database.support.SqlWindowingPagingQueryProvider
 
getSubQueryAlias() - Method in class org.springframework.batch.item.database.support.SybasePagingQueryProvider
 
getSuffix(int) - Method in interface org.springframework.batch.item.file.ResourceSuffixCreator
 
getSuffix(int) - Method in class org.springframework.batch.item.file.SimpleResourceSuffixCreator
 
getSummary(long) - Method in interface org.springframework.batch.core.launch.JobOperator
Summarise the JobExecution with the supplied id, giving details of status, start and end times etc.
getSummary(long) - Method in class org.springframework.batch.core.launch.support.SimpleJobOperator
 
getSummary() - Method in class org.springframework.batch.core.StepExecution
 
getSupportedIncrementerTypes() - Method in interface org.springframework.batch.item.database.support.DataFieldMaxValueIncrementerFactory
Returns the list of supported database incrementer types
getSupportedIncrementerTypes() - Method in class org.springframework.batch.item.database.support.DefaultDataFieldMaxValueIncrementerFactory
 
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.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
 
getTargetType() - Method in class org.springframework.batch.item.data.AbstractNeo4jItemReader
Deprecated.
 
getTaskExecutor() - Method in class org.springframework.batch.core.jsr.launch.JsrJobOperator
 
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
getTemplate() - Method in class org.springframework.batch.item.data.MongoItemWriter
Get the MongoOperations to be used to save items to be written.
getThreads() - Method in class org.springframework.batch.core.jsr.partition.JsrPartitionHandler.PartitionPlanState
 
getThrottleLimit() - Method in class org.springframework.batch.core.step.builder.AbstractTaskletStepBuilder
 
getThrowables() - Method in interface org.springframework.batch.repeat.support.RepeatInternalState
Returns a mutable collection of exceptions that have occurred in the current repeat context.
getThrowables() - Method in class org.springframework.batch.repeat.support.RepeatInternalStateSupport
 
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 interface org.springframework.batch.core.configuration.annotation.BatchConfigurer
 
getTransactionManager() - Method in class org.springframework.batch.core.configuration.annotation.DefaultBatchConfigurer
 
getTransactionManager() - Method in class org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
 
getTransactionManager() - Method in class org.springframework.batch.core.repository.support.AbstractJobRepositoryFactoryBean
The transaction manager used in this factory.
getTransactionManager() - Method in class org.springframework.batch.core.step.builder.StepBuilderHelper.CommonStepProperties
 
getTransactionManager() - Method in class org.springframework.batch.core.step.builder.StepBuilderHelper
 
getTransientUserData() - Method in class org.springframework.batch.core.jsr.JsrJobContext
 
getTransientUserData() - Method in class org.springframework.batch.core.jsr.JsrStepContext
 
getTransitionMap() - Method in class org.springframework.batch.core.job.flow.support.SimpleFlow
 
getType() - Method in class org.springframework.batch.core.JobParameter
 
getType() - Method in class org.springframework.batch.core.jsr.SimpleMetric
 
getUnclosedElements() - Method in class org.springframework.batch.item.xml.stax.UnclosedElementCollectingEventWriter
 
getUniqueJobParameters() - Method in class org.springframework.batch.test.AbstractJobTests
Deprecated.
 
getUniqueJobParameters() - Method in class org.springframework.batch.test.JobLauncherTestUtils
 
getUniqueJobParametersBuilder() - Method in class org.springframework.batch.test.JobLauncherTestUtils
 
getUserData() - Method in class org.springframework.batch.core.step.item.Chunk
 
getValue() - Method in class org.springframework.batch.core.JobParameter
 
getValue() - Method in class org.springframework.batch.core.jsr.SimpleMetric
 
getValueFromJob(JobExecution, String) - Static method in class org.springframework.batch.test.ExecutionContextTestUtils
 
getValueFromStep(StepExecution, String) - Static method in class org.springframework.batch.test.ExecutionContextTestUtils
 
getValueFromStepInJob(JobExecution, String, String) - Static method in class org.springframework.batch.test.ExecutionContextTestUtils
 
getValues() - Method in class org.springframework.batch.item.file.transform.DefaultFieldSet
 
getValues() - Method in interface org.springframework.batch.item.file.transform.FieldSet
 
getVersion() - Method in class org.springframework.batch.core.Entity
 
getVersion() - Method in class org.springframework.batch.item.xml.StaxEventItemWriter
Get XML version.
getWhereClause() - Method in class org.springframework.batch.item.database.support.AbstractSqlPagingQueryProvider
 
getWriteCount() - Method in class org.springframework.batch.core.StepContribution
Public access to the write counter.
getWriteCount() - Method in class org.springframework.batch.core.StepExecution
Returns the current number of items written for this execution
getWriter() - Method in class org.springframework.batch.core.step.builder.SimpleStepBuilder
 
getWriteSkipCount() - Method in class org.springframework.batch.core.StepContribution
 
getWriteSkipCount() - Method in class org.springframework.batch.core.StepExecution
 
getWrittenItems() - Method in class org.springframework.batch.item.support.ListItemWriter
 
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.
gridSize(int) - Method in class org.springframework.batch.integration.partition.RemotePartitioningManagerStepBuilder
 
gridSize(int) - Method in class org.springframework.batch.integration.partition.RemotePartitioningMasterStepBuilder
Deprecated.
 
GroupAwareJob - Class in org.springframework.batch.core.configuration.support
A Job that can optionally prepend a group name to another job's name, to make it fit a naming convention for type or origin.
GroupAwareJob(Job) - Constructor for class org.springframework.batch.core.configuration.support.GroupAwareJob
Create a new Job with the delegate and no group name.
GroupAwareJob(String, Job) - Constructor for class org.springframework.batch.core.configuration.support.GroupAwareJob
Create a new Job with the given group name and delegate.
groupClause(String) - Method in class org.springframework.batch.item.database.builder.JdbcPagingItemReaderBuilder
The SQL GROUP BY clause for a db specific @PagingQueryProvider.
GsonJsonObjectMarshaller<T> - Class in org.springframework.batch.item.json
A json object marshaller that uses Google Gson to marshal an object into a json representation.
GsonJsonObjectMarshaller() - Constructor for class org.springframework.batch.item.json.GsonJsonObjectMarshaller
 
GsonJsonObjectMarshaller(Gson) - Constructor for class org.springframework.batch.item.json.GsonJsonObjectMarshaller
 
GsonJsonObjectReader<T> - Class in org.springframework.batch.item.json
Implementation of JsonObjectReader based on Google Gson.
GsonJsonObjectReader(Class<? extends T>) - Constructor for class org.springframework.batch.item.json.GsonJsonObjectReader
Create a new GsonJsonObjectReader instance.
GsonJsonObjectReader(Gson, Class<? extends T>) - Constructor for class org.springframework.batch.item.json.GsonJsonObjectReader
 

H

H2PagingQueryProvider - Class in org.springframework.batch.item.database.support
H2 implementation of a PagingQueryProvider using database specific features.
H2PagingQueryProvider() - Constructor for class org.springframework.batch.item.database.support.H2PagingQueryProvider
 
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(FlowExecutor) - Method in class org.springframework.batch.core.jsr.job.flow.support.state.JsrEndState
 
handle(FlowExecutor) - Method in class org.springframework.batch.core.jsr.job.flow.support.state.JsrStepState
 
handle(StepExecutionSplitter, StepExecution) - Method in class org.springframework.batch.core.jsr.partition.JsrPartitionHandler
 
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
 
handle(StepExecutionSplitter, StepExecution) - Method in class org.springframework.batch.integration.partition.MessageChannelPartitionHandler
Sends StepExecutionRequest objects to the request channel of the MessagingTemplate, and then receives the result back as a list of StepExecution on a reply channel.
handle(StepExecutionRequest) - Method in class org.springframework.batch.integration.partition.StepExecutionRequestHandler
 
handle(MailMessage, Exception) - Method in class org.springframework.batch.item.mail.DefaultMailErrorHandler
Wraps the input exception with a runtime MailException.
handle(MailMessage, Exception) - Method in interface org.springframework.batch.item.mail.MailErrorHandler
This method will be called for each message that failed sending in the chunk.
handleChunk(ChunkRequest<T>) - Method in interface org.springframework.batch.integration.chunk.ChunkHandler
Handle the chunk, processing all the items and returning a response summarising the result.
handleChunk(ChunkRequest<S>) - Method in class org.springframework.batch.integration.chunk.ChunkProcessorChunkHandler
 
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.
handleException(RepeatContext, Throwable) - Method in class org.springframework.batch.repeat.exception.CompositeExceptionHandler
Iterate over the handlers delegating the call to each in turn.
handleException(RepeatContext, Throwable) - Method in class org.springframework.batch.repeat.exception.DefaultExceptionHandler
Re-throw the throwable.
handleException(RepeatContext, Throwable) - Method in interface org.springframework.batch.repeat.exception.ExceptionHandler
Deal with a Throwable during a batch - decide whether it should be re-thrown in the first place.
handleException(RepeatContext, Throwable) - Method in class org.springframework.batch.repeat.exception.LogOrRethrowExceptionHandler
Classify the throwables and decide whether to rethrow based on the result.
handleException(RepeatContext, Throwable) - Method in class org.springframework.batch.repeat.exception.RethrowOnThresholdExceptionHandler
Classify the throwables and decide whether to re-throw based on the result.
handleException(RepeatContext, Throwable) - Method in class org.springframework.batch.repeat.exception.SimpleLimitExceptionHandler
Rethrows only if the limit is breached for this context on the exception type specified.
handleLine(String) - Method in interface org.springframework.batch.item.file.LineCallbackHandler
 
handleListenersElement(Element, BeanDefinition, ParserContext) - Method in class org.springframework.batch.core.configuration.xml.StepListenerParser
 
handleRecord(LdapAttributes) - Method in interface org.springframework.batch.item.ldif.RecordCallbackHandler
Execute operations on the supplied record.
handleRequestMessage(Message<?>) - Method in class org.springframework.batch.integration.launch.JobLaunchingGateway
Launches a Batch Job using the provided request Message.
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.
handleWarnings(Statement) - Method in class org.springframework.batch.item.database.AbstractCursorItemReader
Throw a SQLWarningException if we're not ignoring warnings, else log the warnings (at debug level).
hasAttribute(String) - Method in class org.springframework.batch.repeat.context.SynchronizedAttributeAccessor
 
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 class org.springframework.batch.core.Entity
Use ID if it exists to establish hash code, otherwise fall back to Object.hashCode().
hashCode() - Method in class org.springframework.batch.core.ExitStatus
Compatible with the equals implementation.
hashCode() - Method in class org.springframework.batch.core.job.flow.FlowExecutionStatus
 
hashCode() - Method in class org.springframework.batch.core.JobParameter
 
hashCode() - Method in class org.springframework.batch.core.JobParameters
 
hashCode() - Method in class org.springframework.batch.core.listener.MethodInvokerMethodInterceptor
hashCode() - Method in class org.springframework.batch.core.scope.context.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
 
hashCode() - Method in class org.springframework.batch.item.ExecutionContext
 
hashCode() - Method in class org.springframework.batch.item.file.transform.DefaultFieldSet
 
hashCode() - Method in class org.springframework.batch.repeat.context.SynchronizedAttributeAccessor
 
hashCode() - Method in class org.springframework.batch.support.SimpleMethodInvoker
 
hashCode() - Method in class org.springframework.batch.test.context.BatchTestContextCustomizer
 
hasMaxValue() - Method in class org.springframework.batch.item.file.transform.Range
 
hasNames() - Method in class org.springframework.batch.item.file.transform.AbstractLineTokenizer
 
hasNames() - Method in class org.springframework.batch.item.file.transform.DefaultFieldSet
 
hasNames() - Method in interface org.springframework.batch.item.file.transform.FieldSet
Check if there are names defined for the fields.
hasNext() - Method in class org.springframework.batch.core.step.item.Chunk.ChunkIterator
 
hasNext() - Method in class org.springframework.batch.item.xml.stax.DefaultFragmentEventReader
 
hasPartitionElement() - Method in class org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
 
hasTasklet() - Method in class org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
 
headerCallback(FlatFileHeaderCallback) - Method in class org.springframework.batch.item.file.builder.FlatFileItemWriterBuilder
A callback for header processing.
headerCallback(FlatFileHeaderCallback) - Method in class org.springframework.batch.item.json.builder.JsonFileItemWriterBuilder
A callback for header processing.
headerCallback(StaxWriterCallback) - Method in class org.springframework.batch.item.xml.builder.StaxEventItemWriterBuilder
A StaxWriterCallback to provide any header elements
HibernateCursorItemReader<T> - Class in org.springframework.batch.item.database
ItemStreamReader for reading database records built on top of Hibernate.
HibernateCursorItemReader() - Constructor for class org.springframework.batch.item.database.HibernateCursorItemReader
 
HibernateCursorItemReaderBuilder<T> - Class in org.springframework.batch.item.database.builder
This is a builder for the HibernateCursorItemReader.
HibernateCursorItemReaderBuilder() - Constructor for class org.springframework.batch.item.database.builder.HibernateCursorItemReaderBuilder
 
HibernateItemReaderHelper<T> - Class in org.springframework.batch.item.database
Internal shared state helper for hibernate readers managing sessions and queries.
HibernateItemReaderHelper() - Constructor for class org.springframework.batch.item.database.HibernateItemReaderHelper
 
HibernateItemWriter<T> - Class in org.springframework.batch.item.database
ItemWriter that uses a Hibernate session to save or update entities that are not part of the current Hibernate session.
HibernateItemWriter() - Constructor for class org.springframework.batch.item.database.HibernateItemWriter
 
HibernateItemWriterBuilder<T> - Class in org.springframework.batch.item.database.builder
A builder for the HibernateItemWriter
HibernateItemWriterBuilder() - Constructor for class org.springframework.batch.item.database.builder.HibernateItemWriterBuilder
 
HibernateNativeQueryProvider<E> - Class in org.springframework.batch.item.database.orm
This query provider creates Hibernate Querys from injected native SQL queries.
HibernateNativeQueryProvider() - Constructor for class org.springframework.batch.item.database.orm.HibernateNativeQueryProvider
 
HibernatePagingItemReader<T> - Class in org.springframework.batch.item.database
ItemReader for reading database records built on top of Hibernate and reading only up to a fixed number of items at a time.
HibernatePagingItemReader() - Constructor for class org.springframework.batch.item.database.HibernatePagingItemReader
 
HibernatePagingItemReaderBuilder<T> - Class in org.springframework.batch.item.database.builder
A builder for the HibernatePagingItemReader.
HibernatePagingItemReaderBuilder() - Constructor for class org.springframework.batch.item.database.builder.HibernatePagingItemReaderBuilder
 
HibernateQueryProvider<T> - Interface in org.springframework.batch.item.database.orm
Interface defining the functionality to be provided for generating queries for use with Hibernate ItemReaders or other custom built artifacts.
hint(String) - Method in class org.springframework.batch.item.data.builder.MongoItemReaderBuilder
JSON String telling MongoDB what index to use.
HippyMethodInvoker - Class in org.springframework.batch.item.adapter
A MethodInvoker that is a bit relaxed about its arguments.
HippyMethodInvoker() - Constructor for class org.springframework.batch.item.adapter.HippyMethodInvoker
 
HsqlPagingQueryProvider - Class in org.springframework.batch.item.database.support
HSQLDB implementation of a PagingQueryProvider using database specific features.
HsqlPagingQueryProvider() - Constructor for class org.springframework.batch.item.database.support.HsqlPagingQueryProvider
 

I

ID_ATTR - Static variable in class org.springframework.batch.core.configuration.xml.AbstractFlowParser
 
ID_ATTR - Static variable in class org.springframework.batch.core.configuration.xml.AbstractStepParser
 
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.
ignoreItemStream(boolean) - Method in class org.springframework.batch.item.support.builder.CompositeItemWriterBuilder
Establishes the policy whether to call the open, close, or update methods for the item writer delegates associated with the CompositeItemWriter.
ignoreWarnings(boolean) - Method in class org.springframework.batch.item.database.builder.JdbcCursorItemReaderBuilder
 
ignoreWarnings(boolean) - Method in class org.springframework.batch.item.database.builder.StoredProcedureItemReaderBuilder
Indicates if SQL warnings should be ignored or if an exception should be thrown.
includedFields(Integer...) - Method in class org.springframework.batch.item.file.builder.FlatFileItemReaderBuilder.DelimitedBuilder
A list of indices of the fields within a delimited file to be included
IncorrectLineLengthException - Exception in org.springframework.batch.item.file.transform
Exception indicating that the line size expected is different from what is expected.
IncorrectLineLengthException(String, int, int, String) - Constructor for exception org.springframework.batch.item.file.transform.IncorrectLineLengthException
 
IncorrectLineLengthException(String, int, int) - Constructor for exception org.springframework.batch.item.file.transform.IncorrectLineLengthException
 
IncorrectLineLengthException(int, int, String) - Constructor for exception org.springframework.batch.item.file.transform.IncorrectLineLengthException
 
IncorrectLineLengthException(int, int) - Constructor for exception org.springframework.batch.item.file.transform.IncorrectLineLengthException
 
IncorrectTokenCountException - Exception in org.springframework.batch.item.file.transform
Exception indicating that an incorrect number of tokens have been found while parsing a file.
IncorrectTokenCountException(String, int, int, String) - Constructor for exception org.springframework.batch.item.file.transform.IncorrectTokenCountException
 
IncorrectTokenCountException(String, int, int) - Constructor for exception org.springframework.batch.item.file.transform.IncorrectTokenCountException
 
IncorrectTokenCountException(int, int, String) - Constructor for exception org.springframework.batch.item.file.transform.IncorrectTokenCountException
 
IncorrectTokenCountException(int, int) - Constructor for exception org.springframework.batch.item.file.transform.IncorrectTokenCountException
 
increment() - Method in class org.springframework.batch.core.scope.context.SynchronizationManagerSupport
 
increment(int) - Method in class org.springframework.batch.repeat.context.RepeatContextCounter
Increment the counter.
increment() - Method in class org.springframework.batch.repeat.context.RepeatContextCounter
Increment by 1.
increment() - Method in class org.springframework.batch.repeat.context.RepeatContextSupport
Used by clients to increment the started count.
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.
incrementer - Variable in class org.springframework.batch.core.jsr.JsrJobParametersConverter
 
incrementFilterCount(int) - Method in class org.springframework.batch.core.StepContribution
Increment the counter for the number of items processed.
incrementOffset() - Method in class org.springframework.batch.core.step.item.ChunkMonitor
 
incrementProcessSkipCount() - Method in class org.springframework.batch.core.StepContribution
 
incrementReadCount() - Method in class org.springframework.batch.core.StepContribution
Increment the counter for the number of items read.
incrementReadSkipCount() - Method in class org.springframework.batch.core.StepContribution
Increment the read skip count for this contribution
incrementReadSkipCount(int) - Method in class org.springframework.batch.core.StepContribution
Increment the read skip count for this contribution
incrementRollbackCount() - Method in class org.springframework.batch.core.StepExecution
On unsuccessful execution after a chunk has rolled back.
incrementVersion() - Method in class org.springframework.batch.core.Entity
Increment the version number
incrementWriteCount(int) - Method in class org.springframework.batch.core.StepContribution
Increment the counter for the number of items written.
incrementWriteSkipCount() - Method in class org.springframework.batch.core.StepContribution
Increment the write skip count for this contribution
indexOf(String) - Method in class org.springframework.batch.item.file.transform.DefaultFieldSet
Retrieve the index of where a specified column is located based on the name parameter.
init() - Method in class org.springframework.batch.core.configuration.xml.CoreNamespaceHandler
 
init() - Method in class org.springframework.batch.core.jsr.configuration.xml.JsrNamespaceHandler
 
init() - Method in class org.springframework.batch.core.repository.dao.XStreamExecutionContextStringSerializer
Deprecated.
 
init() - Method in class org.springframework.batch.integration.config.xml.BatchIntegrationNamespaceHandler
 
init() - Method in class org.springframework.batch.item.data.GemfireItemWriter
 
init(DataSource) - Method in interface org.springframework.batch.item.database.PagingQueryProvider
Initialize the query provider using the provided DataSource if necessary.
init(DataSource) - Method in class org.springframework.batch.item.database.support.AbstractSqlPagingQueryProvider
Check mandatory properties.
init(DataSource) - Method in class org.springframework.batch.item.database.support.DerbyPagingQueryProvider
 
init() - Method in class org.springframework.batch.item.kafka.KafkaItemWriter
 
init() - Method in class org.springframework.batch.item.KeyValueItemWriter
afterPropertiesSet() hook
initBinder(DataBinder) - Method in class org.springframework.batch.item.file.mapping.BeanWrapperFieldSetMapper
Initialize a new binder instance.
initialize() - Method in class org.springframework.batch.core.configuration.annotation.DefaultBatchConfigurer
 
initialize() - Method in class org.springframework.batch.core.configuration.annotation.SimpleBatchConfiguration
Sets up the basic components by extracting them from the configurer, defaulting to some sensible values as long as a unique DataSource is available.
initializeConnection() - Method in class org.springframework.batch.item.database.AbstractCursorItemReader
 
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.
initNamespaceContext(XMLEventWriter) - Method in class org.springframework.batch.item.xml.StaxEventItemWriter
Inits the namespace context of the XMLEventWriter: rootTagNamespacePrefix for rootTagName any other xmlns namespace prefix declarations in the root element attributes
initProperties(Element) - Method in class org.springframework.batch.core.jsr.configuration.xml.JsrBeanDefinitionDocumentReader
 
InlineFlowParser - Class in org.springframework.batch.core.configuration.xml
 
InlineFlowParser(String, String) - Constructor for class org.springframework.batch.core.configuration.xml.InlineFlowParser
Construct a InlineFlowParser with the specified name and using the provided job repository ref.
InlineStepParser - Class in org.springframework.batch.core.configuration.xml
Internal parser for the <step/> elements inside a job.
InlineStepParser() - Constructor for class org.springframework.batch.core.configuration.xml.InlineStepParser
 
inputChannel(PollableChannel) - Method in class org.springframework.batch.integration.chunk.RemoteChunkingManagerStepBuilder
Set the input channel on which replies from workers will be received.
inputChannel(PollableChannel) - Method in class org.springframework.batch.integration.chunk.RemoteChunkingMasterStepBuilder
Deprecated.
Set the input channel on which replies from workers will be received.
inputChannel(MessageChannel) - Method in class org.springframework.batch.integration.chunk.RemoteChunkingWorkerBuilder
Set the input channel on which items sent by the master are received.
inputChannel(MessageChannel) - Method in class org.springframework.batch.integration.partition.RemotePartitioningManagerStepBuilder
Set the input channel on which replies from workers will be received.
inputChannel(MessageChannel) - Method in class org.springframework.batch.integration.partition.RemotePartitioningMasterStepBuilder
Deprecated.
Set the input channel on which replies from workers will be received.
inputChannel(MessageChannel) - Method in class org.springframework.batch.integration.partition.RemotePartitioningWorkerStepBuilder
Set the input channel on which step execution requests sent by the master are received.
IntArrayPropertyEditor - Class in org.springframework.batch.support
 
IntArrayPropertyEditor() - Constructor for class org.springframework.batch.support.IntArrayPropertyEditor
 
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
InvocationTargetThrowableWrapper(Throwable) - Constructor for exception org.springframework.batch.item.adapter.AbstractMethodInvokingDelegator.InvocationTargetThrowableWrapper
 
invoke(MethodInvocation) - Method in class org.springframework.batch.core.launch.support.RuntimeExceptionTranslator
 
invoke(MethodInvocation) - Method in class org.springframework.batch.core.listener.MethodInvokerMethodInterceptor
 
invoke(MethodInvocation) - Method in class org.springframework.batch.repeat.interceptor.RepeatOperationsInterceptor
Invoke the proceeding method call repeatedly, according to the properties of the injected RepeatOperations.
invokeDelegateMethod() - Method in class org.springframework.batch.item.adapter.AbstractMethodInvokingDelegator
Invoker the target method with arguments set by AbstractMethodInvokingDelegator.setArguments(Object[]).
invokeDelegateMethodWithArgument(Object) - Method in class org.springframework.batch.item.adapter.AbstractMethodInvokingDelegator
Invokes the target method with given argument.
invokeDelegateMethodWithArguments(Object[]) - Method in class org.springframework.batch.item.adapter.AbstractMethodInvokingDelegator
Invokes the target method with given arguments.
invokeMethod(Object...) - Method in interface org.springframework.batch.support.MethodInvoker
 
invokeMethod(Object...) - Method in class org.springframework.batch.support.SimpleMethodInvoker
 
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
 
isBusy() - Method in class org.springframework.batch.core.step.item.Chunk
Query the chunk to see if anyone has registered an interest in keeping a reference to it.
isCloseSuppressionActive(Connection) - Method in class org.springframework.batch.item.database.ExtendedConnectionDataSourceProxy
Return the status of close suppression being activated for a given Connection
isComment(String) - Method in class org.springframework.batch.item.file.FlatFileItemReader
 
isComplete(RepeatContext, RepeatStatus) - Method in class org.springframework.batch.core.resource.StepExecutionSimpleCompletionPolicy
 
isComplete(RepeatContext) - Method in class org.springframework.batch.core.resource.StepExecutionSimpleCompletionPolicy
 
isComplete() - Method in class org.springframework.batch.core.scope.context.ChunkContext
 
isComplete(Chunk<I>) - Method in class org.springframework.batch.core.step.item.FaultTolerantChunkProcessor
 
isComplete(Chunk<I>) - Method in class org.springframework.batch.core.step.item.SimpleChunkProcessor
Extension point for subclasses that want to store additional data in the inputs.
isComplete(RepeatContext, RepeatStatus) - Method in class org.springframework.batch.jsr.repeat.CheckpointAlgorithmAdapter
 
isComplete(RepeatContext) - Method in class org.springframework.batch.jsr.repeat.CheckpointAlgorithmAdapter
 
isComplete(RepeatContext, RepeatStatus) - Method in interface org.springframework.batch.repeat.CompletionPolicy
Determine whether a batch is complete given the latest result from the callback.
isComplete(RepeatContext) - Method in interface org.springframework.batch.repeat.CompletionPolicy
Allow policy to signal completion according to internal state, without having to wait for the callback to complete.
isComplete(RepeatContext, RepeatStatus) - Method in class org.springframework.batch.repeat.policy.CompletionPolicySupport
If exit status is not continuable return true, otherwise delegate to CompletionPolicySupport.isComplete(RepeatContext).
isComplete(RepeatContext) - Method in class org.springframework.batch.repeat.policy.CompletionPolicySupport
Always true.
isComplete(RepeatContext, RepeatStatus) - Method in class org.springframework.batch.repeat.policy.CompositeCompletionPolicy
This policy is complete if any of the composed policies is complete.
isComplete(RepeatContext) - Method in class org.springframework.batch.repeat.policy.CompositeCompletionPolicy
This policy is complete if any of the composed policies is complete.
isComplete(RepeatContext) - Method in class org.springframework.batch.repeat.policy.CountingCompletionPolicy
 
isComplete(RepeatContext, RepeatStatus) - Method in class org.springframework.batch.repeat.policy.DefaultResultCompletionPolicy
True if the result is null, or a RepeatStatus indicating completion.
isComplete(RepeatContext) - Method in class org.springframework.batch.repeat.policy.DefaultResultCompletionPolicy
Always false.
isComplete(RepeatContext, RepeatStatus) - Method in class org.springframework.batch.repeat.policy.SimpleCompletionPolicy
Terminate if the chunk size has been reached, or the result is null.
isComplete(RepeatContext) - Method in class org.springframework.batch.repeat.policy.SimpleCompletionPolicy
Terminate if the chunk size has been reached.
isComplete() - Method in class org.springframework.batch.repeat.policy.SimpleCompletionPolicy.SimpleTerminationContext
 
isComplete(RepeatContext) - Method in class org.springframework.batch.repeat.policy.TimeoutTerminationPolicy
Check the timeout and complete gracefully if it has expires.
isComplete() - Method in class org.springframework.batch.repeat.policy.TimeoutTerminationPolicy.TimeoutBatchContext
 
isComplete(RepeatContext, RepeatStatus) - Method in class org.springframework.batch.repeat.support.RepeatTemplate
Delegate to the CompletionPolicy.
isComplete(RepeatContext) - Method in class org.springframework.batch.repeat.support.RepeatTemplate
Delegate to CompletionPolicy.
isCompleteOnly() - Method in class org.springframework.batch.repeat.context.RepeatContextSupport
 
isCompleteOnly() - Method in interface org.springframework.batch.repeat.RepeatContext
Public accessor for the complete flag.
isContinuable() - Method in enum org.springframework.batch.repeat.RepeatStatus
 
isCopyConfiguration() - Method in class org.springframework.batch.core.configuration.support.AbstractApplicationContextFactory
Protected access for subclasses to the flag determining whether configuration should be copied from parent context.
isDirty() - Method in class org.springframework.batch.item.ExecutionContext
Indicates if context has been changed with a "put" operation since the dirty flag was last cleared.
isEagerInit() - Method in class org.springframework.batch.core.configuration.xml.JobParserJobFactoryBean
 
isEagerInit() - Method in class org.springframework.batch.core.jsr.configuration.xml.JobFactoryBean
 
isEmpty() - Method in class org.springframework.batch.core.JobParameters
 
isEmpty() - Method in class org.springframework.batch.core.step.item.Chunk
 
isEmpty() - Method in class org.springframework.batch.item.ExecutionContext
Indicates whether or not the context is empty.
isEmpty() - Method in class org.springframework.batch.repeat.support.ResultHolderResultQueue
 
isEmpty() - Method in class org.springframework.batch.repeat.support.ThrottleLimitResultQueue
 
isEnd() - Method in class org.springframework.batch.core.job.flow.FlowExecutionStatus
 
isEnd() - Method in class org.springframework.batch.core.job.flow.support.StateTransition
Check for a special next State signalling the end of a job.
isEnd() - Method in class org.springframework.batch.core.step.item.Chunk
Flag to indicate if the source data is exhausted.
isEndOfRecord(String) - Method in class org.springframework.batch.item.file.separator.DefaultRecordSeparatorPolicy
Return true if the line does not have unterminated quotes (delimited by "), and does not end with a continuation marker ('\').
isEndOfRecord(String) - Method in class org.springframework.batch.item.file.separator.JsonRecordSeparatorPolicy
True if the line can be parsed to a JSON object.
isEndOfRecord(String) - Method in interface org.springframework.batch.item.file.separator.RecordSeparatorPolicy
Signal the end of a record based on the content of the current record.
isEndOfRecord(String) - Method in class org.springframework.batch.item.file.separator.SimpleRecordSeparatorPolicy
Always returns true.
isEndOfRecord(String) - Method in class org.springframework.batch.item.file.separator.SuffixRecordSeparatorPolicy
Return true if the line ends with the specified substring.
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
 
isExistingTransaction(Object) - Method in class org.springframework.batch.support.transaction.ResourcelessTransactionManager
 
isExpecting() - Method in class org.springframework.batch.repeat.support.ResultHolderResultQueue
 
isExpecting() - Method in class org.springframework.batch.repeat.support.ThrottleLimitResultQueue
 
isFail() - Method in class org.springframework.batch.core.job.flow.FlowExecutionStatus
 
isFaultTolerant() - Method in class org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
 
isFlowContinued(State, FlowExecutionStatus, StepExecution) - Method in class org.springframework.batch.core.job.flow.support.SimpleFlow
 
isFlowContinued(State, FlowExecutionStatus, StepExecution) - Method in class org.springframework.batch.core.jsr.job.flow.support.JsrFlow
 
isFragmentRootElementName(QName) - Method in class org.springframework.batch.item.xml.StaxEventItemReader
 
isGreaterThan(BatchStatus) - Method in enum org.springframework.batch.core.BatchStatus
 
isIdentifying() - Method in class org.springframework.batch.core.JobParameter
 
isInitialized() - Method in class org.springframework.batch.item.support.AbstractFileItemWriter.OutputState
 
isJobInstanceExists(String, JobParameters) - Method in interface org.springframework.batch.core.repository.JobRepository
Check if an instance of this job already exists with the parameters provided.
isJobInstanceExists(String, JobParameters) - Method in class org.springframework.batch.core.repository.support.SimpleJobRepository
 
isLessThan(BatchStatus) - Method in enum org.springframework.batch.core.BatchStatus
 
isLessThanOrEqualTo(BatchStatus) - Method in enum org.springframework.batch.core.BatchStatus
 
isListener(Object, Class<?>, ListenerMetaData[]) - Static method in class org.springframework.batch.core.listener.AbstractListenerFactoryBean
Convenience method to check whether the given object is or can be made into a listener.
isListener(Object) - Static method in class org.springframework.batch.core.listener.JobListenerFactoryBean
Convenience method to check whether the given object is or can be made into a JobExecutionListener.
isListener(Object) - Static method in class org.springframework.batch.core.listener.StepListenerFactoryBean
Convenience method to check whether the given object is or can be made into a StepListener.
isNew(Object[]) - Method in class org.springframework.batch.item.jms.JmsNewMethodArgumentsIdentifier
If any of the arguments is a message, check the JMS re-delivered flag and return it, otherwise return false to be on the safe side.
isNonDefaultExitStatus(ExitStatus) - Static method in class org.springframework.batch.core.ExitStatus
 
isPrototype() - Method in class org.springframework.batch.core.configuration.xml.JobParserJobFactoryBean
 
isPrototype() - Method in class org.springframework.batch.core.jsr.configuration.xml.JobFactoryBean
 
isQuoteCharacter(char) - Method in class org.springframework.batch.item.file.transform.DelimitedLineTokenizer
Is the supplied character a quote character?
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.
isRedelivered() - Method in class org.springframework.batch.integration.chunk.ChunkResponse
 
isRestart() - Method in interface org.springframework.batch.core.job.flow.FlowExecutor
 
isRestart() - Method in class org.springframework.batch.core.job.flow.JobFlowExecutor
 
isRestartable() - Method in class org.springframework.batch.core.configuration.support.GroupAwareJob
 
isRestartable() - Method in class org.springframework.batch.core.job.AbstractJob
 
isRestartable() - Method in class org.springframework.batch.core.job.builder.JobBuilderHelper
 
isRestartable() - Method in interface org.springframework.batch.core.Job
Flag to indicate if this job can be restarted, at least in principle.
isRunning() - Method in enum org.springframework.batch.core.BatchStatus
Convenience method to decide if a status indicates work is in progress.
isRunning() - Method in class org.springframework.batch.core.configuration.support.AutomaticJobRegistrar
Check if this component has been started.
isRunning() - Method in class org.springframework.batch.core.ExitStatus
Check if this status represents a running process.
isRunning() - Method in class org.springframework.batch.core.JobExecution
Test if this JobExecution indicates that it is running.
isSaveState() - Method in class org.springframework.batch.item.kafka.KafkaItemReader
The flag that determines whether to save internal state for restarts.
isSaveState() - Method in class org.springframework.batch.item.support.AbstractItemCountingItemStreamItemReader
The flag that determines whether to save internal state for restarts.
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.jsr.configuration.support.BaseContextListFactoryBean
 
isSingleton() - Method in class org.springframework.batch.core.jsr.configuration.xml.DecisionStepFactoryBean
 
isSingleton() - Method in class org.springframework.batch.core.jsr.configuration.xml.JobFactoryBean
 
isSingleton() - Method in class org.springframework.batch.core.jsr.JsrJobContextFactoryBean
 
isSingleton() - Method in class org.springframework.batch.core.jsr.JsrStepContextFactoryBean
 
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.
isSingleton() - Method in class org.springframework.batch.integration.chunk.RemoteChunkHandlerFactoryBean
Optimization for the bean factory (always returns true).
isSingleton() - Method in class org.springframework.batch.item.database.support.SqlPagingQueryProviderFactoryBean
Always returns true.
isStartable(StepExecution, ExecutionContext) - Method in class org.springframework.batch.core.partition.support.SimpleStepExecutionSplitter
Check if a step execution is startable.
isStatelessSession() - Method in class org.springframework.batch.item.database.orm.AbstractHibernateQueryProvider
 
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.
isStrict() - Method in class org.springframework.batch.item.file.transform.AbstractLineTokenizer
Provides access to the strict flag for subclasses if needed.
isSuccessful() - Method in class org.springframework.batch.integration.chunk.ChunkResponse
 
isSupportedIncrementerType(String) - Method in interface org.springframework.batch.item.database.support.DataFieldMaxValueIncrementerFactory
Returns boolean indicated whether or not the provided string is supported by this factory.
isSupportedIncrementerType(String) - Method in class org.springframework.batch.item.database.support.DefaultDataFieldMaxValueIncrementerFactory
 
isTerminateOnly() - Method in class org.springframework.batch.core.StepExecution
 
isTerminateOnly() - Method in class org.springframework.batch.repeat.context.RepeatContextSupport
 
isTerminateOnly() - Method in interface org.springframework.batch.repeat.RepeatContext
Public accessor for the termination flag.
isUnderspecified(Element) - Static method in class org.springframework.batch.core.configuration.xml.CoreNamespaceUtils
Should this element be treated as incomplete? If it has a parent or is abstract, then it may not have all properties.
isUnsuccessful() - Method in enum org.springframework.batch.core.BatchStatus
Convenience method to decide if a status indicates execution was unsuccessful.
isUseSharedExtendedConnection() - Method in class org.springframework.batch.item.database.AbstractCursorItemReader
 
isUsingNamedParameters() - Method in interface org.springframework.batch.item.database.PagingQueryProvider
Indicate whether the generated queries use named parameter syntax.
isUsingNamedParameters() - Method in class org.springframework.batch.item.database.support.AbstractSqlPagingQueryProvider
 
isWrapperFor(Class<?>) - Method in class org.springframework.batch.item.database.ExtendedConnectionDataSourceProxy
Performs only a 'shallow' non-recursive check of self's and delegate's class to retain Java 5 compatibility.
itemBindingVariableName(String) - Method in class org.springframework.batch.item.support.builder.ScriptItemProcessorBuilder
Provides the ability to change the key name that scripts use to obtain the current item to process if the variable represented by: ScriptItemProcessor.ITEM_BINDING_VARIABLE_NAME is not suitable ("item").
ItemCountAware - Interface in org.springframework.batch.item
Marker interface indicating that an item should have the item count set on it.
itemCountLimitPerResource(int) - Method in class org.springframework.batch.item.file.builder.MultiResourceItemWriterBuilder
After this limit is exceeded the next chunk will be written into newly created resource.
itemKeyMapper(Converter<V, K>) - Method in class org.springframework.batch.item.data.builder.GemfireItemWriterBuilder
Set the Converter to use to derive the key from the item.
itemKeyMapper(Converter<V, K>) - Method in class org.springframework.batch.item.kafka.builder.KafkaItemWriterBuilder
Set the Converter to use to derive the key from the item.
itemKeyMapper - Variable in class org.springframework.batch.item.KeyValueItemWriter
 
itemListenerMetaData() - Static method in enum org.springframework.batch.core.listener.StepListenerMetaData
 
ItemListenerSupport<I,O> - Class in org.springframework.batch.core.listener
Basic no-op implementation of the ItemReadListener, ItemProcessListener, and ItemWriteListener interfaces.
ItemListenerSupport() - Constructor for class org.springframework.batch.core.listener.ItemListenerSupport
 
itemPreparedStatementSetter(ItemPreparedStatementSetter<T>) - Method in class org.springframework.batch.item.database.builder.JdbcBatchItemWriterBuilder
Configures a ItemPreparedStatementSetter for use by the writer.
ItemPreparedStatementSetter<T> - Interface in org.springframework.batch.item.database
A convenient strategy for SQL updates, acting effectively as the inverse of RowMapper.
itemPreparedStatementSetter - Variable in class org.springframework.batch.item.database.JdbcBatchItemWriter
 
ItemProcessListener<T,S> - Interface in org.springframework.batch.core
Listener interface for the processing of an item.
ItemProcessListenerAdapter<T,S> - Class in org.springframework.batch.core.jsr
Wrapper class for ItemProcessListener
ItemProcessListenerAdapter(ItemProcessListener) - Constructor for class org.springframework.batch.core.jsr.ItemProcessListenerAdapter
 
itemProcessor(ItemProcessor<I, O>) - Method in class org.springframework.batch.integration.chunk.RemoteChunkingWorkerBuilder
Set the ItemProcessor to use to process items sent by the master step.
ItemProcessor<I,O> - Interface in org.springframework.batch.item
Interface for item transformation.
ItemProcessorAdapter<I,O> - Class in org.springframework.batch.item.adapter
Invokes a custom method on a delegate plain old Java object which itself processes an item.
ItemProcessorAdapter() - Constructor for class org.springframework.batch.item.adapter.ItemProcessorAdapter
 
ItemProcessorAdapter<I,O> - Class in org.springframework.batch.jsr.item
 
ItemProcessorAdapter(ItemProcessor) - Constructor for class org.springframework.batch.jsr.item.ItemProcessorAdapter
 
itemReader - Variable in class org.springframework.batch.core.step.item.SimpleChunkProvider
 
ItemReader<T> - Interface in org.springframework.batch.item
Strategy interface for providing the data.
ItemReaderAdapter<T> - Class in org.springframework.batch.item.adapter
Invokes a custom method on a delegate plain old Java object which itself provides an item.
ItemReaderAdapter() - Constructor for class org.springframework.batch.item.adapter.ItemReaderAdapter
 
ItemReaderAdapter<T> - Class in org.springframework.batch.jsr.item
Adapter that wraps an ItemReader for use by Spring Batch.
ItemReaderAdapter(ItemReader) - Constructor for class org.springframework.batch.jsr.item.ItemReaderAdapter
 
ItemReaderException - Exception in org.springframework.batch.item
A base exception class that all exceptions thrown from an ItemReader extend.
ItemReaderException(String, Throwable) - Constructor for exception org.springframework.batch.item.ItemReaderException
Create a new ItemReaderException based on a message and another exception.
ItemReaderException(String) - Constructor for exception org.springframework.batch.item.ItemReaderException
Create a new ItemReaderException based on a message.
ItemReadListener<T> - Interface in org.springframework.batch.core
Listener interface around the reading of an item.
ItemReadListenerAdapter<T> - Class in org.springframework.batch.core.jsr
Wrapper class to adapt the ItemReadListener to a ItemReadListener.
ItemReadListenerAdapter(ItemReadListener) - Constructor for class org.springframework.batch.core.jsr.ItemReadListenerAdapter
 
itemSqlParameterSourceProvider(ItemSqlParameterSourceProvider<T>) - Method in class org.springframework.batch.item.database.builder.JdbcBatchItemWriterBuilder
Configures a ItemSqlParameterSourceProvider for use by the writer.
ItemSqlParameterSourceProvider<T> - Interface in org.springframework.batch.item.database
A convenient strategy for providing SqlParameterSource for named parameter SQL updates.
itemSqlParameterSourceProvider - Variable in class org.springframework.batch.item.database.JdbcBatchItemWriter
 
ItemStream - Interface in org.springframework.batch.item
Marker interface defining a contract for periodically storing state and restoring from that state should an error occur.
ItemStreamException - Exception in org.springframework.batch.item
Exception representing any errors encountered while processing a stream.
ItemStreamException(String) - Constructor for exception org.springframework.batch.item.ItemStreamException
 
ItemStreamException(String, Throwable) - Constructor for exception org.springframework.batch.item.ItemStreamException
Constructs a new instance with a message and nested exception.
ItemStreamException(Throwable) - Constructor for exception org.springframework.batch.item.ItemStreamException
Constructs a new instance with a nested exception and empty message.
ItemStreamReader<T> - Interface in org.springframework.batch.item
Convenience interface that combines ItemStream and ItemReader .
ItemStreamSupport - Class in org.springframework.batch.item
Empty method implementation of ItemStream.
ItemStreamSupport() - Constructor for class org.springframework.batch.item.ItemStreamSupport
 
ItemStreamWriter<T> - Interface in org.springframework.batch.item
Convenience interface that combines ItemStream and ItemWriter .
itemType(Class<? extends T>) - Method in class org.springframework.batch.item.amqp.builder.AmqpItemReaderBuilder
Establish the itemType for the reader.
itemType - Variable in class org.springframework.batch.item.jms.builder.JmsItemReaderBuilder
 
itemType(Class<? extends T>) - Method in class org.springframework.batch.item.jms.builder.JmsItemReaderBuilder
Set the expected type of incoming message payloads.
itemType - Variable in class org.springframework.batch.item.jms.JmsItemReader
 
ItemWriteListener<S> - Interface in org.springframework.batch.core
Listener interface for the writing of items.
ItemWriteListenerAdapter<S> - Class in org.springframework.batch.core.jsr
Wrapper class to adapt the ItemWriteListener to a ItemWriteListener.
ItemWriteListenerAdapter(ItemWriteListener) - Constructor for class org.springframework.batch.core.jsr.ItemWriteListenerAdapter
 
itemWriter(ItemWriter<O>) - Method in class org.springframework.batch.integration.chunk.RemoteChunkingWorkerBuilder
Set the ItemWriter to use to write items sent by the master step.
ItemWriter<T> - Interface in org.springframework.batch.item
Basic interface for generic output operations.
ItemWriterAdapter<T> - Class in org.springframework.batch.item.adapter
Delegates item processing to a custom method - passes the item as an argument for the delegate method.
ItemWriterAdapter() - Constructor for class org.springframework.batch.item.adapter.ItemWriterAdapter
 
ItemWriterAdapter<T> - Class in org.springframework.batch.jsr.item
Adapter that wraps an ItemWriter for use by Spring Batch.
ItemWriterAdapter(ItemWriter) - Constructor for class org.springframework.batch.jsr.item.ItemWriterAdapter
 
ItemWriterException - Exception in org.springframework.batch.item
A base exception class that all exceptions thrown from an ItemWriter extend.
ItemWriterException(String, Throwable) - Constructor for exception org.springframework.batch.item.ItemWriterException
Create a new ItemWriterException based on a message and another exception.
ItemWriterException(String) - Constructor for exception org.springframework.batch.item.ItemWriterException
Create a new ItemWriterException based on a message.
iterate(RepeatCallback) - Method in interface org.springframework.batch.repeat.RepeatOperations
Execute the callback repeatedly, until a decision can be made to complete.
iterate(RepeatCallback) - Method in class org.springframework.batch.repeat.support.RepeatTemplate
Execute the batch callback until the completion policy decides that we are finished.
iterator() - Method in class org.springframework.batch.core.step.item.Chunk
Get an unmodifiable iterator for the underlying items.
IteratorItemReader<T> - Class in org.springframework.batch.item.support
An ItemReader that pulls data from a Iterator or Iterable using the constructors.
IteratorItemReader(Iterable<T>) - Constructor for class org.springframework.batch.item.support.IteratorItemReader
Construct a new reader from this iterable (could be a collection), by extracting an instance of Iterator from it.
IteratorItemReader(Iterator<T>) - Constructor for class org.springframework.batch.item.support.IteratorItemReader
Construct a new reader from this iterator directly.

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
JacksonJsonObjectMarshaller<T> - Class in org.springframework.batch.item.json
A json object marshaller that uses Jackson to marshal an object into a json representation.
JacksonJsonObjectMarshaller() - Constructor for class org.springframework.batch.item.json.JacksonJsonObjectMarshaller
 
JacksonJsonObjectMarshaller(ObjectMapper) - Constructor for class org.springframework.batch.item.json.JacksonJsonObjectMarshaller
 
JacksonJsonObjectReader<T> - Class in org.springframework.batch.item.json
Implementation of JsonObjectReader based on Jackson.
JacksonJsonObjectReader(Class<? extends T>) - Constructor for class org.springframework.batch.item.json.JacksonJsonObjectReader
Create a new JacksonJsonObjectReader instance.
JacksonJsonObjectReader(ObjectMapper, Class<? extends T>) - Constructor for class org.springframework.batch.item.json.JacksonJsonObjectReader
 
JdbcBatchItemWriter<T> - Class in org.springframework.batch.item.database
ItemWriter that uses the batching features from NamedParameterJdbcTemplate to execute a batch of statements for all items provided.
JdbcBatchItemWriter() - Constructor for class org.springframework.batch.item.database.JdbcBatchItemWriter
 
JdbcBatchItemWriterBuilder<T> - Class in org.springframework.batch.item.database.builder
A builder implementation for the JdbcBatchItemWriter.
JdbcBatchItemWriterBuilder() - Constructor for class org.springframework.batch.item.database.builder.JdbcBatchItemWriterBuilder
 
JdbcCursorItemReader<T> - Class in org.springframework.batch.item.database
Simple item reader implementation that opens a JDBC cursor and continually retrieves the next row in the ResultSet.
JdbcCursorItemReader() - Constructor for class org.springframework.batch.item.database.JdbcCursorItemReader
 
JdbcCursorItemReaderBuilder<T> - Class in org.springframework.batch.item.database.builder
Builder for the JdbcCursorItemReader
JdbcCursorItemReaderBuilder() - Constructor for class org.springframework.batch.item.database.builder.JdbcCursorItemReaderBuilder
 
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
 
JdbcPagingItemReader<T> - Class in org.springframework.batch.item.database
ItemReader for reading database records using JDBC in a paging fashion.
JdbcPagingItemReader() - Constructor for class org.springframework.batch.item.database.JdbcPagingItemReader
 
JdbcPagingItemReaderBuilder<T> - Class in org.springframework.batch.item.database.builder
This is a builder for the JdbcPagingItemReader.
JdbcPagingItemReaderBuilder() - Constructor for class org.springframework.batch.item.database.builder.JdbcPagingItemReaderBuilder
 
JdbcParameterUtils - Class in org.springframework.batch.item.database
Helper methods for SQL statement parameter parsing.
JdbcParameterUtils() - Constructor for class org.springframework.batch.item.database.JdbcParameterUtils
 
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
 
JmsItemReader<T> - Class in org.springframework.batch.item.jms
An ItemReader for JMS using a JmsTemplate.
JmsItemReader() - Constructor for class org.springframework.batch.item.jms.JmsItemReader
 
JmsItemReaderBuilder<T> - Class in org.springframework.batch.item.jms.builder
Creates a fully qualified JmsItemReader.
JmsItemReaderBuilder() - Constructor for class org.springframework.batch.item.jms.builder.JmsItemReaderBuilder
 
JmsItemWriter<T> - Class in org.springframework.batch.item.jms
An ItemWriter for JMS using a JmsTemplate.
JmsItemWriter() - Constructor for class org.springframework.batch.item.jms.JmsItemWriter
 
JmsItemWriterBuilder<T> - Class in org.springframework.batch.item.jms.builder
Creates a fully qualified JmsItemWriter.
JmsItemWriterBuilder() - Constructor for class org.springframework.batch.item.jms.builder.JmsItemWriterBuilder
 
JmsMethodArgumentsKeyGenerator - Class in org.springframework.batch.item.jms
A MethodArgumentsKeyGenerator for JMS
JmsMethodArgumentsKeyGenerator() - Constructor for class org.springframework.batch.item.jms.JmsMethodArgumentsKeyGenerator
 
JmsMethodInvocationRecoverer<T> - Class in org.springframework.batch.item.jms
 
JmsMethodInvocationRecoverer() - Constructor for class org.springframework.batch.item.jms.JmsMethodInvocationRecoverer
 
JmsNewMethodArgumentsIdentifier<T> - Class in org.springframework.batch.item.jms
A NewMethodArgumentsIdentifier for JMS that looks for a message in the arguments and checks its delivery status.
JmsNewMethodArgumentsIdentifier() - Constructor for class org.springframework.batch.item.jms.JmsNewMethodArgumentsIdentifier
 
JmsRedeliveredExtractor - Class in org.springframework.batch.integration.chunk
 
JmsRedeliveredExtractor() - Constructor for class org.springframework.batch.integration.chunk.JmsRedeliveredExtractor
 
jmsTemplate - Variable in class org.springframework.batch.item.jms.builder.JmsItemReaderBuilder
 
jmsTemplate(JmsOperations) - Method in class org.springframework.batch.item.jms.builder.JmsItemReaderBuilder
Establish the JMS template that will be used by the JmsItemReader.
jmsTemplate(JmsOperations) - Method in class org.springframework.batch.item.jms.builder.JmsItemWriterBuilder
Establish the JMS template that will be used by the JmsItemWriter.
jmsTemplate - Variable in class org.springframework.batch.item.jms.JmsItemReader
 
Job - Interface in org.springframework.batch.core
Batch domain object representing a job.
job(Job) - Method in class org.springframework.batch.core.step.builder.JobStepBuilder
Provide a job to execute during the step.
job(Job) - Method in class org.springframework.batch.core.step.builder.StepBuilder
Create a new step builder that will execute a job.
job(Job) - Method in class org.springframework.batch.integration.partition.RemotePartitioningWorkerStepBuilder
 
JOB_NOT_PROVIDED - Static variable in interface org.springframework.batch.core.launch.support.ExitCodeMapper
 
JOB_RUN_ID - Static variable in class org.springframework.batch.core.jsr.JsrJobParametersConverter
 
JobBuilder - Class in org.springframework.batch.core.job.builder
Convenience for building jobs of various kinds.
JobBuilder(String) - Constructor for class org.springframework.batch.core.job.builder.JobBuilder
Create a new builder for a job with the given name.
JobBuilderException - Exception in org.springframework.batch.core.job.builder
 
JobBuilderException(Exception) - Constructor for exception org.springframework.batch.core.job.builder.JobBuilderException
 
JobBuilderFactory - Class in org.springframework.batch.core.configuration.annotation
Convenient factory for a JobBuilder which sets the JobRepository automatically.
JobBuilderFactory(JobRepository) - Constructor for class org.springframework.batch.core.configuration.annotation.JobBuilderFactory
 
JobBuilderHelper<B extends JobBuilderHelper<B>> - Class in org.springframework.batch.core.job.builder
A base class and utility for other job builders providing access to common properties like job repository.
JobBuilderHelper(String) - Constructor for class org.springframework.batch.core.job.builder.JobBuilderHelper
 
JobBuilderHelper(JobBuilderHelper<?>) - Constructor for class org.springframework.batch.core.job.builder.JobBuilderHelper
Create a new builder initialized with any properties in the parent.
JobBuilderHelper.CommonJobProperties - Class in org.springframework.batch.core.job.builder
 
jobBuilders() - Method in class org.springframework.batch.core.configuration.annotation.AbstractBatchConfiguration
 
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(JobExecution) - Constructor for class org.springframework.batch.core.JobExecution
 
JobExecution(JobInstance, Long, JobParameters, String) - Constructor for class org.springframework.batch.core.JobExecution
Because a JobExecution isn't valid unless the job is set, this constructor is the only valid one from a modeling point of view.
JobExecution(JobInstance, JobParameters, String) - Constructor for class org.springframework.batch.core.JobExecution
 
JobExecution(Long, JobParameters, String) - Constructor for class org.springframework.batch.core.JobExecution
 
JobExecution(JobInstance, JobParameters) - Constructor for class org.springframework.batch.core.JobExecution
Constructor for transient (unsaved) instances.
JobExecution(Long, JobParameters) - Constructor for class org.springframework.batch.core.JobExecution
 
JobExecution(Long) - Constructor for class org.springframework.batch.core.JobExecution
 
JobExecutionAlreadyRunningException - Exception in org.springframework.batch.core.repository
 
JobExecutionAlreadyRunningException(String) - Constructor for exception org.springframework.batch.core.repository.JobExecutionAlreadyRunningException
 
JobExecutionAlreadyRunningException(String, Throwable) - Constructor for exception org.springframework.batch.core.repository.JobExecutionAlreadyRunningException
 
JobExecutionDao - Interface in org.springframework.batch.core.repository.dao
Data Access Object for job executions.
JobExecutionDecider - Interface in org.springframework.batch.core.job.flow
Interface allowing for programmatic access to the decision on what the status of a flow should be.
JobExecutionException - Exception in org.springframework.batch.core
Root of exception hierarchy for checked exceptions in job and step execution.
JobExecutionException(String) - Constructor for exception org.springframework.batch.core.JobExecutionException
Construct a JobExecutionException with a generic message.
JobExecutionException(String, Throwable) - Constructor for exception org.springframework.batch.core.JobExecutionException
Construct a JobExecutionException with a generic message and a cause.
JobExecutionListener - Interface in org.springframework.batch.core
Provide callbacks at specific points in the lifecycle of a Job.
JobExecutionListenerParser - Class in org.springframework.batch.core.configuration.xml
Parser for a step listener element.
JobExecutionListenerParser() - Constructor for class org.springframework.batch.core.configuration.xml.JobExecutionListenerParser
 
JobExecutionListenerSupport - Class in org.springframework.batch.core.listener
 
JobExecutionListenerSupport() - Constructor for class org.springframework.batch.core.listener.JobExecutionListenerSupport
 
JobExecutionNotFailedException - Exception in org.springframework.batch.core.launch
Checked exception to indicate that user asked for a job execution to be resumed when actually it didn't fail.
JobExecutionNotFailedException(String) - Constructor for exception org.springframework.batch.core.launch.JobExecutionNotFailedException
Create an exception with the given message.
JobExecutionNotFailedException(String, Throwable) - Constructor for exception org.springframework.batch.core.launch.JobExecutionNotFailedException
 
JobExecutionNotRunningException - Exception in org.springframework.batch.core.launch
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.annotation.AbstractBatchConfiguration
 
jobExplorer() - Method in class org.springframework.batch.core.configuration.annotation.ModularBatchConfiguration
 
jobExplorer() - Method in class org.springframework.batch.core.configuration.annotation.SimpleBatchConfiguration
 
JobExplorer - Interface in org.springframework.batch.core.explore
Entry point for browsing executions of running or historical jobs and steps.
jobExplorer(JobExplorer) - Method in class org.springframework.batch.integration.partition.RemotePartitioningManagerStepBuilder
Set the job explorer.
jobExplorer(JobExplorer) - Method in class org.springframework.batch.integration.partition.RemotePartitioningMasterStepBuilder
Deprecated.
Set the job explorer.
jobExplorer(JobExplorer) - Method in class org.springframework.batch.integration.partition.RemotePartitioningWorkerStepBuilder
Set the job explorer.
JobExplorerFactoryBean - Class in org.springframework.batch.core.explore.support
A FactoryBean that automates the creation of a SimpleJobExplorer using JDBC DAO implementations.
JobExplorerFactoryBean() - Constructor for class org.springframework.batch.core.explore.support.JobExplorerFactoryBean
 
JobFactory - Interface in org.springframework.batch.core.configuration
Strategy for creating a single job.
JobFactoryBean - Class in org.springframework.batch.core.jsr.configuration.xml
This FactoryBean is used by the JSR-352 namespace parser to create FlowJob objects.
JobFactoryBean(String) - Constructor for class org.springframework.batch.core.jsr.configuration.xml.JobFactoryBean
 
JobFactoryRegistrationListener - Class in org.springframework.batch.core.configuration.support
Generic service that can bind and unbind a JobFactory in a JobRegistry.
JobFactoryRegistrationListener() - Constructor for class org.springframework.batch.core.configuration.support.JobFactoryRegistrationListener
 
JobFlowBuilder - Class in org.springframework.batch.core.job.builder
 
JobFlowBuilder(FlowJobBuilder) - Constructor for class org.springframework.batch.core.job.builder.JobFlowBuilder
 
JobFlowBuilder(FlowJobBuilder, Step) - Constructor for class org.springframework.batch.core.job.builder.JobFlowBuilder
 
JobFlowBuilder(FlowJobBuilder, JobExecutionDecider) - Constructor for class org.springframework.batch.core.job.builder.JobFlowBuilder
 
JobFlowBuilder(FlowJobBuilder, Flow) - Constructor for class org.springframework.batch.core.job.builder.JobFlowBuilder
 
JobFlowExecutor - Class in org.springframework.batch.core.job.flow
Implementation of FlowExecutor for use in components that need to execute a flow related to a JobExecution.
JobFlowExecutor(JobRepository, StepHandler, JobExecution) - Constructor for class org.springframework.batch.core.job.flow.JobFlowExecutor
 
JobInstance - Class in org.springframework.batch.core
Batch domain object representing a uniquely identifiable job run.
JobInstance(Long, String) - Constructor for class org.springframework.batch.core.JobInstance
 
JobInstanceAlreadyCompleteException - Exception in org.springframework.batch.core.repository
An exception indicating an illegal attempt to restart a job that was already completed successfully.
JobInstanceAlreadyCompleteException(String) - Constructor for exception org.springframework.batch.core.repository.JobInstanceAlreadyCompleteException
 
JobInstanceAlreadyCompleteException(String, Throwable) - Constructor for exception org.springframework.batch.core.repository.JobInstanceAlreadyCompleteException
 
JobInstanceAlreadyExistsException - Exception in org.springframework.batch.core.launch
Checked exception to indicate that a required Job is not available.
JobInstanceAlreadyExistsException(String) - Constructor for exception org.springframework.batch.core.launch.JobInstanceAlreadyExistsException
Create an exception with the given message.
JobInstanceAlreadyExistsException(String, Throwable) - Constructor for exception org.springframework.batch.core.launch.JobInstanceAlreadyExistsException
 
JobInstanceDao - Interface in org.springframework.batch.core.repository.dao
Data Access Object for job instances.
JobInterruptedException - Exception in org.springframework.batch.core
Exception to indicate the job has been interrupted.
JobInterruptedException(String) - Constructor for exception org.springframework.batch.core.JobInterruptedException
 
JobInterruptedException(String, BatchStatus) - Constructor for exception org.springframework.batch.core.JobInterruptedException
 
JobKeyGenerator<T> - Interface in org.springframework.batch.core
Strategy interface for the generation of the key used in identifying unique JobInstance.
jobLauncher() - Method in class org.springframework.batch.core.configuration.annotation.AbstractBatchConfiguration
 
jobLauncher() - Method in class org.springframework.batch.core.configuration.annotation.ModularBatchConfiguration
 
jobLauncher() - Method in class org.springframework.batch.core.configuration.annotation.SimpleBatchConfiguration
 
JobLauncher - Interface in org.springframework.batch.core.launch
Simple interface for controlling jobs, including possible ad-hoc executions, based on different runtime identifiers.
JobLauncherTestUtils - Class in org.springframework.batch.test
Utility class for testing batch jobs.
JobLauncherTestUtils() - Constructor for class org.springframework.batch.test.JobLauncherTestUtils
 
JobLaunchingGateway - Class in org.springframework.batch.integration.launch
The JobLaunchingGateway is used to launch Batch Jobs.
JobLaunchingGateway(JobLauncher) - Constructor for class org.springframework.batch.integration.launch.JobLaunchingGateway
Constructor taking a JobLauncher as parameter.
JobLaunchingGatewayParser - Class in org.springframework.batch.integration.config.xml
The parser for the Job-Launching Gateway, which will instantiate a JobLaunchingGatewayParser.
JobLaunchingGatewayParser() - Constructor for class org.springframework.batch.integration.config.xml.JobLaunchingGatewayParser
 
JobLaunchingMessageHandler - Class in org.springframework.batch.integration.launch
Message handler which uses strategies to convert a Message into a job and a set of job parameters
JobLaunchingMessageHandler(JobLauncher) - Constructor for class org.springframework.batch.integration.launch.JobLaunchingMessageHandler
 
JobLaunchRequest - Class in org.springframework.batch.integration.launch
Encapsulation of a Job and its JobParameters forming a request for a job to be launched.
JobLaunchRequest(Job, JobParameters) - Constructor for class org.springframework.batch.integration.launch.JobLaunchRequest
 
JobLaunchRequestHandler - Interface in org.springframework.batch.integration.launch
Interface for handling a JobLaunchRequest and returning a JobExecution.
JobLevelBeanLazyInitializer(ConfigurableListableBeanFactory) - Constructor for class org.springframework.batch.core.jsr.partition.support.JsrBeanScopeBeanFactoryPostProcessor.JobLevelBeanLazyInitializer
 
JobListenerAdapter - Class in org.springframework.batch.core.jsr
Wrapper class to adapt the JobListener to a JobExecutionListener.
JobListenerAdapter(JobListener) - Constructor for class org.springframework.batch.core.jsr.JobListenerAdapter
 
JobListenerFactoryBean - Class in org.springframework.batch.core.listener
This AbstractListenerFactoryBean implementation is used to create a JobExecutionListener.
JobListenerFactoryBean() - Constructor for class org.springframework.batch.core.listener.JobListenerFactoryBean
 
JobListenerMetaData - Enum in org.springframework.batch.core.listener
Enumeration for JobExecutionListener meta data, which ties together the names of methods, their interfaces, annotation, and expected arguments.
JobLoader - Interface in org.springframework.batch.core.configuration.support
 
JobLocator - Interface in org.springframework.batch.core.configuration
A runtime service locator interface for retrieving job configurations by name.
JobOperator - Interface in org.springframework.batch.core.launch
Low level interface for inspecting and controlling jobs with access only to primitive and collection types.
JobParameter - Class in org.springframework.batch.core
Domain representation of a parameter to a batch job.
JobParameter(String, boolean) - Constructor for class org.springframework.batch.core.JobParameter
Construct a new JobParameter as a String.
JobParameter(Long, boolean) - Constructor for class org.springframework.batch.core.JobParameter
Construct a new JobParameter as a Long.
JobParameter(Date, boolean) - Constructor for class org.springframework.batch.core.JobParameter
Construct a new JobParameter as a Date.
JobParameter(Double, boolean) - Constructor for class org.springframework.batch.core.JobParameter
Construct a new JobParameter as a Double.
JobParameter(String) - Constructor for class org.springframework.batch.core.JobParameter
Construct a new JobParameter as a String.
JobParameter(Long) - Constructor for class org.springframework.batch.core.JobParameter
Construct a new JobParameter as a Long.
JobParameter(Date) - Constructor for class org.springframework.batch.core.JobParameter
Construct a new JobParameter as a Date.
JobParameter(Double) - Constructor for class org.springframework.batch.core.JobParameter
Construct a new JobParameter as a Double.
JobParameter.ParameterType - Enum in org.springframework.batch.core
Enumeration representing the type of a JobParameter.
JobParameterExecutionContextCopyListener - Class in org.springframework.batch.core.listener
This class can be used to automatically copy items from the JobParameters to the Step ExecutionContext.
JobParameterExecutionContextCopyListener() - Constructor for class org.springframework.batch.core.listener.JobParameterExecutionContextCopyListener
 
JobParameters - Class in org.springframework.batch.core
Value object representing runtime parameters to a batch job.
JobParameters() - Constructor for class org.springframework.batch.core.JobParameters
 
JobParameters(Map<String, JobParameter>) - Constructor for class org.springframework.batch.core.JobParameters
 
JobParametersBuilder - Class in org.springframework.batch.core
Helper class for creating JobParameters.
JobParametersBuilder() - Constructor for class org.springframework.batch.core.JobParametersBuilder
Default constructor.
JobParametersBuilder(JobExplorer) - Constructor for class org.springframework.batch.core.JobParametersBuilder
 
JobParametersBuilder(JobParameters) - Constructor for class org.springframework.batch.core.JobParametersBuilder
Copy constructor.
JobParametersBuilder(Properties) - Constructor for class org.springframework.batch.core.JobParametersBuilder
Constructor to add conversion capabilities to support JSR-352.
JobParametersBuilder(JobParameters, JobExplorer) - Constructor for class org.springframework.batch.core.JobParametersBuilder
Copy constructor.
JobParametersConverter - Interface in org.springframework.batch.core.converter
A factory for JobParameters instances.
JobParametersExtractor - Interface in org.springframework.batch.core.step.job
Strategy interface for translating a StepExecution into JobParameters.
JobParametersIncrementer - Interface in org.springframework.batch.core
Interface for obtaining the next JobParameters in a sequence.
JobParametersInvalidException - Exception in org.springframework.batch.core
Exception for Job to signal that some JobParameters are invalid.
JobParametersInvalidException(String) - Constructor for exception org.springframework.batch.core.JobParametersInvalidException
 
JobParametersNotFoundException - Exception in org.springframework.batch.core.launch
Checked exception to indicate that a required JobParametersIncrementer is not available.
JobParametersNotFoundException(String) - Constructor for exception org.springframework.batch.core.launch.JobParametersNotFoundException
Create an exception with the given message.
JobParametersNotFoundException(String, Throwable) - Constructor for exception org.springframework.batch.core.launch.JobParametersNotFoundException
 
JobParametersValidator - Interface in org.springframework.batch.core
Strategy interface for a Job to use in validating its parameters for an execution.
JobParser - Class in org.springframework.batch.core.configuration.xml
Parser for the <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
 
jobRegistrar() - Method in class org.springframework.batch.core.configuration.annotation.ModularBatchConfiguration
 
jobRegistry() - Method in class org.springframework.batch.core.configuration.annotation.AbstractBatchConfiguration
 
jobRegistry() - Method in class org.springframework.batch.core.configuration.annotation.SimpleBatchConfiguration
 
JobRegistry - Interface in org.springframework.batch.core.configuration
A runtime service registry interface for registering job configurations by name.
JobRegistryBackgroundJobRunner - Class in org.springframework.batch.core.launch.support
Command line launcher for registering jobs with a JobRegistry.
JobRegistryBackgroundJobRunner(String) - Constructor for class org.springframework.batch.core.launch.support.JobRegistryBackgroundJobRunner
 
JobRegistryBeanPostProcessor - Class in org.springframework.batch.core.configuration.support
A BeanPostProcessor that registers Job beans with a JobRegistry.
JobRegistryBeanPostProcessor() - Constructor for class org.springframework.batch.core.configuration.support.JobRegistryBeanPostProcessor
 
jobRepository() - Method in class org.springframework.batch.core.configuration.annotation.AbstractBatchConfiguration
 
jobRepository() - Method in class org.springframework.batch.core.configuration.annotation.ModularBatchConfiguration
 
jobRepository() - Method in class org.springframework.batch.core.configuration.annotation.SimpleBatchConfiguration
 
JobRepository - Interface in org.springframework.batch.core.repository
Repository responsible for persistence of batch meta-data entities.
JobRepositoryFactoryBean - Class in org.springframework.batch.core.repository.support
A FactoryBean that automates the creation of a SimpleJobRepository using JDBC DAO implementations which persist batch metadata in database.
JobRepositoryFactoryBean() - Constructor for class org.springframework.batch.core.repository.support.JobRepositoryFactoryBean
 
JobRepositoryParser - Class in org.springframework.batch.core.configuration.xml
Parser for the <job-repository/> element in the Batch namespace.
JobRepositoryParser() - Constructor for class org.springframework.batch.core.configuration.xml.JobRepositoryParser
 
JobRepositoryTestUtils - Class in org.springframework.batch.test
Convenience class for creating and removing JobExecution instances from a database.
JobRepositoryTestUtils() - Constructor for class org.springframework.batch.test.JobRepositoryTestUtils
Default constructor.
JobRepositoryTestUtils(JobRepository, DataSource) - Constructor for class org.springframework.batch.test.JobRepositoryTestUtils
Create a JobRepositoryTestUtils with all its mandatory properties.
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 - Annotation Type in org.springframework.batch.core.configuration.annotation
Convenient annotation for job scoped beans that defaults the proxy mode, so that it doesn't have to be specified explicitly on every bean definition.
JobScope - Class in org.springframework.batch.core.scope
Scope for job context.
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
 
JobScopeTestExecutionListener - Class in org.springframework.batch.test
A TestExecutionListener that sets up job-scope context for dependency injection into unit tests.
JobScopeTestExecutionListener() - Constructor for class org.springframework.batch.test.JobScopeTestExecutionListener
 
JobScopeTestUtils - Class in org.springframework.batch.test
Utility class for creating and manipulating JobScope in unit tests.
JobScopeTestUtils() - Constructor for class org.springframework.batch.test.JobScopeTestUtils
 
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
 
JpaCursorItemReader<T> - Class in org.springframework.batch.item.database
ItemStreamReader implementation based on JPA Query.getResultStream().
JpaCursorItemReader() - Constructor for class org.springframework.batch.item.database.JpaCursorItemReader
Create a new JpaCursorItemReader.
JpaCursorItemReaderBuilder<T> - Class in org.springframework.batch.item.database.builder
Builder for JpaCursorItemReader.
JpaCursorItemReaderBuilder() - Constructor for class org.springframework.batch.item.database.builder.JpaCursorItemReaderBuilder
 
JpaItemWriter<T> - Class in org.springframework.batch.item.database
ItemWriter that is using a JPA EntityManagerFactory to merge any Entities that aren't part of the persistence context.
JpaItemWriter() - Constructor for class org.springframework.batch.item.database.JpaItemWriter
 
JpaItemWriterBuilder<T> - Class in org.springframework.batch.item.database.builder
A builder for the JpaItemWriter.
JpaItemWriterBuilder() - Constructor for class org.springframework.batch.item.database.builder.JpaItemWriterBuilder
 
JpaNamedQueryProvider<E> - Class in org.springframework.batch.item.database.orm
This query provider creates JPA named Querys.
JpaNamedQueryProvider() - Constructor for class org.springframework.batch.item.database.orm.JpaNamedQueryProvider
 
JpaNativeQueryProvider<E> - Class in org.springframework.batch.item.database.orm
This query provider creates JPA Querys from injected native SQL queries.
JpaNativeQueryProvider() - Constructor for class org.springframework.batch.item.database.orm.JpaNativeQueryProvider
 
JpaPagingItemReader<T> - Class in org.springframework.batch.item.database
ItemReader for reading database records built on top of JPA.
JpaPagingItemReader() - Constructor for class org.springframework.batch.item.database.JpaPagingItemReader
 
JpaPagingItemReaderBuilder<T> - Class in org.springframework.batch.item.database.builder
Creates a fully qualified JpaPagingItemReader.
JpaPagingItemReaderBuilder() - Constructor for class org.springframework.batch.item.database.builder.JpaPagingItemReaderBuilder
 
JpaQueryProvider - Interface in org.springframework.batch.item.database.orm
Interface defining the functionality to be provided for generating queries for use with JPA ItemReaders or other custom built artifacts.
JsonFileItemWriter<T> - Class in org.springframework.batch.item.json
Item writer that writes data in json format to an output file.
JsonFileItemWriter(Resource, JsonObjectMarshaller<T>) - Constructor for class org.springframework.batch.item.json.JsonFileItemWriter
Create a new JsonFileItemWriter instance.
JsonFileItemWriterBuilder<T> - Class in org.springframework.batch.item.json.builder
Builder for JsonFileItemWriter.
JsonFileItemWriterBuilder() - Constructor for class org.springframework.batch.item.json.builder.JsonFileItemWriterBuilder
 
JsonItemReader<T> - Class in org.springframework.batch.item.json
ItemStreamReader implementation that reads Json objects from a Resource having the following format:
JsonItemReader(Resource, JsonObjectReader<T>) - Constructor for class org.springframework.batch.item.json.JsonItemReader
Create a new JsonItemReader instance.
JsonItemReader() - Constructor for class org.springframework.batch.item.json.JsonItemReader
Create a new JsonItemReader instance.
JsonItemReaderBuilder<T> - Class in org.springframework.batch.item.json.builder
A builder for JsonItemReader.
JsonItemReaderBuilder() - Constructor for class org.springframework.batch.item.json.builder.JsonItemReaderBuilder
 
JsonLineMapper - Class in org.springframework.batch.item.file.mapping
Interpret a line as a JSON object and parse it up to a Map.
JsonLineMapper() - Constructor for class org.springframework.batch.item.file.mapping.JsonLineMapper
 
jsonObjectMarshaller(JsonObjectMarshaller<T>) - Method in class org.springframework.batch.item.json.builder.JsonFileItemWriterBuilder
Set the JsonObjectMarshaller to use to marshal objects to json.
JsonObjectMarshaller<T> - Interface in org.springframework.batch.item.json
Strategy interface to marshal an object into a json representation.
jsonObjectReader(JsonObjectReader<T>) - Method in class org.springframework.batch.item.json.builder.JsonItemReaderBuilder
Set the JsonObjectReader to use to read and map Json objects to domain objects.
JsonObjectReader<T> - Interface in org.springframework.batch.item.json
Strategy interface for Json readers.
jsonQuery(String) - Method in class org.springframework.batch.item.data.builder.MongoItemReaderBuilder
A JSON formatted MongoDB jsonQuery.
JsonRecordSeparatorPolicy - Class in org.springframework.batch.item.file.separator
JSON-based record separator.
JsonRecordSeparatorPolicy() - Constructor for class org.springframework.batch.item.file.separator.JsonRecordSeparatorPolicy
 
JsrAutowiredAnnotationBeanPostProcessor - Class in org.springframework.batch.core.jsr.configuration.support
This class overrides methods in the copied SpringAutowiredAnnotationBeanPostProcessor class to check for the BatchProperty annotation before processing injection annotations.
JsrAutowiredAnnotationBeanPostProcessor() - Constructor for class org.springframework.batch.core.jsr.configuration.support.JsrAutowiredAnnotationBeanPostProcessor
 
JsrBatchletStepBuilder - Class in org.springframework.batch.core.jsr.step.builder
Extension of the TaskletStepBuilder that uses a BatchletStep instead of a TaskletStep.
JsrBatchletStepBuilder(StepBuilderHelper<? extends StepBuilderHelper<?>>) - Constructor for class org.springframework.batch.core.jsr.step.builder.JsrBatchletStepBuilder
 
JsrBeanDefinitionDocumentReader - Class in org.springframework.batch.core.jsr.configuration.xml
DefaultBeanDefinitionDocumentReader extension to hook into the pre processing of the provided XML document, ensuring any references to property operators such as jobParameters and jobProperties are resolved prior to loading the context.
JsrBeanDefinitionDocumentReader() - Constructor for class org.springframework.batch.core.jsr.configuration.xml.JsrBeanDefinitionDocumentReader
Creates a new JsrBeanDefinitionDocumentReader instance.
JsrBeanDefinitionDocumentReader(BeanDefinitionRegistry) - Constructor for class org.springframework.batch.core.jsr.configuration.xml.JsrBeanDefinitionDocumentReader
Create a new JsrBeanDefinitionDocumentReader instance with the provided BeanDefinitionRegistry.
JsrBeanScopeBeanFactoryPostProcessor - Class in org.springframework.batch.core.jsr.partition.support
In order for property resolution to occur correctly within the scope of a JSR-352 batch job, initialization of job level artifacts must occur on the same thread that the job is executing.
JsrBeanScopeBeanFactoryPostProcessor() - Constructor for class org.springframework.batch.core.jsr.partition.support.JsrBeanScopeBeanFactoryPostProcessor
 
JsrBeanScopeBeanFactoryPostProcessor.JobLevelBeanLazyInitializer - Class in org.springframework.batch.core.jsr.partition.support
Looks for beans that may have dependencies that need to be lazily initialized and configures the corresponding BeanDefinition accordingly.
JsrChunkProcessor<I,O> - Class in org.springframework.batch.core.jsr.step.item
ChunkProcessor implementation that implements JSR-352's chunking pattern (read and process in a loop until the chunk is complete then write).
JsrChunkProcessor() - Constructor for class org.springframework.batch.core.jsr.step.item.JsrChunkProcessor
 
JsrChunkProcessor(ItemReader<? extends I>, ItemProcessor<? super I, ? extends O>, ItemWriter<? super O>, RepeatOperations) - Constructor for class org.springframework.batch.core.jsr.step.item.JsrChunkProcessor
 
JsrChunkProvider<T> - Class in org.springframework.batch.core.jsr.step.item
A no-op ChunkProvider.
JsrChunkProvider() - Constructor for class org.springframework.batch.core.jsr.step.item.JsrChunkProvider
 
JsrDecisionParser - Class in org.springframework.batch.core.jsr.configuration.xml
Parser for the <decision /> element as specified in JSR-352.
JsrDecisionParser() - Constructor for class org.springframework.batch.core.jsr.configuration.xml.JsrDecisionParser
 
JsrEndState - Class in org.springframework.batch.core.jsr.job.flow.support.state
State implementation for ending a job per JSR-352 rules if it is in progress and continuing if just starting.
JsrEndState(FlowExecutionStatus, String) - Constructor for class org.springframework.batch.core.jsr.job.flow.support.state.JsrEndState
 
JsrEndState(FlowExecutionStatus, String, String) - Constructor for class org.springframework.batch.core.jsr.job.flow.support.state.JsrEndState
 
JsrEndState(FlowExecutionStatus, String, String, boolean) - Constructor for class org.springframework.batch.core.jsr.job.flow.support.state.JsrEndState
 
JsrEndState(FlowExecutionStatus, String, String, String, boolean, JobRepository) - Constructor for class org.springframework.batch.core.jsr.job.flow.support.state.JsrEndState
 
JsrExpressionParser - Class in org.springframework.batch.core.jsr.configuration.support
Support class for parsing JSR-352 expressions.
JsrExpressionParser() - Constructor for class org.springframework.batch.core.jsr.configuration.support.JsrExpressionParser
Creates a new instance of this expression parser without and expression resolver.
JsrExpressionParser(BeanExpressionResolver, BeanExpressionContext) - Constructor for class org.springframework.batch.core.jsr.configuration.support.JsrExpressionParser
Creates a new instances of this expression parser with the provided expression resolver and context to evaluate against.
JsrFaultTolerantChunkProcessor<I,O> - Class in org.springframework.batch.core.jsr.step.item
Extension of the JsrChunkProcessor that adds skip and retry functionality.
JsrFaultTolerantChunkProcessor(ItemReader<? extends I>, ItemProcessor<? super I, ? extends O>, ItemWriter<? super O>, RepeatOperations, BatchRetryTemplate) - Constructor for class org.springframework.batch.core.jsr.step.item.JsrFaultTolerantChunkProcessor
 
JsrFaultTolerantStepBuilder<I,O> - Class in org.springframework.batch.core.jsr.step.builder
A step builder that extends the FaultTolerantStepBuilder to create JSR-352 specific ChunkProvider and ChunkProcessor supporting both the chunking pattern defined by the spec as well as skip/retry logic.
JsrFaultTolerantStepBuilder(StepBuilder) - Constructor for class org.springframework.batch.core.jsr.step.builder.JsrFaultTolerantStepBuilder
 
JsrFlow - Class in org.springframework.batch.core.jsr.job.flow.support
Implements JSR-352 specific logic around the execution of a flow.
JsrFlow(String) - Constructor for class org.springframework.batch.core.jsr.job.flow.support.JsrFlow
 
JsrFlowExecutor - Class in org.springframework.batch.core.jsr.job.flow
JSR-352 specific JobFlowExecutor.
JsrFlowExecutor(JobRepository, StepHandler, JobExecution) - Constructor for class org.springframework.batch.core.jsr.job.flow.JsrFlowExecutor
 
JsrFlowFactoryBean - Class in org.springframework.batch.core.jsr.configuration.xml
Extension to the SimpleFlowFactoryBean that provides JsrStepState implementations for JSR-352 based jobs.
JsrFlowFactoryBean() - Constructor for class org.springframework.batch.core.jsr.configuration.xml.JsrFlowFactoryBean
 
JsrFlowJob - Class in org.springframework.batch.core.jsr.job.flow
JSR-352 specific extension of the FlowJob.
JsrFlowJob() - Constructor for class org.springframework.batch.core.jsr.job.flow.JsrFlowJob
No arg constructor (invalid state)
JsrFlowJob(String) - Constructor for class org.springframework.batch.core.jsr.job.flow.JsrFlowJob
Main constructor
JsrJobContext - Class in org.springframework.batch.core.jsr
Wrapper class to provide the JobContext functionality as specified in JSR-352.
JsrJobContext() - Constructor for class org.springframework.batch.core.jsr.JsrJobContext
 
JsrJobContextFactoryBean - Class in org.springframework.batch.core.jsr
Provides a single JobContext for each thread in a running job.
JsrJobContextFactoryBean() - Constructor for class org.springframework.batch.core.jsr.JsrJobContextFactoryBean
 
JsrJobExecution - Class in org.springframework.batch.core.jsr
Wrapper class to adapt the JobExecution to a JobExecution.
JsrJobExecution(JobExecution, JobParametersConverter) - Constructor for class org.springframework.batch.core.jsr.JsrJobExecution
 
JsrJobListenerFactoryBean - Class in org.springframework.batch.core.jsr.configuration.xml
This FactoryBean is used by the JSR-352 namespace parser to create JobExecutionListener objects.
JsrJobListenerFactoryBean() - Constructor for class org.springframework.batch.core.jsr.configuration.xml.JsrJobListenerFactoryBean
 
JsrJobListenerMetaData - Enum in org.springframework.batch.core.jsr
Enumeration for JobListener meta data, which ties together the names of methods, their interfaces, annotation, and expected arguments.
JsrJobOperator - Class in org.springframework.batch.core.jsr.launch
The entrance for executing batch jobs as defined by JSR-352.
JsrJobOperator() - Constructor for class org.springframework.batch.core.jsr.launch.JsrJobOperator
Public constructor used by BatchRuntime.getJobOperator().
JsrJobOperator(JobExplorer, JobRepository, JobParametersConverter, PlatformTransactionManager) - Constructor for class org.springframework.batch.core.jsr.launch.JsrJobOperator
The no-arg constructor is used by the BatchRuntime.getJobOperator() and so bootstraps an ApplicationContext.
JsrJobOperator.BaseContextHolder - Class in org.springframework.batch.core.jsr.launch
A singleton holder used to lazily bootstrap the base context used in JSR-352.
JsrJobParametersConverter - Class in org.springframework.batch.core.jsr
Provides default conversion methodology for JSR-352's implementation.
JsrJobParametersConverter(DataSource) - Constructor for class org.springframework.batch.core.jsr.JsrJobParametersConverter
Main constructor.
JsrJobParser - Class in org.springframework.batch.core.jsr.configuration.xml
Parses a <job /> tag as defined in JSR-352.
JsrJobParser() - Constructor for class org.springframework.batch.core.jsr.configuration.xml.JsrJobParser
 
JsrNamespaceHandler - Class in org.springframework.batch.core.jsr.configuration.xml
 
JsrNamespaceHandler() - Constructor for class org.springframework.batch.core.jsr.configuration.xml.JsrNamespaceHandler
 
JsrNamespacePostProcessor - Class in org.springframework.batch.core.jsr.configuration.xml
 
JsrNamespacePostProcessor() - Constructor for class org.springframework.batch.core.jsr.configuration.xml.JsrNamespacePostProcessor
 
JsrPartitionHandler - Class in org.springframework.batch.core.jsr.partition
Executes a step instance per thread using a ThreadPoolTaskExecutor in accordance with JSR-352.
JsrPartitionHandler() - Constructor for class org.springframework.batch.core.jsr.partition.JsrPartitionHandler
 
JsrPartitionHandler.PartitionPlanState - Class in org.springframework.batch.core.jsr.partition
Since a PartitionPlan could provide dynamic data (different results from run to run), the batch runtime needs to save off the results for restarts.
JsrPartitionStepBuilder - Class in org.springframework.batch.core.jsr.step.builder
An extension of the PartitionStepBuilder that uses PartitionStep so that JSR-352 specific semantics are honored.
JsrPartitionStepBuilder(StepBuilderHelper<?>) - Constructor for class org.springframework.batch.core.jsr.step.builder.JsrPartitionStepBuilder
 
JsrSimpleStepBuilder<I,O> - Class in org.springframework.batch.core.jsr.step.builder
A step builder that extends the FaultTolerantStepBuilder to create JSR-352 specific ChunkProvider and ChunkProcessor supporting the chunking pattern defined by the spec.
JsrSimpleStepBuilder(StepBuilder) - Constructor for class org.springframework.batch.core.jsr.step.builder.JsrSimpleStepBuilder
 
JsrSplitParser - Class in org.springframework.batch.core.jsr.configuration.xml
Parses a <split /> element as defined in JSR-352.
JsrSplitParser(String) - Constructor for class org.springframework.batch.core.jsr.configuration.xml.JsrSplitParser
 
JsrSplitState - Class in org.springframework.batch.core.jsr.job.flow.support.state
JSR-352 states that artifacts cannot set the ExitStatus from within a split for a job.
JsrSplitState(Collection<Flow>, String) - Constructor for class org.springframework.batch.core.jsr.job.flow.support.state.JsrSplitState
 
JsrStepContext - Class in org.springframework.batch.core.jsr
Wrapper class to provide the StepContext functionality as specified in JSR-352.
JsrStepContext(StepExecution, Properties) - Constructor for class org.springframework.batch.core.jsr.JsrStepContext
 
JsrStepContextFactoryBean - Class in org.springframework.batch.core.jsr
FactoryBean implementation used to create StepContext instances within the step scope.
JsrStepContextFactoryBean() - Constructor for class org.springframework.batch.core.jsr.JsrStepContextFactoryBean
 
JsrStepExecution - Class in org.springframework.batch.core.jsr
Implementation of the JsrStepExecution as defined in JSR-352.
JsrStepExecution(StepExecution) - Constructor for class org.springframework.batch.core.jsr.JsrStepExecution
 
JsrStepExecutionAggregator - Class in org.springframework.batch.core.jsr.partition.support
Aggregates StepExecutions based on the rules outlined in JSR-352.
JsrStepExecutionAggregator() - Constructor for class org.springframework.batch.core.jsr.partition.support.JsrStepExecutionAggregator
 
JsrStepExecutionSplitter - Class in org.springframework.batch.core.jsr.partition
Provides JSR-352 specific behavior for the splitting of StepExecutions.
JsrStepExecutionSplitter(JobRepository, boolean, String, boolean) - Constructor for class org.springframework.batch.core.jsr.partition.JsrStepExecutionSplitter
 
JsrStepHandler - Class in org.springframework.batch.core.jsr.job
Extends SimpleStepHandler to apply JSR-352 specific logic for whether to start a step.
JsrStepHandler(JobRepository, JobExplorer) - Constructor for class org.springframework.batch.core.jsr.job.JsrStepHandler
 
JsrStepListenerFactoryBean - Class in org.springframework.batch.core.jsr.configuration.xml
 
JsrStepListenerFactoryBean() - Constructor for class org.springframework.batch.core.jsr.configuration.xml.JsrStepListenerFactoryBean
 
JsrStepListenerMetaData - Enum in org.springframework.batch.core.jsr
Enumeration for the JSR specific StepListener meta data, which ties together the names of methods, their interfaces, and expected arguments.
JsrStepState - Class in org.springframework.batch.core.jsr.job.flow.support.state
Extends StepState to persist what the last step that was executed was (used in Decisions and restarts).
JsrStepState(Step) - Constructor for class org.springframework.batch.core.jsr.job.flow.support.state.JsrStepState
 
JsrStepState(String, Step) - Constructor for class org.springframework.batch.core.jsr.job.flow.support.state.JsrStepState
 
JsrTestUtils - Class in org.springframework.batch.test
Provides testing utilities to execute JSR-352 jobs and block until they are complete (since all JSR-352 based jobs are executed asynchronously).
JsrXmlApplicationContext - Class in org.springframework.batch.core.jsr.configuration.xml
GenericApplicationContext implementation providing JSR-352 related context operations.
JsrXmlApplicationContext() - Constructor for class org.springframework.batch.core.jsr.configuration.xml.JsrXmlApplicationContext
Create a new context instance with no job parameters.
JsrXmlApplicationContext(Properties) - Constructor for class org.springframework.batch.core.jsr.configuration.xml.JsrXmlApplicationContext
Create a new context instance using the provided Properties representing job parameters when pre-processing the job definition document.
jumpToItem(int) - Method in class org.springframework.batch.item.data.AbstractPaginatedDataItemReader
 
jumpToItem(int) - Method in class org.springframework.batch.item.data.RepositoryItemReader
 
jumpToItem(int) - Method in class org.springframework.batch.item.database.AbstractCursorItemReader
Use ResultSet.absolute(int) if possible, otherwise scroll by calling ResultSet.next().
jumpToItem(int) - Method in class org.springframework.batch.item.database.AbstractPagingItemReader
 
jumpToItem(int) - Method in class org.springframework.batch.item.database.HibernateCursorItemReader
Wind forward through the result set to the item requested.
jumpToItem(ScrollableResults, int, int) - Method in class org.springframework.batch.item.database.HibernateItemReaderHelper
Scroll through the results up to the item specified.
jumpToItem(int) - Method in class org.springframework.batch.item.file.FlatFileItemReader
 
jumpToItem(int) - Method in class org.springframework.batch.item.support.AbstractItemCountingItemStreamItemReader
Move to the given item index.
jumpToItem(int) - Method in class org.springframework.batch.item.xml.StaxEventItemReader
 
JVM_EXITCODE_COMPLETED - Static variable in interface org.springframework.batch.core.launch.support.ExitCodeMapper
 
JVM_EXITCODE_GENERIC_ERROR - Static variable in interface org.springframework.batch.core.launch.support.ExitCodeMapper
 
JVM_EXITCODE_JOB_ERROR - Static variable in interface org.springframework.batch.core.launch.support.ExitCodeMapper
 
JvmSystemExiter - Class in org.springframework.batch.core.launch.support
Implementation of the SystemExiter interface that calls the standards System.exit method.
JvmSystemExiter() - Constructor for class org.springframework.batch.core.launch.support.JvmSystemExiter
 

K

KafkaItemReader<K,V> - Class in org.springframework.batch.item.kafka
An ItemReader implementation for Apache Kafka.
KafkaItemReader(Properties, String, Integer...) - Constructor for class org.springframework.batch.item.kafka.KafkaItemReader
Create a new KafkaItemReader.
KafkaItemReader(Properties, String, List<Integer>) - Constructor for class org.springframework.batch.item.kafka.KafkaItemReader
Create a new KafkaItemReader.
KafkaItemReaderBuilder<K,V> - Class in org.springframework.batch.item.kafka.builder
A builder implementation for the KafkaItemReader.
KafkaItemReaderBuilder() - Constructor for class org.springframework.batch.item.kafka.builder.KafkaItemReaderBuilder
 
KafkaItemWriter<K,T> - Class in org.springframework.batch.item.kafka
An ItemWriter implementation for Apache Kafka using a KafkaTemplate with default topic configured.
KafkaItemWriter() - Constructor for class org.springframework.batch.item.kafka.KafkaItemWriter
 
KafkaItemWriterBuilder<K,V> - Class in org.springframework.batch.item.kafka.builder
A builder implementation for the KafkaItemWriter
KafkaItemWriterBuilder() - Constructor for class org.springframework.batch.item.kafka.builder.KafkaItemWriterBuilder
 
kafkaTemplate(KafkaTemplate<K, V>) - Method in class org.springframework.batch.item.kafka.builder.KafkaItemWriterBuilder
Establish the KafkaTemplate to be used by the KafkaItemWriter.
kafkaTemplate - Variable in class org.springframework.batch.item.kafka.KafkaItemWriter
 
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.
keyGenerator(KeyGenerator) - Method in class org.springframework.batch.integration.chunk.RemoteChunkingManagerStepBuilder
 
keyGenerator(KeyGenerator) - Method in class org.springframework.batch.integration.chunk.RemoteChunkingMasterStepBuilder
Deprecated.
 
KeyValueItemWriter<K,V> - Class in org.springframework.batch.item
A base class to implement any ItemWriter that writes to a key value store using a Converter to derive a key from an item
KeyValueItemWriter() - Constructor for class org.springframework.batch.item.KeyValueItemWriter
 

L

language(String) - Method in class org.springframework.batch.item.support.builder.ScriptItemProcessorBuilder
Establishes the language of the script.
LastModifiedResourceComparator - Class in org.springframework.batch.support
Comparator to sort resources by the file last modified time.
LastModifiedResourceComparator() - Constructor for class org.springframework.batch.support.LastModifiedResourceComparator
 
launch(JobLaunchRequest) - Method in class org.springframework.batch.integration.launch.JobLaunchingMessageHandler
 
launch(JobLaunchRequest) - Method in interface org.springframework.batch.integration.launch.JobLaunchRequestHandler
 
launcher(JobLauncher) - Method in class org.springframework.batch.core.step.builder.JobStepBuilder
Add a job launcher.
launchJob() - Method in class org.springframework.batch.test.AbstractJobTests
Deprecated.
Launch the entire job, including all steps.
launchJob(JobParameters) - Method in class org.springframework.batch.test.AbstractJobTests
Deprecated.
Launch the entire job, including all steps
launchJob() - Method in class org.springframework.batch.test.JobLauncherTestUtils
Launch the entire job, including all steps.
launchJob(JobParameters) - Method in class org.springframework.batch.test.JobLauncherTestUtils
Launch the entire job, including all steps
launchStep(String) - Method in class org.springframework.batch.test.AbstractJobTests
Deprecated.
Launch just the specified step in the job.
launchStep(String, ExecutionContext) - Method in class org.springframework.batch.test.AbstractJobTests
Deprecated.
Launch just the specified step in the job.
launchStep(String, JobParameters) - Method in class org.springframework.batch.test.AbstractJobTests
Deprecated.
Launch just the specified step in the job.
launchStep(String, JobParameters, ExecutionContext) - Method in class org.springframework.batch.test.AbstractJobTests
Deprecated.
Launch just the specified step in the job.
launchStep(String) - Method in class org.springframework.batch.test.JobLauncherTestUtils
Launch just the specified step in the job.
launchStep(String, ExecutionContext) - Method in class org.springframework.batch.test.JobLauncherTestUtils
Launch just the specified step in the job.
launchStep(String, JobParameters) - Method in class org.springframework.batch.test.JobLauncherTestUtils
Launch just the specified step in the job.
launchStep(String, JobParameters, ExecutionContext) - Method in class org.springframework.batch.test.JobLauncherTestUtils
Launch just the specified step in the job.
launchStep(Step) - Method in class org.springframework.batch.test.StepRunner
Launch just the specified step as its own job.
launchStep(Step, ExecutionContext) - Method in class org.springframework.batch.test.StepRunner
Launch just the specified step as its own job.
launchStep(Step, JobParameters) - Method in class org.springframework.batch.test.StepRunner
Launch just the specified step as its own job.
launchStep(Step, JobParameters, ExecutionContext) - Method in class org.springframework.batch.test.StepRunner
Launch just the specified step as its own job.
LdifReader - Class in org.springframework.batch.item.ldif
The LdifReader is an adaptation of the FlatFileItemReader built around an LdifParser.
LdifReader() - Constructor for class org.springframework.batch.item.ldif.LdifReader
 
LdifReaderBuilder - Class in org.springframework.batch.item.ldif.builder
Creates a fully qualified LdifReader.
LdifReaderBuilder() - Constructor for class org.springframework.batch.item.ldif.builder.LdifReaderBuilder
 
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
 
lineAggregator(LineAggregator<T>) - Method in class org.springframework.batch.item.file.builder.FlatFileItemWriterBuilder
Line aggregator used to build the String version of each item.
lineAggregator - Variable in class org.springframework.batch.item.file.FlatFileItemWriter
 
LineAggregator<T> - Interface in org.springframework.batch.item.file.transform
Interface used to create string representing object.
LineCallbackHandler - Interface in org.springframework.batch.item.file
Callback interface for handling a line from file.
lineMapper(LineMapper<T>) - Method in class org.springframework.batch.item.file.builder.FlatFileItemReaderBuilder
A LineMapper implementation to be used.
LineMapper<T> - Interface in org.springframework.batch.item.file
Interface for mapping lines (strings) to domain objects typically used to map lines read from a file to domain objects on a per line basis.
lineSeparator(String) - Method in class org.springframework.batch.item.file.builder.FlatFileItemWriterBuilder
String used to separate lines in output.
lineSeparator(String) - Method in class org.springframework.batch.item.json.builder.JsonFileItemWriterBuilder
String used to separate lines in output.
lineSeparator - Variable in class org.springframework.batch.item.support.AbstractFileItemWriter
 
linesToSkip(int) - Method in class org.springframework.batch.item.file.builder.FlatFileItemReaderBuilder
The number of lines to skip at the beginning of reading the file.
lineTokenizer(LineTokenizer) - Method in class org.springframework.batch.item.file.builder.FlatFileItemReaderBuilder
A LineTokenizer implementation to be used.
LineTokenizer - Interface in org.springframework.batch.item.file.transform
Interface that is used by framework to split string obtained typically from a file into tokens.
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(JobExecutionListener) - Method in class org.springframework.batch.core.job.builder.JobBuilderHelper
Register a job execution listener.
listener(ChunkListener) - Method in class org.springframework.batch.core.step.builder.AbstractTaskletStepBuilder
Register a chunk listener.
listener(Object) - Method in class org.springframework.batch.core.step.builder.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(SkipListener<? super I, ? super O>) - Method in class org.springframework.batch.core.step.builder.FaultTolerantStepBuilder
Register a skip listener.
listener(RetryListener) - Method in class org.springframework.batch.core.step.builder.FaultTolerantStepBuilder
 
listener(ChunkListener) - Method in class org.springframework.batch.core.step.builder.FaultTolerantStepBuilder
 
listener(RetryListener) - Method in class org.springframework.batch.core.step.builder.FaultTolerantStepBuilder
Register a retry listener.
listener(Object) - Method in class org.springframework.batch.core.step.builder.SimpleStepBuilder
Registers objects using the annotation based listener configuration.
listener(ItemReadListener<? super I>) - Method in class org.springframework.batch.core.step.builder.SimpleStepBuilder
Register an item reader listener.
listener(ItemWriteListener<? super O>) - Method in class org.springframework.batch.core.step.builder.SimpleStepBuilder
Register an item writer listener.
listener(ItemProcessListener<? super I, ? super O>) - Method in class org.springframework.batch.core.step.builder.SimpleStepBuilder
Register an item processor listener.
listener(Object) - Method in class org.springframework.batch.core.step.builder.StepBuilderHelper
Registers objects using the annotation based listener configuration.
listener(StepExecutionListener) - Method in class org.springframework.batch.core.step.builder.StepBuilderHelper
 
listener(Object) - Method in class org.springframework.batch.integration.chunk.RemoteChunkingManagerStepBuilder
 
listener(SkipListener<? super I, ? super O>) - Method in class org.springframework.batch.integration.chunk.RemoteChunkingManagerStepBuilder
 
listener(ChunkListener) - Method in class org.springframework.batch.integration.chunk.RemoteChunkingManagerStepBuilder
 
listener(RetryListener) - Method in class org.springframework.batch.integration.chunk.RemoteChunkingManagerStepBuilder
 
listener(ItemReadListener<? super I>) - Method in class org.springframework.batch.integration.chunk.RemoteChunkingManagerStepBuilder
 
listener(ItemWriteListener<? super O>) - Method in class org.springframework.batch.integration.chunk.RemoteChunkingManagerStepBuilder
 
listener(StepExecutionListener) - Method in class org.springframework.batch.integration.chunk.RemoteChunkingManagerStepBuilder
 
listener(Object) - Method in class org.springframework.batch.integration.chunk.RemoteChunkingMasterStepBuilder
Deprecated.
 
listener(SkipListener<? super I, ? super O>) - Method in class org.springframework.batch.integration.chunk.RemoteChunkingMasterStepBuilder
Deprecated.
 
listener(ChunkListener) - Method in class org.springframework.batch.integration.chunk.RemoteChunkingMasterStepBuilder
Deprecated.
 
listener(RetryListener) - Method in class org.springframework.batch.integration.chunk.RemoteChunkingMasterStepBuilder
Deprecated.
 
listener(ItemReadListener<? super I>) - Method in class org.springframework.batch.integration.chunk.RemoteChunkingMasterStepBuilder
Deprecated.
 
listener(ItemWriteListener<? super O>) - Method in class org.springframework.batch.integration.chunk.RemoteChunkingMasterStepBuilder
Deprecated.
 
listener(StepExecutionListener) - Method in class org.springframework.batch.integration.chunk.RemoteChunkingMasterStepBuilder
Deprecated.
 
listener(Object) - Method in class org.springframework.batch.integration.partition.RemotePartitioningManagerStepBuilder
 
listener(StepExecutionListener) - Method in class org.springframework.batch.integration.partition.RemotePartitioningManagerStepBuilder
 
listener(Object) - Method in class org.springframework.batch.integration.partition.RemotePartitioningMasterStepBuilder
Deprecated.
 
listener(StepExecutionListener) - Method in class org.springframework.batch.integration.partition.RemotePartitioningMasterStepBuilder
Deprecated.
 
listener(Object) - Method in class org.springframework.batch.integration.partition.RemotePartitioningWorkerStepBuilder
 
listener(StepExecutionListener) - Method in class org.springframework.batch.integration.partition.RemotePartitioningWorkerStepBuilder
 
ListenerMetaData - Interface in org.springframework.batch.core.listener
A common interface for listener meta data enumerations.
ListenerParser - Class in org.springframework.batch.core.jsr.configuration.xml
Parses the various listeners defined in JSR-352.
ListenerParser(Class<?>, String) - Constructor for class org.springframework.batch.core.jsr.configuration.xml.ListenerParser
 
ListItemReader<T> - Class in org.springframework.batch.item.support
An ItemReader that pulls data from a list.
ListItemReader(List<T>) - Constructor for class org.springframework.batch.item.support.ListItemReader
 
ListItemWriter<T> - Class in org.springframework.batch.item.support
 
ListItemWriter() - Constructor for class org.springframework.batch.item.support.ListItemWriter
 
ListPreparedStatementSetter - Class in org.springframework.batch.item.database.support
Deprecated.
use ArgumentPreparedStatementSetter instead.
ListPreparedStatementSetter() - Constructor for class org.springframework.batch.item.database.support.ListPreparedStatementSetter
Deprecated.
 
ListPreparedStatementSetter(List<?>) - Constructor for class org.springframework.batch.item.database.support.ListPreparedStatementSetter
Deprecated.
 
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.
load(Resource...) - Method in class org.springframework.batch.core.jsr.configuration.xml.JsrXmlApplicationContext
Load bean definitions from the given XML resources.
locale(Locale) - Method in class org.springframework.batch.item.file.builder.FlatFileItemWriterBuilder.FormattedBuilder
Set the locale.
log - Variable in class org.springframework.batch.item.database.AbstractCursorItemReader
Logger available to subclasses
logger - Static variable in class org.springframework.batch.core.job.AbstractJob
 
logger - Variable in class org.springframework.batch.core.job.builder.JobBuilderHelper
 
logger - Variable in class org.springframework.batch.core.jsr.step.item.JsrFaultTolerantChunkProcessor
 
logger - Static variable in class org.springframework.batch.core.launch.support.CommandLineJobRunner
 
logger - Static variable in class org.springframework.batch.core.launch.support.SimpleJobLauncher
 
logger - Variable in class org.springframework.batch.core.launch.support.SimpleJvmExitCodeMapper
 
logger - Static variable in class org.springframework.batch.core.repository.support.JobRepositoryFactoryBean
 
logger - Variable in class org.springframework.batch.core.step.builder.StepBuilderHelper
 
logger - Variable in class org.springframework.batch.core.step.factory.SimpleStepFactoryBean
 
logger - Static variable in class org.springframework.batch.core.step.item.DefaultItemFailureHandler
 
logger - Variable in class org.springframework.batch.core.step.item.SimpleChunkProvider
 
logger - Static variable in class org.springframework.batch.core.step.tasklet.SystemCommandTasklet
 
logger - Static variable in class org.springframework.batch.core.step.ThreadStepInterruptionPolicy
 
logger - Variable in class org.springframework.batch.item.data.AbstractNeo4jItemReader
Deprecated.
 
logger - Static variable in class org.springframework.batch.item.data.Neo4jItemWriter
 
logger - Variable in class org.springframework.batch.item.data.RepositoryItemReader
 
logger - Static variable in class org.springframework.batch.item.data.RepositoryItemWriter
 
logger - Variable in class org.springframework.batch.item.database.AbstractPagingItemReader
 
logger - Static variable in class org.springframework.batch.item.database.HibernateItemWriter
 
logger - Static variable in class org.springframework.batch.item.database.JdbcBatchItemWriter
 
logger - Static variable in class org.springframework.batch.item.database.JpaItemWriter
 
logger - Variable in class org.springframework.batch.item.file.builder.FlatFileItemReaderBuilder
 
logger - Variable in class org.springframework.batch.item.file.builder.FlatFileItemWriterBuilder
 
logger - Variable in class org.springframework.batch.item.jms.JmsItemReader
 
logger - Variable in class org.springframework.batch.item.jms.JmsItemWriter
 
logger - Variable in class org.springframework.batch.item.jms.JmsMethodInvocationRecoverer
 
logger - Variable in class org.springframework.batch.item.json.builder.JsonItemReaderBuilder
 
logger - Static variable in class org.springframework.batch.item.support.AbstractFileItemWriter
 
logger - Variable in class org.springframework.batch.item.xml.builder.StaxEventItemReaderBuilder
 
logger - Variable in class org.springframework.batch.repeat.exception.LogOrRethrowExceptionHandler
 
logger - Variable in class org.springframework.batch.repeat.exception.RethrowOnThresholdExceptionHandler
 
logger - Variable in class org.springframework.batch.repeat.support.RepeatTemplate
 
logger - Variable in class org.springframework.batch.test.AbstractJobTests
Deprecated.
Logger
logger - Variable in class org.springframework.batch.test.JobLauncherTestUtils
Logger
logger - Variable in class org.springframework.batch.test.StepRunner
Logger
LogOrRethrowExceptionHandler - Class in org.springframework.batch.repeat.exception
Implementation of ExceptionHandler based on an Classifier.
LogOrRethrowExceptionHandler() - Constructor for class org.springframework.batch.repeat.exception.LogOrRethrowExceptionHandler
 
LogOrRethrowExceptionHandler.Level - Enum in org.springframework.batch.repeat.exception
Logging levels for the handler.
LONG_TYPE - Static variable in class org.springframework.batch.core.converter.DefaultJobParametersConverter
 

M

mailErrorHandler(MailErrorHandler) - Method in class org.springframework.batch.item.mail.builder.SimpleMailMessageItemWriterBuilder
The handler for failed messages.
MailErrorHandler - Interface in org.springframework.batch.item.mail
This class is used to handle errors that occur when email messages are unable to be sent.
mailSender(MailSender) - Method in class org.springframework.batch.item.mail.builder.SimpleMailMessageItemWriterBuilder
A MailSender to be used to send messages in SimpleMailMessageItemWriter.write(List).
main(String[]) - Static method in class org.springframework.batch.core.launch.support.CommandLineJobRunner
Launch a batch job using a CommandLineJobRunner.
main(String...) - Static method in class org.springframework.batch.core.launch.support.JobRegistryBackgroundJobRunner
Supply a list of application context locations, starting with the parent context, and followed by the children.
main(String...) - Static method in class org.springframework.batch.test.DataSourceInitializer
Main method as convenient entry point.
MapExecutionContextDao - Class in org.springframework.batch.core.repository.dao
Deprecated.
as of v4.3 in favor of using the JdbcExecutionContextDao with an in-memory database. Scheduled for removal in v5.0.
MapExecutionContextDao() - Constructor for class org.springframework.batch.core.repository.dao.MapExecutionContextDao
Deprecated.
 
mapFieldSet(FieldSet) - Method in class org.springframework.batch.item.file.mapping.ArrayFieldSetMapper
 
mapFieldSet(FieldSet) - Method in class org.springframework.batch.item.file.mapping.BeanWrapperFieldSetMapper
Map the FieldSet to an object retrieved from the enclosing Spring context, or to a new instance of the required type if no prototype is available.
mapFieldSet(FieldSet) - Method in interface org.springframework.batch.item.file.mapping.FieldSetMapper
Method used to map data obtained from a FieldSet into an object.
mapFieldSet(FieldSet) - Method in class org.springframework.batch.item.file.mapping.PassThroughFieldSetMapper
 
mapFieldSet(FieldSet) - Method in class org.springframework.batch.item.file.mapping.RecordFieldSetMapper
 
MapJobExecutionDao - Class in org.springframework.batch.core.repository.dao
Deprecated.
as of v4.3 in favor of using the JdbcJobExecutionDao with an in-memory database. Scheduled for removal in v5.0.
MapJobExecutionDao() - Constructor for class org.springframework.batch.core.repository.dao.MapJobExecutionDao
Deprecated.
 
MapJobExplorerFactoryBean - Class in org.springframework.batch.core.explore.support
Deprecated.
as of v4.3 in favor of using the JobExplorerFactoryBean with an in-memory database. Scheduled for removal in v5.0.
MapJobExplorerFactoryBean(MapJobRepositoryFactoryBean) - Constructor for class org.springframework.batch.core.explore.support.MapJobExplorerFactoryBean
Deprecated.
Create an instance with the provided MapJobRepositoryFactoryBean as a source of Dao instances.
MapJobExplorerFactoryBean() - Constructor for class org.springframework.batch.core.explore.support.MapJobExplorerFactoryBean
Deprecated.
Create a factory with no MapJobRepositoryFactoryBean.
MapJobInstanceDao - Class in org.springframework.batch.core.repository.dao
Deprecated.
as of v4.3 in favor of using the JdbcJobInstanceDao with an in-memory database. Scheduled for removal in v5.0.
MapJobInstanceDao() - Constructor for class org.springframework.batch.core.repository.dao.MapJobInstanceDao
Deprecated.
 
MapJobRegistry - Class in org.springframework.batch.core.configuration.support
Simple, thread-safe, map-based implementation of JobRegistry.
MapJobRegistry() - Constructor for class org.springframework.batch.core.configuration.support.MapJobRegistry
 
MapJobRepositoryFactoryBean - Class in org.springframework.batch.core.repository.support
Deprecated.
as of v4.3 in favor or using the JobRepositoryFactoryBean with an in-memory database. Scheduled for removal in v5.0.
MapJobRepositoryFactoryBean() - Constructor for class org.springframework.batch.core.repository.support.MapJobRepositoryFactoryBean
Deprecated.
Create a new instance with a ResourcelessTransactionManager.
MapJobRepositoryFactoryBean(PlatformTransactionManager) - Constructor for class org.springframework.batch.core.repository.support.MapJobRepositoryFactoryBean
Deprecated.
Create a new instance with the provided transaction manager.
mapLine(String, int) - Method in interface org.springframework.batch.item.file.LineMapper
Implementations must implement this method to map the provided line to the parameter type T.
mapLine(String, int) - Method in class org.springframework.batch.item.file.mapping.DefaultLineMapper
 
mapLine(String, int) - Method in class org.springframework.batch.item.file.mapping.JsonLineMapper
Interpret the line as a Json object and create a Map from it.
mapLine(String, int) - Method in class org.springframework.batch.item.file.mapping.PassThroughLineMapper
 
mapLine(String, int) - Method in class org.springframework.batch.item.file.mapping.PatternMatchingCompositeLineMapper
 
MappingLdifReader<T> - Class in org.springframework.batch.item.ldif
The MappingLdifReader is an adaptation of the FlatFileItemReader built around an LdifParser.
MappingLdifReader() - Constructor for class org.springframework.batch.item.ldif.MappingLdifReader
 
MappingLdifReaderBuilder<T> - Class in org.springframework.batch.item.ldif.builder
Creates a fully qualified MappingLdifReader.
MappingLdifReaderBuilder() - Constructor for class org.springframework.batch.item.ldif.builder.MappingLdifReaderBuilder
 
mapRecord(LdapAttributes) - Method in interface org.springframework.batch.item.ldif.RecordMapper
Maps an LdapAttributes object to the specified type.
mapResult(Object) - Method in class org.springframework.batch.core.step.tasklet.MethodInvokingTaskletAdapter
If the result is an ExitStatus already just return that, otherwise return ExitStatus.COMPLETED.
MapStepExecutionDao - Class in org.springframework.batch.core.repository.dao
Deprecated.
as of v4.3 in favor of using the JdbcStepExecutionDao with an in-memory database. Scheduled for removal in v5.0.
MapStepExecutionDao() - Constructor for class org.springframework.batch.core.repository.dao.MapStepExecutionDao
Deprecated.
 
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
 
markFragmentProcessed() - Method in class org.springframework.batch.item.xml.stax.DefaultFragmentEventReader
Finishes reading the fragment in case the fragment was processed without being read until the end.
markFragmentProcessed() - Method in interface org.springframework.batch.item.xml.stax.FragmentEventReader
Tells the event reader the current fragment has been processed.
markStartFragment() - Method in class org.springframework.batch.item.xml.stax.DefaultFragmentEventReader
 
markStartFragment() - Method in interface org.springframework.batch.item.xml.stax.FragmentEventReader
Tells the event reader its cursor position is exactly before the fragment.
marshal(T) - Method in class org.springframework.batch.item.json.GsonJsonObjectMarshaller
 
marshal(T) - Method in class org.springframework.batch.item.json.JacksonJsonObjectMarshaller
 
marshal(T) - Method in interface org.springframework.batch.item.json.JsonObjectMarshaller
Marshal an object into a json representation.
marshaller(Marshaller) - Method in class org.springframework.batch.item.xml.builder.StaxEventItemWriterBuilder
The Marshaller implementation responsible for the serialization of the items to XML.
match(String) - Static method in enum org.springframework.batch.core.BatchStatus
Find a BatchStatus that matches the beginning of the given value.
match(String, String) - Static method in class org.springframework.batch.support.PatternMatcher
Lifted from AntPathMatcher in Spring Core.
match(String) - Method in class org.springframework.batch.support.PatternMatcher
This method takes a String key and a map from Strings to values of any type.
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.
matchStatement(String) - Method in class org.springframework.batch.item.data.builder.Neo4jItemReaderBuilder
An optional match fragment of the cypher query.
max(BatchStatus, BatchStatus) - Static method in enum org.springframework.batch.core.BatchStatus
 
maximumLength(int) - Method in class org.springframework.batch.item.file.builder.FlatFileItemWriterBuilder.FormattedBuilder
Set the maximum length of the formatted string.
maxItemCount(int) - Method in class org.springframework.batch.item.avro.builder.AvroItemReaderBuilder
Configure the max number of items to be read.
maxItemCount(int) - Method in class org.springframework.batch.item.data.builder.MongoItemReaderBuilder
Configure the max number of items to be read.
maxItemCount(int) - Method in class org.springframework.batch.item.data.builder.Neo4jItemReaderBuilder
Configure the max number of items to be read.
maxItemCount(int) - Method in class org.springframework.batch.item.data.builder.RepositoryItemReaderBuilder
Configure the max number of items to be read.
maxItemCount(int) - Method in class org.springframework.batch.item.database.builder.HibernateCursorItemReaderBuilder
Configure the max number of items to be read.
maxItemCount(int) - Method in class org.springframework.batch.item.database.builder.HibernatePagingItemReaderBuilder
Configure the max number of items to be read.
maxItemCount(int) - Method in class org.springframework.batch.item.database.builder.JdbcCursorItemReaderBuilder
Configure the max number of items to be read.
maxItemCount(int) - Method in class org.springframework.batch.item.database.builder.JdbcPagingItemReaderBuilder
Configure the max number of items to be read.
maxItemCount(int) - Method in class org.springframework.batch.item.database.builder.JpaCursorItemReaderBuilder
Configure the max number of items to be read.
maxItemCount(int) - Method in class org.springframework.batch.item.database.builder.JpaPagingItemReaderBuilder
Configure the max number of items to be read.
maxItemCount(int) - Method in class org.springframework.batch.item.database.builder.StoredProcedureItemReaderBuilder
Configure the max number of items to be read.
maxItemCount(int) - Method in class org.springframework.batch.item.file.builder.FlatFileItemReaderBuilder
Configure the max number of items to be read.
maxItemCount(int) - Method in class org.springframework.batch.item.json.builder.JsonItemReaderBuilder
Configure the max number of items to be read.
maxItemCount(int) - Method in class org.springframework.batch.item.ldif.builder.LdifReaderBuilder
Configure the max number of items to be read.
maxItemCount(int) - Method in class org.springframework.batch.item.ldif.builder.MappingLdifReaderBuilder
Configure the max number of items to be read.
maxItemCount(int) - Method in class org.springframework.batch.item.xml.builder.StaxEventItemReaderBuilder
Configure the max number of items to be read.
maxRows(int) - Method in class org.springframework.batch.item.database.builder.JdbcCursorItemReaderBuilder
The max number of rows the ResultSet can contain
maxRows(int) - Method in class org.springframework.batch.item.database.builder.StoredProcedureItemReaderBuilder
The max number of rows the ResultSet can contain
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
 
maxWaitTimeouts(int) - Method in class org.springframework.batch.integration.chunk.RemoteChunkingManagerStepBuilder
The maximum number of times to wait at the end of a step for a non-null result from the remote workers.
maxWaitTimeouts(int) - Method in class org.springframework.batch.integration.chunk.RemoteChunkingMasterStepBuilder
Deprecated.
The maximum number of times to wait at the end of a step for a non-null result from the remote workers.
MessageChannelPartitionHandler - Class in org.springframework.batch.integration.partition
A PartitionHandler that uses MessageChannel instances to send instructions to remote workers and receive their responses.
MessageChannelPartitionHandler() - Constructor for class org.springframework.batch.integration.partition.MessageChannelPartitionHandler
 
MessageSourcePollerInterceptor - Class in org.springframework.batch.integration.chunk
A ChannelInterceptor that turns a pollable channel into a "pass-thru channel": if a client calls receive() on the channel it will delegate to a MessageSource to pull the message directly from an external source.
MessageSourcePollerInterceptor() - Constructor for class org.springframework.batch.integration.chunk.MessageSourcePollerInterceptor
Convenient default constructor for configuration purposes.
MessageSourcePollerInterceptor(MessageSource<?>) - Constructor for class org.springframework.batch.integration.chunk.MessageSourcePollerInterceptor
 
messagingTemplate(MessagingTemplate) - Method in class org.springframework.batch.integration.chunk.RemoteChunkingManagerStepBuilder
Set the MessagingTemplate to use to send data to workers.
messagingTemplate(MessagingTemplate) - Method in class org.springframework.batch.integration.chunk.RemoteChunkingMasterStepBuilder
Deprecated.
Set the MessagingTemplate to use to send data to workers.
messagingTemplate(MessagingTemplate) - Method in class org.springframework.batch.integration.partition.RemotePartitioningManagerStepBuilder
Set the MessagingTemplate to use to send data to workers.
messagingTemplate(MessagingTemplate) - Method in class org.springframework.batch.integration.partition.RemotePartitioningMasterStepBuilder
Deprecated.
Set the MessagingTemplate to use to send data to workers.
MetaDataInstanceFactory - Class in org.springframework.batch.test
Convenience methods for creating test instances of JobExecution, JobInstance and StepExecution.
MetaDataInstanceFactory() - Constructor for class org.springframework.batch.test.MetaDataInstanceFactory
 
MethodInvoker - Interface in org.springframework.batch.support
A strategy interface for invoking a method.
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
 
MethodInvokerUtils - Class in org.springframework.batch.support
Utility methods for create MethodInvoker instances.
MethodInvokerUtils() - Constructor for class org.springframework.batch.support.MethodInvokerUtils
 
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
 
methodIs() - Method in class org.springframework.batch.item.data.builder.RepositoryItemReaderBuilder.RepositoryMethodReference
The proxy returned prevents actual method execution and is only used to gather, information about the method.
methodIs() - Method in class org.springframework.batch.item.data.builder.RepositoryItemWriterBuilder.RepositoryMethodReference
The proxy returned prevents actual method execution and is only used to gather, information about the method.
methodName(String) - Method in class org.springframework.batch.item.data.builder.RepositoryItemReaderBuilder
Specifies what method on the repository to call.
methodName(String) - Method in class org.springframework.batch.item.data.builder.RepositoryItemWriterBuilder
Specifies what method on the repository to call.
MethodResolver - Interface in org.springframework.batch.support
Strategy interface for detecting a single Method on a Class.
MimeMessageItemWriter - Class in org.springframework.batch.item.mail.javamail
A simple ItemWriter that can send mail messages.
MimeMessageItemWriter() - Constructor for class org.springframework.batch.item.mail.javamail.MimeMessageItemWriter
 
minimumLength(int) - Method in class org.springframework.batch.item.file.builder.FlatFileItemWriterBuilder.FormattedBuilder
Set the minimum length of the formatted string.
ModularBatchConfiguration - Class in org.springframework.batch.core.configuration.annotation
Base Configuration class providing common structure for enabling and using Spring Batch.
ModularBatchConfiguration() - Constructor for class org.springframework.batch.core.configuration.annotation.ModularBatchConfiguration
 
MongoItemReader<T> - Class in org.springframework.batch.item.data
Restartable ItemReader that reads documents from MongoDB via a paging technique.
MongoItemReader() - Constructor for class org.springframework.batch.item.data.MongoItemReader
 
MongoItemReaderBuilder<T> - Class in org.springframework.batch.item.data.builder
A builder implementation for the MongoItemReader
MongoItemReaderBuilder() - Constructor for class org.springframework.batch.item.data.builder.MongoItemReaderBuilder
 
MongoItemWriter<T> - Class in org.springframework.batch.item.data
A ItemWriter implementation that writes to a MongoDB store using an implementation of Spring Data's MongoOperations.
MongoItemWriter() - Constructor for class org.springframework.batch.item.data.MongoItemWriter
 
MongoItemWriterBuilder<T> - Class in org.springframework.batch.item.data.builder
A builder implementation for the MongoItemWriter
MongoItemWriterBuilder() - Constructor for class org.springframework.batch.item.data.builder.MongoItemWriterBuilder
 
moveCursorToNextFragment(XMLEventReader) - Method in class org.springframework.batch.item.xml.StaxEventItemReader
Responsible for moving the cursor before the StartElement of the fragment root.
MulticasterBatchListener<T,S> - Class in org.springframework.batch.core.listener
 
MulticasterBatchListener() - Constructor for class org.springframework.batch.core.listener.MulticasterBatchListener
Initialize the listener instance.
MultiResourceItemReader<T> - Class in org.springframework.batch.item.file
Reads items from multiple resources sequentially - resource list is given by MultiResourceItemReader.setResources(Resource[]), the actual reading is delegated to MultiResourceItemReader.setDelegate(ResourceAwareItemReaderItemStream).
MultiResourceItemReader() - Constructor for class org.springframework.batch.item.file.MultiResourceItemReader
 
MultiResourceItemReaderBuilder<T> - Class in org.springframework.batch.item.file.builder
A builder implementation for the MultiResourceItemReader.
MultiResourceItemReaderBuilder() - Constructor for class org.springframework.batch.item.file.builder.MultiResourceItemReaderBuilder
 
MultiResourceItemWriter<T> - Class in org.springframework.batch.item.file
Wraps a ResourceAwareItemWriterItemStream and creates a new output resource when the count of items written in current resource exceeds MultiResourceItemWriter.setItemCountLimitPerResource(int).
MultiResourceItemWriter() - Constructor for class org.springframework.batch.item.file.MultiResourceItemWriter
 
MultiResourceItemWriterBuilder<T> - Class in org.springframework.batch.item.file.builder
A builder implementation for the MultiResourceItemWriter.
MultiResourceItemWriterBuilder() - Constructor for class org.springframework.batch.item.file.builder.MultiResourceItemWriterBuilder
 
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
 
MySqlPagingQueryProvider - Class in org.springframework.batch.item.database.support
MySQL implementation of a PagingQueryProvider using database specific features.
MySqlPagingQueryProvider() - Constructor for class org.springframework.batch.item.database.support.MySqlPagingQueryProvider
 

N

name(String) - Method in class org.springframework.batch.item.avro.builder.AvroItemReaderBuilder
The name used to calculate the key within the ExecutionContext.
name(String) - Method in class org.springframework.batch.item.avro.builder.AvroItemWriterBuilder
The name used to calculate the key within the ExecutionContext.
name(String) - Method in class org.springframework.batch.item.data.builder.MongoItemReaderBuilder
The name used to calculate the key within the ExecutionContext.
name(String) - Method in class org.springframework.batch.item.data.builder.Neo4jItemReaderBuilder
The name used to calculate the key within the ExecutionContext.
name(String) - Method in class org.springframework.batch.item.data.builder.RepositoryItemReaderBuilder
The name used to calculate the key within the ExecutionContext.
name(String) - Method in class org.springframework.batch.item.database.builder.HibernateCursorItemReaderBuilder
The name used to calculate the key within the ExecutionContext.
name(String) - Method in class org.springframework.batch.item.database.builder.HibernatePagingItemReaderBuilder
The name used to calculate the key within the ExecutionContext.
name(String) - Method in class org.springframework.batch.item.database.builder.JdbcCursorItemReaderBuilder
The name used to calculate the key within the ExecutionContext.
name(String) - Method in class org.springframework.batch.item.database.builder.JdbcPagingItemReaderBuilder
The name used to calculate the key within the ExecutionContext.
name(String) - Method in class org.springframework.batch.item.database.builder.JpaCursorItemReaderBuilder
The name used to calculate the key within the ExecutionContext.
name(String) - Method in class org.springframework.batch.item.database.builder.JpaPagingItemReaderBuilder
The name used to calculate the key within the ExecutionContext.
name(String) - Method in class org.springframework.batch.item.database.builder.StoredProcedureItemReaderBuilder
The name used to calculate the key within the ExecutionContext.
name(String) - Method in class org.springframework.batch.item.file.builder.FlatFileItemReaderBuilder
The name used to calculate the key within the ExecutionContext.
name(String) - Method in class org.springframework.batch.item.file.builder.FlatFileItemWriterBuilder
The name used to calculate the key within the ExecutionContext.
name(String) - Method in class org.springframework.batch.item.file.builder.MultiResourceItemReaderBuilder
The name used to calculate the key within the ExecutionContext.
name(String) - Method in class org.springframework.batch.item.file.builder.MultiResourceItemWriterBuilder
The name used to calculate the key within the ExecutionContext.
name(String) - Method in class org.springframework.batch.item.json.builder.JsonFileItemWriterBuilder
The name used to calculate the key within the ExecutionContext.
name(String) - Method in class org.springframework.batch.item.json.builder.JsonItemReaderBuilder
The name used to calculate the key within the ExecutionContext.
name(String) - Method in class org.springframework.batch.item.kafka.builder.KafkaItemReaderBuilder
The name used to calculate the key within the ExecutionContext.
name(String) - Method in class org.springframework.batch.item.ldif.builder.LdifReaderBuilder
The name used to calculate the key within the ExecutionContext.
name(String) - Method in class org.springframework.batch.item.ldif.builder.MappingLdifReaderBuilder
The name used to calculate the key within the ExecutionContext.
name(String) - Method in class org.springframework.batch.item.xml.builder.StaxEventItemReaderBuilder
The name used to calculate the key within the ExecutionContext.
name(String) - Method in class org.springframework.batch.item.xml.builder.StaxEventItemWriterBuilder
The name used to calculate the key within the ExecutionContext.
namedParameterJdbcTemplate - Variable in class org.springframework.batch.item.database.JdbcBatchItemWriter
 
namedParametersJdbcTemplate(NamedParameterJdbcOperations) - Method in class org.springframework.batch.item.database.builder.JdbcBatchItemWriterBuilder
The NamedParameterJdbcOperations instance to use.
names(String...) - Method in class org.springframework.batch.item.file.builder.FlatFileItemReaderBuilder.DelimitedBuilder
Names of each of the fields within the fields that are returned in the order they occur within the delimited file.
names(String...) - Method in class org.springframework.batch.item.file.builder.FlatFileItemReaderBuilder.FixedLengthBuilder
The names of the fields to be parsed from the file.
names(String...) - Method in class org.springframework.batch.item.file.builder.FlatFileItemWriterBuilder.DelimitedBuilder
Names of each of the fields within the fields that are returned in the order they occur within the delimited file.
names(String...) - Method in class org.springframework.batch.item.file.builder.FlatFileItemWriterBuilder.FormattedBuilder
Names of each of the fields within the fields that are returned in the order they occur within the formatted file.
names - Variable in class org.springframework.batch.item.file.transform.AbstractLineTokenizer
 
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.
nativeQuery(String) - Method in class org.springframework.batch.item.database.builder.HibernateCursorItemReaderBuilder
Used to configure a HibernateNativeQueryProvider.
Neo4jItemReader<T> - Class in org.springframework.batch.item.data
Extensions of the AbstractNeo4jItemReader.
Neo4jItemReader() - Constructor for class org.springframework.batch.item.data.Neo4jItemReader
 
Neo4jItemReaderBuilder<T> - Class in org.springframework.batch.item.data.builder
A builder for the Neo4jItemReader.
Neo4jItemReaderBuilder() - Constructor for class org.springframework.batch.item.data.builder.Neo4jItemReaderBuilder
 
Neo4jItemWriter<T> - Class in org.springframework.batch.item.data
A ItemWriter implementation that writes to a Neo4j database.
Neo4jItemWriter() - Constructor for class org.springframework.batch.item.data.Neo4jItemWriter
 
Neo4jItemWriterBuilder<T> - Class in org.springframework.batch.item.data.builder
A builder implementation for the Neo4jItemWriter
Neo4jItemWriterBuilder() - Constructor for class org.springframework.batch.item.data.builder.Neo4jItemWriterBuilder
 
NestedRepeatCallback - Class in org.springframework.batch.repeat.callback
Callback that delegates to another callback, via a RepeatOperations instance.
NestedRepeatCallback(RepeatOperations, RepeatCallback) - Constructor for class org.springframework.batch.repeat.callback.NestedRepeatCallback
Constructor setting mandatory fields.
NeverSkipItemSkipPolicy - Class in org.springframework.batch.core.step.skip
SkipPolicy implementation that always returns false, indicating that an item should not be skipped.
NeverSkipItemSkipPolicy() - Constructor for class org.springframework.batch.core.step.skip.NeverSkipItemSkipPolicy
 
next(Step) - Method in class org.springframework.batch.core.job.builder.FlowBuilder
Transition to the next step on successful completion of the current step.
next(JobExecutionDecider) - Method in class org.springframework.batch.core.job.builder.FlowBuilder
Transition to the decider on successful completion of the current step.
next(Flow) - Method in class org.springframework.batch.core.job.builder.FlowBuilder
Go next on successful completion to a subflow.
next(JobExecutionDecider) - Method in class org.springframework.batch.core.job.builder.SimpleJobBuilder
Continue with this decider if the previous step was successful.
next(Step) - Method in class org.springframework.batch.core.job.builder.SimpleJobBuilder
Continue or end a job with this step if the previous step was successful.
next() - Method in class org.springframework.batch.core.step.item.Chunk.ChunkIterator
 
next() - Method in class org.springframework.batch.item.xml.stax.DefaultFragmentEventReader
 
NEXT_ATTR - Static variable in class org.springframework.batch.core.configuration.xml.AbstractFlowParser
 
NEXT_ELE - Static variable in class org.springframework.batch.core.configuration.xml.AbstractFlowParser
 
nextEvent() - Method in class org.springframework.batch.item.xml.stax.DefaultFragmentEventReader
 
nextState(String, FlowExecutionStatus, StepExecution) - Method in class org.springframework.batch.core.job.flow.support.SimpleFlow
 
nextState(String, FlowExecutionStatus, StepExecution) - Method in class org.springframework.batch.core.jsr.job.flow.support.JsrFlow
 
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
 
NonTransientFlatFileException - Exception in org.springframework.batch.item.file
Exception thrown when errors are encountered with the underlying resource.
NonTransientFlatFileException(String, String) - Constructor for exception org.springframework.batch.item.file.NonTransientFlatFileException
 
NonTransientFlatFileException(String, String, int) - Constructor for exception org.springframework.batch.item.file.NonTransientFlatFileException
 
NonTransientFlatFileException(String, Throwable, String, int) - Constructor for exception org.springframework.batch.item.file.NonTransientFlatFileException
 
NonTransientResourceException - Exception in org.springframework.batch.item
Exception indicating that an error has been encountered doing I/O from a reader, and the exception should be considered fatal.
NonTransientResourceException(String, Throwable) - Constructor for exception org.springframework.batch.item.NonTransientResourceException
Create a new NonTransientResourceException based on a message and another exception.
NonTransientResourceException(String) - Constructor for exception org.springframework.batch.item.NonTransientResourceException
Create a new NonTransientResourceException based on a message.
NOOP - Static variable in class org.springframework.batch.core.ExitStatus
Convenient constant value representing job that did no processing (e.g.
noRetry(Class<? extends Throwable>) - Method in class org.springframework.batch.core.step.builder.FaultTolerantStepBuilder
Explicitly ask for an exception (and subclasses) to be excluded from retry.
noRetry(Class<? extends Throwable>) - Method in class org.springframework.batch.integration.chunk.RemoteChunkingManagerStepBuilder
 
noRetry(Class<? extends Throwable>) - Method in class org.springframework.batch.integration.chunk.RemoteChunkingMasterStepBuilder
Deprecated.
 
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.
noRollback(Class<? extends Throwable>) - Method in class org.springframework.batch.integration.chunk.RemoteChunkingManagerStepBuilder
 
noRollback(Class<? extends Throwable>) - Method in class org.springframework.batch.integration.chunk.RemoteChunkingMasterStepBuilder
Deprecated.
 
noSkip(Class<? extends Throwable>) - Method in class org.springframework.batch.core.step.builder.FaultTolerantStepBuilder
Explicitly prevent certain exceptions (and subclasses) from being skipped.
noSkip(Class<? extends Throwable>) - Method in class org.springframework.batch.integration.chunk.RemoteChunkingManagerStepBuilder
 
noSkip(Class<? extends Throwable>) - Method in class org.springframework.batch.integration.chunk.RemoteChunkingMasterStepBuilder
Deprecated.
 
NoStartEndDocumentStreamWriter - Class in org.springframework.batch.item.xml.stax
Delegating XMLEventWriter, which ignores start and end document events, but passes through everything else.
NoStartEndDocumentStreamWriter(XMLEventWriter) - Constructor for class org.springframework.batch.item.xml.stax.NoStartEndDocumentStreamWriter
 
NoSuchJobException - Exception in org.springframework.batch.core.launch
Checked exception to indicate that a required Job is not available.
NoSuchJobException(String) - Constructor for exception org.springframework.batch.core.launch.NoSuchJobException
Create an exception with the given message.
NoSuchJobException(String, Throwable) - Constructor for exception org.springframework.batch.core.launch.NoSuchJobException
 
NoSuchJobExecutionException - Exception in org.springframework.batch.core.launch
Checked exception to indicate that a required JobExecution is not available.
NoSuchJobExecutionException(String) - Constructor for exception org.springframework.batch.core.launch.NoSuchJobExecutionException
Create an exception with the given message.
NoSuchJobExecutionException(String, Throwable) - Constructor for exception org.springframework.batch.core.launch.NoSuchJobExecutionException
 
NoSuchJobInstanceException - Exception in org.springframework.batch.core.launch
Exception that signals that the user requested an operation on a non-existent JobInstance.
NoSuchJobInstanceException(String) - Constructor for exception org.springframework.batch.core.launch.NoSuchJobInstanceException
Create an exception with the given message.
NoSuchJobInstanceException(String, Throwable) - Constructor for exception org.springframework.batch.core.launch.NoSuchJobInstanceException
 
NoSuchObjectException - Exception in org.springframework.batch.core.repository.dao
This exception identifies that a batch domain object is invalid, which is generally caused by an invalid ID.
NoSuchObjectException(String) - Constructor for exception org.springframework.batch.core.repository.dao.NoSuchObjectException
 
NoSuchStepException - Exception in org.springframework.batch.core.step
Exception to signal that a step was requested that is unknown or does not exist.
NoSuchStepException(String) - Constructor for exception org.springframework.batch.core.step.NoSuchStepException
Create a new exception instance with the message provided.
NoWorkFoundStepExecutionListener - Class in org.springframework.batch.core.step
Fails the step if no items have been processed ( item count is 0).
NoWorkFoundStepExecutionListener() - Constructor for class org.springframework.batch.core.step.NoWorkFoundStepExecutionListener
 

O

offset - Variable in class org.springframework.batch.core.step.item.ChunkMonitor.ChunkMonitorData
 
on(String) - Method in class org.springframework.batch.core.job.builder.FlowBuilder
Start a transition to a new state if the exit status from the previous state matches the pattern given.
on(String) - Method in class org.springframework.batch.core.job.builder.FlowBuilder.UnterminatedFlowBuilder
Start a transition to a new state if the exit status from the previous state matches the pattern given.
on(String) - Method in class org.springframework.batch.core.job.builder.SimpleJobBuilder
Branch into a flow conditional on the outcome of the current step.
ON_ATTR - Static variable in class org.springframework.batch.core.configuration.xml.AbstractFlowParser
 
onError(RepeatContext, Throwable) - Method in class org.springframework.batch.repeat.listener.CompositeRepeatListener
 
onError(RepeatContext, Throwable) - Method in class org.springframework.batch.repeat.listener.RepeatListenerSupport
 
onError(RepeatContext, Throwable) - Method in interface org.springframework.batch.repeat.RepeatListener
Called when a repeat callback fails by throwing an exception.
OnProcessError - Annotation Type in org.springframework.batch.core.annotation
Marks a method to be called if an exception is thrown by an ItemProcessor

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

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

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

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

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

Expected signature: void onWriteError(Exception exception, List<? extends S> items)
onWriteError(Exception, List<? extends S>) - Method in interface org.springframework.batch.core.ItemWriteListener
Called if an error occurs while trying to write.
onWriteError(Exception, List<? extends S>) - Method in class org.springframework.batch.core.jsr.ItemWriteListenerAdapter
 
onWriteError(Exception, List<? extends S>) - Method in class org.springframework.batch.core.listener.CompositeItemWriteListener
Call the registered listeners in reverse order, respecting and prioritising those that implement Ordered.
onWriteError(Exception, List<? extends O>) - Method in class org.springframework.batch.core.listener.ItemListenerSupport
 
onWriteError(Exception, List<? extends S>) - Method in class org.springframework.batch.core.listener.MulticasterBatchListener
 
onWriteError(Exception, List<? extends S>) - Method in class org.springframework.batch.core.listener.StepListenerSupport
 
onWriteError(Exception, List<? extends Object>) - Method in class org.springframework.batch.core.step.item.DefaultItemFailureHandler
 
open(ExecutionContext) - Method in class org.springframework.batch.core.step.AbstractStep
Extension point for subclasses to provide callbacks to their collaborators at the beginning of a step, to open or acquire resources.
open(ExecutionContext) - Method in class org.springframework.batch.core.step.item.ChunkMonitor
 
open(ExecutionContext) - Method in class org.springframework.batch.core.step.tasklet.TaskletStep
 
open(ExecutionContext) - Method in class org.springframework.batch.integration.async.AsyncItemWriter
 
open(ExecutionContext) - Method in class org.springframework.batch.integration.chunk.ChunkMessageChannelItemWriter
 
open(ExecutionContext) - Method in class org.springframework.batch.item.avro.AvroItemWriter
 
open(ExecutionContext) - Method in class org.springframework.batch.item.database.JdbcPagingItemReader
 
open(ExecutionContext) - Method in class org.springframework.batch.item.file.MultiResourceItemReader
Figure out which resource to start with in case of restart, open the delegate and restore delegate's position in the resource.
open(ExecutionContext) - Method in class org.springframework.batch.item.file.MultiResourceItemWriter
 
open(ExecutionContext) - Method in class org.springframework.batch.item.file.ResourcesItemReader
 
open(ExecutionContext) - Method in interface org.springframework.batch.item.ItemStream
Open the stream for the provided ExecutionContext.
open(ExecutionContext) - Method in class org.springframework.batch.item.ItemStreamSupport
No-op.
open(Resource) - Method in class org.springframework.batch.item.json.GsonJsonObjectReader
 
open(Resource) - Method in class org.springframework.batch.item.json.JacksonJsonObjectReader
 
open(Resource) - Method in interface org.springframework.batch.item.json.JsonObjectReader
Open the Json resource for reading.
open(ExecutionContext) - Method in class org.springframework.batch.item.kafka.KafkaItemReader
 
open(ExecutionContext) - Method in class org.springframework.batch.item.support.AbstractFileItemWriter
Initialize the reader.
open(ExecutionContext) - Method in class org.springframework.batch.item.support.AbstractItemCountingItemStreamItemReader
 
open(ExecutionContext) - Method in class org.springframework.batch.item.support.CompositeItemStream
Broadcast the call to open.
open(ExecutionContext) - Method in class org.springframework.batch.item.support.CompositeItemWriter
 
open(ExecutionContext) - Method in class org.springframework.batch.item.support.SingleItemPeekableItemReader
If the delegate is an ItemStream, just pass the call on, otherwise reset the peek cache.
open(ExecutionContext) - Method in class org.springframework.batch.item.support.SynchronizedItemStreamReader
 
open(ExecutionContext) - Method in class org.springframework.batch.item.support.SynchronizedItemStreamWriter
 
open(ExecutionContext) - Method in class org.springframework.batch.item.xml.StaxEventItemWriter
Open the output source
open(ExecutionContext) - Method in class org.springframework.batch.jsr.item.CheckpointSupport
 
open(RepeatContext) - Method in class org.springframework.batch.repeat.listener.CompositeRepeatListener
 
open(RepeatContext) - Method in class org.springframework.batch.repeat.listener.RepeatListenerSupport
 
open(RepeatContext) - Method in interface org.springframework.batch.repeat.RepeatListener
Called once at the start of a complete batch, before any items are processed.
openCursor(Connection) - Method in class org.springframework.batch.item.database.AbstractCursorItemReader
 
openCursor(Connection) - Method in class org.springframework.batch.item.database.JdbcCursorItemReader
 
openCursor(Connection) - Method in class org.springframework.batch.item.database.StoredProcedureItemReader
 
OraclePagingQueryProvider - Class in org.springframework.batch.item.database.support
Oracle implementation of a PagingQueryProvider using database specific features.
OraclePagingQueryProvider() - Constructor for class org.springframework.batch.item.database.support.OraclePagingQueryProvider
 
Order - Enum in org.springframework.batch.item.database
The direction of the sort in an ORDER BY clause.
orderByStatement(String) - Method in class org.springframework.batch.item.data.builder.Neo4jItemReaderBuilder
A list of properties to order the results by.
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.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.jsr - package org.springframework.batch.core.jsr
Extensions of core batch components to apply JSR-352 specific logic.
org.springframework.batch.core.jsr.configuration.support - package org.springframework.batch.core.jsr.configuration.support
Extensions of Spring components to support JSR-352 functionality.
org.springframework.batch.core.jsr.configuration.xml - package org.springframework.batch.core.jsr.configuration.xml
XML parsers for JSR-352 based Job Specification Language (JSL).
org.springframework.batch.core.jsr.job - package org.springframework.batch.core.jsr.job
JSR-352 specific handler implementations.
org.springframework.batch.core.jsr.job.flow - package org.springframework.batch.core.jsr.job.flow
JSR-352 specific extensions of Flow constructs (executor and job).
org.springframework.batch.core.jsr.job.flow.support - package org.springframework.batch.core.jsr.job.flow.support
JSR-352 specific flow extensions.
org.springframework.batch.core.jsr.job.flow.support.state - package org.springframework.batch.core.jsr.job.flow.support.state
JSR-352 specific states used in flow execution.
org.springframework.batch.core.jsr.launch - package org.springframework.batch.core.jsr.launch
Implementation of the JSR-352 specific job launching facilities.
org.springframework.batch.core.jsr.launch.support - package org.springframework.batch.core.jsr.launch.support
 
org.springframework.batch.core.jsr.partition - package org.springframework.batch.core.jsr.partition
Implementation of JSR-352 specific partitioning extensions.
org.springframework.batch.core.jsr.partition.support - package org.springframework.batch.core.jsr.partition.support
Support classes for JSR-352 partitioning configuration.
org.springframework.batch.core.jsr.step - package org.springframework.batch.core.jsr.step
JSR-352 extensions of existing batch Step types.
org.springframework.batch.core.jsr.step.batchlet - package org.springframework.batch.core.jsr.step.batchlet
Classes for supporting JSR-352's Batchlet.
org.springframework.batch.core.jsr.step.builder - package org.springframework.batch.core.jsr.step.builder
Extensions to step related builders to implement JSR-352 specific functionality
org.springframework.batch.core.jsr.step.item - package org.springframework.batch.core.jsr.step.item
JSR-352 specific components for implementing item based processing including fault tolerance.
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.metrics - package org.springframework.batch.core.metrics
 
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.
org.springframework.batch.integration.async - package org.springframework.batch.integration.async
Components for executing item processing asynchronously and writing the results when processing is complete.
org.springframework.batch.integration.chunk - package org.springframework.batch.integration.chunk
Components for remote chunking.
org.springframework.batch.integration.config.annotation - package org.springframework.batch.integration.config.annotation
APIs for the configuration of Spring Integration components through annotations.
org.springframework.batch.integration.config.xml - package org.springframework.batch.integration.config.xml
APIs for the configuration of Spring Integration components through XML.
org.springframework.batch.integration.launch - package org.springframework.batch.integration.launch
Message based job launching components.
org.springframework.batch.integration.partition - package org.springframework.batch.integration.partition
Remote partitioning components.
org.springframework.batch.integration.step - package org.springframework.batch.integration.step
Support classes related to steps when used with Spring Integration.
org.springframework.batch.item - package org.springframework.batch.item
Infrastructure interfaces and primary dependencies for item concerns.
org.springframework.batch.item.adapter - package org.springframework.batch.item.adapter
Adapters for Plain Old Java Objects.
org.springframework.batch.item.amqp - package org.springframework.batch.item.amqp
AMQP related batch components.
org.springframework.batch.item.amqp.builder - package org.springframework.batch.item.amqp.builder
Builders for AMQP item reader and writer.
org.springframework.batch.item.avro - package org.springframework.batch.item.avro
 
org.springframework.batch.item.avro.builder - package org.springframework.batch.item.avro.builder
 
org.springframework.batch.item.data - package org.springframework.batch.item.data
Spring Data related readers and writers.
org.springframework.batch.item.data.builder - package org.springframework.batch.item.data.builder
Builders for Spring Data item readers and writers.
org.springframework.batch.item.database - package org.springframework.batch.item.database
Infrastructure implementations of database based item readers and writers.
org.springframework.batch.item.database.builder - package org.springframework.batch.item.database.builder
Builders for database item readers and writers.
org.springframework.batch.item.database.orm - package org.springframework.batch.item.database.orm
Support classes for components using various ORM related technologies.
org.springframework.batch.item.database.support - package org.springframework.batch.item.database.support
Support classes for database specific semantics.
org.springframework.batch.item.file - package org.springframework.batch.item.file
Infrastructure implementations of io file concerns.
org.springframework.batch.item.file.builder - package org.springframework.batch.item.file.builder
Builders for file item readers and writers.
org.springframework.batch.item.file.mapping - package org.springframework.batch.item.file.mapping
Infrastructure implementations of io file support mapping concerns.
org.springframework.batch.item.file.separator - package org.springframework.batch.item.file.separator
Infrastructure implementations of io file support separator concerns.
org.springframework.batch.item.file.transform - package org.springframework.batch.item.file.transform
Infrastructure implementations of io file support transform concerns.
org.springframework.batch.item.function - package org.springframework.batch.item.function
Adapters for java.util.function components.
org.springframework.batch.item.jms - package org.springframework.batch.item.jms
JMS based reader/writer and related components.
org.springframework.batch.item.jms.builder - package org.springframework.batch.item.jms.builder
Builders for JMS item reader and writer.
org.springframework.batch.item.json - package org.springframework.batch.item.json
Infrastructure implementations of JSON input and output.
org.springframework.batch.item.json.builder - package org.springframework.batch.item.json.builder
Builders for JSON item reader and writer.
org.springframework.batch.item.kafka - package org.springframework.batch.item.kafka
Apache Kafka related readers and writers
org.springframework.batch.item.kafka.builder - package org.springframework.batch.item.kafka.builder
Builders for Apache Kafka item reader and writer.
org.springframework.batch.item.ldif - package org.springframework.batch.item.ldif
This package contains the classes required for using the LdifParser in Spring LDAP.
org.springframework.batch.item.ldif.builder - package org.springframework.batch.item.ldif.builder
Builders for LDIF related components.
org.springframework.batch.item.mail - package org.springframework.batch.item.mail
Java Mail based components.
org.springframework.batch.item.mail.builder - package org.springframework.batch.item.mail.builder
Builders for JavaMail related components.
org.springframework.batch.item.mail.javamail - package org.springframework.batch.item.mail.javamail
JavaMail related components.
org.springframework.batch.item.support - package org.springframework.batch.item.support
Internal support package
org.springframework.batch.item.support.builder - package org.springframework.batch.item.support.builder
Builders for support classes.
org.springframework.batch.item.util - package org.springframework.batch.item.util
Infrastructure utility classes.
org.springframework.batch.item.validator - package org.springframework.batch.item.validator
Infrastructure implementations of item validator concerns.
org.springframework.batch.item.xml - package org.springframework.batch.item.xml
Infrastructure implementations of xml input and output.
org.springframework.batch.item.xml.builder - package org.springframework.batch.item.xml.builder
Builders for Stax event item reader and writer.
org.springframework.batch.item.xml.stax - package org.springframework.batch.item.xml.stax
Item reader and writer based on Stax.
org.springframework.batch.jsr.item - package org.springframework.batch.jsr.item
Components for adapting JSR item based components to Spring Batch.
org.springframework.batch.jsr.repeat - package org.springframework.batch.jsr.repeat
APIs for JSR-352 repeat support.
org.springframework.batch.poller - package org.springframework.batch.poller
APIs for polling support.
org.springframework.batch.repeat - package org.springframework.batch.repeat
Infrastructure implementations of repeat concerns.
org.springframework.batch.repeat.callback - package org.springframework.batch.repeat.callback
Infrastructure implementations of repeat callback concerns.
org.springframework.batch.repeat.context - package org.springframework.batch.repeat.context
Infrastructure implementations of repeat context concerns.
org.springframework.batch.repeat.exception - package org.springframework.batch.repeat.exception
Infrastructure implementations of repeat exception handler concerns.
org.springframework.batch.repeat.interceptor - package org.springframework.batch.repeat.interceptor
Infrastructure implementations of repeat aop concerns.
org.springframework.batch.repeat.listener - package org.springframework.batch.repeat.listener
Infrastructure implementations of repeat interceptor concerns.
org.springframework.batch.repeat.policy - package org.springframework.batch.repeat.policy
Infrastructure implementations of repeat policy concerns.
org.springframework.batch.repeat.support - package org.springframework.batch.repeat.support
Infrastructure implementations of repeat support concerns.
org.springframework.batch.support - package org.springframework.batch.support
Infrastructure implementations of support concerns.
org.springframework.batch.support.annotation - package org.springframework.batch.support.annotation
 
org.springframework.batch.support.transaction - package org.springframework.batch.support.transaction
Infrastructure implementations of support transaction concerns.
org.springframework.batch.test - package org.springframework.batch.test
Utility classes for batch job/step testing.
org.springframework.batch.test.context - package org.springframework.batch.test.context
APIs for the configuration of Spring Batch test support.
outputChannel(MessageChannel) - Method in class org.springframework.batch.integration.chunk.RemoteChunkingManagerStepBuilder
Set the output channel on which requests to workers will be sent.
outputChannel(MessageChannel) - Method in class org.springframework.batch.integration.chunk.RemoteChunkingMasterStepBuilder
Deprecated.
Set the output channel on which requests to workers will be sent.
outputChannel(MessageChannel) - Method in class org.springframework.batch.integration.chunk.RemoteChunkingWorkerBuilder
Set the output channel on which replies will be sent to the master step.
outputChannel(MessageChannel) - Method in class org.springframework.batch.integration.partition.RemotePartitioningManagerStepBuilder
Set the output channel on which requests to workers will be sent.
outputChannel(MessageChannel) - Method in class org.springframework.batch.integration.partition.RemotePartitioningMasterStepBuilder
Deprecated.
Set the output channel on which requests to workers will be sent.
outputChannel(MessageChannel) - Method in class org.springframework.batch.integration.partition.RemotePartitioningWorkerStepBuilder
Set the output channel on which replies will be sent to the master step.
OutputState() - Constructor for class org.springframework.batch.item.support.AbstractFileItemWriter.OutputState
 
overwriteOutput(boolean) - Method in class org.springframework.batch.item.xml.builder.StaxEventItemWriterBuilder
Indicates if an existing file should be overwritten if found.

P

page - Variable in class org.springframework.batch.item.data.AbstractPaginatedDataItemReader
 
pageSize - Variable in class org.springframework.batch.item.data.AbstractPaginatedDataItemReader
 
pageSize - Variable in class org.springframework.batch.item.data.builder.MongoItemReaderBuilder
 
pageSize(int) - Method in class org.springframework.batch.item.data.builder.MongoItemReaderBuilder
The number of items to be read with each page.
pageSize(int) - Method in class org.springframework.batch.item.data.builder.Neo4jItemReaderBuilder
The number of items to be read with each page.
pageSize(int) - Method in class org.springframework.batch.item.data.builder.RepositoryItemReaderBuilder
Establish the pageSize for the generated RepositoryItemReader.
pageSize(int) - Method in class org.springframework.batch.item.database.builder.HibernatePagingItemReaderBuilder
The number of records to request per page/query.
pageSize(int) - Method in class org.springframework.batch.item.database.builder.JdbcPagingItemReaderBuilder
The number of records to request per page/query.
pageSize(int) - Method in class org.springframework.batch.item.database.builder.JpaPagingItemReaderBuilder
The number of records to request per page/query.
PagingQueryProvider - Interface in org.springframework.batch.item.database
Interface defining the functionality to be provided for generating paging queries for use with Paging Item Readers.
parameterCount - Variable in class org.springframework.batch.item.database.JdbcBatchItemWriter
 
parameters(SqlParameter...) - Method in class org.springframework.batch.item.database.builder.StoredProcedureItemReaderBuilder
SQL parameters to be set when executing the stored procedure
parametersExtractor(JobParametersExtractor) - Method in class org.springframework.batch.core.step.builder.JobStepBuilder
Provide a job parameters extractor.
parameterValues(List<Object>) - Method in class org.springframework.batch.item.data.builder.MongoItemReaderBuilder
List of values to be substituted in for each of the parameters in the query.
parameterValues(Object...) - Method in class org.springframework.batch.item.data.builder.MongoItemReaderBuilder
Values to be substituted in for each of the parameters in the query.
parameterValues(Map<String, Object>) - Method in class org.springframework.batch.item.data.builder.Neo4jItemReaderBuilder
Optional parameters to be used in the cypher query.
parameterValues(Map<String, Object>) - Method in class org.springframework.batch.item.database.builder.HibernateCursorItemReaderBuilder
A map of parameter values to be set on the query.
parameterValues(Map<String, Object>) - Method in class org.springframework.batch.item.database.builder.HibernatePagingItemReaderBuilder
A map of parameter values to be set on the query.
parameterValues(Map<String, Object>) - Method in class org.springframework.batch.item.database.builder.JdbcPagingItemReaderBuilder
A Map of values to set on the SQL's prepared statement.
parameterValues(Map<String, Object>) - Method in class org.springframework.batch.item.database.builder.JpaCursorItemReaderBuilder
A map of parameter values to be set on the query.
parameterValues(Map<String, Object>) - Method in class org.springframework.batch.item.database.builder.JpaPagingItemReaderBuilder
A map of parameter values to be set on the query.
parse(Element, ParserContext) - Method in class org.springframework.batch.core.configuration.xml.AbstractListenerParser
 
parse(Element, AbstractBeanDefinition, ParserContext, boolean) - Method in class org.springframework.batch.core.configuration.xml.ChunkElementParser
 
parse(Element, ParserContext) - Method in class org.springframework.batch.core.configuration.xml.DecisionParser
Parse the decision and turn it into a list of transitions.
parse(Element, ParserContext, String) - Method in class org.springframework.batch.core.configuration.xml.ExceptionElementParser
 
parse(Element, ParserContext) - Method in class org.springframework.batch.core.configuration.xml.FlowElementParser
Parse the flow and turn it into a list of transitions.
parse(Element, ParserContext, String) - Method in class org.springframework.batch.core.configuration.xml.InlineStepParser
Parse the step and turn it into a list of transitions.
parse(Element, ParserContext) - Method in class org.springframework.batch.core.configuration.xml.SplitParser
Parse the split and turn it into a list of transitions.
parse(Element, ParserContext) - Method in class org.springframework.batch.core.configuration.xml.StandaloneStepParser
Parse the step and turn it into a list of transitions.
parse(Element, AbstractBeanDefinition, ParserContext, String) - Method in class org.springframework.batch.core.jsr.configuration.xml.ChunkParser
 
parse(Element, ParserContext, String) - Method in class org.springframework.batch.core.jsr.configuration.xml.JsrDecisionParser
 
parse(Element, ParserContext) - Method in class org.springframework.batch.core.jsr.configuration.xml.JsrSplitParser
 
parse(Element, AbstractBeanDefinition, ParserContext, String) - Method in class org.springframework.batch.core.jsr.configuration.xml.PartitionParser
 
parse(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.batch.core.jsr.configuration.xml.StepParser
 
parseBatchlet(Element, AbstractBeanDefinition, ParserContext, String) - Method in class org.springframework.batch.core.jsr.configuration.xml.BatchletParser
 
parseBeanElement(Element, ParserContext) - Method in class org.springframework.batch.core.configuration.xml.JobParser
 
ParseException - Exception in org.springframework.batch.item
Exception indicating that an error has been encountered parsing IO, typically from a file.
ParseException(String, Throwable) - Constructor for exception org.springframework.batch.item.ParseException
Create a new ParseException based on a message and another exception.
ParseException(String) - Constructor for exception org.springframework.batch.item.ParseException
Create a new ParseException based on a message.
parseExpression(String) - Method in class org.springframework.batch.core.jsr.configuration.support.JsrExpressionParser
Parses the provided expression, applying any transformations needed to evaluate as a SPeL expression.
parseHandler(Element, ParserContext) - Method in class org.springframework.batch.integration.config.xml.JobLaunchingGatewayParser
 
parseInternal(Element, ParserContext) - Method in class org.springframework.batch.core.configuration.xml.TopLevelStepParser
 
parseInternal(Element, ParserContext) - Method in class org.springframework.batch.core.jsr.configuration.xml.BatchParser
 
parseInternal(Element, ParserContext) - Method in class org.springframework.batch.integration.config.xml.RemoteChunkingManagerParser
 
parseInternal(Element, ParserContext) - Method in class org.springframework.batch.integration.config.xml.RemoteChunkingWorkerParser
 
parseListenerElement(Element, ParserContext, BeanDefinition) - Static method in class org.springframework.batch.core.configuration.xml.AbstractListenerParser
 
parseListeners(Element, ParserContext, AbstractBeanDefinition, String) - Method in class org.springframework.batch.core.jsr.configuration.xml.ListenerParser
 
parseListeners(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.batch.core.jsr.configuration.xml.ListenerParser
 
parsePartitionPlan(Element, ParserContext, String, MutablePropertyValues) - Method in class org.springframework.batch.core.jsr.configuration.xml.PartitionParser
 
parseProperties(Element) - Method in class org.springframework.batch.core.jsr.configuration.xml.PropertyParser
Parses <property> tag values from the provided Element if it contains a <properties /> element.
parseProperty(Element) - Method in class org.springframework.batch.core.jsr.configuration.xml.PropertyParser
Parses a <property> tag value from the provided Element.
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
 
parseTransitionElement(Element, String, BeanDefinition, ParserContext) - Static method in class org.springframework.batch.core.jsr.configuration.xml.FlowParser
 
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
 
PartitionCollectorAdapter - Class in org.springframework.batch.core.jsr.partition
Adapter class used to wrap a PartitionCollector so that it can be consumed as a ChunkListener.
PartitionCollectorAdapter(Queue<Serializable>, PartitionCollector) - Constructor for class org.springframework.batch.core.jsr.partition.PartitionCollectorAdapter
 
partitioner(Step) - Method in class org.springframework.batch.core.jsr.step.builder.JsrSimpleStepBuilder
 
Partitioner - Interface in org.springframework.batch.core.partition.support
Central strategy interface for creating input parameters for a partitioned step in the form of ExecutionContext instances.
partitioner(String, Partitioner) - Method in class org.springframework.batch.core.step.builder.PartitionStepBuilder
Add a partitioner which can be used to create a StepExecutionSplitter.
partitioner(String, Partitioner) - Method in class org.springframework.batch.core.step.builder.StepBuilder
Create a partition step builder for a remote (or local) step.
partitioner(Step) - Method in class org.springframework.batch.core.step.builder.StepBuilder
Create a partition step builder for a remote (or local) step.
partitioner(String, Partitioner) - Method in class org.springframework.batch.integration.partition.RemotePartitioningManagerStepBuilder
 
partitioner(String, Partitioner) - Method in class org.springframework.batch.integration.partition.RemotePartitioningMasterStepBuilder
Deprecated.
 
partitioner(String, Partitioner) - Method in class org.springframework.batch.integration.partition.RemotePartitioningWorkerStepBuilder
 
partitioner(Step) - Method in class org.springframework.batch.integration.partition.RemotePartitioningWorkerStepBuilder
 
PartitionHandler - Interface in org.springframework.batch.core.partition
Interface defining the responsibilities of controlling the execution of a partitioned StepExecution.
partitionHandler(PartitionHandler) - Method in class org.springframework.batch.core.step.builder.PartitionStepBuilder
Provide an explicit partition handler that will carry out the work of the partition step.
partitionHandler(PartitionHandler) - Method in class org.springframework.batch.integration.partition.RemotePartitioningManagerStepBuilder
This method will throw a UnsupportedOperationException since the partition handler of the manager step will be automatically set to an instance of MessageChannelPartitionHandler.
partitionHandler(PartitionHandler) - Method in class org.springframework.batch.integration.partition.RemotePartitioningMasterStepBuilder
Deprecated.
This method will throw a UnsupportedOperationException since the partition handler of the master step will be automatically set to an instance of MessageChannelPartitionHandler.
PartitionNameProvider - Interface in org.springframework.batch.core.partition.support
Optional interface for Partitioner implementations that need to use a custom naming scheme for partitions.
partitionOffsets(Map<TopicPartition, Long>) - Method in class org.springframework.batch.item.kafka.builder.KafkaItemReaderBuilder
Setter for partition offsets.
PartitionParser - Class in org.springframework.batch.core.jsr.configuration.xml
Parser for the <partition> element as defined by JSR-352.
PartitionParser(String, boolean) - Constructor for class org.springframework.batch.core.jsr.configuration.xml.PartitionParser
 
PartitionPlanState(PartitionPlan) - Constructor for class org.springframework.batch.core.jsr.partition.JsrPartitionHandler.PartitionPlanState
 
PartitionPlanState() - Constructor for class org.springframework.batch.core.jsr.partition.JsrPartitionHandler.PartitionPlanState
 
partitions(Integer...) - Method in class org.springframework.batch.item.kafka.builder.KafkaItemReaderBuilder
A list of partitions to manually assign to the consumer.
partitions(List<Integer>) - Method in class org.springframework.batch.item.kafka.builder.KafkaItemReaderBuilder
A list of partitions to manually assign to the consumer.
PartitionStep - Class in org.springframework.batch.core.jsr.step
An extension of the PartitionStep that provides additional semantics required by JSR-352.
PartitionStep() - Constructor for class org.springframework.batch.core.jsr.step.PartitionStep
 
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.
PassThroughFieldExtractor<T> - Class in org.springframework.batch.item.file.transform
FieldExtractor that just returns the original item.
PassThroughFieldExtractor() - Constructor for class org.springframework.batch.item.file.transform.PassThroughFieldExtractor
 
PassThroughFieldSetMapper - Class in org.springframework.batch.item.file.mapping
Pass through FieldSetMapper useful for passing a FieldSet back directly rather than a mapped object.
PassThroughFieldSetMapper() - Constructor for class org.springframework.batch.item.file.mapping.PassThroughFieldSetMapper
 
PassThroughItemProcessor<T> - Class in org.springframework.batch.item.support
Simple ItemProcessor that does nothing - simply passes its argument through to the caller.
PassThroughItemProcessor() - Constructor for class org.springframework.batch.item.support.PassThroughItemProcessor
 
PassThroughLineAggregator<T> - Class in org.springframework.batch.item.file.transform
A LineAggregator implementation that simply calls Object.toString() on the given object
PassThroughLineAggregator() - Constructor for class org.springframework.batch.item.file.transform.PassThroughLineAggregator
 
PassThroughLineMapper - Class in org.springframework.batch.item.file.mapping
Pass through LineMapper useful for passing the original String back directly rather than a mapped object.
PassThroughLineMapper() - Constructor for class org.springframework.batch.item.file.mapping.PassThroughLineMapper
 
PatternMatcher<S> - Class in org.springframework.batch.support
 
PatternMatcher(Map<String, S>) - Constructor for class org.springframework.batch.support.PatternMatcher
Initialize a new PatternMatcher with a map of patterns to values
PatternMatchingCompositeLineMapper<T> - Class in org.springframework.batch.item.file.mapping
A LineMapper implementation that stores a mapping of String patterns to delegate LineTokenizers as well as a mapping of String patterns to delegate FieldSetMappers.
PatternMatchingCompositeLineMapper() - Constructor for class org.springframework.batch.item.file.mapping.PatternMatchingCompositeLineMapper
 
PatternMatchingCompositeLineTokenizer - Class in org.springframework.batch.item.file.transform
A LineTokenizer implementation that stores a mapping of String patterns to delegate LineTokenizers.
PatternMatchingCompositeLineTokenizer() - Constructor for class org.springframework.batch.item.file.transform.PatternMatchingCompositeLineTokenizer
 
peek() - Method in interface org.springframework.batch.item.PeekableItemReader
Get the next item that would be returned by ItemReader.read(), without affecting the result of ItemReader.read().
peek() - Method in class org.springframework.batch.item.support.SingleItemPeekableItemReader
Peek at the next item, ensuring that if the delegate is an ItemStream the state is stored for the next call to SingleItemPeekableItemReader.update(ExecutionContext).
peek() - Method in class org.springframework.batch.item.xml.stax.DefaultFragmentEventReader
 
PeekableItemReader<T> - Interface in org.springframework.batch.item
A specialisation of ItemReader that allows the user to look ahead into the stream of items.
persist(StepContribution, Chunk<O>) - Method in class org.springframework.batch.core.jsr.step.item.JsrChunkProcessor
Responsible for the writing portion of the chunking loop.
persist(StepContribution, Chunk<O>) - Method in class org.springframework.batch.core.jsr.step.item.JsrFaultTolerantChunkProcessor
Adds retry and skip logic to the write phase of the chunk loop.
poll(Callable<S>) - Method in class org.springframework.batch.poller.DirectPoller
Get a future for a non-null result from the callback.
poll(Callable<T>) - Method in interface org.springframework.batch.poller.Poller
Use the callable provided to poll for a non-null result.
Poller<T> - Interface in org.springframework.batch.poller
Interface for polling a Callable instance provided by the user.
pollInterval(long) - Method in class org.springframework.batch.integration.partition.RemotePartitioningManagerStepBuilder
How often to poll the job repository for the status of the workers.
pollInterval(long) - Method in class org.springframework.batch.integration.partition.RemotePartitioningMasterStepBuilder
Deprecated.
How often to poll the job repository for the status of the workers.
pollTimeout(Duration) - Method in class org.springframework.batch.item.kafka.builder.KafkaItemReaderBuilder
Set the pollTimeout for the poll() operations.
position() - Method in class org.springframework.batch.item.support.AbstractFileItemWriter.OutputState
Return the byte offset position of the cursor in the output file as a long integer.
PostgresPagingQueryProvider - Class in org.springframework.batch.item.database.support
Postgres implementation of a PagingQueryProvider using database specific features.
PostgresPagingQueryProvider() - Constructor for class org.springframework.batch.item.database.support.PostgresPagingQueryProvider
 
postProcess(StepContribution, Chunk<T>) - Method in class org.springframework.batch.core.jsr.step.item.JsrChunkProvider
 
postProcess(StepContribution, Chunk<T>) - Method in interface org.springframework.batch.core.step.item.ChunkProvider
 
postProcess(StepContribution, Chunk<I>) - Method in class org.springframework.batch.core.step.item.FaultTolerantChunkProvider
 
postProcess(StepContribution, Chunk<I>) - Method in class org.springframework.batch.core.step.item.SimpleChunkProvider
 
postProcess(String) - Method in interface org.springframework.batch.item.file.separator.RecordSeparatorPolicy
Give the policy a chance to post-process a complete record, e.g.
postProcess(String) - Method in class org.springframework.batch.item.file.separator.SimpleRecordSeparatorPolicy
Pass the record through.
postProcess(String) - Method in class org.springframework.batch.item.file.separator.SuffixRecordSeparatorPolicy
Remove the suffix from the end of the record.
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
 
postProcessAfterInitialization(Object, String) - Method in class org.springframework.batch.core.jsr.configuration.xml.JsrNamespacePostProcessor
 
postProcessAfterInitialization(Object, String) - Method in class org.springframework.batch.core.jsr.launch.support.BatchPropertyBeanPostProcessor
 
postProcessBeanFactory(ConfigurableListableBeanFactory) - Method in class org.springframework.batch.core.configuration.xml.CoreNamespacePostProcessor
 
postProcessBeanFactory(ConfigurableListableBeanFactory) - Method in class org.springframework.batch.core.jsr.configuration.support.ThreadLocalClassloaderBeanPostProcessor
 
postProcessBeanFactory(ConfigurableListableBeanFactory) - Method in class org.springframework.batch.core.jsr.partition.support.JsrBeanScopeBeanFactoryPostProcessor
 
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
 
postProcessBeforeInitialization(Object, String) - Method in class org.springframework.batch.core.jsr.configuration.xml.JsrNamespacePostProcessor
 
postProcessBeforeInitialization(Object, String) - Method in class org.springframework.batch.core.jsr.launch.support.BatchPropertyBeanPostProcessor
 
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.
preparedStatementSetter(PreparedStatementSetter) - Method in class org.springframework.batch.item.database.builder.JdbcCursorItemReaderBuilder
Configures the provided PreparedStatementSetter to be used to populate any arguments in the SQL query to be executed for the reader.
preparedStatementSetter(PreparedStatementSetter) - Method in class org.springframework.batch.item.database.builder.StoredProcedureItemReaderBuilder
Configures the provided PreparedStatementSetter to be used to populate any arguments in the SQL query to be executed for the reader.
prepareTestInstance(TestContext) - Method in class org.springframework.batch.test.JobScopeTestExecutionListener
Set up a JobExecution as a test context attribute.
prepareTestInstance(TestContext) - Method in class org.springframework.batch.test.StepScopeTestExecutionListener
Set up a StepExecution as a test context attribute.
preProcess(String) - Method in class org.springframework.batch.item.file.separator.DefaultRecordSeparatorPolicy
If we are in an unterminated quote, add a line separator.
preProcess(String) - Method in interface org.springframework.batch.item.file.separator.RecordSeparatorPolicy
Pre-process a record before another line is appended, in the case of a multi-line record.
preProcess(String) - Method in class org.springframework.batch.item.file.separator.SimpleRecordSeparatorPolicy
Pass the line through.
preProcessXml(Element) - Method in class org.springframework.batch.core.jsr.configuration.xml.JsrBeanDefinitionDocumentReader
 
preReceive(MessageChannel) - Method in class org.springframework.batch.integration.chunk.MessageSourcePollerInterceptor
Receive from the MessageSource and send immediately to the input channel, so that the call that we are intercepting always a message to receive.
preSend(Message<?>, MessageChannel) - Method in class org.springframework.batch.integration.async.StepExecutionInterceptor
 
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.
procedureName(String) - Method in class org.springframework.batch.item.database.builder.StoredProcedureItemReaderBuilder
The name of the stored procedure to execute
process(StepContribution, Chunk<I>) - Method in class org.springframework.batch.core.jsr.step.item.JsrChunkProcessor
Loops through reading (via JsrChunkProcessor.provide(StepContribution, Chunk) and processing (via JsrChunkProcessor.transform(StepContribution, Object)) until the chunk is complete.
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
 
process(I) - Method in class org.springframework.batch.integration.async.AsyncItemProcessor
Transform the input by delegating to the provided item processor.
process(I) - Method in class org.springframework.batch.item.adapter.ItemProcessorAdapter
Invoke the delegate method and return the result.
process(I) - Method in class org.springframework.batch.item.function.FunctionItemProcessor
 
process(I) - Method in interface org.springframework.batch.item.ItemProcessor
Process the provided item, returning a potentially modified or new item for continued processing.
process(I) - Method in class org.springframework.batch.item.support.ClassifierCompositeItemProcessor
Delegates to injected ItemProcessor instances according to the classification by the Classifier.
process(I) - Method in class org.springframework.batch.item.support.CompositeItemProcessor
 
process(T) - Method in class org.springframework.batch.item.support.PassThroughItemProcessor
Just returns the item back to the caller.
process(I) - Method in class org.springframework.batch.item.support.ScriptItemProcessor
 
process(T) - Method in class org.springframework.batch.item.validator.ValidatingItemProcessor
Validate the item and return it unmodified
process(I) - Method in class org.springframework.batch.jsr.item.ItemProcessorAdapter
 
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.
processor(Function<? super I, ? extends O>) - Method in class org.springframework.batch.core.step.builder.SimpleStepBuilder
A Function to be delegated to as an ItemProcessor.
processor(ItemProcessor<? super I, ? extends O>) - Method in class org.springframework.batch.integration.chunk.RemoteChunkingManagerStepBuilder
 
processor(ItemProcessor<? super I, ? extends O>) - Method in class org.springframework.batch.integration.chunk.RemoteChunkingMasterStepBuilder
Deprecated.
 
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
 
PropertiesConverter - Class in org.springframework.batch.support
Utility to convert a Properties object to a String and back.
propertiesToString(Properties) - Static method in class org.springframework.batch.support.PropertiesConverter
Convert Properties object to String.
PropertyExtractingDelegatingItemWriter<T> - Class in org.springframework.batch.item.adapter
Delegates processing to a custom method - extracts property values from item object and uses them as arguments for the delegate method.
PropertyExtractingDelegatingItemWriter() - Constructor for class org.springframework.batch.item.adapter.PropertyExtractingDelegatingItemWriter
 
PropertyParser - Class in org.springframework.batch.core.jsr.configuration.xml
Parser for the <properties /> element defined by JSR-352.
PropertyParser(String, ParserContext, BatchArtifactType) - Constructor for class org.springframework.batch.core.jsr.configuration.xml.PropertyParser
 
PropertyParser(String, ParserContext, BatchArtifactType, String) - Constructor for class org.springframework.batch.core.jsr.configuration.xml.PropertyParser
 
prototypeBeanName(String) - Method in class org.springframework.batch.item.file.builder.FlatFileItemReaderBuilder
Configures the id of a prototype scoped bean to be used as the item returned by the reader.
provide(StepContribution, Chunk<I>) - Method in class org.springframework.batch.core.jsr.step.item.JsrChunkProcessor
Responsible for the reading portion of the chunking loop.
provide(StepContribution) - Method in class org.springframework.batch.core.jsr.step.item.JsrChunkProvider
 
provide(StepContribution, Chunk<I>) - Method in class org.springframework.batch.core.jsr.step.item.JsrFaultTolerantChunkProcessor
Adds retry and skip logic to the reading phase of the chunk loop.
provide(StepContribution) - Method in interface org.springframework.batch.core.step.item.ChunkProvider
 
provide(StepContribution) - Method in class org.springframework.batch.core.step.item.SimpleChunkProvider
 
put(String, Object) - Method in class org.springframework.batch.item.ExecutionContext
Add an Object value to the context.
put(ResultHolder) - Method in class org.springframework.batch.repeat.support.ResultHolderResultQueue
 
put(T) - Method in class org.springframework.batch.repeat.support.ThrottleLimitResultQueue
 
putDouble(String, double) - Method in class org.springframework.batch.item.ExecutionContext
Add a Double value to the context.
putInt(String, int) - Method in class org.springframework.batch.item.ExecutionContext
Adds an Integer value to the context.
putLong(String, long) - Method in class org.springframework.batch.item.ExecutionContext
Adds a Long value to the context.
putString(String, String) - Method in class org.springframework.batch.item.ExecutionContext
Adds a String value to the context.

Q

query(Query) - Method in class org.springframework.batch.item.data.builder.MongoItemReaderBuilder
Provide a Spring Data Mongo Query.
queryArguments(Object...) - Method in class org.springframework.batch.item.database.builder.JdbcCursorItemReaderBuilder
Configures a PreparedStatementSetter that will use the array as the values to be set on the query to be executed for this reader.
queryArguments(Object[], int[]) - Method in class org.springframework.batch.item.database.builder.JdbcCursorItemReaderBuilder
Configures a PreparedStatementSetter that will use the Object [] as the values to be set on the query to be executed for this reader.
queryArguments(List<?>) - Method in class org.springframework.batch.item.database.builder.JdbcCursorItemReaderBuilder
Configures a PreparedStatementSetter that will use the List as the values to be set on the query to be executed for this reader.
queryName(String) - Method in class org.springframework.batch.item.database.builder.HibernateCursorItemReaderBuilder
The name of the Hibernate named query to be executed for this reader.
queryName(String) - Method in class org.springframework.batch.item.database.builder.HibernatePagingItemReaderBuilder
The name of the Hibernate named query to be executed for this reader.
queryProvider(HibernateQueryProvider<T>) - Method in class org.springframework.batch.item.database.builder.HibernateCursorItemReaderBuilder
A query provider.
queryProvider(HibernateQueryProvider<T>) - Method in class org.springframework.batch.item.database.builder.HibernatePagingItemReaderBuilder
A query provider.
queryProvider(PagingQueryProvider) - Method in class org.springframework.batch.item.database.builder.JdbcPagingItemReaderBuilder
A PagingQueryProvider to provide the queries required.
queryProvider(JpaQueryProvider) - Method in class org.springframework.batch.item.database.builder.JpaCursorItemReaderBuilder
A query provider.
queryProvider(JpaQueryProvider) - Method in class org.springframework.batch.item.database.builder.JpaPagingItemReaderBuilder
A query provider.
queryString(String) - Method in class org.springframework.batch.item.database.builder.HibernateCursorItemReaderBuilder
The HQL query string to execute.
queryString(String) - Method in class org.springframework.batch.item.database.builder.HibernatePagingItemReaderBuilder
The HQL query string to execute.
queryString(String) - Method in class org.springframework.batch.item.database.builder.JpaCursorItemReaderBuilder
The JPQL query string to execute.
queryString(String) - Method in class org.springframework.batch.item.database.builder.JpaPagingItemReaderBuilder
The HQL query string to execute.
queryTimeout(int) - Method in class org.springframework.batch.item.database.builder.JdbcCursorItemReaderBuilder
The time in milliseconds for the query to timeout
queryTimeout(int) - Method in class org.springframework.batch.item.database.builder.StoredProcedureItemReaderBuilder
The time in milliseconds for the query to timeout
quoteCharacter(char) - Method in class org.springframework.batch.item.file.builder.FlatFileItemReaderBuilder.DelimitedBuilder
Define the character used to quote fields.

R

Range - Class in org.springframework.batch.item.file.transform
A class to represent ranges.
Range(int) - Constructor for class org.springframework.batch.item.file.transform.Range
 
Range(int, int) - Constructor for class org.springframework.batch.item.file.transform.Range
 
RangeArrayPropertyEditor - Class in org.springframework.batch.item.file.transform
Property editor implementation which parses string and creates array of ranges.
RangeArrayPropertyEditor() - Constructor for class org.springframework.batch.item.file.transform.RangeArrayPropertyEditor
 
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
read() - Method in class org.springframework.batch.item.adapter.ItemReaderAdapter
 
read() - Method in class org.springframework.batch.item.amqp.AmqpItemReader
 
read() - Method in class org.springframework.batch.item.file.MultiResourceItemReader
Reads the next item, jumping to next resource if necessary.
read() - Method in class org.springframework.batch.item.file.ResourcesItemReader
Increments a counter and returns the next Resource instance from the input, or null if none remain.
read() - Method in interface org.springframework.batch.item.ItemReader
Reads a piece of input data and advance to the next one.
read() - Method in class org.springframework.batch.item.jms.JmsItemReader
 
read() - Method in class org.springframework.batch.item.json.GsonJsonObjectReader
 
read() - Method in class org.springframework.batch.item.json.JacksonJsonObjectReader
 
read() - Method in interface org.springframework.batch.item.json.JsonObjectReader
Read the next object in the Json resource if any.
read() - Method in class org.springframework.batch.item.kafka.KafkaItemReader
 
read() - Method in class org.springframework.batch.item.support.AbstractItemCountingItemStreamItemReader
 
read() - Method in class org.springframework.batch.item.support.IteratorItemReader
Implementation of ItemReader.read() that just iterates over the iterator provided.
read() - Method in class org.springframework.batch.item.support.ListItemReader
 
read() - Method in class org.springframework.batch.item.support.SingleItemPeekableItemReader
Get the next item from the delegate (whether or not it has already been peeked at).
read() - Method in class org.springframework.batch.item.support.SynchronizedItemStreamReader
This delegates to the read method of the delegate
read() - Method in class org.springframework.batch.jsr.item.ItemReaderAdapter
 
readAndTrim(int) - Method in class org.springframework.batch.item.file.transform.DefaultFieldSet
Read and trim the String value at 'index'.
readBigDecimal(int) - Method in class org.springframework.batch.item.file.transform.DefaultFieldSet
 
readBigDecimal(String) - Method in class org.springframework.batch.item.file.transform.DefaultFieldSet
 
readBigDecimal(int, BigDecimal) - Method in class org.springframework.batch.item.file.transform.DefaultFieldSet
 
readBigDecimal(String, BigDecimal) - Method in class org.springframework.batch.item.file.transform.DefaultFieldSet
 
readBigDecimal(int) - Method in interface org.springframework.batch.item.file.transform.FieldSet
Read the BigDecimal value at index 'index'.
readBigDecimal(String) - Method in interface org.springframework.batch.item.file.transform.FieldSet
Read the BigDecimal value from column with given 'name.
readBigDecimal(int, BigDecimal) - Method in interface org.springframework.batch.item.file.transform.FieldSet
Read the BigDecimal value at index 'index', returning the supplied defaultValue if the trimmed string value at index 'index' is blank.
readBigDecimal(String, BigDecimal) - Method in interface org.springframework.batch.item.file.transform.FieldSet
Read the BigDecimal value from column with given 'name, returning the supplied defaultValue if the trimmed string value at index 'index' is blank.
readBoolean(int) - Method in class org.springframework.batch.item.file.transform.DefaultFieldSet
 
readBoolean(String) - Method in class org.springframework.batch.item.file.transform.DefaultFieldSet
 
readBoolean(int, String) - Method in class org.springframework.batch.item.file.transform.DefaultFieldSet
 
readBoolean(String, String) - Method in class org.springframework.batch.item.file.transform.DefaultFieldSet
 
readBoolean(int) - Method in interface org.springframework.batch.item.file.transform.FieldSet
Read the 'boolean' value at index 'index'.
readBoolean(String) - Method in interface org.springframework.batch.item.file.transform.FieldSet
Read the 'boolean' value from column with given 'name'.
readBoolean(int, String) - Method in interface org.springframework.batch.item.file.transform.FieldSet
Read the 'boolean' value at index 'index'.
readBoolean(String, String) - Method in interface org.springframework.batch.item.file.transform.FieldSet
Read the 'boolean' value from column with given 'name'.
readByte(int) - Method in class org.springframework.batch.item.file.transform.DefaultFieldSet
 
readByte(String) - Method in class org.springframework.batch.item.file.transform.DefaultFieldSet
 
readByte(int) - Method in interface org.springframework.batch.item.file.transform.FieldSet
Read the 'byte' value at index 'index'.
readByte(String) - Method in interface org.springframework.batch.item.file.transform.FieldSet
Read the 'byte' value from column with given 'name'.
readChar(int) - Method in class org.springframework.batch.item.file.transform.DefaultFieldSet
 
readChar(String) - Method in class org.springframework.batch.item.file.transform.DefaultFieldSet
 
readChar(int) - Method in interface org.springframework.batch.item.file.transform.FieldSet
Read the 'char' value at index 'index'.
readChar(String) - Method in interface org.springframework.batch.item.file.transform.FieldSet
Read the 'char' value from column with given 'name'.
readCursor(ResultSet, int) - Method in class org.springframework.batch.item.database.AbstractCursorItemReader
Read the cursor and map to the type of object this reader should return.
readCursor(ResultSet, int) - Method in class org.springframework.batch.item.database.JdbcCursorItemReader
 
readCursor(ResultSet, int) - Method in class org.springframework.batch.item.database.StoredProcedureItemReader
 
readDate(int) - Method in class org.springframework.batch.item.file.transform.DefaultFieldSet
 
readDate(int, Date) - Method in class org.springframework.batch.item.file.transform.DefaultFieldSet
 
readDate(String) - Method in class org.springframework.batch.item.file.transform.DefaultFieldSet
 
readDate(String, Date) - Method in class org.springframework.batch.item.file.transform.DefaultFieldSet
 
readDate(int, String) - Method in class org.springframework.batch.item.file.transform.DefaultFieldSet
 
readDate(int, String, Date) - Method in class org.springframework.batch.item.file.transform.DefaultFieldSet
 
readDate(String, String) - Method in class org.springframework.batch.item.file.transform.DefaultFieldSet
 
readDate(String, String, Date) - Method in class org.springframework.batch.item.file.transform.DefaultFieldSet
 
readDate(int) - Method in interface org.springframework.batch.item.file.transform.FieldSet
Read the java.util.Date value in default format at designated column index.
readDate(String) - Method in interface org.springframework.batch.item.file.transform.FieldSet
Read the java.sql.Date value in given format from column with given name.
readDate(int, Date) - Method in interface org.springframework.batch.item.file.transform.FieldSet
Read the java.util.Date value in default format at designated column index.
readDate(String, Date) - Method in interface org.springframework.batch.item.file.transform.FieldSet
Read the java.sql.Date value in given format from column with given name.
readDate(int, String) - Method in interface org.springframework.batch.item.file.transform.FieldSet
Read the java.util.Date value in default format at designated column index.
readDate(String, String) - Method in interface org.springframework.batch.item.file.transform.FieldSet
Read the java.sql.Date value in given format from column with given name.
readDate(int, String, Date) - Method in interface org.springframework.batch.item.file.transform.FieldSet
Read the java.util.Date value in default format at designated column index.
readDate(String, String, Date) - Method in interface org.springframework.batch.item.file.transform.FieldSet
Read the java.sql.Date value in given format from column with given name.
readDouble(int) - Method in class org.springframework.batch.item.file.transform.DefaultFieldSet
 
readDouble(String) - Method in class org.springframework.batch.item.file.transform.DefaultFieldSet
 
readDouble(int) - Method in interface org.springframework.batch.item.file.transform.FieldSet
Read the 'double' value at index 'index'.
readDouble(String) - Method in interface org.springframework.batch.item.file.transform.FieldSet
Read the 'double' value from column with given 'name.
reader(ItemReader<? extends I>) - Method in class org.springframework.batch.core.step.builder.SimpleStepBuilder
An item reader that provides a stream of items.
reader(ItemReader<? extends I>) - Method in class org.springframework.batch.integration.chunk.RemoteChunkingManagerStepBuilder
 
reader(ItemReader<? extends I>) - Method in class org.springframework.batch.integration.chunk.RemoteChunkingMasterStepBuilder
Deprecated.
 
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.
readerIsTransactionalQueue() - Method in class org.springframework.batch.integration.chunk.RemoteChunkingManagerStepBuilder
 
readerIsTransactionalQueue() - Method in class org.springframework.batch.integration.chunk.RemoteChunkingMasterStepBuilder
Deprecated.
 
ReaderNotOpenException - Exception in org.springframework.batch.item
Exception indicating that an ItemReader needed to be opened before read.
ReaderNotOpenException(String) - Constructor for exception org.springframework.batch.item.ReaderNotOpenException
Create a new ReaderNotOpenException based on a message.
ReaderNotOpenException(String, Throwable) - Constructor for exception org.springframework.batch.item.ReaderNotOpenException
Create a new ReaderNotOpenException based on a message and another exception.
readFloat(int) - Method in class org.springframework.batch.item.file.transform.DefaultFieldSet
 
readFloat(String) - Method in class org.springframework.batch.item.file.transform.DefaultFieldSet
 
readFloat(int) - Method in interface org.springframework.batch.item.file.transform.FieldSet
Read the 'float' value at index 'index'.
readFloat(String) - Method in interface org.springframework.batch.item.file.transform.FieldSet
Read the 'float' value from column with given 'name.
readInt(int) - Method in class org.springframework.batch.item.file.transform.DefaultFieldSet
 
readInt(String) - Method in class org.springframework.batch.item.file.transform.DefaultFieldSet
 
readInt(int, int) - Method in class org.springframework.batch.item.file.transform.DefaultFieldSet
 
readInt(String, int) - Method in class org.springframework.batch.item.file.transform.DefaultFieldSet
 
readInt(int) - Method in interface org.springframework.batch.item.file.transform.FieldSet
Read the 'int' value at index 'index'.
readInt(String) - Method in interface org.springframework.batch.item.file.transform.FieldSet
Read the 'int' value from column with given 'name'.
readInt(int, int) - Method in interface org.springframework.batch.item.file.transform.FieldSet
Read the 'int' value at index 'index', using the supplied defaultValue if the field value is blank.
readInt(String, int) - Method in interface org.springframework.batch.item.file.transform.FieldSet
Read the 'int' value from column with given 'name', using the supplied defaultValue if the field value is blank.
readLong(int) - Method in class org.springframework.batch.item.file.transform.DefaultFieldSet
 
readLong(String) - Method in class org.springframework.batch.item.file.transform.DefaultFieldSet
 
readLong(int, long) - Method in class org.springframework.batch.item.file.transform.DefaultFieldSet
 
readLong(String, long) - Method in class org.springframework.batch.item.file.transform.DefaultFieldSet
 
readLong(int) - Method in interface org.springframework.batch.item.file.transform.FieldSet
Read the 'long' value at index 'index'.
readLong(String) - Method in interface org.springframework.batch.item.file.transform.FieldSet
Read the 'long' value from column with given 'name'.
readLong(int, long) - Method in interface org.springframework.batch.item.file.transform.FieldSet
Read the 'long' value at index 'index', using the supplied defaultValue if the field value is blank.
readLong(String, long) - Method in interface org.springframework.batch.item.file.transform.FieldSet
Read the 'long' value from column with given 'name', using the supplied defaultValue if the field value is blank.
readPage(int, int, int, Map<String, Object>) - Method in class org.springframework.batch.item.database.HibernateItemReaderHelper
Read a page of data, clearing the existing session (if necessary) first, and creating a new session before executing the query.
readRawString(int) - Method in class org.springframework.batch.item.file.transform.DefaultFieldSet
 
readRawString(String) - Method in class org.springframework.batch.item.file.transform.DefaultFieldSet
 
readRawString(int) - Method in interface org.springframework.batch.item.file.transform.FieldSet
Read the String value at index 'index' including trailing whitespace (don't trim).
readRawString(String) - Method in interface org.springframework.batch.item.file.transform.FieldSet
Read the String value from column with given 'name' including trailing whitespace (don't trim).
readShort(int) - Method in class org.springframework.batch.item.file.transform.DefaultFieldSet
 
readShort(String) - Method in class org.springframework.batch.item.file.transform.DefaultFieldSet
 
readShort(int) - Method in interface org.springframework.batch.item.file.transform.FieldSet
Read the 'short' value at index 'index'.
readShort(String) - Method in interface org.springframework.batch.item.file.transform.FieldSet
Read the 'short' value from column with given 'name'.
readString(int) - Method in class org.springframework.batch.item.file.transform.DefaultFieldSet
 
readString(String) - Method in class org.springframework.batch.item.file.transform.DefaultFieldSet
 
readString(int) - Method in interface org.springframework.batch.item.file.transform.FieldSet
Read the String value at index 'index'.
readString(String) - Method in interface org.springframework.batch.item.file.transform.FieldSet
Read the String value from column with given 'name'.
RecordCallbackHandler - Interface in org.springframework.batch.item.ldif
This interface can be used to operate on skipped records during open in the LdifReader and the MappingLdifReader.
RecordFieldSetMapper<T> - Class in org.springframework.batch.item.file.mapping
This is a FieldSetMapper that supports Java records mapping (requires JKD 14 or higher).
RecordFieldSetMapper(Class<T>) - Constructor for class org.springframework.batch.item.file.mapping.RecordFieldSetMapper
Create a new RecordFieldSetMapper.
RecordFieldSetMapper(Class<T>, ConversionService) - Constructor for class org.springframework.batch.item.file.mapping.RecordFieldSetMapper
Create a new RecordFieldSetMapper.
recordMapper(RecordMapper<T>) - Method in class org.springframework.batch.item.ldif.builder.MappingLdifReaderBuilder
Setter for object mapper.
RecordMapper<T> - Interface in org.springframework.batch.item.ldif
This interface should be implemented to map LdapAttributes objects to POJOs.
recordSeparatorPolicy(RecordSeparatorPolicy) - Method in class org.springframework.batch.item.file.builder.FlatFileItemReaderBuilder
Configure a custom RecordSeparatorPolicy for the reader.
RecordSeparatorPolicy - Interface in org.springframework.batch.item.file.separator
Policy for text file-based input sources to determine the end of a record, e.g.
recordsToSkip(int) - Method in class org.springframework.batch.item.ldif.builder.LdifReaderBuilder
Public setter for the number of lines to skip at the start of a file.
recordsToSkip(int) - Method in class org.springframework.batch.item.ldif.builder.MappingLdifReaderBuilder
Public setter for the number of lines to skip at the start of a file.
recover(Object[], Throwable) - Method in class org.springframework.batch.item.jms.JmsMethodInvocationRecoverer
Send one message per item in the arguments list using the default destination of the jms template.
RecursiveCollectionLineAggregator<T> - Class in org.springframework.batch.item.file.transform
An implementation of LineAggregator that concatenates a collection of items of a common type with the system line separator.
RecursiveCollectionLineAggregator() - Constructor for class org.springframework.batch.item.file.transform.RecursiveCollectionLineAggregator
 
reducer(PartitionReducer) - Method in class org.springframework.batch.core.jsr.step.builder.JsrPartitionStepBuilder
 
refCursorPosition(int) - Method in class org.springframework.batch.item.database.builder.StoredProcedureItemReaderBuilder
The parameter position of the REF CURSOR.
ReferenceJobFactory - Class in org.springframework.batch.core.configuration.support
A JobFactory that just keeps a reference to a Job.
ReferenceJobFactory(Job) - Constructor for class org.springframework.batch.core.configuration.support.ReferenceJobFactory
 
ReflectionUtils - Class in org.springframework.batch.support
Provides reflection based utilities for Spring Batch that are not available via Spring Core
RegexLineTokenizer - Class in org.springframework.batch.item.file.transform
Line-tokenizer using a regular expression to filter out data (by using matching and non-matching groups).
RegexLineTokenizer() - Constructor for class org.springframework.batch.item.file.transform.RegexLineTokenizer
 
register(JobFactory) - Method in interface org.springframework.batch.core.configuration.JobRegistry
Registers a Job at runtime.
register(String, Collection<Step>) - Method in interface org.springframework.batch.core.configuration.StepRegistry
Registers all the step of the given job.
register(JobFactory) - Method in class org.springframework.batch.core.configuration.support.MapJobRegistry
 
register(String, Collection<Step>) - Method in class org.springframework.batch.core.configuration.support.MapStepRegistry
 
register(ChunkListener) - Method in class org.springframework.batch.core.listener.CompositeChunkListener
Register additional listener.
register(ItemProcessListener<? super T, ? super S>) - Method in class org.springframework.batch.core.listener.CompositeItemProcessListener
Register additional listener.
register(ItemReadListener<? super T>) - Method in class org.springframework.batch.core.listener.CompositeItemReadListener
Register additional listener.
register(ItemWriteListener<? super S>) - Method in class org.springframework.batch.core.listener.CompositeItemWriteListener
Register additional listener.
register(JobExecutionListener) - Method in class org.springframework.batch.core.listener.CompositeJobExecutionListener
Register additional listener.
register(RetryProcessListener) - Method in class org.springframework.batch.core.listener.CompositeRetryProcessListener
Register an additional RetryProcessListener.
register(RetryReadListener) - Method in class org.springframework.batch.core.listener.CompositeRetryReadListener
Register an additional RetryReadListener.
register(RetryWriteListener) - Method in class org.springframework.batch.core.listener.CompositeRetryWriteListener
Register an additional RetryWriteListener.
register(SkipListener<? super T, ? super S>) - Method in class org.springframework.batch.core.listener.CompositeSkipListener
Register additional listener.
register(StepExecutionListener) - Method in class org.springframework.batch.core.listener.CompositeStepExecutionListener
Register additional listener.
register(StepListener) - Method in class org.springframework.batch.core.listener.MulticasterBatchListener
Register the listener for callbacks on the appropriate interfaces implemented.
register(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(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(StepExecution, BatchPropertyContext) - 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(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(E, BatchPropertyContext) - 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(ItemStream) - Method in class org.springframework.batch.item.support.CompositeItemStream
Register a ItemStream as one of the interesting providers under the provided key.
register(RepeatListener) - Method in class org.springframework.batch.repeat.listener.CompositeRepeatListener
Register additional listener.
register(RepeatContext) - Static method in class org.springframework.batch.repeat.support.RepeatSynchronizationManager
Method for registering a context - should only be used by RepeatOperations implementations to ensure that RepeatSynchronizationManager.getContext() always returns the correct value.
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.
registerCustomEditors(PropertyEditorRegistry) - Method in class org.springframework.batch.support.DefaultPropertyEditorRegistrar
Register the custom editors with the given registry.
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
 
registerDestructionCallback(String, Runnable) - Method in class org.springframework.batch.repeat.context.RepeatContextSupport
 
registerDestructionCallback(String, Runnable) - Method in interface org.springframework.batch.repeat.RepeatContext
Register a callback to be executed on close, associated with the attribute having the given name.
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.jsr.step.item.JsrChunkProcessor
Register a listener for callbacks at the appropriate stages in a process.
registerListener(StepListener) - Method in class org.springframework.batch.core.jsr.step.item.JsrFaultTolerantChunkProcessor
Register a listener for callbacks at the appropriate stages in a process.
registerListener(RetryListener) - Method in class org.springframework.batch.core.step.item.BatchRetryTemplate
 
registerListener(StepListener) - Method in class org.springframework.batch.core.step.item.SimpleChunkProcessor
Register a listener for callbacks at the appropriate stages in a process.
registerListener(StepListener) - Method in class org.springframework.batch.core.step.item.SimpleChunkProvider
Register a listener for callbacks at the appropriate stages in a process.
registerListener(RepeatListener) - Method in class org.springframework.batch.repeat.support.RepeatTemplate
Register an additional listener.
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.
RemoteChunkHandlerFactoryBean<T> - Class in org.springframework.batch.integration.chunk
Convenient factory bean for a chunk handler that also converts an existing chunk-oriented step into a remote chunk master.
RemoteChunkHandlerFactoryBean() - Constructor for class org.springframework.batch.integration.chunk.RemoteChunkHandlerFactoryBean
 
RemoteChunkingManagerParser - Class in org.springframework.batch.integration.config.xml
Parser for the remote-chunking-manager namespace element.
RemoteChunkingManagerParser() - Constructor for class org.springframework.batch.integration.config.xml.RemoteChunkingManagerParser
 
RemoteChunkingManagerStepBuilder<I,O> - Class in org.springframework.batch.integration.chunk
Builder for a manager step in a remote chunking setup.
RemoteChunkingManagerStepBuilder(String) - Constructor for class org.springframework.batch.integration.chunk.RemoteChunkingManagerStepBuilder
RemoteChunkingManagerStepBuilderFactory - Class in org.springframework.batch.integration.chunk
Convenient factory for a RemoteChunkingManagerStepBuilder which sets the JobRepository and PlatformTransactionManager automatically.
RemoteChunkingManagerStepBuilderFactory(JobRepository, PlatformTransactionManager) - Constructor for class org.springframework.batch.integration.chunk.RemoteChunkingManagerStepBuilderFactory
remoteChunkingManagerStepBuilderFactory() - Method in class org.springframework.batch.integration.config.annotation.BatchIntegrationConfiguration
 
RemoteChunkingMasterStepBuilder<I,O> - Class in org.springframework.batch.integration.chunk
Deprecated.
RemoteChunkingMasterStepBuilder(String) - Constructor for class org.springframework.batch.integration.chunk.RemoteChunkingMasterStepBuilder
Deprecated.
RemoteChunkingMasterStepBuilderFactory - Class in org.springframework.batch.integration.chunk
Deprecated.
RemoteChunkingMasterStepBuilderFactory(JobRepository, PlatformTransactionManager) - Constructor for class org.springframework.batch.integration.chunk.RemoteChunkingMasterStepBuilderFactory
Deprecated.
remoteChunkingMasterStepBuilderFactory() - Method in class org.springframework.batch.integration.config.annotation.BatchIntegrationConfiguration
Deprecated.
RemoteChunkingWorkerBuilder<I,O> - Class in org.springframework.batch.integration.chunk
Builder for a worker in a remote chunking setup.
RemoteChunkingWorkerBuilder() - Constructor for class org.springframework.batch.integration.chunk.RemoteChunkingWorkerBuilder
 
remoteChunkingWorkerBuilder() - Method in class org.springframework.batch.integration.config.annotation.BatchIntegrationConfiguration
 
RemoteChunkingWorkerParser - Class in org.springframework.batch.integration.config.xml
Parser for the remote-chunking-worker namespace element.
RemoteChunkingWorkerParser() - Constructor for class org.springframework.batch.integration.config.xml.RemoteChunkingWorkerParser
 
RemotePartitioningManagerStepBuilder - Class in org.springframework.batch.integration.partition
Builder for a manager step in a remote partitioning setup.
RemotePartitioningManagerStepBuilder(String) - Constructor for class org.springframework.batch.integration.partition.RemotePartitioningManagerStepBuilder
remotePartitioningManagerStepBuilderFactory() - Method in class org.springframework.batch.integration.config.annotation.BatchIntegrationConfiguration
 
RemotePartitioningManagerStepBuilderFactory - Class in org.springframework.batch.integration.partition
Convenient factory for a RemotePartitioningManagerStepBuilder which sets the JobRepository, JobExplorer, BeanFactory and PlatformTransactionManager automatically.
RemotePartitioningManagerStepBuilderFactory(JobRepository, JobExplorer, PlatformTransactionManager) - Constructor for class org.springframework.batch.integration.partition.RemotePartitioningManagerStepBuilderFactory
RemotePartitioningMasterStepBuilder - Class in org.springframework.batch.integration.partition
Deprecated.
RemotePartitioningMasterStepBuilder(String) - Constructor for class org.springframework.batch.integration.partition.RemotePartitioningMasterStepBuilder
Deprecated.
remotePartitioningMasterStepBuilderFactory() - Method in class org.springframework.batch.integration.config.annotation.BatchIntegrationConfiguration
Deprecated.
RemotePartitioningMasterStepBuilderFactory - Class in org.springframework.batch.integration.partition
RemotePartitioningMasterStepBuilderFactory(JobRepository, JobExplorer, PlatformTransactionManager) - Constructor for class org.springframework.batch.integration.partition.RemotePartitioningMasterStepBuilderFactory
Deprecated.
RemotePartitioningWorkerStepBuilder - Class in org.springframework.batch.integration.partition
Builder for a worker step in a remote partitioning setup.
RemotePartitioningWorkerStepBuilder(String) - Constructor for class org.springframework.batch.integration.partition.RemotePartitioningWorkerStepBuilder
Initialize a step builder for a step with the given name.
remotePartitioningWorkerStepBuilderFactory() - Method in class org.springframework.batch.integration.config.annotation.BatchIntegrationConfiguration
 
RemotePartitioningWorkerStepBuilderFactory - Class in org.springframework.batch.integration.partition
Convenient factory for a RemotePartitioningWorkerStepBuilder which sets the JobRepository, JobExplorer, BeanFactory and PlatformTransactionManager automatically.
RemotePartitioningWorkerStepBuilderFactory(JobRepository, JobExplorer, PlatformTransactionManager) - Constructor for class org.springframework.batch.integration.partition.RemotePartitioningWorkerStepBuilderFactory
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() - Method in class org.springframework.batch.core.jsr.JsrStepContextFactoryBean
 
remove(String) - Method in class org.springframework.batch.core.scope.JobScope
 
remove(String) - Method in class org.springframework.batch.core.scope.StepScope
 
remove(Throwable) - Method in class org.springframework.batch.core.step.item.Chunk.ChunkIterator
 
remove() - Method in class org.springframework.batch.core.step.item.Chunk.ChunkIterator
 
remove(String) - Method in class org.springframework.batch.item.ExecutionContext
Removes the mapping for a key from this context if it is present.
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.
removeAttribute(String) - Method in class org.springframework.batch.repeat.context.SynchronizedAttributeAccessor
 
removeJobExecutions(Collection<JobExecution>) - Method in class org.springframework.batch.test.JobRepositoryTestUtils
Remove the JobExecution instances, and all associated JobInstance and StepExecution instances from the standard RDBMS locations used by Spring Batch.
removeJobExecutions() - Method in class org.springframework.batch.test.JobRepositoryTestUtils
Remove all the JobExecution instances, and all associated JobInstance and StepExecution instances from the standard RDBMS locations used by Spring Batch.
RepeatCallback - Interface in org.springframework.batch.repeat
Callback interface for batch operations.
RepeatContext - Interface in org.springframework.batch.repeat
Base interface for context which controls the state and completion / termination of a batch step.
RepeatContextCounter - Class in org.springframework.batch.repeat.context
Helper class for policies that need to count the number of occurrences of some event (e.g.
RepeatContextCounter(RepeatContext, String) - Constructor for class org.springframework.batch.repeat.context.RepeatContextCounter
Convenience constructor with useParent=false.
RepeatContextCounter(RepeatContext, String, boolean) - Constructor for class org.springframework.batch.repeat.context.RepeatContextCounter
Construct a new RepeatContextCounter.
RepeatContextSupport - Class in org.springframework.batch.repeat.context
 
RepeatContextSupport(RepeatContext) - Constructor for class org.springframework.batch.repeat.context.RepeatContextSupport
Constructor for RepeatContextSupport.
RepeatException - Exception in org.springframework.batch.repeat
 
RepeatException(String) - Constructor for exception org.springframework.batch.repeat.RepeatException
 
RepeatException(String, Throwable) - Constructor for exception org.springframework.batch.repeat.RepeatException
 
RepeatInternalState - Interface in org.springframework.batch.repeat.support
Internal interface for extensions of RepeatTemplate.
RepeatInternalStateSupport - Class in org.springframework.batch.repeat.support
 
RepeatInternalStateSupport() - Constructor for class org.springframework.batch.repeat.support.RepeatInternalStateSupport
 
RepeatListener - Interface in org.springframework.batch.repeat
Interface for listeners to the batch process.
RepeatListenerSupport - Class in org.springframework.batch.repeat.listener
Empty method implementation of RepeatListener.
RepeatListenerSupport() - Constructor for class org.springframework.batch.repeat.listener.RepeatListenerSupport
 
RepeatOperations - Interface in org.springframework.batch.repeat
The main interface providing access to batch operations.
RepeatOperationsInterceptor - Class in org.springframework.batch.repeat.interceptor
A MethodInterceptor that can be used to automatically repeat calls to a method on a service.
RepeatOperationsInterceptor() - Constructor for class org.springframework.batch.repeat.interceptor.RepeatOperationsInterceptor
 
RepeatStatus - Enum in org.springframework.batch.repeat
 
RepeatSynchronizationManager - Class in org.springframework.batch.repeat.support
Global variable support for repeat clients.
RepeatTemplate - Class in org.springframework.batch.repeat.support
Simple implementation and base class for batch templates implementing RepeatOperations.
RepeatTemplate() - Constructor for class org.springframework.batch.repeat.support.RepeatTemplate
 
replaceExitCode(String) - Method in class org.springframework.batch.core.ExitStatus
Add an exit code to an existing ExitStatus.
repository(JobRepository) - Method in class org.springframework.batch.core.job.builder.JobBuilderHelper
Sets the job repository for the job.
repository(JobRepository) - Method in class org.springframework.batch.core.step.builder.StepBuilderHelper
 
repository(JobRepository) - Method in class org.springframework.batch.integration.chunk.RemoteChunkingManagerStepBuilder
 
repository(JobRepository) - Method in class org.springframework.batch.integration.chunk.RemoteChunkingMasterStepBuilder
Deprecated.
 
repository(JobRepository) - Method in class org.springframework.batch.integration.partition.RemotePartitioningManagerStepBuilder
 
repository(JobRepository) - Method in class org.springframework.batch.integration.partition.RemotePartitioningMasterStepBuilder
Deprecated.
 
repository(JobRepository) - Method in class org.springframework.batch.integration.partition.RemotePartitioningWorkerStepBuilder
 
repository(PagingAndSortingRepository<?, ?>) - Method in class org.springframework.batch.item.data.builder.RepositoryItemReaderBuilder
The PagingAndSortingRepository implementation used to read input from.
repository(RepositoryItemReaderBuilder.RepositoryMethodReference<?>) - Method in class org.springframework.batch.item.data.builder.RepositoryItemReaderBuilder
Specifies a repository and the type-safe method to call for the reader.
repository(CrudRepository<T, ?>) - Method in class org.springframework.batch.item.data.builder.RepositoryItemWriterBuilder
Set the CrudRepository implementation for persistence
repository(RepositoryItemWriterBuilder.RepositoryMethodReference) - Method in class org.springframework.batch.item.data.builder.RepositoryItemWriterBuilder
Specifies a repository and the type-safe method to call for the writer.
RepositoryItemReader<T> - Class in org.springframework.batch.item.data
A ItemReader that reads records utilizing a PagingAndSortingRepository.
RepositoryItemReader() - Constructor for class org.springframework.batch.item.data.RepositoryItemReader
 
RepositoryItemReaderBuilder<T> - Class in org.springframework.batch.item.data.builder
A builder implementation for the RepositoryItemReader.
RepositoryItemReaderBuilder() - Constructor for class org.springframework.batch.item.data.builder.RepositoryItemReaderBuilder
 
RepositoryItemReaderBuilder.RepositoryMethodReference<T> - Class in org.springframework.batch.item.data.builder
Establishes a proxy that will capture a the Repository and the associated methodName that will be used by the reader.
RepositoryItemWriter<T> - Class in org.springframework.batch.item.data
A ItemWriter wrapper for a CrudRepository from Spring Data.
RepositoryItemWriter() - Constructor for class org.springframework.batch.item.data.RepositoryItemWriter
 
RepositoryItemWriterBuilder<T> - Class in org.springframework.batch.item.data.builder
A builder implementation for the RepositoryItemWriter.
RepositoryItemWriterBuilder() - Constructor for class org.springframework.batch.item.data.builder.RepositoryItemWriterBuilder
 
RepositoryItemWriterBuilder.RepositoryMethodReference<T> - Class in org.springframework.batch.item.data.builder
Establishes a proxy that will capture a the Repository and the associated methodName that will be used by the writer.
RepositoryMethodReference(PagingAndSortingRepository<?, ?>) - Constructor for class org.springframework.batch.item.data.builder.RepositoryItemReaderBuilder.RepositoryMethodReference
 
RepositoryMethodReference(CrudRepository<?, ?>) - Constructor for class org.springframework.batch.item.data.builder.RepositoryItemWriterBuilder.RepositoryMethodReference
 
requiresTransactionManager() - Method in class org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
 
reset() - Method in class org.springframework.batch.item.xml.stax.DefaultFragmentEventReader
 
reset() - Method in interface org.springframework.batch.item.xml.stax.FragmentEventReader
Reset the state of the fragment reader - make it forget it assumptions about current position of cursor (e.g.
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
 
resource(Resource) - Method in class org.springframework.batch.item.avro.builder.AvroItemReaderBuilder
Configure a Resource containing Avro serialized objects.
resource(WritableResource) - Method in class org.springframework.batch.item.avro.builder.AvroItemWriterBuilder
 
resource(Resource) - Method in class org.springframework.batch.item.file.builder.FlatFileItemReaderBuilder
The Resource to be used as input.
resource(Resource) - Method in class org.springframework.batch.item.file.builder.FlatFileItemWriterBuilder
The Resource to be used as output.
resource(Resource) - Method in class org.springframework.batch.item.file.builder.MultiResourceItemWriterBuilder
Prototype for output resources.
resource(Resource) - Method in class org.springframework.batch.item.json.builder.JsonFileItemWriterBuilder
The Resource to be used as output.
resource(Resource) - Method in class org.springframework.batch.item.json.builder.JsonItemReaderBuilder
The Resource to be used as input.
resource(Resource) - Method in class org.springframework.batch.item.ldif.builder.LdifReaderBuilder
Establishes the resource that will be used as the input for the LdifReader.
resource(Resource) - Method in class org.springframework.batch.item.ldif.builder.MappingLdifReaderBuilder
Establishes the resource that will be used as the input for the MappingLdifReader.
resource(Resource) - Method in class org.springframework.batch.item.xml.builder.StaxEventItemReaderBuilder
The Resource to be used as input.
resource(Resource) - Method in class org.springframework.batch.item.xml.builder.StaxEventItemWriterBuilder
The Resource to be used as output.
ResourceAware - Interface in org.springframework.batch.item
Marker interface indicating that an item should have the Spring Resource in which it was read from, set on it.
ResourceAwareItemReaderItemStream<T> - Interface in org.springframework.batch.item.file
Interface for ItemReaders that implement ItemStream and read input from Resource.
ResourceAwareItemWriterItemStream<T> - Interface in org.springframework.batch.item.file
Interface for ItemWriters that implement ItemStream and write output to Resource.
ResourcelessTransactionManager - Class in org.springframework.batch.support.transaction
 
ResourcelessTransactionManager() - Constructor for class org.springframework.batch.support.transaction.ResourcelessTransactionManager
 
resources(Resource...) - Method in class org.springframework.batch.item.file.builder.MultiResourceItemReaderBuilder
The array of resources that the MultiResourceItemReader will use to retrieve items.
ResourcesItemReader - Class in org.springframework.batch.item.file
ItemReader which produces Resource instances from an array.
ResourcesItemReader() - Constructor for class org.springframework.batch.item.file.ResourcesItemReader
 
resourceSuffixCreator(ResourceSuffixCreator) - Method in class org.springframework.batch.item.file.builder.MultiResourceItemWriterBuilder
Allows customization of the suffix of the created resources based on the index.
ResourceSuffixCreator - Interface in org.springframework.batch.item.file
Strategy interface for translating resource index into unique filename suffix.
restart(long, Properties) - Method in class org.springframework.batch.core.jsr.launch.JsrJobOperator
Creates a child ApplicationContext for the job being requested based upon the /META-INF/batch.xml (if exists) and the /META-INF/batch-jobs/<jobName>.xml configuration and restart the job.
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
 
restartJob(long, Properties, long) - Static method in class org.springframework.batch.test.JsrTestUtils
Restarts a job and waits for it's status to be any of BatchStatus.STOPPED, BatchStatus.COMPLETED, or BatchStatus.FAILED.
restoreFrom(ExecutionContext) - Method in class org.springframework.batch.item.support.AbstractFileItemWriter.OutputState
 
ResultHolderResultQueue - Class in org.springframework.batch.repeat.support
An implementation of the ResultQueue that throttles the number of expected results, limiting it to a maximum at any given time.
ResultHolderResultQueue(int) - Constructor for class org.springframework.batch.repeat.support.ResultHolderResultQueue
 
results - Variable in class org.springframework.batch.item.data.AbstractPaginatedDataItemReader
 
results - Variable in class org.springframework.batch.item.database.AbstractPagingItemReader
 
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
 
RethrowOnThresholdExceptionHandler - Class in org.springframework.batch.repeat.exception
Implementation of ExceptionHandler that rethrows when exceptions of a given type reach a threshold.
RethrowOnThresholdExceptionHandler() - Constructor for class org.springframework.batch.repeat.exception.RethrowOnThresholdExceptionHandler
Set up the exception handler.
retry(Class<? extends Throwable>) - Method in class org.springframework.batch.core.step.builder.FaultTolerantStepBuilder
Explicitly ask for an exception (and subclasses) to be retried.
retry(Class<? extends Throwable>) - Method in class org.springframework.batch.integration.chunk.RemoteChunkingManagerStepBuilder
 
retry(Class<? extends Throwable>) - Method in class org.springframework.batch.integration.chunk.RemoteChunkingMasterStepBuilder
Deprecated.
 
retryContextCache(RetryContextCache) - Method in class org.springframework.batch.core.step.builder.FaultTolerantStepBuilder
Provide an explicit retry context cache.
retryContextCache(RetryContextCache) - Method in class org.springframework.batch.integration.chunk.RemoteChunkingManagerStepBuilder
 
retryContextCache(RetryContextCache) - Method in class org.springframework.batch.integration.chunk.RemoteChunkingMasterStepBuilder
Deprecated.
 
retryLimit(int) - Method in class org.springframework.batch.core.step.builder.FaultTolerantStepBuilder
The maximum number of times to try a failed item.
retryLimit(int) - Method in class org.springframework.batch.integration.chunk.RemoteChunkingManagerStepBuilder
 
retryLimit(int) - Method in class org.springframework.batch.integration.chunk.RemoteChunkingMasterStepBuilder
Deprecated.
 
RetryListener - Interface in org.springframework.batch.core.jsr
Interface used internally by RetryListener adapters to provide consistent naming.
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.
retryPolicy(RetryPolicy) - Method in class org.springframework.batch.integration.chunk.RemoteChunkingManagerStepBuilder
 
retryPolicy(RetryPolicy) - Method in class org.springframework.batch.integration.chunk.RemoteChunkingMasterStepBuilder
Deprecated.
 
RetryProcessListenerAdapter - Class in org.springframework.batch.core.jsr
Wrapper class to adapt a RetryProcessListener to a RetryListener.
RetryProcessListenerAdapter(RetryProcessListener) - Constructor for class org.springframework.batch.core.jsr.RetryProcessListenerAdapter
 
RetryReadListenerAdapter - Class in org.springframework.batch.core.jsr
Wrapper class to adapt a RetryReadListener to a RetryListener.
RetryReadListenerAdapter(RetryReadListener) - Constructor for class org.springframework.batch.core.jsr.RetryReadListenerAdapter
 
RetryWriteListenerAdapter - Class in org.springframework.batch.core.jsr
Wrapper class to adapt a RetryWriteListener to a RetryListener.
RetryWriteListenerAdapter(RetryWriteListener) - Constructor for class org.springframework.batch.core.jsr.RetryWriteListenerAdapter
 
returnStatement(String) - Method in class org.springframework.batch.item.data.builder.Neo4jItemReaderBuilder
The return statement of the cypher query.
ROLLBACK_EXCEPTION_KEY - Static variable in interface org.springframework.batch.core.ChunkListener
 
rootElementAttributes(Map<String, String>) - Method in class org.springframework.batch.item.xml.builder.StaxEventItemWriterBuilder
A Map of attributes to be included in the document's root element.
rootTagName(String) - Method in class org.springframework.batch.item.xml.builder.StaxEventItemWriterBuilder
The name of the root tag for the output document.
rowMapper(RowMapper<T>) - Method in class org.springframework.batch.item.database.builder.JdbcCursorItemReaderBuilder
The RowMapper used to map the results of the cursor to each item.
rowMapper(RowMapper<T>) - Method in class org.springframework.batch.item.database.builder.JdbcPagingItemReaderBuilder
The RowMapper used to map the query results to objects.
rowMapper(RowMapper<T>) - Method in class org.springframework.batch.item.database.builder.StoredProcedureItemReaderBuilder
The RowMapper used to map the results of the cursor to each item.
rs - Variable in class org.springframework.batch.item.database.AbstractCursorItemReader
 
run(Job, JobParameters) - Method in interface org.springframework.batch.core.launch.JobLauncher
Start a job execution for the given Job and JobParameters .
run(Job, JobParameters) - Method in class org.springframework.batch.core.launch.support.SimpleJobLauncher
Run the provided job with the given JobParameters.
RunIdIncrementer - Class in org.springframework.batch.core.launch.support
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
 
runJob(String, Properties, long) - Static method in class org.springframework.batch.test.JsrTestUtils
Executes a job and waits for it's status to be any of BatchStatus.STOPPED, BatchStatus.COMPLETED, or BatchStatus.FAILED.
RuntimeExceptionTranslator - Class in org.springframework.batch.core.launch.support
 
RuntimeExceptionTranslator() - Constructor for class org.springframework.batch.core.launch.support.RuntimeExceptionTranslator
 

S

saveExecutionContext(JobExecution) - Method in interface org.springframework.batch.core.repository.dao.ExecutionContextDao
Persist the execution context associated with the given jobExecution, persistent entry for the context should not exist yet.
saveExecutionContext(StepExecution) - Method in interface org.springframework.batch.core.repository.dao.ExecutionContextDao
Persist the execution context associated with the given stepExecution, persistent entry for the context should not exist yet.
saveExecutionContext(JobExecution) - Method in class org.springframework.batch.core.repository.dao.JdbcExecutionContextDao
 
saveExecutionContext(StepExecution) - Method in class org.springframework.batch.core.repository.dao.JdbcExecutionContextDao
 
saveExecutionContext(JobExecution) - Method in class org.springframework.batch.core.repository.dao.MapExecutionContextDao
Deprecated.
 
saveExecutionContext(StepExecution) - Method in class org.springframework.batch.core.repository.dao.MapExecutionContextDao
Deprecated.
 
saveExecutionContexts(Collection<StepExecution>) - Method in interface org.springframework.batch.core.repository.dao.ExecutionContextDao
Persist the execution context associated with each stepExecution in a given collection, persistent entry for the context should not exist yet.
saveExecutionContexts(Collection<StepExecution>) - Method in class org.springframework.batch.core.repository.dao.JdbcExecutionContextDao
 
saveExecutionContexts(Collection<StepExecution>) - Method in class org.springframework.batch.core.repository.dao.MapExecutionContextDao
Deprecated.
 
saveJobExecution(JobExecution) - Method in class org.springframework.batch.core.repository.dao.JdbcJobExecutionDao
SQL implementation using Sequences via the Spring incrementer abstraction.
saveJobExecution(JobExecution) - Method in interface org.springframework.batch.core.repository.dao.JobExecutionDao
Save a new JobExecution.
saveJobExecution(JobExecution) - Method in class org.springframework.batch.core.repository.dao.MapJobExecutionDao
Deprecated.
 
saveState(boolean) - Method in class org.springframework.batch.item.avro.builder.AvroItemReaderBuilder
Configure if the state of the ItemStreamSupport should be persisted within the ExecutionContext for restart purposes.
saveState(boolean) - Method in class org.springframework.batch.item.data.builder.MongoItemReaderBuilder
Configure if the state of the ItemStreamSupport should be persisted within the ExecutionContext for restart purposes.
saveState(boolean) - Method in class org.springframework.batch.item.data.builder.Neo4jItemReaderBuilder
Configure if the state of the ItemStreamSupport should be persisted within the ExecutionContext for restart purposes.
saveState(boolean) - Method in class org.springframework.batch.item.data.builder.RepositoryItemReaderBuilder
Configure if the state of the ItemStreamSupport should be persisted within the ExecutionContext for restart purposes.
saveState(boolean) - Method in class org.springframework.batch.item.database.builder.HibernateCursorItemReaderBuilder
Configure if the state of the ItemStreamSupport should be persisted within the ExecutionContext for restart purposes.
saveState(boolean) - Method in class org.springframework.batch.item.database.builder.HibernatePagingItemReaderBuilder
Configure if the state of the ItemStreamSupport should be persisted within the ExecutionContext for restart purposes.
saveState(boolean) - Method in class org.springframework.batch.item.database.builder.JdbcCursorItemReaderBuilder
Configure if the state of the ItemStreamSupport should be persisted within the ExecutionContext for restart purposes.
saveState(boolean) - Method in class org.springframework.batch.item.database.builder.JdbcPagingItemReaderBuilder
Configure if the state of the ItemStreamSupport should be persisted within the ExecutionContext for restart purposes.
saveState(boolean) - Method in class org.springframework.batch.item.database.builder.JpaCursorItemReaderBuilder
Configure if the state of the ItemStreamSupport should be persisted within the ExecutionContext for restart purposes.
saveState(boolean) - Method in class org.springframework.batch.item.database.builder.JpaPagingItemReaderBuilder
Configure if the state of the ItemStreamSupport should be persisted within the ExecutionContext for restart purposes.
saveState(boolean) - Method in class org.springframework.batch.item.database.builder.StoredProcedureItemReaderBuilder
Configure if the state of the ItemStreamSupport should be persisted within the ExecutionContext for restart purposes.
saveState(boolean) - Method in class org.springframework.batch.item.file.builder.FlatFileItemReaderBuilder
Configure if the state of the ItemStreamSupport should be persisted within the ExecutionContext for restart purposes.
saveState(boolean) - Method in class org.springframework.batch.item.file.builder.FlatFileItemWriterBuilder
Configure if the state of the ItemStreamSupport should be persisted within the ExecutionContext for restart purposes.
saveState(boolean) - Method in class org.springframework.batch.item.file.builder.MultiResourceItemReaderBuilder
Configure if the state of the ItemStreamSupport should be persisted within the ExecutionContext for restart purposes.
saveState(boolean) - Method in class org.springframework.batch.item.file.builder.MultiResourceItemWriterBuilder
Configure if the state of the ItemStreamSupport should be persisted within the ExecutionContext for restart purposes.
saveState(boolean) - Method in class org.springframework.batch.item.json.builder.JsonFileItemWriterBuilder
Configure if the state of the ItemStreamSupport should be persisted within the ExecutionContext for restart purposes.
saveState(boolean) - Method in class org.springframework.batch.item.json.builder.JsonItemReaderBuilder
Configure if the state of the ItemStreamSupport should be persisted within the ExecutionContext for restart purposes.
saveState(boolean) - Method in class org.springframework.batch.item.kafka.builder.KafkaItemReaderBuilder
Configure if the state of the ItemStreamSupport should be persisted within the ExecutionContext for restart purposes.
saveState(boolean) - Method in class org.springframework.batch.item.ldif.builder.LdifReaderBuilder
Configure if the state of the ItemStreamSupport should be persisted within the ExecutionContext for restart purposes.
saveState(boolean) - Method in class org.springframework.batch.item.ldif.builder.MappingLdifReaderBuilder
Configure if the state of the ItemStreamSupport should be persisted within the ExecutionContext for restart purposes.
saveState(boolean) - Method in class org.springframework.batch.item.xml.builder.StaxEventItemReaderBuilder
Configure if the state of the ItemStreamSupport should be persisted within the ExecutionContext for restart purposes.
saveState(boolean) - Method in class org.springframework.batch.item.xml.builder.StaxEventItemWriterBuilder
Indicates if the state of the writer should be saved in the ExecutionContext.
saveStepExecution(StepExecution) - Method in class org.springframework.batch.core.repository.dao.JdbcStepExecutionDao
Save a StepExecution.
saveStepExecution(StepExecution) - Method in class org.springframework.batch.core.repository.dao.MapStepExecutionDao
Deprecated.
 
saveStepExecution(StepExecution) - Method in interface org.springframework.batch.core.repository.dao.StepExecutionDao
Save the given StepExecution.
saveStepExecutions(Collection<StepExecution>) - Method in class org.springframework.batch.core.repository.dao.JdbcStepExecutionDao
Batch insert StepExecutions
saveStepExecutions(Collection<StepExecution>) - Method in class org.springframework.batch.core.repository.dao.MapStepExecutionDao
Deprecated.
 
saveStepExecutions(Collection<StepExecution>) - Method in interface org.springframework.batch.core.repository.dao.StepExecutionDao
Save the given collection of StepExecution as a batch.
SCHEDULE_DATE_KEY - Static variable in class org.springframework.batch.core.launch.support.ScheduledJobParametersFactory
Deprecated.
 
ScheduledJobParametersFactory - Class in org.springframework.batch.core.launch.support
Deprecated.
as of v4.3 in favor of DefaultJobParametersConverter and scheduled for removal in v5.0.
ScheduledJobParametersFactory() - Constructor for class org.springframework.batch.core.launch.support.ScheduledJobParametersFactory
Deprecated.
 
schema(Resource) - Method in class org.springframework.batch.item.avro.builder.AvroItemReaderBuilder
Configure an Avro Schema from a Resource.
schema(String) - Method in class org.springframework.batch.item.avro.builder.AvroItemReaderBuilder
Configure an Avro Schema from a String.
schema(Resource) - Method in class org.springframework.batch.item.avro.builder.AvroItemWriterBuilder
 
schema(String) - Method in class org.springframework.batch.item.avro.builder.AvroItemWriterBuilder
 
Scopifier(BeanDefinitionRegistry, String, boolean, boolean) - Constructor for class org.springframework.batch.core.scope.BatchScopeSupport.Scopifier
 
ScriptItemProcessor<I,O> - Class in org.springframework.batch.item.support
ItemProcessor implementation that passes the current item to process to the provided script.
ScriptItemProcessor() - Constructor for class org.springframework.batch.item.support.ScriptItemProcessor
 
ScriptItemProcessorBuilder<I,O> - Class in org.springframework.batch.item.support.builder
Creates a fully qualified ScriptItemProcessor.
ScriptItemProcessorBuilder() - Constructor for class org.springframework.batch.item.support.builder.ScriptItemProcessorBuilder
 
scriptResource(Resource) - Method in class org.springframework.batch.item.support.builder.ScriptItemProcessorBuilder
Sets the Resource location of the script to use.
scriptSource(String) - Method in class org.springframework.batch.item.support.builder.ScriptItemProcessorBuilder
Sets the provided String as the script source code to use.
selectClause(String) - Method in class org.springframework.batch.item.database.builder.JdbcPagingItemReaderBuilder
The SQL SELECT clause for a db specific PagingQueryProvider.
selectImports(AnnotationMetadata) - Method in class org.springframework.batch.core.configuration.annotation.BatchConfigurationSelector
 
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
 
serialize(Map<String, Object>, OutputStream) - Method in class org.springframework.batch.core.repository.dao.XStreamExecutionContextStringSerializer
Deprecated.
Serializes the passed execution context to the supplied OutputStream.
sessionFactory(SessionFactory) - Method in class org.springframework.batch.item.data.builder.Neo4jItemReaderBuilder
Establish the session factory for the reader.
sessionFactory(SessionFactory) - Method in class org.springframework.batch.item.data.builder.Neo4jItemWriterBuilder
Establish the session factory that will be used to create Session instances for interacting with Neo4j.
sessionFactory(SessionFactory) - Method in class org.springframework.batch.item.database.builder.HibernateCursorItemReaderBuilder
The Hibernate SessionFactory to execute the query against.
sessionFactory(SessionFactory) - Method in class org.springframework.batch.item.database.builder.HibernateItemWriterBuilder
The Hibernate SessionFactory to obtain a session from.
sessionFactory(SessionFactory) - Method in class org.springframework.batch.item.database.builder.HibernatePagingItemReaderBuilder
The Hibernate SessionFactory to execute the query against.
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.jsr.partition.JsrPartitionHandler
 
setAllowStartIfComplete(boolean) - Method in class org.springframework.batch.core.partition.support.SimpleStepExecutionSplitter
Flag to indicate that the partition target step is allowed to start if an execution is complete.
setAllowStartIfComplete(boolean) - Method in class org.springframework.batch.core.step.AbstractStep
Public setter for flag that determines whether the step should start again if it is already complete.
setAllowStartIfComplete(Boolean) - Method in class org.springframework.batch.core.step.builder.StepBuilderHelper.CommonStepProperties
 
setAllowStartIfComplete(boolean) - Method in class org.springframework.batch.core.step.factory.SimpleStepFactoryBean
Public setter for the flag to indicate that the step should be replayed on a restart, even if successful the first time.
setAncestorsCompleteOnly() - Static method in class org.springframework.batch.repeat.support.RepeatSynchronizationManager
Set current session and all ancestors (via parent) to complete.,
setAppendAllowed(boolean) - Method in class org.springframework.batch.item.support.AbstractFileItemWriter.OutputState
 
setAppendAllowed(boolean) - Method in class org.springframework.batch.item.support.AbstractFileItemWriter
Flag to indicate that the target file should be appended if it already exists.
setApplicationContext(ApplicationContext) - Method in class org.springframework.batch.core.configuration.support.AbstractApplicationContextFactory
Setter for the parent application context.
setApplicationContext(ApplicationContext) - Method in class org.springframework.batch.core.configuration.support.AutomaticJobRegistrar
The enclosing application context, which can be used to check if events come from the expected source.
setApplicationContext(ApplicationContext) - Method in class org.springframework.batch.core.configuration.support.ClasspathXmlApplicationContextsFactoryBean
An application context that can be used as a parent context for all the factories.
setApplicationContext(ApplicationContext) - Method in class org.springframework.batch.core.configuration.xml.CoreNamespacePostProcessor
 
setApplicationContext(ApplicationContext) - Method in class org.springframework.batch.core.jsr.configuration.xml.JsrNamespacePostProcessor
 
setApplicationContext(ApplicationContext) - Method in class org.springframework.batch.core.jsr.launch.JsrJobOperator
 
setApplicationContext(ApplicationContext) - Method in class org.springframework.batch.test.AbstractJobTests
Deprecated.
setApplicationContextFactories(ApplicationContextFactory[]) - Method in class org.springframework.batch.core.configuration.support.AutomaticJobRegistrar
Add some factories to the set that will be used to load contexts and jobs.
setArguments(Object[]) - Method in class org.springframework.batch.item.adapter.AbstractMethodInvokingDelegator
 
setArguments(List<?>) - Method in class org.springframework.batch.item.data.RepositoryItemReader
Arguments to be passed to the data providing method.
setArtifactProperties(Map<String, Properties>) - Method in class org.springframework.batch.core.jsr.configuration.support.BatchPropertyContext
Adds non-step artifact properties to the context.
setAssertUpdates(boolean) - Method in class org.springframework.batch.item.database.JdbcBatchItemWriter
Public setter for the flag that determines whether an assertion is made that all items cause at least one row to be updated.
setAsText(String) - Method in class org.springframework.batch.item.file.transform.RangeArrayPropertyEditor
 
setAsText(String) - Method in class org.springframework.batch.support.IntArrayPropertyEditor
 
setAttribute(String, Object) - Method in class org.springframework.batch.repeat.context.SynchronizedAttributeAccessor
 
setAttributeIfAbsent(String, Object) - Method in class org.springframework.batch.repeat.context.SynchronizedAttributeAccessor
Additional support for atomic put if absent.
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 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
 
setBatchPropertyContext(BatchPropertyContext) - Method in class org.springframework.batch.core.jsr.configuration.xml.StepFactoryBean
 
setBatchPropertyContext(BatchPropertyContext) - Method in class org.springframework.batch.core.jsr.JsrJobContextFactoryBean
 
setBatchPropertyContext(BatchPropertyContext) - Method in class org.springframework.batch.core.jsr.JsrStepContextFactoryBean
 
setBatchPropertyContext(BatchPropertyContext) - Method in class org.springframework.batch.core.jsr.launch.support.BatchPropertyBeanPostProcessor
 
setBatchPropertyContext(BatchPropertyContext) - Method in class org.springframework.batch.core.jsr.step.builder.JsrBatchletStepBuilder
 
setBatchPropertyContext(BatchPropertyContext) - Method in class org.springframework.batch.core.jsr.step.builder.JsrFaultTolerantStepBuilder
 
setBatchPropertyContext(BatchPropertyContext) - Method in class org.springframework.batch.core.jsr.step.builder.JsrSimpleStepBuilder
 
setBeanFactory(BeanFactory) - Method in class org.springframework.batch.core.configuration.support.JobRegistryBeanPostProcessor
 
setBeanFactory(BeanFactory) - Method in class org.springframework.batch.core.jsr.launch.support.BatchPropertyBeanPostProcessor
 
setBeanFactory(BeanFactory) - Method in class org.springframework.batch.integration.partition.BeanFactoryStepLocator
 
setBeanFactory(BeanFactory) - Method in class org.springframework.batch.integration.partition.RemotePartitioningManagerStepBuilderFactory
 
setBeanFactory(BeanFactory) - Method in class org.springframework.batch.integration.partition.RemotePartitioningMasterStepBuilderFactory
Deprecated.
 
setBeanFactory(BeanFactory) - Method in class org.springframework.batch.integration.partition.RemotePartitioningWorkerStepBuilderFactory
 
setBeanFactory(BeanFactory) - Method in class org.springframework.batch.item.file.mapping.BeanWrapperFieldSetMapper
 
setBeanFactoryPostProcessorClasses(Class<? extends BeanFactoryPostProcessor>[]) - Method in class org.springframework.batch.core.configuration.support.AbstractApplicationContextFactory
Determines which bean factory post processors (like property placeholders) should be copied from the parent context.
setBeanFactoryPostProcessorClasses(Class<? extends BeanFactoryPostProcessor>[]) - Method in class org.springframework.batch.core.configuration.support.ClasspathXmlApplicationContextsFactoryBean
Determines which bean factory post processors (like property placeholders) should be copied from the parent context.
setBeanName(String) - Method in class org.springframework.batch.core.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.
setBufferedReaderFactory(BufferedReaderFactory) - Method in class org.springframework.batch.item.file.FlatFileItemReader
Factory for the BufferedReader that will be used to extract lines from the file.
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.
setBusy(boolean) - Method in class org.springframework.batch.core.step.item.Chunk
Register an interest in the chunk to prevent it from being cleaned up before the flag is reset to false.
setCacheCapacity(int) - Method in class org.springframework.batch.core.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.
setChannel(MessageChannel) - Method in class org.springframework.batch.integration.chunk.MessageSourcePollerInterceptor
Optional MessageChannel for injecting the message received from the source (defaults to the channel intercepted in MessageSourcePollerInterceptor.preReceive(MessageChannel)).
setChunk(SimpleStepBuilder<I, O>) - Method in class org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
 
setChunk(SimpleStepBuilder<I, O>) - Method in class org.springframework.batch.core.jsr.configuration.xml.StepFactoryBean
 
setChunkCompletionPolicy(CompletionPolicy) - Method in class org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
Public setter for the CompletionPolicy applying 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.jsr.step.item.JsrFaultTolerantChunkProcessor
 
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.
setChunkProcessor(ChunkProcessor<S>) - Method in class org.springframework.batch.integration.chunk.ChunkProcessorChunkHandler
Public setter for the ChunkProcessor.
setChunkSize(int) - Method in class org.springframework.batch.core.step.item.ChunkMonitor
 
setChunkSize(int) - Method in class org.springframework.batch.repeat.policy.SimpleCompletionPolicy
 
setChunkWriter(ItemWriter<T>) - Method in class org.springframework.batch.integration.chunk.RemoteChunkHandlerFactoryBean
The item writer to be injected into the step.
setClassifier(Classifier<? super I, ItemProcessor<?, ? extends O>>) - Method in class org.springframework.batch.item.support.ClassifierCompositeItemProcessor
Establishes the classifier that will determine which ItemProcessor to use.
setClassifier(Classifier<T, ItemWriter<? super T>>) - Method in class org.springframework.batch.item.support.ClassifierCompositeItemWriter
 
setClearSession(boolean) - Method in class org.springframework.batch.item.database.HibernateItemWriter
Flag to indicate that the session should be cleared and flushed at the end of the write (default true).
setClobType(int) - Method in class org.springframework.batch.core.repository.support.JobRepositoryFactoryBean
 
setClobTypeToUse(int) - Method in class org.springframework.batch.core.repository.dao.AbstractJdbcBatchMetadataDao
 
setCollection(String) - Method in class org.springframework.batch.item.data.MongoItemReader
 
setCollection(String) - Method in class org.springframework.batch.item.data.MongoItemWriter
Set the name of the Mongo collection to be written to.
setColumns(Range...) - Method in class org.springframework.batch.item.file.transform.FixedLengthTokenizer
Set the column ranges.
setCommand(String) - Method in class org.springframework.batch.core.step.tasklet.SystemCommandTasklet
 
setComments(String[]) - Method in class org.springframework.batch.item.file.FlatFileItemReader
Setter for comment prefixes.
setCommitCount(int) - Method in class org.springframework.batch.core.StepExecution
Sets the current number of commits for this execution
setCommitInterval(int) - Method in class org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
Set the commit interval.
setCommitInterval(int) - Method in class org.springframework.batch.core.step.factory.SimpleStepFactoryBean
Set the commit interval.
setComparator(Comparator<Resource>) - Method in class org.springframework.batch.item.file.MultiResourceItemReader
 
setComplete() - Method in class org.springframework.batch.core.scope.context.ChunkContext
Setter for the flag to signal complete processing of a chunk.
setCompleteOnly() - Method in class org.springframework.batch.repeat.context.RepeatContextSupport
 
setCompleteOnly() - Method in interface org.springframework.batch.repeat.RepeatContext
Signal to the framework that the current batch should complete normally, independent of the current CompletionPolicy.
setCompleteOnly() - Static method in class org.springframework.batch.repeat.support.RepeatSynchronizationManager
Convenience method to set the current repeat operation to complete if it exists.
setCompletionPolicy(CompletionPolicy) - Method in class org.springframework.batch.repeat.support.RepeatTemplate
Setter for policy to decide when the batch is complete.
setConnectionAutoCommit(boolean) - Method in class org.springframework.batch.item.database.AbstractCursorItemReader
Set whether "autoCommit" should be overridden for the connection used by the cursor.
setContinuation(String) - Method in class org.springframework.batch.item.file.separator.DefaultRecordSeparatorPolicy
Public setter for the continuation.
setConversionService(ConversionService) - Method in class org.springframework.batch.item.file.mapping.BeanWrapperFieldSetMapper
Public setter for the 'conversionService' property.
setCopyConfiguration(boolean) - Method in class org.springframework.batch.core.configuration.support.AbstractApplicationContextFactory
Flag to indicate that configuration such as bean post processors and custom editors should be copied from the parent context.
setCopyConfiguration(boolean) - Method in class org.springframework.batch.core.configuration.support.ClasspathXmlApplicationContextsFactoryBean
Flag to indicate that configuration such as bean post processors and custom editors should be copied from the parent context.
setCreateTime(Date) - Method in class org.springframework.batch.core.JobExecution
 
setCurrentItemCount(int) - Method in class org.springframework.batch.item.support.AbstractItemCountingItemStreamItemReader
The index of the item to start reading from.
setCustomEditors(Map<? extends Object, ? extends PropertyEditor>) - Method in class org.springframework.batch.item.file.mapping.BeanWrapperFieldSetMapper
Specify the custom editors to register.
setCustomEditors(Map<? extends Object, ? extends PropertyEditor>) - Method in class org.springframework.batch.support.DefaultPropertyEditorRegistrar
Specify the custom editors to register.
setDatabaseType(String) - Method in class org.springframework.batch.core.repository.support.JobRepositoryFactoryBean
Sets the database type.
setDatabaseType(String) - Method in class org.springframework.batch.item.database.support.SqlPagingQueryProviderFactoryBean
 
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.configuration.annotation.DefaultBatchConfigurer
Sets the dataSource.
setDataSource(DataSource) - Method in class org.springframework.batch.core.explore.support.JobExplorerFactoryBean
Public setter for the DataSource.
setDataSource(DataSource) - Method in class org.springframework.batch.core.repository.support.JobRepositoryFactoryBean
Public setter for the DataSource.
setDataSource(DataSource) - Method in class org.springframework.batch.integration.partition.MessageChannelPartitionHandler
DataSource pointing to the job repository
setDataSource(DataSource) - Method in class org.springframework.batch.item.database.AbstractCursorItemReader
Public setter for the data source for injection purposes.
setDataSource(DataSource) - Method in class org.springframework.batch.item.database.ExtendedConnectionDataSourceProxy
Setter for the DataSource that is to be wrapped.
setDataSource(DataSource) - Method in class org.springframework.batch.item.database.JdbcBatchItemWriter
Public setter for the data source for injection purposes.
setDataSource(DataSource) - Method in class org.springframework.batch.item.database.JdbcPagingItemReader
 
setDataSource(DataSource) - Method in class org.springframework.batch.item.database.support.SqlPagingQueryProviderFactoryBean
 
setDataSource(DataSource) - Method in class org.springframework.batch.test.DataSourceInitializer
 
setDataSource(DataSource) - Method in class org.springframework.batch.test.JobRepositoryTestUtils
 
setDateFormat(DateFormat) - Method in class org.springframework.batch.core.converter.DefaultJobParametersConverter
Public setter for injecting a date format.
setDateFormat(DateFormat) - Method in class org.springframework.batch.core.launch.support.ScheduledJobParametersFactory
Deprecated.
Public setter for injecting a date format.
setDateFormat(DateFormat) - Method in class org.springframework.batch.item.file.transform.DefaultFieldSet
The DateFormat to use for parsing dates.
setDateFormat(DateFormat) - Method in class org.springframework.batch.item.file.transform.DefaultFieldSetFactory
The DateFormat to use for parsing dates.
setDecider(Decider) - Method in class org.springframework.batch.core.jsr.configuration.xml.DecisionStepFactoryBean
 
setDefaultValue(String) - Method in class org.springframework.batch.support.SystemPropertyInitializer
Mandatory property specifying the default value of the System property.
setDelegate(Object) - Method in class org.springframework.batch.core.listener.AbstractListenerFactoryBean
 
setDelegate(StepExecutionAggregator) - Method in class org.springframework.batch.core.partition.support.RemoteStepExecutionAggregator
 
setDelegate(ItemProcessor<I, O>) - Method in class org.springframework.batch.integration.async.AsyncItemProcessor
The ItemProcessor to use to delegate processing to in a background thread.
setDelegate(ItemWriter<T>) - Method in class org.springframework.batch.integration.async.AsyncItemWriter
 
setDelegate(Step) - Method in class org.springframework.batch.integration.step.DelegateStep
 
setDelegate(ResourceAwareItemReaderItemStream<? extends T>) - Method in class org.springframework.batch.item.file.MultiResourceItemReader
 
setDelegate(ResourceAwareItemWriterItemStream<? super T>) - Method in class org.springframework.batch.item.file.MultiResourceItemWriter
Delegate used for actual writing of the output.
setDelegate(LineAggregator<T>) - Method in class org.springframework.batch.item.file.transform.RecursiveCollectionLineAggregator
Public setter for the LineAggregator to use on single items, that are not Strings.
setDelegate(ItemReader<T>) - Method in class org.springframework.batch.item.support.SingleItemPeekableItemReader
The item reader to use as a delegate.
setDelegate(ItemStreamReader<T>) - Method in class org.springframework.batch.item.support.SynchronizedItemStreamReader
 
setDelegate(ItemStreamWriter<T>) - Method in class org.springframework.batch.item.support.SynchronizedItemStreamWriter
Set the delegate ItemStreamWriter.
setDelegates(List<? extends ItemProcessor<?, ?>>) - Method in class org.springframework.batch.item.support.CompositeItemProcessor
Establishes the ItemProcessor delegates that will work on the item to be processed.
setDelegates(List<ItemWriter<? super T>>) - Method in class org.springframework.batch.item.support.CompositeItemWriter
The list of item writers to use as delegates.
setDelete(boolean) - Method in class org.springframework.batch.item.data.MongoItemWriter
Indicates if the items being passed to the writer are to be saved or removed from the data store.
setDelete(boolean) - Method in class org.springframework.batch.item.data.Neo4jItemWriter
Boolean flag indicating whether the writer should save or delete the item at write time.
setDelete(boolean) - Method in class org.springframework.batch.item.KeyValueItemWriter
Sets the delete flag to have the item writer perform deletes
setDeleteIfExists(boolean) - Method in class org.springframework.batch.item.support.AbstractFileItemWriter.OutputState
 
setDelimiter(String) - Method in class org.springframework.batch.item.file.transform.DelimitedLineAggregator
Public setter for the delimiter.
setDelimiter(String) - Method in class org.springframework.batch.item.file.transform.DelimitedLineTokenizer
Setter for the delimiter character.
setDestroyScripts(Resource[]) - Method in class org.springframework.batch.test.DataSourceInitializer
 
setDistanceLimit(int) - Method in class org.springframework.batch.item.file.mapping.BeanWrapperFieldSetMapper
The maximum difference that can be tolerated in spelling between input key names and bean property names.
setDriverSupportsAbsolute(boolean) - Method in class org.springframework.batch.item.database.AbstractCursorItemReader
Indicate whether the JDBC driver supports setting the absolute row on a ResultSet.
setEmbeddedSchema(boolean) - Method in class org.springframework.batch.item.avro.AvroItemReader
Disable or enable reading an embedded Avro schema.
setEncoding(String) - Method in class org.springframework.batch.item.file.FlatFileItemReader
Setter for the encoding for this input source.
setEncoding(String) - Method in class org.springframework.batch.item.support.AbstractFileItemWriter.OutputState
 
setEncoding(String) - Method in class org.springframework.batch.item.support.AbstractFileItemWriter
Sets encoding for output template.
setEncoding(String) - Method in class org.springframework.batch.item.xml.StaxEventItemReader
Set encoding to be used for the input file.
setEncoding(String) - Method in class org.springframework.batch.item.xml.StaxEventItemWriter
Set encoding to be used for output file.
setEncoding(String) - Method in class org.springframework.batch.support.transaction.TransactionAwareBufferedWriter
 
setEnd() - Method in class org.springframework.batch.core.step.item.Chunk
Set the flag to say that this chunk represents an end of stream (there is no more data to process).
setEndTime(Date) - Method in class org.springframework.batch.core.JobExecution
 
setEndTime(Date) - Method in class org.springframework.batch.core.StepExecution
Sets the time that this execution ended
setEntityClass(Class<E>) - Method in class org.springframework.batch.item.database.orm.HibernateNativeQueryProvider
 
setEntityClass(Class<E>) - Method in class org.springframework.batch.item.database.orm.JpaNamedQueryProvider
 
setEntityClass(Class<E>) - Method in class org.springframework.batch.item.database.orm.JpaNativeQueryProvider
 
setEntityManager(EntityManager) - Method in class org.springframework.batch.item.database.orm.AbstractJpaQueryProvider
Public setter to override the entityManager that was created by this HibernateQueryProvider.
setEntityManager(EntityManager) - Method in interface org.springframework.batch.item.database.orm.JpaQueryProvider
Provide an EntityManager for the query to be built.
setEntityManagerFactory(EntityManagerFactory) - Method in class org.springframework.batch.item.database.JpaCursorItemReader
Set the JPA entity manager factory.
setEntityManagerFactory(EntityManagerFactory) - Method in class org.springframework.batch.item.database.JpaItemWriter
Set the EntityManager to be used internally.
setEntityManagerFactory(EntityManagerFactory) - Method in class org.springframework.batch.item.database.JpaPagingItemReader
 
setEnvironmentParams(String[]) - Method in class org.springframework.batch.core.step.tasklet.SystemCommandTasklet
 
setExceptionClasses(Collection<Class<? extends Throwable>>) - Method in class org.springframework.batch.repeat.exception.SimpleLimitExceptionHandler
Setter for the exception classes that this handler counts.
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.
setExceptionClassifier(Classifier<Throwable, LogOrRethrowExceptionHandler.Level>) - Method in class org.springframework.batch.repeat.exception.LogOrRethrowExceptionHandler
Setter for the Classifier used by this handler.
setExceptionHandler(ExceptionHandler) - Method in class org.springframework.batch.core.step.factory.SimpleStepFactoryBean
Public setter for the ExceptionHandler.
setExceptionHandler(ExceptionHandler) - Method in class org.springframework.batch.repeat.support.RepeatTemplate
Setter for exception handler strategy.
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
setExecutionContextName(String) - Method in class org.springframework.batch.item.ItemStreamSupport
 
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(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.
setExitStatus(ExitStatus) - Method in class org.springframework.batch.core.JobExecution
 
setExitStatus(FlowExecutor, String) - Method in class org.springframework.batch.core.jsr.job.flow.support.state.JsrEndState
 
setExitStatus(String) - Method in class org.springframework.batch.core.jsr.JsrJobContext
 
setExitStatus(String) - Method in class org.springframework.batch.core.jsr.JsrStepContext
 
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
 
setFatalExceptionClasses(Collection<Class<? extends Throwable>>) - Method in class org.springframework.batch.repeat.exception.SimpleLimitExceptionHandler
Setter for the exception classes that shouldn't be counted, but rethrown immediately.
setFetchSize(int) - Method in class org.springframework.batch.item.database.AbstractCursorItemReader
Gives the JDBC driver a hint as to the number of rows that should be fetched from the database when more rows are needed for this ResultSet object.
setFetchSize(int) - Method in class org.springframework.batch.item.database.HibernateCursorItemReader
Fetch size used internally by Hibernate to limit amount of data fetched from database per round trip.
setFetchSize(int) - Method in class org.springframework.batch.item.database.HibernatePagingItemReader
Fetch size used internally by Hibernate to limit amount of data fetched from database per round trip.
setFetchSize(int) - Method in class org.springframework.batch.item.database.JdbcPagingItemReader
Gives the JDBC driver a hint as to the number of rows that should be fetched from the database when more rows are needed for this ResultSet object.
setFieldExtractor(FieldExtractor<T>) - Method in class org.springframework.batch.item.file.transform.ExtractorLineAggregator
Public setter for the field extractor responsible for splitting an input object up into an array of objects.
setFields(String) - Method in class org.springframework.batch.item.data.MongoItemReader
JSON defining the fields to be returned from the matching documents by MongoDB.
setFieldSetFactory(FieldSetFactory) - Method in class org.springframework.batch.item.file.transform.AbstractLineTokenizer
Factory for FieldSet instances.
setFieldSetMapper(FieldSetMapper<T>) - Method in class org.springframework.batch.item.file.mapping.DefaultLineMapper
 
setFieldSetMappers(Map<String, FieldSetMapper<T>>) - Method in class org.springframework.batch.item.file.mapping.PatternMatchingCompositeLineMapper
 
setFieldsUsedAsTargetMethodArguments(String[]) - Method in class org.springframework.batch.item.adapter.PropertyExtractingDelegatingItemWriter
 
setFilter(boolean) - Method in class org.springframework.batch.item.validator.ValidatingItemProcessor
Should the processor filter invalid records instead of skipping them?
setFilterCount(int) - Method in class org.springframework.batch.core.StepExecution
Public setter for the number of items filtered out of this execution.
setFlow(Flow) - Method in class org.springframework.batch.core.configuration.xml.JobParserJobFactoryBean
 
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.
setFlow(Flow) - Method in class org.springframework.batch.core.jsr.configuration.xml.JobFactoryBean
 
setFlowType(Class<SimpleFlow>) - Method in class org.springframework.batch.core.configuration.xml.SimpleFlowFactoryBean
 
setFooterCallback(FlatFileFooterCallback) - Method in class org.springframework.batch.item.support.AbstractFileItemWriter
footerCallback will be called after writing the last item to file, but before the file is closed.
setFooterCallback(StaxWriterCallback) - Method in class org.springframework.batch.item.xml.StaxEventItemWriter
footerCallback is called after writing all items but before closing the file.
setForceDisjointRanges(boolean) - Method in class org.springframework.batch.item.file.transform.RangeArrayPropertyEditor
Set force disjoint ranges.
setForceSync(boolean) - Method in class org.springframework.batch.item.support.AbstractFileItemWriter
Flag to indicate that changes should be force-synced to disk on flush.
setForceSync(boolean) - Method in class org.springframework.batch.item.xml.StaxEventItemWriter
Flag to indicate that changes should be force-synced to disk on flush.
setForceSync(boolean) - Method in class org.springframework.batch.support.transaction.TransactionAwareBufferedWriter
Flag to indicate that changes should be force-synced to disk on flush.
setFormat(String) - Method in class org.springframework.batch.item.file.transform.FormatterLineAggregator
Set the format string used to aggregate items.
setFragmentRootElementName(String) - Method in class org.springframework.batch.item.xml.StaxEventItemReader
 
setFragmentRootElementNames(String[]) - Method in class org.springframework.batch.item.xml.StaxEventItemReader
 
setFromClause(String) - Method in class org.springframework.batch.item.database.support.AbstractSqlPagingQueryProvider
 
setFromClause(String) - Method in class org.springframework.batch.item.database.support.SqlPagingQueryProviderFactoryBean
 
setFunction(boolean) - Method in class org.springframework.batch.item.database.StoredProcedureItemReader
Set whether this stored procedure is a function.
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.
setGridSize(int) - Method in class org.springframework.batch.integration.partition.MessageChannelPartitionHandler
Passed to the StepExecutionSplitter in the MessageChannelPartitionHandler.handle(StepExecutionSplitter, StepExecution) method, instructing it how many StepExecution instances are required, ideally.
setGroupClause(String) - Method in class org.springframework.batch.item.database.support.AbstractSqlPagingQueryProvider
The setter for the group by clause
setGroupClause(String) - Method in class org.springframework.batch.item.database.support.SqlPagingQueryProviderFactoryBean
 
setGroupName(String) - Method in class org.springframework.batch.core.configuration.support.JobRegistryBeanPostProcessor
The group name for jobs registered by this component.
setGson(Gson) - Method in class org.springframework.batch.item.json.GsonJsonObjectMarshaller
Set the Gson object to use.
setHandlers(ExceptionHandler[]) - Method in class org.springframework.batch.repeat.exception.CompositeExceptionHandler
 
setHasChunkElement(boolean) - Method in class org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
 
setHeaderCallback(FlatFileHeaderCallback) - Method in class org.springframework.batch.item.support.AbstractFileItemWriter
headerCallback will be called before writing the first item to file.
setHeaderCallback(StaxWriterCallback) - Method in class org.springframework.batch.item.xml.StaxEventItemWriter
headerCallback is called before writing any items.
setHierarchicalStreamDriver(HierarchicalStreamDriver) - Method in class org.springframework.batch.core.repository.dao.XStreamExecutionContextStringSerializer
Deprecated.
 
setHint(String) - Method in class org.springframework.batch.item.data.MongoItemReader
JSON String telling MongoDB what index to use.
setId(Long) - Method in class org.springframework.batch.core.Entity
 
setIgnoreFailedDrop(boolean) - Method in class org.springframework.batch.test.DataSourceInitializer
 
setIgnoreItemStream(boolean) - Method in class org.springframework.batch.item.support.CompositeItemWriter
Establishes the policy whether to call the open, close, or update methods for the item writer delegates associated with the CompositeItemWriter.
setIgnoreWarnings(boolean) - Method in class org.springframework.batch.item.database.AbstractCursorItemReader
Set whether SQLWarnings should be ignored (only logged) or exception should be thrown.
setIgnoreWhitespace(boolean) - Method in class org.springframework.batch.item.file.separator.SuffixRecordSeparatorPolicy
Flag to indicate that the decision to terminate a record should ignore whitespace at the end of the line.
setImportMetadata(AnnotationMetadata) - Method in class org.springframework.batch.core.configuration.annotation.AbstractBatchConfiguration
 
setIncludedFields(int...) - Method in class org.springframework.batch.item.file.transform.DelimitedLineTokenizer
The fields to include in the output by position (starting at 0).
setIncrementerColumnName(String) - Method in class org.springframework.batch.item.database.support.DefaultDataFieldMaxValueIncrementerFactory
Public setter for the column name (defaults to "ID") in the incrementer.
setIncrementerFactory(DataFieldMaxValueIncrementerFactory) - Method in class org.springframework.batch.core.repository.support.JobRepositoryFactoryBean
 
setInitScripts(Resource[]) - Method in class org.springframework.batch.test.DataSourceInitializer
 
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.
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.
setItemBindingVariableName(String) - Method in class org.springframework.batch.item.support.ScriptItemProcessor
Provides the ability to change the key name that scripts use to obtain the current item to process if the variable represented by: ScriptItemProcessor.ITEM_BINDING_VARIABLE_NAME is not suitable ("item").
setItemCount(int) - Method in interface org.springframework.batch.item.ItemCountAware
Setter for the injection of the current item count.
setItemCountLimitPerResource(int) - Method in class org.springframework.batch.item.file.MultiResourceItemWriter
After this limit is exceeded the next chunk will be written into newly created resource.
setItemKeyMapper(Converter<V, K>) - Method in class org.springframework.batch.item.KeyValueItemWriter
Set the Converter to use to derive the key from the item
setItemPreparedStatementSetter(ItemPreparedStatementSetter<T>) - Method in class org.springframework.batch.item.database.JdbcBatchItemWriter
Public setter for the ItemPreparedStatementSetter.
setItemProcessor(ItemProcessor<? super I, ? extends O>) - Method in class org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
 
setItemProcessor(ItemProcessor<? super T, ? extends S>) - Method in class org.springframework.batch.core.step.factory.SimpleStepFactoryBean
 
setItemProcessor(ItemProcessor<? super I, ? extends O>) - Method in class org.springframework.batch.core.step.item.SimpleChunkProcessor
 
setItemReader(ItemReader<? extends 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
 
setItemReader(ItemReader<?>) - Method in class org.springframework.batch.core.step.item.ChunkMonitor
 
setItemSqlParameterSourceProvider(ItemSqlParameterSourceProvider<T>) - Method in class org.springframework.batch.item.database.JdbcBatchItemWriter
Public setter for the ItemSqlParameterSourceProvider.
setItemType(Class<? extends T>) - Method in class org.springframework.batch.item.amqp.AmqpItemReader
Establish the itemType for the reader.
setItemType(Class<? extends T>) - Method in class org.springframework.batch.item.jms.JmsItemReader
Set the expected type of incoming message payloads.
setItemWriter(ItemWriter<? super O>) - Method in class org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
 
setItemWriter(ItemWriter<? super S>) - Method in class org.springframework.batch.core.step.factory.SimpleStepFactoryBean
 
setItemWriter(ItemWriter<? super O>) - Method in class org.springframework.batch.core.step.item.SimpleChunkProcessor
 
setJavaMailSender(JavaMailSender) - Method in class org.springframework.batch.item.mail.javamail.MimeMessageItemWriter
A JavaMailSender to be used to send messages in MimeMessageItemWriter.write(List).
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
 
setJdbcTemplate(NamedParameterJdbcOperations) - Method in class org.springframework.batch.item.database.JdbcBatchItemWriter
Public setter for the NamedParameterJdbcOperations.
setJmsTemplate(JmsOperations) - Method in class org.springframework.batch.item.jms.JmsItemReader
Setter for JMS template.
setJmsTemplate(JmsOperations) - Method in class org.springframework.batch.item.jms.JmsItemWriter
Setter for JMS template.
setJmsTemplate(JmsOperations) - Method in class org.springframework.batch.item.jms.JmsMethodInvocationRecoverer
Setter for jms template.
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.
setJob(Job) - Method in class org.springframework.batch.test.JobLauncherTestUtils
The Job instance that can be manipulated (e.g.
setJobExecution(JobExecution) - Method in class org.springframework.batch.core.jsr.JsrJobContext
 
setJobExecution(JobExecution) - Method in class org.springframework.batch.core.jsr.JsrJobContextFactoryBean
Used to provide JobContext instances to batch artifacts that are not within the scope of a given 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.
setJobExecutionListeners(Object[]) - Method in class org.springframework.batch.core.jsr.configuration.xml.JobFactoryBean
Addresses wrapping JobListener as needed to be used with the framework.
setJobExplorer(JobExplorer) - Method in class org.springframework.batch.core.jsr.configuration.xml.JobFactoryBean
 
setJobExplorer(JobExplorer) - Method in class org.springframework.batch.core.jsr.job.flow.JsrFlowJob
 
setJobExplorer(JobExplorer) - Method in class org.springframework.batch.core.jsr.launch.JsrJobOperator
 
setJobExplorer(JobExplorer) - Method in class org.springframework.batch.core.launch.support.CommandLineJobRunner
Injection setter for JobExplorer.
setJobExplorer(JobExplorer) - Method in class org.springframework.batch.core.launch.support.SimpleJobOperator
Public setter for the JobExplorer.
setJobExplorer(JobExplorer) - Method in class org.springframework.batch.core.partition.support.RemoteStepExecutionAggregator
 
setJobExplorer(JobExplorer) - Method in class org.springframework.batch.core.step.tasklet.SystemCommandTasklet
 
setJobExplorer(JobExplorer) - Method in class org.springframework.batch.integration.partition.MessageChannelPartitionHandler
JobExplorer to use to query the job repository.
setJobExplorer(JobExplorer) - Method in class org.springframework.batch.integration.partition.StepExecutionRequestHandler
An explorer that should be used to check for StepExecution completion.
setJobFactoryRef(String) - Method in class org.springframework.batch.core.configuration.xml.AbstractFlowParser
Convenience method for subclasses to set the job factory reference if it is available (null is fine, but the quality of error reports is better if it is available).
setJobIncrementer(DataFieldMaxValueIncrementer) - Method in class org.springframework.batch.core.repository.dao.JdbcJobInstanceDao
Setter for DataFieldMaxValueIncrementer to be used when generating primary keys for JobInstance instances.
setJobInstance(JobInstance) - Method in class org.springframework.batch.core.JobExecution
 
setJobLauncher(JobLauncher) - Method in class org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
 
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.
setJobLauncher(JobLauncher) - Method in class org.springframework.batch.test.JobLauncherTestUtils
A JobLauncher instance that can be used to launch jobs.
setJobLoader(JobLoader) - Method in class org.springframework.batch.core.configuration.support.AutomaticJobRegistrar
The job loader that will be used to load and manage jobs.
setJobLoader(JobLoader) - Method in class org.springframework.batch.core.launch.support.JobRegistryBackgroundJobRunner
A loader for the jobs that are going to be registered.
setJobLocator(JobLocator) - Method in class org.springframework.batch.core.launch.support.CommandLineJobRunner
JobLocator to find a job to run.
setJobParametersConverter(JobParametersConverter) - Method in class org.springframework.batch.core.jsr.launch.JsrJobOperator
Used to convert the Properties objects used by JSR-352 to the JobParameters objects used in Spring Batch.
setJobParametersConverter(JobParametersConverter) - Method in class org.springframework.batch.core.launch.support.CommandLineJobRunner
Injection setter for JobParametersConverter.
setJobParametersConverter(JobParametersConverter) - Method in class org.springframework.batch.core.launch.support.SimpleJobOperator
Public setter for the JobParametersConverter.
setJobParametersExtractor(JobParametersExtractor) - Method in class org.springframework.batch.core.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
 
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
 
setJobParametersIncrementer(JobParametersIncrementer) - Method in class org.springframework.batch.core.jsr.configuration.xml.JobFactoryBean
 
setJobParametersIncrementer(JobParametersIncrementer) - Method in class org.springframework.batch.test.JobRepositoryTestUtils
 
setJobParametersValidator(JobParametersValidator) - Method in class org.springframework.batch.core.configuration.xml.JobParserJobFactoryBean
 
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
 
setJobParametersValidator(JobParametersValidator) - Method in class org.springframework.batch.core.jsr.configuration.xml.JobFactoryBean
 
setJobProperties(Properties) - Method in class org.springframework.batch.core.jsr.configuration.support.BatchPropertyContext
Adds Job level properties to the context.
setJobRegistry(JobRegistry) - Method in class org.springframework.batch.core.configuration.support.DefaultJobLoader
The JobRegistry to use for jobs created.
setJobRegistry(JobRegistry) - Method in class org.springframework.batch.core.configuration.support.JobFactoryRegistrationListener
Public setter for a JobRegistry to use for all the bind and unbind events.
setJobRegistry(JobRegistry) - Method in class org.springframework.batch.core.configuration.support.JobRegistryBeanPostProcessor
Injection setter for JobRegistry.
setJobRegistry(JobRegistry) - Method in class org.springframework.batch.core.launch.support.JobRegistryBackgroundJobRunner
A job registry that can be used to create a job loader (if none is provided).
setJobRegistry(ListableJobLocator) - Method in class org.springframework.batch.core.launch.support.SimpleJobOperator
Public setter for the ListableJobLocator.
setJobRepository(JobRepository) - Method in class org.springframework.batch.core.configuration.xml.JobParserJobFactoryBean
 
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.jsr.configuration.xml.DecisionStepFactoryBean
 
setJobRepository(JobRepository) - Method in class org.springframework.batch.core.jsr.configuration.xml.JobFactoryBean
 
setJobRepository(JobRepository) - Method in class org.springframework.batch.core.jsr.launch.JsrJobOperator
 
setJobRepository(JobRepository) - Method in class org.springframework.batch.core.jsr.partition.JsrPartitionHandler
 
setJobRepository(JobRepository) - Method in class org.springframework.batch.core.launch.support.CommandLineJobRunner
 
setJobRepository(JobRepository) - Method in class org.springframework.batch.core.launch.support.SimpleJobLauncher
Set the JobRepository.
setJobRepository(JobRepository) - Method in class org.springframework.batch.core.launch.support.SimpleJobOperator
 
setJobRepository(JobRepository) - Method in class org.springframework.batch.core.partition.support.SimpleStepExecutionSplitter
The job repository that will be used to manage the persistence of the delegate step executions.
setJobRepository(JobRepository) - Method in class org.springframework.batch.core.step.AbstractStep
Public setter for JobRepository.
setJobRepository(JobRepository) - Method in class org.springframework.batch.core.step.builder.StepBuilderHelper.CommonStepProperties
 
setJobRepository(JobRepository) - Method in class org.springframework.batch.core.step.factory.SimpleStepFactoryBean
Public setter for JobRepository.
setJobRepository(JobRepository) - Method in class org.springframework.batch.test.JobLauncherTestUtils
The JobRepository to use for creating new JobExecution instances.
setJobRepository(JobRepository) - Method in class org.springframework.batch.test.JobRepositoryTestUtils
 
setJsonObjectMarshaller(JsonObjectMarshaller<T>) - Method in class org.springframework.batch.item.json.JsonFileItemWriter
Set the JsonObjectMarshaller to use to marshal object to json.
setJsonObjectReader(JsonObjectReader<T>) - Method in class org.springframework.batch.item.json.JsonItemReader
Set the JsonObjectReader to use to read and map Json fragments to domain objects.
setKafkaTemplate(KafkaTemplate<K, T>) - Method in class org.springframework.batch.item.kafka.KafkaItemWriter
Set the KafkaTemplate to use.
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.
setKeyName(String) - Method in class org.springframework.batch.support.SystemPropertyInitializer
Set the key name for the System property that is created.
setKeys(String[]) - Method in class org.springframework.batch.core.listener.ExecutionContextPromotionListener
 
setKeys(String[]) - Method in class org.springframework.batch.core.listener.JobParameterExecutionContextCopyListener
 
setKeys(String[]) - Method in class org.springframework.batch.core.step.job.DefaultJobParametersExtractor
The key names to pull out of the execution context or job parameters, if they exist.
setLastUpdated(Date) - Method in class org.springframework.batch.core.JobExecution
Set the last time this JobExecution was updated.
setLastUpdated(Date) - Method in class org.springframework.batch.core.StepExecution
Set the time when the StepExecution was last updated before persisting
setLauncher(JobLauncher) - Method in class org.springframework.batch.core.launch.support.CommandLineJobRunner
Injection setter for the JobLauncher.
setLimit(int) - Method in class org.springframework.batch.repeat.exception.SimpleLimitExceptionHandler
The limit on the given exception type within a single context before it is rethrown.
setLineAggregator(LineAggregator<T>) - Method in class org.springframework.batch.item.file.FlatFileItemWriter
Public setter for the LineAggregator.
setLineEnding(String) - Method in class org.springframework.batch.item.file.SimpleBinaryBufferedReaderFactory
 
setLineMapper(LineMapper<T>) - Method in class org.springframework.batch.item.file.FlatFileItemReader
Setter for line mapper.
setLineSeparator(String) - Method in class org.springframework.batch.item.support.AbstractFileItemWriter
Public setter for the line separator.
setLinesToSkip(int) - Method in class org.springframework.batch.item.file.FlatFileItemReader
Public setter for the number of lines to skip at the start of a file.
setLinesWritten(long) - Method in class org.springframework.batch.item.support.AbstractFileItemWriter.OutputState
 
setLineTokenizer(LineTokenizer) - Method in class org.springframework.batch.item.file.mapping.DefaultLineMapper
 
setListeners(Object[]) - Method in class org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
The listeners to inject into the Step.
setListeners(List<? extends StepListener>) - Method in class org.springframework.batch.core.jsr.step.item.JsrChunkProcessor
Register some StepListeners with the handler.
setListeners(List<? extends StepListener>) - Method in class org.springframework.batch.core.jsr.step.item.JsrFaultTolerantChunkProcessor
Register some StepListeners with the handler.
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 RetryProcessListener>) - Method in class org.springframework.batch.core.listener.CompositeRetryProcessListener
Public setter for the RetryProcessListener's.
setListeners(List<? extends RetryReadListener>) - Method in class org.springframework.batch.core.listener.CompositeRetryReadListener
Public setter for the RetryReadListener's.
setListeners(List<? extends RetryWriteListener>) - Method in class org.springframework.batch.core.listener.CompositeRetryWriteListener
Public setter for the RetryWriteListener's.
setListeners(List<? extends SkipListener<? super T, ? super S>>) - Method in class org.springframework.batch.core.listener.CompositeSkipListener
Public setter for the listeners.
setListeners(StepExecutionListener[]) - Method in class org.springframework.batch.core.listener.CompositeStepExecutionListener
Public setter for the listeners.
setListeners(List<? extends StepListener>) - Method in class org.springframework.batch.core.listener.MulticasterBatchListener
Register each of the objects as listeners.
setListeners(StepListener[]) - Method in class org.springframework.batch.core.step.factory.SimpleStepFactoryBean
The listeners to inject into the Step.
setListeners(RetryListener[]) - Method in class org.springframework.batch.core.step.item.BatchRetryTemplate
 
setListeners(List<? extends StepListener>) - Method in class org.springframework.batch.core.step.item.SimpleChunkProcessor
Register some StepListeners with the handler.
setListeners(List<? extends StepListener>) - Method in class org.springframework.batch.core.step.item.SimpleChunkProvider
Register some StepListeners with the handler.
setListeners(RepeatListener[]) - Method in class org.springframework.batch.repeat.listener.CompositeRepeatListener
Public setter for the listeners.
setListeners(RepeatListener[]) - Method in class org.springframework.batch.repeat.support.RepeatTemplate
Set the listeners for this template, registering them for callbacks at appropriate times in the iteration.
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.
setLocale(Locale) - Method in class org.springframework.batch.item.file.transform.FormatterLineAggregator
Public setter for the locale.
setLoginTimeout(int) - Method in class org.springframework.batch.item.database.ExtendedConnectionDataSourceProxy
 
setLogWriter(PrintWriter) - Method in class org.springframework.batch.item.database.ExtendedConnectionDataSourceProxy
 
setMailErrorHandler(MailErrorHandler) - Method in class org.springframework.batch.item.mail.javamail.MimeMessageItemWriter
The handler for failed messages.
setMailErrorHandler(MailErrorHandler) - Method in class org.springframework.batch.item.mail.SimpleMailMessageItemWriter
The handler for failed messages.
setMailSender(MailSender) - Method in class org.springframework.batch.item.mail.SimpleMailMessageItemWriter
A MailSender to be used to send messages in SimpleMailMessageItemWriter.write(List).
setMapper(Gson) - Method in class org.springframework.batch.item.json.GsonJsonObjectReader
Set the object mapper to use to map Json objects to domain objects.
setMapper(ObjectMapper) - Method in class org.springframework.batch.item.json.JacksonJsonObjectReader
Set the object mapper to use to map Json objects to domain 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
 
setMarshaller(Marshaller) - Method in class org.springframework.batch.item.xml.StaxEventItemWriter
Set Object to XML marshaller.
setMatchStatement(String) - Method in class org.springframework.batch.item.data.AbstractNeo4jItemReader
Deprecated.
An optional match fragment of the cypher query.
setMaxCount(int) - Method in class org.springframework.batch.repeat.policy.CountingCompletionPolicy
Setter for maximum value of count before termination.
setMaximumLength(int) - Method in class org.springframework.batch.item.file.transform.FormatterLineAggregator
Public setter for the maximum length of the formatted string.
setMaxItemCount(int) - Method in class org.springframework.batch.item.support.AbstractItemCountingItemStreamItemReader
The maximum index of the items to be read.
setMaxMessageLength(int) - Method in class org.springframework.batch.item.mail.DefaultMailErrorHandler
The limit for the size of message that will be copied to the exception message.
setMaxRows(int) - Method in class org.springframework.batch.item.database.AbstractCursorItemReader
Sets the limit for the maximum number of rows that any ResultSet object can contain to the given number.
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.
setMaxWaitTimeouts(int) - Method in class org.springframework.batch.integration.chunk.ChunkMessageChannelItemWriter
The maximum number of times to wait at the end of a step for a non-null result from the remote workers.
setMessageSource(MessageSource<?>) - Method in class org.springframework.batch.integration.chunk.MessageSourcePollerInterceptor
 
setMessagingOperations(MessagingTemplate) - Method in class org.springframework.batch.integration.chunk.ChunkMessageChannelItemWriter
 
setMessagingOperations(MessagingTemplate) - Method in class org.springframework.batch.integration.partition.MessageChannelPartitionHandler
A pre-configured gateway for sending and receiving messages to the remote workers.
setMetaDataMap(Map<String, String>) - Method in class org.springframework.batch.core.listener.AbstractListenerFactoryBean
 
setMethodName(String) - Method in class org.springframework.batch.item.data.RepositoryItemReader
Specifies what method on the repository to call.
setMethodName(String) - Method in class org.springframework.batch.item.data.RepositoryItemWriter
Specifies what method on the repository to call.
setMinimumLength(int) - Method in class org.springframework.batch.item.file.transform.FormatterLineAggregator
Public setter for the minimum length of the formatted string.
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.jsr.configuration.xml.DecisionStepFactoryBean
The name of the state
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
 
setName(String) - Method in class org.springframework.batch.item.ItemStreamSupport
The name of the component which will be used as a stem for keys in the ExecutionContext.
setName(String) - Method in class org.springframework.batch.item.util.ExecutionContextUserSupport
 
setNamedQuery(String) - Method in class org.springframework.batch.item.database.orm.JpaNamedQueryProvider
 
setNames(String...) - Method in class org.springframework.batch.item.file.transform.AbstractLineTokenizer
Setter for column names.
setNames(String[]) - Method in class org.springframework.batch.item.file.transform.BeanWrapperFieldExtractor
 
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.
setNumberFormat(NumberFormat) - Method in class org.springframework.batch.core.converter.DefaultJobParametersConverter
Public setter for the NumberFormat.
setNumberFormat(NumberFormat) - Method in class org.springframework.batch.item.file.transform.DefaultFieldSet
The NumberFormat to use for parsing numbers.
setNumberFormat(NumberFormat) - Method in class org.springframework.batch.item.file.transform.DefaultFieldSetFactory
The NumberFormat to use for parsing numbers.
setObjectMapper(ObjectMapper) - Method in class org.springframework.batch.core.repository.dao.Jackson2ExecutionContextStringSerializer
 
setObjectMapper(ObjectMapper) - Method in class org.springframework.batch.item.json.JacksonJsonObjectMarshaller
Set the ObjectMapper to use.
setOptionalKeys(String[]) - Method in class org.springframework.batch.core.job.DefaultJobParametersValidator
The keys that are optional in the parameters.
setOrder(int) - Method in class org.springframework.batch.core.configuration.support.AutomaticJobRegistrar
The order to start up and shutdown.
setOrder(int) - Method in class org.springframework.batch.core.scope.BatchScopeSupport
 
setOrderByStatement(String) - Method in class org.springframework.batch.item.data.AbstractNeo4jItemReader
Deprecated.
A list of properties to order the results by.
setOverwriteOutput(boolean) - Method in class org.springframework.batch.item.xml.StaxEventItemWriter
Set "overwrite" flag for the output file.
setPageSize(int) - Method in class org.springframework.batch.item.data.AbstractPaginatedDataItemReader
The number of items to be read with each page.
setPageSize(int) - Method in class org.springframework.batch.item.data.RepositoryItemReader
 
setPageSize(int) - Method in class org.springframework.batch.item.database.AbstractPagingItemReader
The number of rows to retrieve at a time.
setParameters(SqlParameter[]) - Method in class org.springframework.batch.item.database.StoredProcedureItemReader
Add one or more declared parameters.
setParameters(List<?>) - Method in class org.springframework.batch.item.database.support.ListPreparedStatementSetter
Deprecated.
In favor of the constructor
setParameterValues(Map<String, Object>) - Method in class org.springframework.batch.item.data.AbstractNeo4jItemReader
Deprecated.
Optional parameters to be used in the cypher query.
setParameterValues(List<Object>) - Method in class org.springframework.batch.item.data.MongoItemReader
List of values to be substituted in for each of the parameters in the query.
setParameterValues(Map<String, Object>) - Method in class org.springframework.batch.item.database.HibernateCursorItemReader
The parameter values to apply to a query (map of name:value).
setParameterValues(Map<String, Object>) - Method in class org.springframework.batch.item.database.HibernatePagingItemReader
The parameter values to apply to a query (map of name:value).
setParameterValues(Map<String, Object>) - Method in class org.springframework.batch.item.database.JdbcPagingItemReader
The parameter values to be used for the query execution.
setParameterValues(Map<String, Object>) - Method in class org.springframework.batch.item.database.JpaCursorItemReader
Set the parameter values to be used for the query execution.
setParameterValues(Map<String, Object>) - Method in class org.springframework.batch.item.database.JpaPagingItemReader
The parameter values to be used for the query execution.
setPartitionAnalyzer(PartitionAnalyzer) - Method in class org.springframework.batch.core.jsr.partition.JsrPartitionHandler
 
setPartitionDataQueue(Queue<Serializable>) - Method in class org.springframework.batch.core.jsr.partition.JsrPartitionHandler
 
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.
setPartitionLock(ReentrantLock) - Method in class org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
Used to coordinate access to the partition queue between the PartitionCollector and AbstractPartitionAnalyzer
setPartitionLock(ReentrantLock) - Method in class org.springframework.batch.core.jsr.partition.JsrPartitionHandler
 
setPartitionLock(ReentrantLock) - Method in class org.springframework.batch.core.jsr.partition.PartitionCollectorAdapter
 
setPartitionMapper(PartitionMapper) - Method in class org.springframework.batch.core.jsr.partition.JsrPartitionHandler
 
setPartitionOffsets(Map<TopicPartition, Long>) - Method in class org.springframework.batch.item.kafka.KafkaItemReader
Setter for partition offsets.
setPartitionPlan(PartitionPlan) - Method in class org.springframework.batch.core.jsr.partition.JsrPartitionHandler.PartitionPlanState
 
setPartitionProperties(Properties[]) - Method in class org.springframework.batch.core.jsr.partition.JsrPartitionHandler.PartitionPlanState
 
setPartitionQueue(Queue<Serializable>) - Method in class org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
 
setPartitionReducer(PartitionReducer) - Method in class org.springframework.batch.core.jsr.configuration.xml.StepFactoryBean
 
setPartitionReducer(PartitionReducer) - Method in class org.springframework.batch.core.jsr.step.PartitionStep
 
setPartitions(int) - Method in class org.springframework.batch.core.jsr.configuration.xml.StepFactoryBean
 
setPartitions(int) - Method in class org.springframework.batch.core.jsr.partition.JsrPartitionHandler.PartitionPlanState
 
setPartitions(int) - Method in class org.springframework.batch.core.jsr.partition.JsrPartitionHandler
 
setPartitionsOverride(boolean) - Method in class org.springframework.batch.core.jsr.partition.JsrPartitionHandler.PartitionPlanState
 
setPattern(Pattern) - Method in class org.springframework.batch.item.file.transform.RegexLineTokenizer
Sets the regex pattern to use.
setPersistentUserData(Serializable) - Method in class org.springframework.batch.core.jsr.JsrStepContext
 
setPhase(int) - Method in class org.springframework.batch.core.configuration.support.AutomaticJobRegistrar
 
setPolicies(CompletionPolicy[]) - Method in class org.springframework.batch.repeat.policy.CompositeCompletionPolicy
Setter for the policies.
setPolicyMap(Map<Class<? extends Throwable>, SkipPolicy>) - Method in class org.springframework.batch.core.step.skip.ExceptionClassifierSkipPolicy
Setter for policy map.
setPollingInterval(int) - Method in class org.springframework.batch.core.jsr.partition.JsrPartitionHandler
 
setPollInterval(long) - Method in class org.springframework.batch.integration.partition.MessageChannelPartitionHandler
How often to poll the job repository for the status of the workers.
setPollTimeout(Duration) - Method in class org.springframework.batch.item.kafka.KafkaItemReader
Set a timeout for the consumer topic polling duration.
setPreparedStatementSetter(PreparedStatementSetter) - Method in class org.springframework.batch.item.database.JdbcCursorItemReader
Set the PreparedStatementSetter to use if any parameter values that need to be set in the supplied query.
setPreparedStatementSetter(PreparedStatementSetter) - Method in class org.springframework.batch.item.database.StoredProcedureItemReader
Set the PreparedStatementSetter to use if any parameter values that need to be set in the supplied query.
setProcedureName(String) - Method in class org.springframework.batch.item.database.StoredProcedureItemReader
Set the SQL statement to be used when creating the cursor.
setProcessorTransactional(Boolean) - Method in class org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
Flag to signal that the processor is transactional, in which case it should be called for every item in every transaction.
setProcessorTransactional(boolean) - Method in class org.springframework.batch.core.step.factory.FaultTolerantStepFactoryBean
 
setProcessorTransactional(boolean) - Method in class org.springframework.batch.core.step.item.FaultTolerantChunkProcessor
Flag to say that the ItemProcessor is transactional (defaults to true).
setProcessSkipCount(int) - Method in class org.springframework.batch.core.StepExecution
Set the number of records skipped during processing.
setProcessSkipPolicy(SkipPolicy) - Method in class org.springframework.batch.core.step.item.FaultTolerantChunkProcessor
 
setPropagation(Propagation) - Method in class org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
 
setPropagation(Propagation) - Method in class org.springframework.batch.core.step.factory.SimpleStepFactoryBean
 
setProperties(Properties) - Method in class org.springframework.batch.core.jsr.JsrJobContext
 
setPropertyContext(BatchPropertyContext) - Method in class org.springframework.batch.core.jsr.partition.JsrPartitionHandler
 
setPrototypeBeanName(String) - Method in class org.springframework.batch.item.file.mapping.BeanWrapperFieldSetMapper
The bean name (id) for an object that can be populated from the field set that will be passed into BeanWrapperFieldSetMapper.mapFieldSet(FieldSet).
setProxyTargetClass(boolean) - Method in class org.springframework.batch.core.scope.BatchScopeSupport
Flag to indicate that proxies should use dynamic subclassing.
setQuery(Query) - Method in class org.springframework.batch.item.data.MongoItemReader
A Mongo Query to be used.
setQuery(String) - Method in class org.springframework.batch.item.data.MongoItemReader
A JSON formatted MongoDB query.
setQueryName(String) - Method in class org.springframework.batch.item.database.HibernateCursorItemReader
A query name for an externalized query.
setQueryName(String) - Method in class org.springframework.batch.item.database.HibernateItemReaderHelper
 
setQueryName(String) - Method in class org.springframework.batch.item.database.HibernatePagingItemReader
A query name for an externalized query.
setQueryProvider(HibernateQueryProvider<T>) - Method in class org.springframework.batch.item.database.HibernateCursorItemReader
A query provider.
setQueryProvider(HibernateQueryProvider<? extends T>) - Method in class org.springframework.batch.item.database.HibernateItemReaderHelper
 
setQueryProvider(HibernateQueryProvider<? extends T>) - Method in class org.springframework.batch.item.database.HibernatePagingItemReader
A query provider.
setQueryProvider(PagingQueryProvider) - Method in class org.springframework.batch.item.database.JdbcPagingItemReader
setQueryProvider(JpaQueryProvider) - Method in class org.springframework.batch.item.database.JpaCursorItemReader
Set the JPA query provider.
setQueryProvider(JpaQueryProvider) - Method in class org.springframework.batch.item.database.JpaPagingItemReader
 
setQueryString(String) - Method in class org.springframework.batch.item.database.HibernateCursorItemReader
A query string in HQL.
setQueryString(String) - Method in class org.springframework.batch.item.database.HibernateItemReaderHelper
 
setQueryString(String) - Method in class org.springframework.batch.item.database.HibernatePagingItemReader
A query string in HQL.
setQueryString(String) - Method in class org.springframework.batch.item.database.JpaCursorItemReader
Set the JPQL query string.
setQueryString(String) - Method in class org.springframework.batch.item.database.JpaPagingItemReader
 
setQueryTimeout(int) - Method in class org.springframework.batch.item.database.AbstractCursorItemReader
Sets the number of seconds the driver will wait for a Statement object to execute to the given number of seconds.
setQuoteCharacter(String) - Method in class org.springframework.batch.item.file.separator.DefaultRecordSeparatorPolicy
Public setter for the quoteCharacter.
setQuoteCharacter(char) - Method in class org.springframework.batch.item.file.transform.DelimitedLineTokenizer
Public setter for the quoteCharacter.
setReadCount(int) - Method in class org.springframework.batch.core.StepExecution
Sets the current number of read items for this execution
setReadSkipCount(int) - Method in class org.springframework.batch.core.StepExecution
Set the number of records skipped on read
setRecordMapper(RecordMapper<T>) - Method in class org.springframework.batch.item.ldif.MappingLdifReader
Setter for object mapper.
setRecordSeparatorPolicy(RecordSeparatorPolicy) - Method in class org.springframework.batch.item.file.FlatFileItemReader
Public setter for the recordSeparatorPolicy.
setRecordsToSkip(int) - Method in class org.springframework.batch.item.ldif.LdifReader
Public setter for the number of lines to skip at the start of a file.
setRecordsToSkip(int) - Method in class org.springframework.batch.item.ldif.MappingLdifReader
Public setter for the number of lines to skip at the start of a file.
setRefCursorPosition(int) - Method in class org.springframework.batch.item.database.StoredProcedureItemReader
Set the parameter position of the REF CURSOR.
setReflectionProvider(ReflectionProvider) - Method in class org.springframework.batch.core.repository.dao.XStreamExecutionContextStringSerializer
Deprecated.
 
setRegex(String) - Method in class org.springframework.batch.item.file.transform.RegexLineTokenizer
Sets the regular expression to use.
setRepeatOperations(RepeatOperations) - Method in class org.springframework.batch.repeat.interceptor.RepeatOperationsInterceptor
Setter for the RepeatOperations.
setReplyChannel(PollableChannel) - Method in class org.springframework.batch.integration.chunk.ChunkMessageChannelItemWriter
 
setReplyChannel(PollableChannel) - Method in class org.springframework.batch.integration.partition.MessageChannelPartitionHandler
 
setRepository(PagingAndSortingRepository<?, ?>) - Method in class org.springframework.batch.item.data.RepositoryItemReader
The PagingAndSortingRepository implementation used to read input from.
setRepository(CrudRepository<T, ?>) - Method in class org.springframework.batch.item.data.RepositoryItemWriter
Set the CrudRepository implementation for persistence
setRepositoryFactory(MapJobRepositoryFactoryBean) - Method in class org.springframework.batch.core.explore.support.MapJobExplorerFactoryBean
Deprecated.
The repository factory that can be used to create daos for the explorer.
setRequiredKeys(String[]) - Method in class org.springframework.batch.core.job.DefaultJobParametersValidator
The keys that are required in the parameters.
setResource(Resource) - Method in class org.springframework.batch.item.file.FlatFileItemReader
Public setter for the input resource.
setResource(Resource) - Method in class org.springframework.batch.item.file.MultiResourceItemWriter
Prototype for output resources.
setResource(Resource) - Method in interface org.springframework.batch.item.file.ResourceAwareItemReaderItemStream
 
setResource(Resource) - Method in interface org.springframework.batch.item.file.ResourceAwareItemWriterItemStream
 
setResource(Resource) - Method in class org.springframework.batch.item.json.JsonItemReader
 
setResource(Resource) - Method in class org.springframework.batch.item.ldif.LdifReader
Establishes the resource that will be used as the input for the LdifReader.
setResource(Resource) - Method in class org.springframework.batch.item.ldif.MappingLdifReader
 
setResource(Resource) - Method in interface org.springframework.batch.item.ResourceAware
 
setResource(Resource) - Method in class org.springframework.batch.item.support.AbstractFileItemWriter
Setter for resource.
setResource(Resource) - Method in class org.springframework.batch.item.xml.StaxEventItemReader
 
setResource(Resource) - Method in class org.springframework.batch.item.xml.StaxEventItemWriter
Set output file.
setResources(Resource[]) - Method in class org.springframework.batch.core.configuration.support.ClasspathXmlApplicationContextsFactoryBean
A set of resources to load using a GenericApplicationContextFactory.
setResources(Resource[]) - Method in class org.springframework.batch.core.partition.support.MultiResourcePartitioner
The resources to assign to each partition.
setResources(Resource[]) - Method in class org.springframework.batch.item.file.MultiResourceItemReader
 
setResources(Resource[]) - Method in class org.springframework.batch.item.file.ResourcesItemReader
The resources to serve up as items.
setResourceSuffixCreator(ResourceSuffixCreator) - Method in class org.springframework.batch.item.file.MultiResourceItemWriter
Allows customization of the suffix of the created resources based on the index.
setRestartable(Boolean) - Method in class org.springframework.batch.core.configuration.xml.JobParserJobFactoryBean
 
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.jsr.configuration.xml.JobFactoryBean
 
setRetryableExceptionClasses(Map<Class<? extends Throwable>, Boolean>) - Method in class org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
Public setter for exception classes that will retry 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 RetryListeners.
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
 
setReturnStatement(String) - Method in class org.springframework.batch.item.data.AbstractNeo4jItemReader
Deprecated.
The return statement of the cypher query.
setRollbackClassifier(Classifier<Throwable, Boolean>) - Method in class org.springframework.batch.core.jsr.step.item.JsrFaultTolerantChunkProcessor
 
setRollbackClassifier(Classifier<Throwable, Boolean>) - Method in class org.springframework.batch.core.step.item.FaultTolerantChunkProcessor
A classifier that can distinguish between exceptions that cause rollback (return true) or not (return false).
setRollbackClassifier(Classifier<Throwable, Boolean>) - Method in class org.springframework.batch.core.step.item.FaultTolerantChunkProvider
Classifier to determine whether exceptions have been marked as no-rollback (as opposed to skippable).
setRollbackCount(int) - Method in class org.springframework.batch.core.StepExecution
Setter for number of rollbacks for this execution
setRootElementAttributes(Map<String, String>) - Method in class org.springframework.batch.item.xml.StaxEventItemWriter
Set the root element attributes to be written.
setRootTagName(String) - Method in class org.springframework.batch.item.xml.StaxEventItemWriter
Set the tag name of the root element.
setRowMapper(RowMapper<T>) - Method in class org.springframework.batch.item.database.JdbcCursorItemReader
Set the RowMapper to be used for all calls to read().
setRowMapper(RowMapper<T>) - Method in class org.springframework.batch.item.database.JdbcPagingItemReader
The row mapper implementation to be used by this reader.
setRowMapper(RowMapper<T>) - Method in class org.springframework.batch.item.database.StoredProcedureItemReader
Set the RowMapper to be used for all calls to read().
setSaveState(boolean) - Method in class org.springframework.batch.item.file.MultiResourceItemReader
Set the boolean indicating whether or not state should be saved in the provided ExecutionContext during the ItemStream call to update.
setSaveState(boolean) - Method in class org.springframework.batch.item.file.MultiResourceItemWriter
Indicates that the state of the reader will be saved after each commit.
setSaveState(boolean) - Method in class org.springframework.batch.item.kafka.KafkaItemReader
Set the flag that determines whether to save internal data for ExecutionContext.
setSaveState(boolean) - Method in class org.springframework.batch.item.support.AbstractFileItemWriter
Set the flag indicating whether or not state should be saved in the provided ExecutionContext during the ItemStream call to update.
setSaveState(boolean) - Method in class org.springframework.batch.item.support.AbstractItemCountingItemStreamItemReader
Set the flag that determines whether to save internal data for ExecutionContext.
setSaveState(boolean) - Method in class org.springframework.batch.item.xml.StaxEventItemWriter
 
setScript(Resource) - Method in class org.springframework.batch.item.support.ScriptItemProcessor
Sets the Resource location of the script to use.
setScriptEvaluator(ScriptEvaluator) - Method in class org.springframework.batch.item.support.ScriptItemProcessor
Provides the ability to set a custom ScriptEvaluator implementation.
setScriptSource(String, String) - Method in class org.springframework.batch.item.support.ScriptItemProcessor
Sets the provided String as the script source code to use.
setSelectClause(String) - Method in class org.springframework.batch.item.database.support.AbstractSqlPagingQueryProvider
 
setSelectClause(String) - Method in class org.springframework.batch.item.database.support.SqlPagingQueryProviderFactoryBean
 
setSerializer(ExecutionContextSerializer) - Method in class org.springframework.batch.core.explore.support.JobExplorerFactoryBean
A custom implementation of the ExecutionContextSerializer.
setSerializer(ExecutionContextSerializer) - Method in class org.springframework.batch.core.repository.dao.JdbcExecutionContextDao
Setter for Serializer implementation
setSerializer(ExecutionContextSerializer) - Method in class org.springframework.batch.core.repository.support.JobRepositoryFactoryBean
A custom implementation of the ExecutionContextSerializer.
setSession(Session) - Method in class org.springframework.batch.item.database.orm.AbstractHibernateQueryProvider
 
setSession(Session) - Method in interface org.springframework.batch.item.database.orm.HibernateQueryProvider
Inject a Session that can be used as a factory for queries.
setSessionFactory(SessionFactory) - Method in class org.springframework.batch.item.data.AbstractNeo4jItemReader
Deprecated.
Establish the session factory for the reader.
setSessionFactory(SessionFactory) - Method in class org.springframework.batch.item.data.Neo4jItemWriter
Establish the session factory that will be used to create Session instances for interacting with Neo4j.
setSessionFactory(SessionFactory) - Method in class org.springframework.batch.item.database.HibernateCursorItemReader
The Hibernate SessionFactory to use the create a session.
setSessionFactory(SessionFactory) - Method in class org.springframework.batch.item.database.HibernateItemReaderHelper
 
setSessionFactory(SessionFactory) - Method in class org.springframework.batch.item.database.HibernateItemWriter
Set the Hibernate SessionFactory to be used internally.
setSessionFactory(SessionFactory) - Method in class org.springframework.batch.item.database.HibernatePagingItemReader
The Hibernate SessionFactory to use the create a session.
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.
setShouldDeleteIfEmpty(boolean) - Method in class org.springframework.batch.item.support.AbstractFileItemWriter
Flag to indicate that the target file should be deleted if no lines have been written (other than header and footer) on close.
setShouldDeleteIfEmpty(boolean) - Method in class org.springframework.batch.item.xml.StaxEventItemWriter
Flag to indicate that the target file should be deleted if no items have been written (other than header and footer) on close.
setShouldDeleteIfExists(boolean) - Method in class org.springframework.batch.item.support.AbstractFileItemWriter
Flag to indicate that the target file should be deleted if it already exists, otherwise it will be created.
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(int) - Method in class org.springframework.batch.core.step.skip.LimitCheckingItemSkipPolicy
The absolute number of skips (of skippable exceptions) that can be tolerated before a failure.
setSkippableExceptionClasses(Map<Class<? extends Throwable>, Boolean>) - Method in class org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
Public setter for exception classes that when raised won't crash the job but will result in transaction rollback and the item which handling caused the exception will be skipped.
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).
setSkippedLinesCallback(LineCallbackHandler) - Method in class org.springframework.batch.item.file.FlatFileItemReader
 
setSkippedRecordsCallback(RecordCallbackHandler) - Method in class org.springframework.batch.item.ldif.LdifReader
RecordCallbackHandler implementations can be used to take action on skipped records.
setSkippedRecordsCallback(RecordCallbackHandler) - Method in class org.springframework.batch.item.ldif.MappingLdifReader
RecordCallbackHandler implementations can be used to take action on skipped records.
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.jsr.step.item.JsrFaultTolerantChunkProcessor
 
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.
setSort(Map<String, Sort.Direction>) - Method in class org.springframework.batch.item.data.MongoItemReader
Map of property names/Sort.Direction values to sort the input by.
setSort(Map<String, Sort.Direction>) - Method in class org.springframework.batch.item.data.RepositoryItemReader
Provides ordering of the results so that order is maintained between paged queries
setSortKey(String) - Method in class org.springframework.batch.item.database.support.SqlPagingQueryProviderFactoryBean
 
setSortKeys(Map<String, Order>) - Method in class org.springframework.batch.item.database.support.AbstractSqlPagingQueryProvider
 
setSortKeys(Map<String, Order>) - Method in class org.springframework.batch.item.database.support.SqlPagingQueryProviderFactoryBean
 
setSql(String) - Method in class org.springframework.batch.item.database.JdbcBatchItemWriter
Public setter for the query string to execute on write.
setSql(String) - Method in class org.springframework.batch.item.database.JdbcCursorItemReader
Set the SQL statement to be used when creating the cursor.
setSqlQuery(String) - Method in class org.springframework.batch.item.database.orm.HibernateNativeQueryProvider
 
setSqlQuery(String) - Method in class org.springframework.batch.item.database.orm.JpaNativeQueryProvider
 
setStandalone(Boolean) - Method in class org.springframework.batch.item.xml.StaxEventItemWriter
Set standalone document declaration to be used for output XML.
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(Integer) - Method in class org.springframework.batch.core.step.builder.StepBuilderHelper.CommonStepProperties
 
setStartLimit(int) - Method in class org.springframework.batch.core.step.factory.SimpleStepFactoryBean
Public setter for the start limit for the step.
setStartStatement(String) - Method in class org.springframework.batch.item.data.AbstractNeo4jItemReader
Deprecated.
The start segment of the cypher query.
setStartTime(Date) - Method in class org.springframework.batch.core.JobExecution
 
setStartTime(Date) - Method in class org.springframework.batch.core.StepExecution
Sets the time this execution started
setStatelessSession(StatelessSession) - Method in class org.springframework.batch.item.database.orm.AbstractHibernateQueryProvider
 
setStatelessSession(StatelessSession) - Method in interface org.springframework.batch.item.database.orm.HibernateQueryProvider
Inject a StatelessSession that can be used as a factory for queries.
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.jsr.partition.JsrPartitionHandler
 
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.
setStep(TaskletStep) - Method in class org.springframework.batch.integration.chunk.RemoteChunkHandlerFactoryBean
The local step that is to be converted to a remote chunk master.
setStepArtifactProperties(Map<String, Map<String, Properties>>) - Method in class org.springframework.batch.core.jsr.configuration.support.BatchPropertyContext
Adds Step artifact properties to the context.
setStepChunkCompletionPolicy(Object) - Method in class org.springframework.batch.core.jsr.configuration.xml.StepFactoryBean
Wraps a CheckpointAlgorithm in a CheckpointAlgorithmAdapter if required for consumption by the rest of the framework.
setStepContributionSource(StepContributionSource) - Method in class org.springframework.batch.integration.chunk.RemoteChunkHandlerFactoryBean
A source of StepContribution instances coming back from remote workers.
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.
setStepItemProcessor(Object) - Method in class org.springframework.batch.core.jsr.configuration.xml.StepFactoryBean
Wraps a ItemProcessor in a ItemProcessorAdapter if required for consumption by the rest of the framework.
setStepItemReader(Object) - Method in class org.springframework.batch.core.jsr.configuration.xml.StepFactoryBean
Wraps a ItemReader in a ItemReaderAdapter if required for consumption by the rest of the framework.
setStepItemWriter(Object) - Method in class org.springframework.batch.core.jsr.configuration.xml.StepFactoryBean
Wraps a ItemWriter in a ItemWriterAdapter if required for consumption by the rest of the framework.
setStepLocator(StepLocator) - Method in class org.springframework.batch.core.step.StepLocatorStepFactoryBean
 
setStepLocator(StepLocator) - Method in class org.springframework.batch.integration.partition.StepExecutionRequestHandler
Used to locate a Step to execute for each request.
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
 
setStepName(String) - Method in class org.springframework.batch.integration.partition.MessageChannelPartitionHandler
The name of the Step that will be used to execute the partitioned StepExecution.
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.
setStepProperties(Map<String, Properties>) - Method in class org.springframework.batch.core.jsr.configuration.support.BatchPropertyContext
Adds Step level properties to the context.
setStepProperties(String, Properties) - Method in class org.springframework.batch.core.jsr.configuration.support.BatchPropertyContext
Convenience method to set step level properties.
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.
setStepTasklet(Object) - Method in class org.springframework.batch.core.jsr.configuration.xml.StepFactoryBean
Wraps a Batchlet in a BatchletAdapter if required for consumption by the rest of the framework.
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.
setStreams(ItemStream[]) - Method in class org.springframework.batch.item.support.CompositeItemStream
Public setter for the ItemStreams.
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.
setStrict(boolean) - Method in class org.springframework.batch.item.file.builder.MultiResourceItemReaderBuilder
In strict mode the reader will throw an exception on MultiResourceItemReader.open(org.springframework.batch.item.ExecutionContext) if there are no resources to read.
setStrict(boolean) - Method in class org.springframework.batch.item.file.FlatFileItemReader
In strict mode the reader will throw an exception on AbstractItemCountingItemStreamItemReader.open(org.springframework.batch.item.ExecutionContext) if the input resource does not exist.
setStrict(boolean) - Method in class org.springframework.batch.item.file.mapping.BeanWrapperFieldSetMapper
Public setter for the 'strict' property.
setStrict(boolean) - Method in class org.springframework.batch.item.file.MultiResourceItemReader
In strict mode the reader will throw an exception on MultiResourceItemReader.open(org.springframework.batch.item.ExecutionContext) if there are no resources to read.
setStrict(boolean) - Method in class org.springframework.batch.item.file.transform.AbstractLineTokenizer
Public setter for the strict flag.
setStrict(boolean) - Method in class org.springframework.batch.item.json.JsonItemReader
In strict mode the reader will throw an exception on AbstractItemCountingItemStreamItemReader.open(org.springframework.batch.item.ExecutionContext) if the input resource does not exist.
setStrict(boolean) - Method in class org.springframework.batch.item.ldif.LdifReader
In strict mode the reader will throw an exception on AbstractItemCountingItemStreamItemReader.open(org.springframework.batch.item.ExecutionContext) if the input resource does not exist.
setStrict(boolean) - Method in class org.springframework.batch.item.ldif.MappingLdifReader
In strict mode the reader will throw an exception on AbstractItemCountingItemStreamItemReader.open(org.springframework.batch.item.ExecutionContext) if the input resource does not exist.
setStrict(boolean) - Method in class org.springframework.batch.item.xml.StaxEventItemReader
In strict mode the reader will throw an exception on AbstractItemCountingItemStreamItemReader.open(org.springframework.batch.item.ExecutionContext) if the input resource does not exist.
setSuffix(String) - Method in class org.springframework.batch.item.file.separator.SuffixRecordSeparatorPolicy
Lines ending in this terminator String signal the end of a record.
setSystemExiter(SystemExiter) - Method in class org.springframework.batch.core.launch.support.CommandLineJobRunner
Injection setter for the SystemExiter.
setSystemProcessExitCodeMapper(SystemProcessExitCodeMapper) - Method in class org.springframework.batch.core.step.tasklet.SystemCommandTasklet
 
setTablePrefix(String) - Method in class org.springframework.batch.core.explore.support.JobExplorerFactoryBean
Sets the table prefix for all the batch meta-data tables.
setTablePrefix(String) - Method in class org.springframework.batch.core.jsr.JsrJobParametersConverter
The table prefix used in the current JobRepository
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.
setTargetMethod(String) - Method in class org.springframework.batch.item.adapter.AbstractMethodInvokingDelegator
 
setTargetObject(Object) - Method in class org.springframework.batch.item.adapter.AbstractMethodInvokingDelegator
 
setTargetType(Class<T>) - Method in class org.springframework.batch.item.data.AbstractNeo4jItemReader
Deprecated.
The object type to be returned from each call to AbstractItemCountingItemStreamItemReader.read()
setTargetType(Class<? extends T>) - Method in class org.springframework.batch.item.data.MongoItemReader
The type of object to be returned for each AbstractItemCountingItemStreamItemReader.read() call.
setTargetType(Class<? extends T>) - Method in class org.springframework.batch.item.file.mapping.BeanWrapperFieldSetMapper
Public setter for the type of bean to create instead of using a prototype bean.
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.jsr.launch.JsrJobOperator
 
setTaskExecutor(TaskExecutor) - Method in class org.springframework.batch.core.launch.support.SimpleJobLauncher
Set the TaskExecutor.
setTaskExecutor(TaskExecutor) - Method in class org.springframework.batch.core.partition.support.TaskExecutorPartitionHandler
Setter for the TaskExecutor that is used to farm out step executions to multiple threads.
setTaskExecutor(TaskExecutor) - Method in class org.springframework.batch.core.step.factory.SimpleStepFactoryBean
Public setter for the TaskExecutor.
setTaskExecutor(TaskExecutor) - Method in class org.springframework.batch.core.step.tasklet.SystemCommandTasklet
Sets the task executor that will be used to execute the system command NB! Avoid using a synchronous task executor
setTaskExecutor(TaskExecutor) - Method in class org.springframework.batch.integration.async.AsyncItemProcessor
The TaskExecutor to use to allow the item processing to proceed in the background.
setTaskExecutor(TaskExecutor) - Method in class org.springframework.batch.repeat.support.TaskExecutorRepeatTemplate
Setter for task executor to be used to run the individual item callbacks.
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.
setTemplate(GemfireTemplate) - Method in class org.springframework.batch.item.data.GemfireItemWriter
 
setTemplate(MongoOperations) - Method in class org.springframework.batch.item.data.MongoItemReader
Used to perform operations against the MongoDB instance.
setTemplate(MongoOperations) - Method in class org.springframework.batch.item.data.MongoItemWriter
Set the MongoOperations to be used to save items to be written.
setTerminateOnly() - Method in class org.springframework.batch.core.StepExecution
Set a flag that will signal to an execution environment that this execution (and its surrounding job) wishes to exit.
setTerminateOnly() - Method in class org.springframework.batch.repeat.context.RepeatContextSupport
 
setTerminateOnly() - Method in interface org.springframework.batch.repeat.RepeatContext
Signal to the framework that the current batch should complete abnormally, independent of the current CompletionPolicy.
setTerminationCheckInterval(long) - Method in class org.springframework.batch.core.step.tasklet.SystemCommandTasklet
The time interval how often the tasklet will check for termination status.
setThreads(int) - Method in class org.springframework.batch.core.jsr.partition.JsrPartitionHandler.PartitionPlanState
 
setThreads(int) - Method in class org.springframework.batch.core.jsr.partition.JsrPartitionHandler
 
setThresholds(Map<Class<? extends Throwable>, Integer>) - Method in class org.springframework.batch.repeat.exception.RethrowOnThresholdExceptionHandler
A map from exception classes to a threshold value of type Integer.
setThrottleLimit(Integer) - Method in class org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
Public setter for the throttle limit.
setThrottleLimit(int) - Method in class org.springframework.batch.core.step.factory.SimpleStepFactoryBean
Public setter for the throttle limit.
setThrottleLimit(long) - Method in class org.springframework.batch.integration.chunk.ChunkMessageChannelItemWriter
Public setter for the throttle limit.
setThrottleLimit(int) - Method in class org.springframework.batch.repeat.support.TaskExecutorRepeatTemplate
Public setter for the throttle limit.
setTimeout(Integer) - Method in class org.springframework.batch.core.jsr.configuration.xml.StepFactoryBean
 
setTimeout(long) - Method in class org.springframework.batch.core.step.tasklet.SystemCommandTasklet
Timeout in milliseconds.
setTimeout(long) - Method in class org.springframework.batch.integration.partition.MessageChannelPartitionHandler
When using job repository polling, the time limit to wait.
setTimeout(long) - Method in class org.springframework.batch.item.kafka.KafkaItemWriter
The time limit to wait when flushing items to Kafka.
setTokenizers(Map<String, LineTokenizer>) - Method in class org.springframework.batch.item.file.mapping.PatternMatchingCompositeLineMapper
 
setTokenizers(Map<String, LineTokenizer>) - Method in class org.springframework.batch.item.file.transform.PatternMatchingCompositeLineTokenizer
 
setTransacted(boolean) - Method in class org.springframework.batch.item.database.JpaPagingItemReader
By default (true) the EntityTransaction will be started and committed around the read.
setTransactional(boolean) - Method in class org.springframework.batch.item.support.AbstractFileItemWriter
Flag to indicate that writing to the buffer should be delayed if a transaction is active.
setTransactional(boolean) - Method in class org.springframework.batch.item.xml.StaxEventItemWriter
Flag to indicate that writes should be deferred to the end of a transaction if present.
setTransactionAttribute(TransactionAttribute) - Method in class org.springframework.batch.core.step.tasklet.TaskletStep
Public setter for the TransactionAttribute.
setTransactionManager(PlatformTransactionManager) - Method in class org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
 
setTransactionManager(PlatformTransactionManager) - Method in class org.springframework.batch.core.jsr.launch.JsrJobOperator
 
setTransactionManager(PlatformTransactionManager) - Method in class org.springframework.batch.core.repository.support.AbstractJobRepositoryFactoryBean
Public setter for the PlatformTransactionManager.
setTransactionManager(PlatformTransactionManager) - Method in class org.springframework.batch.core.step.builder.StepBuilderHelper.CommonStepProperties
 
setTransactionManager(PlatformTransactionManager) - Method in class org.springframework.batch.core.step.factory.SimpleStepFactoryBean
Public setter for the PlatformTransactionManager.
setTransactionManager(PlatformTransactionManager) - Method in class org.springframework.batch.core.step.tasklet.TaskletStep
Public setter for the PlatformTransactionManager.
setTransactionTimeout(int) - Method in class org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
 
setTransactionTimeout(int) - Method in class org.springframework.batch.core.step.factory.SimpleStepFactoryBean
The timeout for an individual transaction in the step.
setTransientUserData(Object) - Method in class org.springframework.batch.core.jsr.JsrJobContext
 
setTransientUserData(Object) - Method in class org.springframework.batch.core.jsr.JsrStepContext
 
setUnmarshaller(Unmarshaller) - Method in class org.springframework.batch.item.xml.StaxEventItemReader
 
setUpOutputFile(File, boolean, boolean, boolean) - Static method in class org.springframework.batch.item.util.FileUtils
Set up output file for batch processing.
setUpOutputFile(File, boolean, boolean) - Static method in class org.springframework.batch.item.util.FileUtils
Deprecated.
use the version with explicit append parameter instead. Here append=false is assumed.
setUseAllParentParameters(boolean) - Method in class org.springframework.batch.core.step.job.DefaultJobParametersExtractor
setter to support switching off all parent parameters
setUseParent(boolean) - Method in class org.springframework.batch.repeat.exception.RethrowOnThresholdExceptionHandler
Flag to indicate the exception counters should be shared between sibling contexts in a nested batch.
setUseParent(boolean) - Method in class org.springframework.batch.repeat.exception.SimpleLimitExceptionHandler
Flag to indicate the exception counters should be shared between sibling contexts in a nested batch (i.e.
setUseParent(boolean) - Method in class org.springframework.batch.repeat.policy.CountingCompletionPolicy
Flag to indicate whether the count is at the level of the parent context, or just local to the context.
setUsePersist(boolean) - Method in class org.springframework.batch.item.database.JpaItemWriter
Set whether the EntityManager should perform a persist instead of a merge.
setUserData(Object) - Method in class org.springframework.batch.core.step.item.Chunk
 
setUseSharedExtendedConnection(boolean) - Method in class org.springframework.batch.item.database.AbstractCursorItemReader
Indicate whether the connection used for the cursor should be used by all other processing thus sharing the same transaction.
setUseStatelessSession(boolean) - Method in class org.springframework.batch.item.database.HibernateCursorItemReader
Can be set only in uninitialized state.
setUseStatelessSession(boolean) - Method in class org.springframework.batch.item.database.HibernateItemReaderHelper
Can be set only in uninitialized state.
setUseStatelessSession(boolean) - Method in class org.springframework.batch.item.database.HibernatePagingItemReader
Can be set only in uninitialized state.
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.
setValidating(boolean) - Method in class org.springframework.batch.core.jsr.configuration.xml.JsrXmlApplicationContext
Set whether to use XML validation.
setValidator(Validator) - Method in class org.springframework.batch.item.validator.SpringValidator
 
setValidator(Validator<? super T>) - Method in class org.springframework.batch.item.validator.ValidatingItemProcessor
Set the validator used to validate each item.
setValidators(List<JobParametersValidator>) - Method in class org.springframework.batch.core.job.CompositeJobParametersValidator
Public setter for the validators
setValues(T, PreparedStatement) - Method in interface org.springframework.batch.item.database.ItemPreparedStatementSetter
Set parameter values on the given PreparedStatement as determined from the provided item.
setValues(Map<String, Object>, PreparedStatement) - Method in class org.springframework.batch.item.database.support.ColumnMapItemPreparedStatementSetter
 
setValues(PreparedStatement) - Method in class org.springframework.batch.item.database.support.ListPreparedStatementSetter
Deprecated.
 
setVerifyCursorPosition(boolean) - Method in class org.springframework.batch.item.database.AbstractCursorItemReader
Allow verification of cursor position after current row is processed by RowMapper or RowCallbackHandler.
setVersion(Integer) - Method in class org.springframework.batch.core.Entity
Public setter for the version needed only by repository methods.
setVersion(String) - Method in class org.springframework.batch.item.xml.StaxEventItemWriter
Set XML version to be used for output XML.
setWhereClause(String) - Method in class org.springframework.batch.item.database.support.AbstractSqlPagingQueryProvider
 
setWhereClause(String) - Method in class org.springframework.batch.item.database.support.SqlPagingQueryProviderFactoryBean
 
setWhereStatement(String) - Method in class org.springframework.batch.item.data.AbstractNeo4jItemReader
Deprecated.
An optional where fragment of the cypher query.
setWorkingDirectory(String) - Method in class org.springframework.batch.core.step.tasklet.SystemCommandTasklet
 
setWriteCount(int) - Method in class org.springframework.batch.core.StepExecution
Sets the current number of written items for this execution
setWriteSkipCount(int) - Method in class org.springframework.batch.core.StepExecution
Set the number of records skipped on write
setWriteSkipPolicy(SkipPolicy) - Method in class org.springframework.batch.core.step.item.FaultTolerantChunkProcessor
 
setXmlInputFactory(XMLInputFactory) - Method in class org.springframework.batch.item.xml.StaxEventItemReader
Set the XMLInputFactory.
shouldClose(Connection) - Method in class org.springframework.batch.item.database.ExtendedConnectionDataSourceProxy
 
shouldDeleteIfEmpty(boolean) - Method in class org.springframework.batch.item.file.builder.FlatFileItemWriterBuilder
If set to true, once the step is complete, if the resource previously provided is empty, it will be deleted.
shouldDeleteIfEmpty(boolean) - Method in class org.springframework.batch.item.json.builder.JsonFileItemWriterBuilder
If set to true, once the step is complete, if the resource previously provided is empty, it will be deleted.
shouldDeleteIfEmpty(boolean) - Method in class org.springframework.batch.item.xml.builder.StaxEventItemWriterBuilder
Flag to indicate that the output file should be deleted if no results were written to it.
shouldDeleteIfExists(boolean) - Method in class org.springframework.batch.item.file.builder.FlatFileItemWriterBuilder
If set to true, upon the start of the step, if the resource already exists, it will be deleted and recreated.
shouldDeleteIfExists(boolean) - Method in class org.springframework.batch.item.json.builder.JsonFileItemWriterBuilder
If set to true, upon the start of the step, if the resource already exists, it will be deleted and recreated.
shouldDeleteIfExists - Variable in class org.springframework.batch.item.support.AbstractFileItemWriter
 
shouldGenerateId() - Method in class org.springframework.batch.core.configuration.xml.InlineFlowParser
 
shouldGenerateIdAsFallback() - Method in class org.springframework.batch.core.jsr.configuration.xml.BatchParser
 
shouldSkip(Throwable, int) - Method in class org.springframework.batch.core.step.skip.AlwaysSkipItemSkipPolicy
 
shouldSkip(Throwable, int) - Method in class org.springframework.batch.core.step.skip.CompositeSkipPolicy
 
shouldSkip(Throwable, int) - Method in class org.springframework.batch.core.step.skip.ExceptionClassifierSkipPolicy
Consult the classifier and find a delegate policy, and then use that to determine the outcome.
shouldSkip(Throwable, int) - Method in class org.springframework.batch.core.step.skip.LimitCheckingItemSkipPolicy
Given the provided exception and skip count, determine whether or not processing should continue for the given exception.
shouldSkip(Throwable, int) - Method in class org.springframework.batch.core.step.skip.NeverSkipItemSkipPolicy
 
shouldSkip(Throwable, int) - Method in interface org.springframework.batch.core.step.skip.SkipPolicy
Returns true or false, indicating whether or not processing should continue with the given throwable.
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.
shouldStart(StepExecution, JobExecution, Step) - Method in class org.springframework.batch.core.jsr.job.JsrStepHandler
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.
SimpleBatchConfiguration - Class in org.springframework.batch.core.configuration.annotation
Base Configuration class providing common structure for enabling and using Spring Batch.
SimpleBatchConfiguration() - Constructor for class org.springframework.batch.core.configuration.annotation.SimpleBatchConfiguration
 
SimpleBinaryBufferedReaderFactory - Class in org.springframework.batch.item.file
A BufferedReaderFactory useful for reading simple binary (or text) files with no line endings, such as those produced by mainframe copy books.
SimpleBinaryBufferedReaderFactory() - Constructor for class org.springframework.batch.item.file.SimpleBinaryBufferedReaderFactory
 
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
 
SimpleCompletionPolicy - Class in org.springframework.batch.repeat.policy
Policy for terminating a batch after a fixed number of operations.
SimpleCompletionPolicy() - Constructor for class org.springframework.batch.repeat.policy.SimpleCompletionPolicy
 
SimpleCompletionPolicy(int) - Constructor for class org.springframework.batch.repeat.policy.SimpleCompletionPolicy
 
SimpleCompletionPolicy.SimpleTerminationContext - Class in org.springframework.batch.repeat.policy
 
SimpleFlow - Class in org.springframework.batch.core.job.flow.support
A Flow that branches conditionally depending on the exit status of the last State.
SimpleFlow(String) - Constructor for class org.springframework.batch.core.job.flow.support.SimpleFlow
Create a flow with the given name.
SimpleFlowFactoryBean - Class in org.springframework.batch.core.configuration.xml
Convenience factory for SimpleFlow instances for use in XML namespace.
SimpleFlowFactoryBean() - Constructor for class org.springframework.batch.core.configuration.xml.SimpleFlowFactoryBean
 
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 using the injected DAOs.
SimpleJobExplorer(JobInstanceDao, JobExecutionDao, StepExecutionDao, ExecutionContextDao) - Constructor for class org.springframework.batch.core.explore.support.SimpleJobExplorer
 
SimpleJobLauncher - Class in org.springframework.batch.core.launch.support
Simple implementation of the JobLauncher interface.
SimpleJobLauncher() - Constructor for class org.springframework.batch.core.launch.support.SimpleJobLauncher
 
SimpleJobOperator - Class in org.springframework.batch.core.launch.support
Simple implementation of the JobOperator interface.
SimpleJobOperator() - Constructor for class org.springframework.batch.core.launch.support.SimpleJobOperator
 
SimpleJobRepository - Class in org.springframework.batch.core.repository.support
Implementation of JobRepository that stores JobInstances, JobExecutions, and StepExecutions using the injected DAOs.
SimpleJobRepository(JobInstanceDao, JobExecutionDao, StepExecutionDao, ExecutionContextDao) - Constructor for class org.springframework.batch.core.repository.support.SimpleJobRepository
 
SimpleJvmExitCodeMapper - Class in org.springframework.batch.core.launch.support
An implementation of ExitCodeMapper that can be configured through a map from batch exit codes (String) to integer results.
SimpleJvmExitCodeMapper() - Constructor for class org.springframework.batch.core.launch.support.SimpleJvmExitCodeMapper
 
SimpleLimitExceptionHandler - Class in org.springframework.batch.repeat.exception
Simple implementation of exception handler which looks for given exception types.
SimpleLimitExceptionHandler(int) - Constructor for class org.springframework.batch.repeat.exception.SimpleLimitExceptionHandler
Convenience constructor for the SimpleLimitExceptionHandler to set the limit.
SimpleLimitExceptionHandler() - Constructor for class org.springframework.batch.repeat.exception.SimpleLimitExceptionHandler
Default constructor for the SimpleLimitExceptionHandler.
SimpleMailMessageItemWriter - Class in org.springframework.batch.item.mail
A simple ItemWriter that can send mail messages.
SimpleMailMessageItemWriter() - Constructor for class org.springframework.batch.item.mail.SimpleMailMessageItemWriter
 
SimpleMailMessageItemWriterBuilder - Class in org.springframework.batch.item.mail.builder
Creates a fully qualified SimpleMailMessageItemWriter.
SimpleMailMessageItemWriterBuilder() - Constructor for class org.springframework.batch.item.mail.builder.SimpleMailMessageItemWriterBuilder
 
SimpleMethodInvoker - Class in org.springframework.batch.support
Simple implementation of the MethodInvoker interface that invokes a method on an object.
SimpleMethodInvoker(Object, Method) - Constructor for class org.springframework.batch.support.SimpleMethodInvoker
 
SimpleMethodInvoker(Object, String, Class<?>...) - Constructor for class org.springframework.batch.support.SimpleMethodInvoker
 
SimpleMetric - Class in org.springframework.batch.core.jsr
Simple implementation of the Metric interface as required by JSR-352.
SimpleMetric(Metric.MetricType, long) - Constructor for class org.springframework.batch.core.jsr.SimpleMetric
Basic constructor.
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
 
SimpleRecordSeparatorPolicy - Class in org.springframework.batch.item.file.separator
Simplest possible RecordSeparatorPolicy - treats all lines as record endings.
SimpleRecordSeparatorPolicy() - Constructor for class org.springframework.batch.item.file.separator.SimpleRecordSeparatorPolicy
 
SimpleResourceSuffixCreator - Class in org.springframework.batch.item.file
Trivial implementation of ResourceSuffixCreator that uses the index itself as suffix, separated by dot.
SimpleResourceSuffixCreator() - Constructor for class org.springframework.batch.item.file.SimpleResourceSuffixCreator
 
SimpleRetryExceptionHandler - Class in org.springframework.batch.core.step.item
An ExceptionHandler that is aware of the retry context so that it can distinguish between a fatal exception and one that can be retried.
SimpleRetryExceptionHandler(RetryPolicy, ExceptionHandler, Collection<Class<? extends Throwable>>) - Constructor for class org.springframework.batch.core.step.item.SimpleRetryExceptionHandler
Create an exception handler from its mandatory properties.
SimpleStepBuilder<I,O> - Class in org.springframework.batch.core.step.builder
Step builder for simple item processing (chunk oriented) steps.
SimpleStepBuilder(StepBuilderHelper<?>) - Constructor for class org.springframework.batch.core.step.builder.SimpleStepBuilder
Create a new builder initialized with any properties in the parent.
SimpleStepBuilder(SimpleStepBuilder<I, O>) - Constructor for class org.springframework.batch.core.step.builder.SimpleStepBuilder
Create a new builder initialized with any properties in the parent.
SimpleStepExecutionSplitter - Class in org.springframework.batch.core.partition.support
Generic implementation of StepExecutionSplitter that delegates to a Partitioner to generate ExecutionContext instances.
SimpleStepExecutionSplitter() - Constructor for class org.springframework.batch.core.partition.support.SimpleStepExecutionSplitter
Default constructor for convenience in configuration.
SimpleStepExecutionSplitter(JobRepository, boolean, String, Partitioner) - Constructor for class org.springframework.batch.core.partition.support.SimpleStepExecutionSplitter
Construct a SimpleStepExecutionSplitter from its mandatory properties.
SimpleStepExecutionSplitter(JobRepository, Step, Partitioner) - Constructor for class org.springframework.batch.core.partition.support.SimpleStepExecutionSplitter
SimpleStepFactoryBean<T,S> - Class in org.springframework.batch.core.step.factory
Most common configuration options for simple steps should be found here.
SimpleStepFactoryBean() - Constructor for class org.springframework.batch.core.step.factory.SimpleStepFactoryBean
Default constructor for SimpleStepFactoryBean.
SimpleStepHandler - Class in org.springframework.batch.core.job
Implementation of StepHandler that manages repository and restart concerns.
SimpleStepHandler() - Constructor for class org.springframework.batch.core.job.SimpleStepHandler
Convenient default constructor for configuration usage.
SimpleStepHandler(JobRepository) - Constructor for class org.springframework.batch.core.job.SimpleStepHandler
 
SimpleStepHandler(JobRepository, ExecutionContext) - Constructor for class org.springframework.batch.core.job.SimpleStepHandler
 
SimpleSystemProcessExitCodeMapper - Class in org.springframework.batch.core.step.tasklet
Simple SystemProcessExitCodeMapper implementation that performs following mapping: 0 -> ExitStatus.FINISHED else -> ExitStatus.FAILED
SimpleSystemProcessExitCodeMapper() - Constructor for class org.springframework.batch.core.step.tasklet.SimpleSystemProcessExitCodeMapper
 
SimpleTerminationContext(RepeatContext) - Constructor for class org.springframework.batch.repeat.policy.SimpleCompletionPolicy.SimpleTerminationContext
 
SingleItemPeekableItemReader<T> - Class in org.springframework.batch.item.support
A PeekableItemReader that allows the user to peek one item ahead.
SingleItemPeekableItemReader() - Constructor for class org.springframework.batch.item.support.SingleItemPeekableItemReader
 
SingleItemPeekableItemReaderBuilder<T> - Class in org.springframework.batch.item.support.builder
Creates a fully qualified SingleItemPeekeableItemReader.
SingleItemPeekableItemReaderBuilder() - Constructor for class org.springframework.batch.item.support.builder.SingleItemPeekableItemReaderBuilder
 
size() - Method in class org.springframework.batch.core.step.item.Chunk
 
size() - Method in class org.springframework.batch.item.ExecutionContext
Returns number of entries in the context
skip(Class<? extends Throwable>) - Method in class org.springframework.batch.core.step.builder.FaultTolerantStepBuilder
Explicitly request certain exceptions (and subclasses) to be skipped.
skip(Exception) - Method in class org.springframework.batch.core.step.item.Chunk
Register an anonymous skip.
skip(Class<? extends Throwable>) - Method in class org.springframework.batch.integration.chunk.RemoteChunkingManagerStepBuilder
 
skip(Class<? extends Throwable>) - Method in class org.springframework.batch.integration.chunk.RemoteChunkingMasterStepBuilder
Deprecated.
 
SkipException - Exception in org.springframework.batch.core.step.skip
Base exception indicating that the skip has failed or caused a failure.
SkipException(String, Throwable) - Constructor for exception org.springframework.batch.core.step.skip.SkipException
 
SkipException(String) - Constructor for exception org.springframework.batch.core.step.skip.SkipException
 
skipLimit(int) - Method in class org.springframework.batch.core.step.builder.FaultTolerantStepBuilder
Sets the maximum number of failed items to skip before the step fails.
skipLimit(int) - Method in class org.springframework.batch.integration.chunk.RemoteChunkingManagerStepBuilder
 
skipLimit(int) - Method in class org.springframework.batch.integration.chunk.RemoteChunkingMasterStepBuilder
Deprecated.
 
SkipLimitExceededException - Exception in org.springframework.batch.core.step.skip
Exception indicating that the skip limit for a particular Step has been exceeded.
SkipLimitExceededException(int, Throwable) - Constructor for exception org.springframework.batch.core.step.skip.SkipLimitExceededException
 
SkipListener<T,S> - Interface in org.springframework.batch.core
Interface for listener to skipped items.
SkipListenerAdapter<T,S> - Class in org.springframework.batch.core.jsr
 
SkipListenerAdapter(SkipReadListener, SkipProcessListener, SkipWriteListener) - Constructor for class org.springframework.batch.core.jsr.SkipListenerAdapter
 
SkipListenerFailedException - Exception in org.springframework.batch.core.step.skip
Special exception to indicate a failure in a skip listener.
SkipListenerFailedException(String, RuntimeException, Throwable) - Constructor for exception org.springframework.batch.core.step.skip.SkipListenerFailedException
 
SkipListenerSupport<T,S> - Class in org.springframework.batch.core.listener
Basic no-op implementations of all SkipListener implementations.
SkipListenerSupport() - Constructor for class org.springframework.batch.core.listener.SkipListenerSupport
 
SkipOverflowException - Exception in org.springframework.batch.core.step.item
 
SkipOverflowException(String) - Constructor for exception org.springframework.batch.core.step.item.SkipOverflowException
 
skippedLinesCallback(LineCallbackHandler) - Method in class org.springframework.batch.item.file.builder.FlatFileItemReaderBuilder
A callback to be called for each line that is skipped.
skippedRecordsCallback(RecordCallbackHandler) - Method in class org.springframework.batch.item.ldif.builder.LdifReaderBuilder
RecordCallbackHandler implementations can be used to take action on skipped records.
skippedRecordsCallback(RecordCallbackHandler) - Method in class org.springframework.batch.item.ldif.builder.MappingLdifReaderBuilder
RecordCallbackHandler implementations can be used to take action on skipped records.
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.
skipPolicy(SkipPolicy) - Method in class org.springframework.batch.integration.chunk.RemoteChunkingManagerStepBuilder
 
skipPolicy(SkipPolicy) - Method in class org.springframework.batch.integration.chunk.RemoteChunkingMasterStepBuilder
Deprecated.
 
SkipPolicyFailedException - Exception in org.springframework.batch.core.step.skip
Special exception to indicate a failure in a skip policy.
SkipPolicyFailedException(String, RuntimeException, Throwable) - Constructor for exception org.springframework.batch.core.step.skip.SkipPolicyFailedException
 
SkipWrapper<T> - Class in org.springframework.batch.core.step.item
Wrapper for an item and its exception if it failed processing.
SkipWrapper(T) - Constructor for class org.springframework.batch.core.step.item.SkipWrapper
 
SkipWrapper(Throwable) - Constructor for class org.springframework.batch.core.step.item.SkipWrapper
 
SkipWrapper(T, Throwable) - Constructor for class org.springframework.batch.core.step.item.SkipWrapper
 
sortKeys(Map<String, Order>) - Method in class org.springframework.batch.item.database.builder.JdbcPagingItemReaderBuilder
The keys to sort by.
sorts(Map<String, Sort.Direction>) - Method in class org.springframework.batch.item.data.builder.MongoItemReaderBuilder
Map of property names/Sort.Direction values to sort the input by.
sorts(Map<String, Sort.Direction>) - Method in class org.springframework.batch.item.data.builder.RepositoryItemReaderBuilder
Provides ordering of the results so that order is maintained between paged queries.
SpELItemKeyMapper<K,V> - Class in org.springframework.batch.item
An implementation of Converter that uses SpEL to map a Value to a key
SpELItemKeyMapper(String) - Constructor for class org.springframework.batch.item.SpELItemKeyMapper
 
SpELMappingGemfireItemWriter<K,V> - Class in org.springframework.batch.item.data
A convenient GemfireItemWriter implementation that uses a SpELItemKeyMapper
split(TaskExecutor) - Method in class org.springframework.batch.core.job.builder.FlowBuilder
 
split(TaskExecutor) - Method in class org.springframework.batch.core.job.builder.SimpleJobBuilder
 
split(StepExecution, int) - Method in class org.springframework.batch.core.jsr.partition.JsrStepExecutionSplitter
Returns the same number of StepExecutions as the gridSize specifies.
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_ELE - Static variable in class org.springframework.batch.core.configuration.xml.AbstractFlowParser
 
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 using the provided job repository ref.
SplitState - Class in org.springframework.batch.core.job.flow.support.state
A State implementation that splits a Flow into multiple parallel subflows.
SplitState(Collection<Flow>, String) - Constructor for class org.springframework.batch.core.job.flow.support.state.SplitState
 
splitter(StepExecutionSplitter) - Method in class org.springframework.batch.core.step.builder.PartitionStepBuilder
Provide an explicit StepExecutionSplitter instead of having one build from the PartitionStepBuilder.partitioner(String, Partitioner).
splitter(StepExecutionSplitter) - Method in class org.springframework.batch.integration.partition.RemotePartitioningManagerStepBuilder
 
splitter(StepExecutionSplitter) - Method in class org.springframework.batch.integration.partition.RemotePartitioningMasterStepBuilder
Deprecated.
 
SpringBatchTest - Annotation Type in org.springframework.batch.test.context
Annotation that can be specified on a test class that runs Spring Batch based tests.
SpringValidator<T> - Class in org.springframework.batch.item.validator
Adapts the Validator interface to Validator.
SpringValidator() - Constructor for class org.springframework.batch.item.validator.SpringValidator
 
sql(String) - Method in class org.springframework.batch.item.database.builder.JdbcBatchItemWriterBuilder
Set the SQL statement to be used for each item's updates.
sql(String) - Method in class org.springframework.batch.item.database.builder.JdbcCursorItemReaderBuilder
The query to be executed for this reader
sql - Variable in class org.springframework.batch.item.database.JdbcBatchItemWriter
 
SqlitePagingQueryProvider - Class in org.springframework.batch.item.database.support
SQLite implementation of a PagingQueryProvider using database specific features.
SqlitePagingQueryProvider() - Constructor for class org.springframework.batch.item.database.support.SqlitePagingQueryProvider
 
SqlPagingQueryProviderFactoryBean - Class in org.springframework.batch.item.database.support
Factory bean for PagingQueryProvider interface.
SqlPagingQueryProviderFactoryBean() - Constructor for class org.springframework.batch.item.database.support.SqlPagingQueryProviderFactoryBean
 
SqlPagingQueryUtils - Class in org.springframework.batch.item.database.support
Utility class that generates the actual SQL statements used by query providers.
SqlPagingQueryUtils() - Constructor for class org.springframework.batch.item.database.support.SqlPagingQueryUtils
 
SqlServerPagingQueryProvider - Class in org.springframework.batch.item.database.support
SQL Server implementation of a PagingQueryProvider using database specific features.
SqlServerPagingQueryProvider() - Constructor for class org.springframework.batch.item.database.support.SqlServerPagingQueryProvider
 
SqlWindowingPagingQueryProvider - Class in org.springframework.batch.item.database.support
Generic Paging Query Provider using standard SQL:2003 windowing functions.
SqlWindowingPagingQueryProvider() - Constructor for class org.springframework.batch.item.database.support.SqlWindowingPagingQueryProvider
 
standalone(Boolean) - Method in class org.springframework.batch.item.xml.builder.StaxEventItemWriterBuilder
Standalone document declaration for the output document.
StandaloneStepParser - Class in org.springframework.batch.core.configuration.xml
Internal parser for the <step/> elements for a job.
StandaloneStepParser() - Constructor for class org.springframework.batch.core.configuration.xml.StandaloneStepParser
 
start() - Method in class org.springframework.batch.core.configuration.support.AutomaticJobRegistrar
Take all the contexts from the factories provided and pass them to the JobLoader.
start(Step) - Method in class org.springframework.batch.core.job.builder.FlowBuilder
Start a flow.
start(JobExecutionDecider) - Method in class org.springframework.batch.core.job.builder.FlowBuilder
If a flow should start with a decision use this as the first state.
start(Flow) - Method in class org.springframework.batch.core.job.builder.FlowBuilder
If a flow should start with a subflow use this as the first state.
start(Flow) - Method in class org.springframework.batch.core.job.builder.FlowJobBuilder
Start a job with this flow, but expect to transition from there to other flows or steps.
start(Step) - Method in class org.springframework.batch.core.job.builder.FlowJobBuilder
Start a job with this step, but expect to transition from there to other flows or steps.
start(Step) - Method in class org.springframework.batch.core.job.builder.JobBuilder
Create a new job builder that will execute a step or sequence of steps.
start(Flow) - Method in class org.springframework.batch.core.job.builder.JobBuilder
Create a new job builder that will execute a flow.
start(Step) - Method in class org.springframework.batch.core.job.builder.SimpleJobBuilder
Start the job with this step.
start(JobExecutionDecider) - Method in class org.springframework.batch.core.job.builder.SimpleJobBuilder
Start with this decider.
start(FlowExecutor) - Method in interface org.springframework.batch.core.job.flow.Flow
 
start(FlowExecutor) - Method in class org.springframework.batch.core.job.flow.support.SimpleFlow
 
start(String, Properties) - Method in class org.springframework.batch.core.jsr.launch.JsrJobOperator
Creates a child ApplicationContext for the job being requested based upon the /META-INF/batch.xml (if exists) and the /META-INF/batch-jobs/<jobName>.xml configuration and launches the job.
start(String, String) - Method in interface org.springframework.batch.core.launch.JobOperator
Start a new instance of a job with the parameters specified.
start(String, String) - Method in class org.springframework.batch.core.launch.support.SimpleJobOperator
 
start(RepeatContext) - Method in class org.springframework.batch.core.resource.StepExecutionSimpleCompletionPolicy
 
start(RepeatContext) - Method in class org.springframework.batch.jsr.repeat.CheckpointAlgorithmAdapter
 
start(RepeatContext) - Method in interface org.springframework.batch.repeat.CompletionPolicy
Create a new context for the execution of a batch.
start(RepeatContext) - Method in class org.springframework.batch.repeat.policy.CompletionPolicySupport
Build a new RepeatContextSupport and return it.
start(RepeatContext) - Method in class org.springframework.batch.repeat.policy.CompositeCompletionPolicy
Create a new composite context from all the available policies.
start(RepeatContext) - Method in class org.springframework.batch.repeat.policy.CountingCompletionPolicy
 
start(RepeatContext) - Method in class org.springframework.batch.repeat.policy.SimpleCompletionPolicy
Reset the counter.
start(RepeatContext) - Method in class org.springframework.batch.repeat.policy.TimeoutTerminationPolicy
Start the clock on the timeout.
start() - Method in class org.springframework.batch.repeat.support.RepeatTemplate
Delegate to the CompletionPolicy.
startCloseSuppression(Connection) - Method in class org.springframework.batch.item.database.ExtendedConnectionDataSourceProxy
 
startDocument(XMLEventWriter) - Method in class org.springframework.batch.item.xml.StaxEventItemWriter
Writes simple XML header containing: xml declaration - defines encoding and XML version opening tag of the root element and its attributes If this is not sufficient for you, simply override this method.
startLimit(int) - Method in class org.springframework.batch.core.step.builder.StepBuilderHelper
 
startLimit(int) - Method in class org.springframework.batch.integration.chunk.RemoteChunkingManagerStepBuilder
 
startLimit(int) - Method in class org.springframework.batch.integration.chunk.RemoteChunkingMasterStepBuilder
Deprecated.
 
startLimit(int) - Method in class org.springframework.batch.integration.partition.RemotePartitioningManagerStepBuilder
 
startLimit(int) - Method in class org.springframework.batch.integration.partition.RemotePartitioningMasterStepBuilder
Deprecated.
 
startLimit(int) - Method in class org.springframework.batch.integration.partition.RemotePartitioningWorkerStepBuilder
 
StartLimitExceededException - Exception in org.springframework.batch.core
Indicates the step's start limit has been exceeded.
StartLimitExceededException(String) - Constructor for exception org.springframework.batch.core.StartLimitExceededException
 
startNextInstance(String) - Method in interface org.springframework.batch.core.launch.JobOperator
Launch the next in a sequence of JobInstance determined by the JobParametersIncrementer attached to the specified job.
startNextInstance(String) - Method in class org.springframework.batch.core.launch.support.SimpleJobOperator
 
startStatement(String) - Method in class org.springframework.batch.item.data.builder.Neo4jItemReaderBuilder
The start segment of the cypher query.
State - Interface in org.springframework.batch.core.job.flow
 
state - Variable in class org.springframework.batch.item.support.AbstractFileItemWriter
 
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.metrics.BatchMetrics
 
STATUS_SUCCESS - Static variable in class org.springframework.batch.core.metrics.BatchMetrics
 
StaxEventItemReader<T> - Class in org.springframework.batch.item.xml
Item reader for reading XML input based on StAX.
StaxEventItemReader() - Constructor for class org.springframework.batch.item.xml.StaxEventItemReader
 
StaxEventItemReaderBuilder<T> - Class in org.springframework.batch.item.xml.builder
A fluent builder for the StaxEventItemReader
StaxEventItemReaderBuilder() - Constructor for class org.springframework.batch.item.xml.builder.StaxEventItemReaderBuilder
 
StaxEventItemWriter<T> - Class in org.springframework.batch.item.xml
An implementation of ItemWriter which uses StAX and Marshaller for serializing object to XML.
StaxEventItemWriter() - Constructor for class org.springframework.batch.item.xml.StaxEventItemWriter
 
StaxEventItemWriterBuilder<T> - Class in org.springframework.batch.item.xml.builder
A builder for the StaxEventItemWriter.
StaxEventItemWriterBuilder() - Constructor for class org.springframework.batch.item.xml.builder.StaxEventItemWriterBuilder
 
StaxUtils - Class in org.springframework.batch.item.xml
Deprecated.
in favor of StaxUtils
StaxUtils() - Constructor for class org.springframework.batch.item.xml.StaxUtils
Deprecated.
 
StaxWriterCallback - Interface in org.springframework.batch.item.xml
Callback interface for writing to an XML file - useful e.g.
step(Step) - Method in class org.springframework.batch.core.jsr.step.builder.JsrPartitionStepBuilder
 
Step - Interface in org.springframework.batch.core
Batch domain interface representing the configuration of a step.
step(Step) - Method in class org.springframework.batch.core.step.builder.PartitionStepBuilder
Provide an actual step instance to execute in parallel.
step(Step) - Method in class org.springframework.batch.integration.partition.RemotePartitioningManagerStepBuilder
 
step(Step) - Method in class org.springframework.batch.integration.partition.RemotePartitioningMasterStepBuilder
Deprecated.
 
STEP_ELE - Static variable in class org.springframework.batch.core.configuration.xml.AbstractFlowParser
 
STEP_EXECUTION - Static variable in class org.springframework.batch.integration.async.StepExecutionInterceptor
The name of the header
STEP_TYPE_KEY - Static variable in interface org.springframework.batch.core.Step
 
StepBuilder - Class in org.springframework.batch.core.step.builder
Convenient entry point for building all kinds of steps.
StepBuilder(String) - Constructor for class org.springframework.batch.core.step.builder.StepBuilder
Initialize a step builder for a step with the given name.
StepBuilderException - Exception in org.springframework.batch.core.step.builder
Utility exception thrown by builders when they encounter unexpected checked exceptions.
StepBuilderException(Exception) - Constructor for exception org.springframework.batch.core.step.builder.StepBuilderException
 
StepBuilderFactory - Class in org.springframework.batch.core.configuration.annotation
Convenient factory for a StepBuilder which sets the JobRepository and PlatformTransactionManager automatically.
StepBuilderFactory(JobRepository, PlatformTransactionManager) - Constructor for class org.springframework.batch.core.configuration.annotation.StepBuilderFactory
 
StepBuilderHelper<B extends StepBuilderHelper<B>> - Class in org.springframework.batch.core.step.builder
A base class and utility for other step builders providing access to common properties like job repository and transaction manager.
StepBuilderHelper(String) - Constructor for class org.springframework.batch.core.step.builder.StepBuilderHelper
 
StepBuilderHelper(StepBuilderHelper<?>) - Constructor for class org.springframework.batch.core.step.builder.StepBuilderHelper
Create a new builder initialized with any properties in the parent.
StepBuilderHelper.CommonStepProperties - Class in org.springframework.batch.core.step.builder
 
stepBuilders() - Method in class org.springframework.batch.core.configuration.annotation.AbstractBatchConfiguration
 
StepContext - Class in org.springframework.batch.core.scope.context
A context object that can be used to interrogate the current StepExecution and some of its associated properties using expressions based on bean paths.
StepContext(StepExecution) - Constructor for class org.springframework.batch.core.scope.context.StepContext
Create a new instance of StepContext for this StepExecution.
StepContext(StepExecution, BatchPropertyContext) - Constructor for class org.springframework.batch.core.scope.context.StepContext
 
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
 
StepContributionSource - Interface in org.springframework.batch.integration.chunk
A source of StepContribution instances that can be aggregated and used to update an ongoing StepExecution.
StepExecution - Class in org.springframework.batch.core
Batch domain object representation the execution of a step.
StepExecution(String, JobExecution, Long) - Constructor for class org.springframework.batch.core.StepExecution
Constructor with mandatory properties.
StepExecution(String, JobExecution) - Constructor for class org.springframework.batch.core.StepExecution
Constructor that substitutes in null for the execution id
StepExecutionAggregator - Interface in org.springframework.batch.core.partition.support
Strategy for a aggregating step executions, usually when they are the result of partitioned or remote execution.
StepExecutionDao - Interface in org.springframework.batch.core.repository.dao
 
StepExecutionInterceptor - Class in org.springframework.batch.integration.async
A ChannelInterceptor that adds the current StepExecution (if there is one) as a header to the message.
StepExecutionInterceptor() - Constructor for class org.springframework.batch.integration.async.StepExecutionInterceptor
 
StepExecutionListener - Interface in org.springframework.batch.core
Listener interface for the lifecycle of a Step.
stepExecutionListenerMetaData() - Static method in enum org.springframework.batch.core.listener.StepListenerMetaData
 
StepExecutionListenerSupport - Class in org.springframework.batch.core.listener
 
StepExecutionListenerSupport() - Constructor for class org.springframework.batch.core.listener.StepExecutionListenerSupport
 
StepExecutionRequest - Class in org.springframework.batch.integration.partition
Class encapsulating information required to request a step execution in a remote partitioning setup.
StepExecutionRequest(String, Long, Long) - Constructor for class org.springframework.batch.integration.partition.StepExecutionRequest
Create a new StepExecutionRequest instance.
StepExecutionRequestHandler - Class in org.springframework.batch.integration.partition
A MessageEndpoint that can handle a StepExecutionRequest and return a StepExecution as the result.
StepExecutionRequestHandler() - Constructor for class org.springframework.batch.integration.partition.StepExecutionRequestHandler
 
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.
StepFactoryBean<I,O> - Class in org.springframework.batch.core.jsr.configuration.xml
This FactoryBean is used by the JSR-352 namespace parser to create Step objects.
StepFactoryBean() - Constructor for class org.springframework.batch.core.jsr.configuration.xml.StepFactoryBean
 
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
StepListenerAdapter - Class in org.springframework.batch.core.jsr
Wrapper class to adapt the StepListener to a StepExecutionListener.
StepListenerAdapter(StepListener) - Constructor for class org.springframework.batch.core.jsr.StepListenerAdapter
 
StepListenerFactoryBean - Class in org.springframework.batch.core.listener
This AbstractListenerFactoryBean implementation is used to create a StepListener.
StepListenerFactoryBean() - Constructor for class org.springframework.batch.core.listener.StepListenerFactoryBean
 
StepListenerFailedException - Exception in org.springframework.batch.core.listener
Exception to indicate a problem in a step listener.
StepListenerFailedException(String, Throwable) - Constructor for exception org.springframework.batch.core.listener.StepListenerFailedException
 
StepListenerMetaData - Enum in org.springframework.batch.core.listener
Enumeration for StepListener meta data, which ties together the names of methods, their interfaces, annotation, and expected arguments.
StepListenerParser - Class in org.springframework.batch.core.configuration.xml
Parser for a step listener element.
StepListenerParser() - Constructor for class org.springframework.batch.core.configuration.xml.StepListenerParser
 
StepListenerParser(ListenerMetaData[]) - Constructor for class org.springframework.batch.core.configuration.xml.StepListenerParser
 
StepListenerSupport<T,S> - Class in org.springframework.batch.core.listener
Basic no-op implementations of all StepListener interfaces.
StepListenerSupport() - Constructor for class org.springframework.batch.core.listener.StepListenerSupport
 
StepLocator - Interface in org.springframework.batch.core.step
Interface for locating a Step instance by name.
stepLocator - Variable in class org.springframework.batch.core.step.StepLocatorStepFactoryBean
 
stepLocator(StepLocator) - Method in class org.springframework.batch.integration.partition.RemotePartitioningWorkerStepBuilder
Set the step locator used to locate the worker step to execute.
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.
stepOperations(RepeatOperations) - Method in class org.springframework.batch.integration.chunk.RemoteChunkingManagerStepBuilder
 
stepOperations(RepeatOperations) - Method in class org.springframework.batch.integration.chunk.RemoteChunkingMasterStepBuilder
Deprecated.
 
StepParser - Class in org.springframework.batch.core.jsr.configuration.xml
Parser for the <step /> element defined by JSR-352.
StepParser() - Constructor for class org.springframework.batch.core.jsr.configuration.xml.StepParser
 
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 defined in a Job.
StepRunner - Class in org.springframework.batch.test
Utility class for executing steps outside of a Job.
StepRunner(JobLauncher, JobRepository) - Constructor for class org.springframework.batch.test.StepRunner
 
StepScope - Annotation Type in org.springframework.batch.core.configuration.annotation
Convenient annotation for step scoped beans that defaults the proxy mode, so that it doesn't have to be specified explicitly on every bean definition.
StepScope - Class in org.springframework.batch.core.scope
Scope for step context.
StepScope() - Constructor for class org.springframework.batch.core.scope.StepScope
 
StepScopeManager - Class in org.springframework.batch.core.scope.context
Convenient aspect to wrap a single threaded step execution, where the implementation of the Step is not step scope aware (i.e.
StepScopeManager() - Constructor for class org.springframework.batch.core.scope.context.StepScopeManager
 
StepScopeTestExecutionListener - Class in org.springframework.batch.test
A TestExecutionListener that sets up step-scope context for dependency injection into unit tests.
StepScopeTestExecutionListener() - Constructor for class org.springframework.batch.test.StepScopeTestExecutionListener
 
StepScopeTestUtils - Class in org.springframework.batch.test
Utility class for creating and manipulating StepScope in unit tests.
StepScopeTestUtils() - Constructor for class org.springframework.batch.test.StepScopeTestUtils
 
StepState - Class in org.springframework.batch.core.job.flow.support.state
State implementation that delegates to a FlowExecutor to execute the specified Step.
StepState(Step) - Constructor for class org.springframework.batch.core.job.flow.support.state.StepState
 
StepState(String, Step) - Constructor for class org.springframework.batch.core.job.flow.support.state.StepState
 
StepSynchronizationManager - Class in org.springframework.batch.core.scope.context
Central convenience class for framework use in managing the step scope context.
StepSynchronizationManager() - Constructor for class org.springframework.batch.core.scope.context.StepSynchronizationManager
 
stop() - Method in class org.springframework.batch.core.configuration.support.AutomaticJobRegistrar
Delegates to JobLoader.clear().
stop(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() - Method in class org.springframework.batch.core.job.builder.FlowBuilder.TransitionBuilder
Signal the successful end of the flow.
stop() - Method in class org.springframework.batch.core.JobExecution
Deprecated.
Use JobOperator.stop(long) or CommandLineJobRunner with the "-stop" option instead.
stop(long) - Method in class org.springframework.batch.core.jsr.launch.JsrJobOperator
Stops the running job execution if it is currently running.
stop() - Method in class org.springframework.batch.core.jsr.step.batchlet.BatchletAdapter
 
stop(long) - Method in interface org.springframework.batch.core.launch.JobOperator
Send a stop signal to the JobExecution with the supplied id.
stop() - Static method in class org.springframework.batch.core.launch.support.JobRegistryBackgroundJobRunner
If embedded in a JVM, call this method to terminate the main method.
stop(long) - Method in class org.springframework.batch.core.launch.support.SimpleJobOperator
 
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_ELE - Static variable in class org.springframework.batch.core.configuration.xml.AbstractFlowParser
 
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.
stopCloseSuppression(Connection) - Method in class org.springframework.batch.item.database.ExtendedConnectionDataSourceProxy
 
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 - 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.
stopTimer(Timer.Sample, StepExecution, String, String, String) - Method in class org.springframework.batch.core.step.item.SimpleChunkProcessor
 
StoredProcedureItemReader<T> - Class in org.springframework.batch.item.database
Item reader implementation that executes a stored procedure and then reads the returned cursor and continually retrieves the next row in the ResultSet.
StoredProcedureItemReader() - Constructor for class org.springframework.batch.item.database.StoredProcedureItemReader
 
StoredProcedureItemReaderBuilder<T> - Class in org.springframework.batch.item.database.builder
A fluent builder API for the configuration of a StoredProcedureItemReader.
StoredProcedureItemReaderBuilder() - Constructor for class org.springframework.batch.item.database.builder.StoredProcedureItemReaderBuilder
 
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
 
stream(ItemStream) - Method in class org.springframework.batch.integration.chunk.RemoteChunkingManagerStepBuilder
 
stream(ItemStream) - Method in class org.springframework.batch.integration.chunk.RemoteChunkingMasterStepBuilder
Deprecated.
 
strict(boolean) - Method in class org.springframework.batch.item.file.builder.FlatFileItemReaderBuilder.FixedLengthBuilder
Boolean indicating if the number of tokens in a line must match the number of fields (ranges) configured.
strict(boolean) - Method in class org.springframework.batch.item.file.builder.FlatFileItemReaderBuilder
Configure if the reader should be in strict mode (require the input Resource to exist).
strict(boolean) - Method in class org.springframework.batch.item.json.builder.JsonItemReaderBuilder
Setting this value to true indicates that it is an error if the input does not exist and an exception will be thrown.
strict(boolean) - Method in class org.springframework.batch.item.ldif.builder.LdifReaderBuilder
In strict mode the reader will throw an exception on AbstractItemCountingItemStreamItemReader.open(org.springframework.batch.item.ExecutionContext) if the input resource does not exist.
strict(boolean) - Method in class org.springframework.batch.item.ldif.builder.MappingLdifReaderBuilder
In strict mode the reader will throw an exception on AbstractItemCountingItemStreamItemReader.open(org.springframework.batch.item.ExecutionContext) if the input resource does not exist.
strict(boolean) - Method in class org.springframework.batch.item.xml.builder.StaxEventItemReaderBuilder
Setting this value to true indicates that it is an error if the input does not exist and an exception will be thrown.
STRING_TYPE - Static variable in class org.springframework.batch.core.converter.DefaultJobParametersConverter
 
stringToProperties(String) - Static method in class org.springframework.batch.support.PropertiesConverter
Parse a String to a Properties object.
SuffixRecordSeparatorPolicy - Class in org.springframework.batch.item.file.separator
A RecordSeparatorPolicy that looks for an exact match for a String at the end of a line (e.g.
SuffixRecordSeparatorPolicy() - Constructor for class org.springframework.batch.item.file.separator.SuffixRecordSeparatorPolicy
 
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.
SybasePagingQueryProvider - Class in org.springframework.batch.item.database.support
Sybase implementation of a PagingQueryProvider using database specific features.
SybasePagingQueryProvider() - Constructor for class org.springframework.batch.item.database.support.SybasePagingQueryProvider
 
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
 
SynchronizedAttributeAccessor - Class in org.springframework.batch.repeat.context
An AttributeAccessor that synchronizes on a mutex (not this) before modifying or accessing the underlying attributes.
SynchronizedAttributeAccessor() - Constructor for class org.springframework.batch.repeat.context.SynchronizedAttributeAccessor
 
SynchronizedItemStreamReader<T> - Class in org.springframework.batch.item.support
This is a simple ItemStreamReader decorator with a synchronized ItemReader.read() method - which makes a non-thread-safe ItemReader thread-safe.
SynchronizedItemStreamReader() - Constructor for class org.springframework.batch.item.support.SynchronizedItemStreamReader
 
SynchronizedItemStreamReaderBuilder<T> - Class in org.springframework.batch.item.support.builder
Creates a fully qualified SynchronizedItemStreamReader.
SynchronizedItemStreamReaderBuilder() - Constructor for class org.springframework.batch.item.support.builder.SynchronizedItemStreamReaderBuilder
 
SynchronizedItemStreamWriter<T> - Class in org.springframework.batch.item.support
An ItemStreamWriter decorator with a synchronized write() method.
SynchronizedItemStreamWriter() - Constructor for class org.springframework.batch.item.support.SynchronizedItemStreamWriter
 
SynchronizedItemStreamWriterBuilder<T> - Class in org.springframework.batch.item.support.builder
Creates a fully qualified SynchronizedItemStreamWriter.
SynchronizedItemStreamWriterBuilder() - Constructor for class org.springframework.batch.item.support.builder.SynchronizedItemStreamWriterBuilder
 
synchronizeStatus(JobExecution) - Method in class org.springframework.batch.core.repository.dao.JdbcJobExecutionDao
 
synchronizeStatus(JobExecution) - Method in interface org.springframework.batch.core.repository.dao.JobExecutionDao
Because it may be possible that the status of a JobExecution is updated while running, the following method will synchronize only the status and version fields.
synchronizeStatus(JobExecution) - Method in class org.springframework.batch.core.repository.dao.MapJobExecutionDao
Deprecated.
 
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.
SystemPropertyInitializer - Class in org.springframework.batch.support
Helper class that sets up a System property with a default value.
SystemPropertyInitializer() - Constructor for class org.springframework.batch.support.SystemPropertyInitializer
 

T

tablePrefix - Variable in class org.springframework.batch.core.jsr.JsrJobParametersConverter
 
take() - Method in class org.springframework.batch.repeat.support.ResultHolderResultQueue
Get the next result as soon as it becomes available.
take() - Method in class org.springframework.batch.repeat.support.ThrottleLimitResultQueue
 
targetType(Class<? extends T>) - Method in class org.springframework.batch.item.data.builder.MongoItemReaderBuilder
The type of object to be returned for each AbstractItemCountingItemStreamItemReader.read() call.
targetType(Class<T>) - Method in class org.springframework.batch.item.data.builder.Neo4jItemReaderBuilder
The object type to be returned from each call to AbstractItemCountingItemStreamItemReader.read()
targetType(Class<? extends T>) - Method in class org.springframework.batch.item.file.builder.FlatFileItemReaderBuilder
The class that will represent the "item" to be returned from the reader.
taskExecutor(TaskExecutor) - Method in class org.springframework.batch.core.step.builder.AbstractTaskletStepBuilder
Provide a task executor to use when executing the tasklet.
taskExecutor(TaskExecutor) - Method in class org.springframework.batch.core.step.builder.PartitionStepBuilder
Provide a task executor to use when constructing a PartitionHandler from the PartitionStepBuilder.step(Step).
TaskExecutorPartitionHandler - Class in org.springframework.batch.core.partition.support
A PartitionHandler that uses a TaskExecutor to execute the partitioned Step locally in multiple threads.
TaskExecutorPartitionHandler() - Constructor for class org.springframework.batch.core.partition.support.TaskExecutorPartitionHandler
 
TaskExecutorRepeatTemplate - Class in org.springframework.batch.repeat.support
Provides RepeatOperations support including interceptors that can be used to modify or monitor the behaviour at run time.
This implementation is sufficient to be used to configure transactional behaviour for each item by making the RepeatCallback transactional, or for the whole batch by making the execute method transactional (but only then if the task executor is synchronous).
This class is thread-safe if its collaborators are thread-safe (interceptors, terminationPolicy, callback).
TaskExecutorRepeatTemplate() - Constructor for class org.springframework.batch.repeat.support.TaskExecutorRepeatTemplate
 
tasklet(Tasklet) - Method in class org.springframework.batch.core.step.builder.StepBuilder
Build a step with a custom tasklet, not necessarily item processing.
tasklet(Tasklet) - Method in class org.springframework.batch.core.step.builder.TaskletStepBuilder
 
Tasklet - Interface in org.springframework.batch.core.step.tasklet
Strategy for processing in a step.
tasklet(Tasklet) - Method in class org.springframework.batch.integration.partition.RemotePartitioningWorkerStepBuilder
 
TASKLET_TYPE_KEY - Static variable in class org.springframework.batch.core.step.tasklet.TaskletStep
 
taskletListenerMetaData() - Static method in enum org.springframework.batch.core.listener.StepListenerMetaData
 
TaskletParser - Class in org.springframework.batch.core.configuration.xml
Parse a tasklet element for a step.
TaskletParser() - Constructor for class org.springframework.batch.core.configuration.xml.TaskletParser
 
TaskletStep - Class in org.springframework.batch.core.step.tasklet
Simple implementation of executing the step as a call to a Tasklet, possibly repeated, and each call surrounded by a transaction.
TaskletStep() - Constructor for class org.springframework.batch.core.step.tasklet.TaskletStep
Default constructor.
TaskletStep(String) - Constructor for class org.springframework.batch.core.step.tasklet.TaskletStep
 
TaskletStepBuilder - Class in org.springframework.batch.core.step.builder
Builder for tasklet step based on a custom tasklet (not item oriented).
TaskletStepBuilder(StepBuilderHelper<?>) - Constructor for class org.springframework.batch.core.step.builder.TaskletStepBuilder
Create a new builder initialized with any properties in the parent.
template(GemfireTemplate) - Method in class org.springframework.batch.item.data.builder.GemfireItemWriterBuilder
Establishes the GemfireTemplate the writer should use.
template(MongoOperations) - Method in class org.springframework.batch.item.data.builder.MongoItemReaderBuilder
Used to perform operations against the MongoDB instance.
template(MongoOperations) - Method in class org.springframework.batch.item.data.builder.MongoItemWriterBuilder
Set the MongoOperations to be used to save items to be written.
testing - Static variable in class org.springframework.batch.core.launch.support.JobRegistryBackgroundJobRunner
 
ThreadLocalClassloaderBeanPostProcessor - Class in org.springframework.batch.core.jsr.configuration.support
After the BeanFactory is created, this post processor will evaluate to see if any of the beans referenced from a job definition (as defined by JSR-352) point to class names instead of bean names.
ThreadLocalClassloaderBeanPostProcessor() - Constructor for class org.springframework.batch.core.jsr.configuration.support.ThreadLocalClassloaderBeanPostProcessor
 
ThreadStepInterruptionPolicy - Class in org.springframework.batch.core.step
Policy that checks the current thread to see if it has been interrupted.
ThreadStepInterruptionPolicy() - Constructor for class org.springframework.batch.core.step.ThreadStepInterruptionPolicy
 
throttleLimit(int) - Method in class org.springframework.batch.core.step.builder.AbstractTaskletStepBuilder
In the case of an asynchronous AbstractTaskletStepBuilder.taskExecutor(TaskExecutor) the number of concurrent tasklet executions can be throttled (beyond any throttling provided by a thread pool).
throttleLimit(long) - Method in class org.springframework.batch.integration.chunk.RemoteChunkingManagerStepBuilder
Public setter for the throttle limit.
throttleLimit(long) - Method in class org.springframework.batch.integration.chunk.RemoteChunkingMasterStepBuilder
Deprecated.
Public setter for the throttle limit.
ThrottleLimitResultQueue<T> - Class in org.springframework.batch.repeat.support
An implementation of the ResultQueue that throttles the number of expected results, limiting it to a maximum at any given time.
ThrottleLimitResultQueue(int) - Constructor for class org.springframework.batch.repeat.support.ThrottleLimitResultQueue
 
timeout(long) - Method in class org.springframework.batch.integration.partition.RemotePartitioningManagerStepBuilder
When using job repository polling, the time limit to wait.
timeout(long) - Method in class org.springframework.batch.integration.partition.RemotePartitioningMasterStepBuilder
Deprecated.
When using job repository polling, the time limit to wait.
timeout(long) - Method in class org.springframework.batch.item.kafka.builder.KafkaItemWriterBuilder
The time limit to wait when flushing items to Kafka.
TimeoutBatchContext(RepeatContext) - Constructor for class org.springframework.batch.repeat.policy.TimeoutTerminationPolicy.TimeoutBatchContext
 
TimeoutTerminationPolicy - Class in org.springframework.batch.repeat.policy
Termination policy that times out after a fixed period.
TimeoutTerminationPolicy() - Constructor for class org.springframework.batch.repeat.policy.TimeoutTerminationPolicy
Default constructor.
TimeoutTerminationPolicy(long) - Constructor for class org.springframework.batch.repeat.policy.TimeoutTerminationPolicy
Construct a TimeoutTerminationPolicy with the specified timeout value (in milliseconds).
TimeoutTerminationPolicy.TimeoutBatchContext - Class in org.springframework.batch.repeat.policy
 
to(Step) - Method in class org.springframework.batch.core.job.builder.FlowBuilder.TransitionBuilder
Specify the next step.
to(Flow) - Method in class org.springframework.batch.core.job.builder.FlowBuilder.TransitionBuilder
Specify the next state as a complete flow.
to(JobExecutionDecider) - Method in class org.springframework.batch.core.job.builder.FlowBuilder.TransitionBuilder
Specify the next state as a decision.
TO_ATTR - Static variable in class org.springframework.batch.core.configuration.xml.AbstractFlowParser
 
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.
tokenize(String) - Method in class org.springframework.batch.item.file.transform.AbstractLineTokenizer
Yields the tokens resulting from the splitting of the supplied line.
tokenize(String) - Method in interface org.springframework.batch.item.file.transform.LineTokenizer
Yields the tokens resulting from the splitting of the supplied line.
tokenize(String) - Method in class org.springframework.batch.item.file.transform.PatternMatchingCompositeLineTokenizer
 
topic(String) - Method in class org.springframework.batch.item.kafka.builder.KafkaItemReaderBuilder
A topic name to manually assign to the consumer.
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
 
toString() - Method in class org.springframework.batch.core.configuration.support.AbstractApplicationContextFactory
 
toString() - Method in class org.springframework.batch.core.configuration.support.GroupAwareJob
 
toString() - Method in class org.springframework.batch.core.Entity
 
toString() - Method in class org.springframework.batch.core.ExitStatus
 
toString() - Method in class org.springframework.batch.core.job.AbstractJob
 
toString() - Method in class org.springframework.batch.core.job.flow.FlowExecution
 
toString() - Method in class org.springframework.batch.core.job.flow.FlowExecutionStatus
 
toString() - Method in class org.springframework.batch.core.job.flow.support.state.AbstractState
 
toString() - Method in class org.springframework.batch.core.job.flow.support.state.EndState
 
toString() - Method in class org.springframework.batch.core.job.flow.support.StateTransition
 
toString() - Method in class org.springframework.batch.core.JobExecution
 
toString() - Method in class org.springframework.batch.core.JobInstance
 
toString() - Method in class org.springframework.batch.core.JobParameter
 
toString() - Method in class org.springframework.batch.core.JobParameters
 
toString() - Method in class org.springframework.batch.core.resource.StepExecutionSimpleCompletionPolicy
Delegates to the wrapped CompletionPolicy if set, otherwise returns the value of StepExecutionSimpleCompletionPolicy.setKeyName(String).
toString() - Method in class org.springframework.batch.core.scope.context.ChunkContext
 
toString() - Method in class org.springframework.batch.core.scope.context.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.step.item.Chunk.ChunkIterator
 
toString() - Method in class org.springframework.batch.core.step.item.Chunk
 
toString() - Method in class org.springframework.batch.core.step.item.SkipWrapper
 
toString() - Method in class org.springframework.batch.core.StepContribution
 
toString() - Method in class org.springframework.batch.core.StepExecution
 
toString() - Method in class org.springframework.batch.integration.chunk.ChunkRequest
 
toString() - Method in class org.springframework.batch.integration.chunk.ChunkResponse
 
toString() - Method in class org.springframework.batch.integration.launch.JobLaunchRequest
 
toString() - Method in class org.springframework.batch.integration.partition.StepExecutionRequest
 
toString() - Method in class org.springframework.batch.item.ExecutionContext
 
toString() - Method in class org.springframework.batch.item.file.transform.DefaultFieldSet
 
toString() - Method in class org.springframework.batch.item.file.transform.Range
 
toString() - Method in class org.springframework.batch.repeat.context.SynchronizedAttributeAccessor
 
toString() - Method in class org.springframework.batch.repeat.policy.SimpleCompletionPolicy
 
transacted(boolean) - Method in class org.springframework.batch.item.database.builder.JpaPagingItemReaderBuilder
Indicates if a transaction should be created around the read (true by default).
transactional(boolean) - Method in class org.springframework.batch.item.file.builder.FlatFileItemWriterBuilder
If set to true, the flushing of the buffer is delayed while a transaction is active.
transactional(boolean) - Method in class org.springframework.batch.item.json.builder.JsonFileItemWriterBuilder
If set to true, the flushing of the buffer is delayed while a transaction is active.
transactional(boolean) - Method in class org.springframework.batch.item.xml.builder.StaxEventItemWriterBuilder
The resulting writer is participating in a transaction and writes should be delayed as late as possible.
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
 
transactionAttribute(TransactionAttribute) - Method in class org.springframework.batch.integration.chunk.RemoteChunkingManagerStepBuilder
 
transactionAttribute(TransactionAttribute) - Method in class org.springframework.batch.integration.chunk.RemoteChunkingMasterStepBuilder
Deprecated.
 
TransactionAwareBufferedWriter - Class in org.springframework.batch.support.transaction
Wrapper for a FileChannel that delays actually writing to or closing the buffer if a transaction is active.
TransactionAwareBufferedWriter(FileChannel, Runnable) - Constructor for class org.springframework.batch.support.transaction.TransactionAwareBufferedWriter
Create a new instance with the underlying file channel provided, and a callback to execute on close.
TransactionAwareProxyFactory<T> - Class in org.springframework.batch.support.transaction
Factory for transaction aware objects (like lists, sets, maps).
transactionManager() - Method in class org.springframework.batch.core.configuration.annotation.AbstractBatchConfiguration
 
transactionManager() - Method in class org.springframework.batch.core.configuration.annotation.ModularBatchConfiguration
 
transactionManager() - Method in class org.springframework.batch.core.configuration.annotation.SimpleBatchConfiguration
 
transactionManager(PlatformTransactionManager) - Method in class org.springframework.batch.core.step.builder.StepBuilderHelper
 
transactionManager(PlatformTransactionManager) - Method in class org.springframework.batch.integration.chunk.RemoteChunkingManagerStepBuilder
 
transactionManager(PlatformTransactionManager) - Method in class org.springframework.batch.integration.chunk.RemoteChunkingMasterStepBuilder
Deprecated.
 
transactionManager(PlatformTransactionManager) - Method in class org.springframework.batch.integration.partition.RemotePartitioningManagerStepBuilder
 
transactionManager(PlatformTransactionManager) - Method in class org.springframework.batch.integration.partition.RemotePartitioningMasterStepBuilder
Deprecated.
 
transactionManager(PlatformTransactionManager) - Method in class org.springframework.batch.integration.partition.RemotePartitioningWorkerStepBuilder
 
transform(StepContribution, I) - Method in class org.springframework.batch.core.jsr.step.item.JsrChunkProcessor
Responsible for the processing portion of the chunking loop.
transform(StepContribution, I) - Method in class org.springframework.batch.core.jsr.step.item.JsrFaultTolerantChunkProcessor
Adds retry and skip logic to the process phase of the chunk loop.
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
 
translateSqlException(String, String, SQLException) - Method in class org.springframework.batch.item.database.AbstractCursorItemReader
 
truncate() - Method in class org.springframework.batch.item.support.AbstractFileItemWriter.OutputState
Truncate the output at the last known good point.
type(Class<T>) - Method in class org.springframework.batch.item.avro.builder.AvroItemReaderBuilder
Configure a type to be deserialized.
type(Class<T>) - Method in class org.springframework.batch.item.avro.builder.AvroItemWriterBuilder
 

U

unbind(JobFactory, Map<String, ?>) - Method in class org.springframework.batch.core.configuration.support.JobFactoryRegistrationListener
Take the JobFactory provided and unregister it with the JobRegistry.
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
 
UnclosedElementCollectingEventWriter - Class in org.springframework.batch.item.xml.stax
Delegating XMLEventWriter, which collects the QNames of elements that were opened but not closed.
UnclosedElementCollectingEventWriter(XMLEventWriter) - Constructor for class org.springframework.batch.item.xml.stax.UnclosedElementCollectingEventWriter
 
UnexpectedInputException - Exception in org.springframework.batch.item
Used to signal an unexpected end of an input or message stream.
UnexpectedInputException(String) - Constructor for exception org.springframework.batch.item.UnexpectedInputException
Create a new UnexpectedInputException based on a message.
UnexpectedInputException(String, Throwable) - Constructor for exception org.springframework.batch.item.UnexpectedInputException
Create a new UnexpectedInputException based on a message and another exception.
UnexpectedJobExecutionException - Exception in org.springframework.batch.core
Indicates to the framework that a critical error has occurred and processing should immediately stop.
UnexpectedJobExecutionException(String) - Constructor for exception org.springframework.batch.core.UnexpectedJobExecutionException
Constructs a new instance with a message.
UnexpectedJobExecutionException(String, Throwable) - Constructor for exception org.springframework.batch.core.UnexpectedJobExecutionException
Constructs a new instance with a message.
UNKNOWN - Static variable in class org.springframework.batch.core.ExitStatus
Convenient constant value representing unknown state - assumed not continuable.
UNKNOWN - Static variable in class org.springframework.batch.core.job.flow.FlowExecutionStatus
Special well-known status value.
unmarshaller(Unmarshaller) - Method in class org.springframework.batch.item.xml.builder.StaxEventItemReaderBuilder
An implementation of the Unmarshaller from Spring's OXM module.
UnopenedElementClosingEventWriter - Class in org.springframework.batch.item.xml.stax
Delegating XMLEventWriter, which writes EndElement events that match a given collection of QNames directly to the underlying java.io.Writer instead of to the delegate XMLEventWriter.
UnopenedElementClosingEventWriter(XMLEventWriter, Writer, List<QName>) - Constructor for class org.springframework.batch.item.xml.stax.UnopenedElementClosingEventWriter
 
unregister(String) - Method in interface org.springframework.batch.core.configuration.JobRegistry
Unregisters a previously registered Job.
unregister(String) - Method in class org.springframework.batch.core.configuration.support.MapJobRegistry
 
unregisterStepsFromJob(String) - Method in interface org.springframework.batch.core.configuration.StepRegistry
Unregisters all the steps of the given job.
unregisterStepsFromJob(String) - Method in class org.springframework.batch.core.configuration.support.MapStepRegistry
 
UnterminatedFlowBuilder(FlowBuilder<Q>) - Constructor for class org.springframework.batch.core.job.builder.FlowBuilder.UnterminatedFlowBuilder
 
unwrap(Class<T>) - Method in class org.springframework.batch.item.database.ExtendedConnectionDataSourceProxy
Returns either self or delegate (in this order) if one of them can be cast to supplied parameter class.
update(JobExecution) - Method in interface org.springframework.batch.core.repository.JobRepository
Update the JobExecution (but not its ExecutionContext).
update(StepExecution) - Method in interface org.springframework.batch.core.repository.JobRepository
Update the StepExecution (but not its ExecutionContext).
update(JobExecution) - Method in class org.springframework.batch.core.repository.support.SimpleJobRepository
 
update(StepExecution) - Method in class org.springframework.batch.core.repository.support.SimpleJobRepository
 
update(RepeatContext) - Method in class org.springframework.batch.core.resource.StepExecutionSimpleCompletionPolicy
 
update(ExecutionContext) - Method in class org.springframework.batch.core.step.item.ChunkMonitor
 
update(ExecutionContext) - Method in class org.springframework.batch.integration.async.AsyncItemWriter
 
update(ExecutionContext) - Method in class org.springframework.batch.integration.chunk.ChunkMessageChannelItemWriter
 
update(ExecutionContext) - Method in class org.springframework.batch.item.database.HibernateCursorItemReader
Update the context and clear the session if stateful.
update(ExecutionContext) - Method in class org.springframework.batch.item.database.JdbcPagingItemReader
 
update(ExecutionContext) - Method in class org.springframework.batch.item.database.JpaCursorItemReader
 
update(ExecutionContext) - Method in class org.springframework.batch.item.file.MultiResourceItemReader
Store the current resource index and position in the resource.
update(ExecutionContext) - Method in class org.springframework.batch.item.file.MultiResourceItemWriter
 
update(ExecutionContext) - Method in class org.springframework.batch.item.file.ResourcesItemReader
 
update(ExecutionContext) - Method in interface org.springframework.batch.item.ItemStream
Indicates that the execution context provided during open is about to be saved.
update(ExecutionContext) - Method in class org.springframework.batch.item.ItemStreamSupport
Return empty ExecutionContext.
update(ExecutionContext) - Method in class org.springframework.batch.item.kafka.KafkaItemReader
 
update(ExecutionContext) - Method in class org.springframework.batch.item.support.AbstractFileItemWriter
 
update(ExecutionContext) - Method in class org.springframework.batch.item.support.AbstractItemCountingItemStreamItemReader
 
update(ExecutionContext) - Method in class org.springframework.batch.item.support.CompositeItemStream
Simple aggregate ExecutionContext provider for the contributions registered under the given key.
update(ExecutionContext) - Method in class org.springframework.batch.item.support.CompositeItemWriter
 
update(ExecutionContext) - Method in class org.springframework.batch.item.support.SingleItemPeekableItemReader
If there is a cached peek, then retrieve the execution context state from that point.
update(ExecutionContext) - Method in class org.springframework.batch.item.support.SynchronizedItemStreamReader
 
update(ExecutionContext) - Method in class org.springframework.batch.item.support.SynchronizedItemStreamWriter
 
update(ExecutionContext) - Method in class org.springframework.batch.item.xml.StaxEventItemWriter
Get the restart data.
update(ExecutionContext) - Method in class org.springframework.batch.jsr.item.CheckpointSupport
 
update(RepeatContext) - Method in class org.springframework.batch.jsr.repeat.CheckpointAlgorithmAdapter
If CheckpointAlgorithm.isReadyToCheckpoint() is true we will call CheckpointAlgorithm.endCheckpoint()
update(RepeatContext) - Method in interface org.springframework.batch.repeat.CompletionPolicy
Give implementations the opportunity to update the state of the current batch.
update(RepeatContext) - Method in class org.springframework.batch.repeat.policy.CompletionPolicySupport
Increment the context so the counter is up to date.
update(RepeatContext) - Method in class org.springframework.batch.repeat.policy.CompositeCompletionPolicy
Update all the composed contexts, and also increment the parent context.
update(RepeatContext) - Method in class org.springframework.batch.repeat.policy.CountingCompletionPolicy
 
update() - Method in class org.springframework.batch.repeat.policy.SimpleCompletionPolicy.SimpleTerminationContext
 
update(RepeatContext) - Method in class org.springframework.batch.repeat.policy.SimpleCompletionPolicy
Increment the counter in the context.
update(RepeatContext) - Method in class org.springframework.batch.repeat.support.RepeatTemplate
Delegate to the CompletionPolicy.
updateExecutionContext(JobExecution) - Method in interface org.springframework.batch.core.repository.dao.ExecutionContextDao
Persist the updates of execution context associated with the given jobExecution.
updateExecutionContext(StepExecution) - Method in interface org.springframework.batch.core.repository.dao.ExecutionContextDao
Persist the updates of execution context associated with the given stepExecution.
updateExecutionContext(JobExecution) - Method in class org.springframework.batch.core.repository.dao.JdbcExecutionContextDao
 
updateExecutionContext(StepExecution) - Method in class org.springframework.batch.core.repository.dao.JdbcExecutionContextDao
 
updateExecutionContext(StepExecution) - Method in class org.springframework.batch.core.repository.dao.MapExecutionContextDao
Deprecated.
 
updateExecutionContext(JobExecution) - Method in class org.springframework.batch.core.repository.dao.MapExecutionContextDao
Deprecated.
 
updateExecutionContext(StepExecution) - Method in interface org.springframework.batch.core.repository.JobRepository
Persist the updated ExecutionContexts of the given StepExecution.
updateExecutionContext(JobExecution) - Method in interface org.springframework.batch.core.repository.JobRepository
Persist the updated ExecutionContext of the given JobExecution.
updateExecutionContext(StepExecution) - Method in class org.springframework.batch.core.repository.support.SimpleJobRepository
 
updateExecutionContext(JobExecution) - Method in class org.springframework.batch.core.repository.support.SimpleJobRepository
 
updateJobExecution(JobExecution) - Method in class org.springframework.batch.core.repository.dao.JdbcJobExecutionDao
Update given JobExecution using a SQL UPDATE statement.
updateJobExecution(JobExecution) - Method in interface org.springframework.batch.core.repository.dao.JobExecutionDao
Update and existing JobExecution.
updateJobExecution(JobExecution) - Method in class org.springframework.batch.core.repository.dao.MapJobExecutionDao
Deprecated.
 
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
 
updateJobExecutionStatus(FlowExecutionStatus) - Method in class org.springframework.batch.core.jsr.job.flow.JsrFlowExecutor
 
updateStepContribution(StepContribution, StepContributionSource) - Method in class org.springframework.batch.integration.chunk.RemoteChunkHandlerFactoryBean
Update a StepContribution with all the data from a StepContributionSource.
updateStepExecution(StepExecution) - Method in class org.springframework.batch.core.repository.dao.JdbcStepExecutionDao
 
updateStepExecution(StepExecution) - Method in class org.springframework.batch.core.repository.dao.MapStepExecutionDao
Deprecated.
 
updateStepExecution(StepExecution) - Method in interface org.springframework.batch.core.repository.dao.StepExecutionDao
Update the given StepExecution Preconditions: Id must not be null.
upgradeStatus(BatchStatus) - Method in class org.springframework.batch.core.JobExecution
Upgrade the status field if the provided value is greater than the existing one.
upgradeStatus(BatchStatus) - Method in class org.springframework.batch.core.StepExecution
Upgrade the status field if the provided value is greater than the existing one.
upgradeTo(BatchStatus) - Method in enum org.springframework.batch.core.BatchStatus
Method used to move status values through their logical progression, and override less severe failures with more severe ones.
UPPER_BORDER_NOT_DEFINED - Static variable in class org.springframework.batch.item.file.transform.Range
 
usePersist(boolean) - Method in class org.springframework.batch.item.database.builder.JpaItemWriterBuilder
Set whether the entity manager should perform a persist instead of a merge.
useSatelessSession(boolean) - Method in class org.springframework.batch.item.database.builder.HibernatePagingItemReaderBuilder
Deprecated.
This method is deprecated in favor of HibernatePagingItemReaderBuilder.useStatelessSession(boolean) and will be removed in a future version.
useSharedExtendedConnection(boolean) - Method in class org.springframework.batch.item.database.builder.JdbcCursorItemReaderBuilder
Indicates that the connection used for the cursor is being used by all other processing, therefor part of the same transaction.
useSharedExtendedConnection(boolean) - Method in class org.springframework.batch.item.database.builder.StoredProcedureItemReaderBuilder
Indicates that the connection used for the cursor is being used by all other processing, therefor part of the same transaction.
useStatelessSession(boolean) - Method in class org.springframework.batch.item.database.builder.HibernateCursorItemReaderBuilder
Indicator for whether to use a StatelessSession (true) or a Session (false).
useStatelessSession(boolean) - Method in class org.springframework.batch.item.database.builder.HibernatePagingItemReaderBuilder
Indicator for whether to use a StatelessSession (true) or a Session (false).
usingNamedParameters - Variable in class org.springframework.batch.item.database.JdbcBatchItemWriter
 

V

validate(JobParameters) - Method in class org.springframework.batch.core.job.CompositeJobParametersValidator
Validates the JobParameters according to the injected JobParameterValidators Validation stops and exception is thrown on first validation error
validate(JobParameters) - Method in class org.springframework.batch.core.job.DefaultJobParametersValidator
Check the parameters meet the specification provided.
validate(JobParameters) - Method in interface org.springframework.batch.core.JobParametersValidator
Check the parameters meet whatever requirements are appropriate, and throw an exception if not.
validate(T) - Method in class org.springframework.batch.item.validator.SpringValidator
 
validate(T) - Method in interface org.springframework.batch.item.validator.Validator
Method used to validate if the value is valid.
validateFaultTolerantSettings() - Method in class org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
Validates that all components required to build a fault tolerant step are set
ValidatingItemProcessor<T> - Class in org.springframework.batch.item.validator
Simple implementation of ItemProcessor that validates input and returns it without modifications.
ValidatingItemProcessor() - Constructor for class org.springframework.batch.item.validator.ValidatingItemProcessor
Default constructor
ValidatingItemProcessor(Validator<? super T>) - Constructor for class org.springframework.batch.item.validator.ValidatingItemProcessor
Creates a ValidatingItemProcessor based on the given Validator.
ValidationException - Exception in org.springframework.batch.item.validator
This exception should be thrown when there are validation errors.
ValidationException(String, Throwable) - Constructor for exception org.springframework.batch.item.validator.ValidationException
Create a new ValidationException based on a message and another exception.
ValidationException(String) - Constructor for exception org.springframework.batch.item.validator.ValidationException
Create a new ValidationException based on a message.
validator(JobParametersValidator) - Method in class org.springframework.batch.core.job.builder.JobBuilderHelper
Add a job parameters validator.
Validator<T> - Interface in org.springframework.batch.item.validator
Interface used to validate objects.
VALUE_NOT_SET - Static variable in class org.springframework.batch.item.database.AbstractCursorItemReader
 
VALUE_NOT_SET - Static variable in class org.springframework.batch.item.database.builder.StoredProcedureItemReaderBuilder
 
VALUE_NOT_SET - Static variable in class org.springframework.batch.item.database.JdbcPagingItemReader
 
valueOf(String) - Static method in enum org.springframework.batch.core.BatchStatus
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.springframework.batch.core.JobParameter.ParameterType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.springframework.batch.core.jsr.configuration.support.BatchArtifactType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.springframework.batch.core.jsr.JsrJobListenerMetaData
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.springframework.batch.core.jsr.JsrStepListenerMetaData
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.springframework.batch.core.listener.JobListenerMetaData
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.springframework.batch.core.listener.StepListenerMetaData
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.springframework.batch.item.database.Order
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.springframework.batch.item.file.transform.Alignment
Deprecated.
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.springframework.batch.repeat.exception.LogOrRethrowExceptionHandler.Level
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.springframework.batch.repeat.RepeatStatus
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.springframework.batch.support.DatabaseType
Returns the enum constant of this type with the specified name.
values() - Static method in enum org.springframework.batch.core.BatchStatus
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.springframework.batch.core.JobParameter.ParameterType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.springframework.batch.core.jsr.configuration.support.BatchArtifactType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.springframework.batch.core.jsr.JsrJobListenerMetaData
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.springframework.batch.core.jsr.JsrStepListenerMetaData
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.springframework.batch.core.listener.JobListenerMetaData
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.springframework.batch.core.listener.StepListenerMetaData
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.springframework.batch.item.database.Order
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.springframework.batch.item.file.transform.Alignment
Deprecated.
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.springframework.batch.repeat.exception.LogOrRethrowExceptionHandler.Level
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.springframework.batch.repeat.RepeatStatus
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.springframework.batch.support.DatabaseType
Returns an array containing the constants of this enum type, in the order they are declared.
verifyCursorPosition(boolean) - Method in class org.springframework.batch.item.database.builder.JdbcCursorItemReaderBuilder
Indicates if the reader should verify the current position of the ResultSet after being passed to the RowMapper.
verifyCursorPosition(boolean) - Method in class org.springframework.batch.item.database.builder.StoredProcedureItemReaderBuilder
Indicates if the reader should verify the current position of the ResultSet after being passed to the RowMapper.
verifyUniquePattern(Element, List<String>, Element, ParserContext) - Static method in class org.springframework.batch.core.configuration.xml.AbstractFlowParser
 
version(String) - Method in class org.springframework.batch.item.xml.builder.StaxEventItemWriterBuilder
Version of XML to be generated.
visitBeanDefinition(BeanDefinition) - Method in class org.springframework.batch.core.jsr.partition.support.JsrBeanScopeBeanFactoryPostProcessor.JobLevelBeanLazyInitializer
 

W

waitForResults(RepeatInternalState) - Method in class org.springframework.batch.repeat.support.RepeatTemplate
If necessary, wait for results to come back from remote or concurrent processes.
waitForResults(RepeatInternalState) - Method in class org.springframework.batch.repeat.support.TaskExecutorRepeatTemplate
Wait for all the results to appear on the queue and execute the after interceptors for each one.
whereClause(String) - Method in class org.springframework.batch.item.database.builder.JdbcPagingItemReaderBuilder
The SQL WHERE clause for a db specific PagingQueryProvider.
whereStatement(String) - Method in class org.springframework.batch.item.data.builder.Neo4jItemReaderBuilder
An optional where fragment of the cypher query.
write(StepContribution, Chunk<I>, Chunk<O>) - Method in class org.springframework.batch.core.step.item.FaultTolerantChunkProcessor
 
write(StepContribution, Chunk<I>, Chunk<O>) - Method in class org.springframework.batch.core.step.item.SimpleChunkProcessor
Simple implementation delegates to the SimpleChunkProcessor.doWrite(List) method and increments the write count in the contribution.
write(List<? extends Future<T>>) - Method in class org.springframework.batch.integration.async.AsyncItemWriter
In the processing of the Futures passed, nulls are not passed to the delegate since they are considered filtered out by the AsyncItemProcessor's delegated ItemProcessor.
write(List<? extends T>) - Method in class org.springframework.batch.integration.chunk.ChunkMessageChannelItemWriter
 
write(List<? extends T>) - Method in class org.springframework.batch.item.adapter.ItemWriterAdapter
 
write(List<? extends T>) - Method in class org.springframework.batch.item.adapter.PropertyExtractingDelegatingItemWriter
Extracts values from item's fields named in fieldsUsedAsTargetMethodArguments and passes them as arguments to the delegate method.
write(List<? extends T>) - Method in class org.springframework.batch.item.amqp.AmqpItemWriter
 
write(List<? extends T>) - Method in class org.springframework.batch.item.avro.AvroItemWriter
 
write(List<? extends T>) - Method in class org.springframework.batch.item.data.MongoItemWriter
If a transaction is active, buffer items to be written just before commit.
write(List<? extends T>) - Method in class org.springframework.batch.item.data.Neo4jItemWriter
Write all items to the data store.
write(List<? extends T>) - Method in class org.springframework.batch.item.data.RepositoryItemWriter
Write all items to the data store via a Spring Data repository.
write(List<? extends T>) - Method in class org.springframework.batch.item.database.HibernateItemWriter
Save or update any entities not in the current hibernate session and then flush the hibernate session.
write(List<? extends T>) - Method in class org.springframework.batch.item.database.JdbcBatchItemWriter
 
write(List<? extends T>) - Method in class org.springframework.batch.item.database.JpaItemWriter
Merge all provided items that aren't already in the persistence context and then flush the entity manager.
write(List<? extends T>) - Method in class org.springframework.batch.item.file.MultiResourceItemWriter
 
write(List<? extends T>) - Method in interface org.springframework.batch.item.ItemWriter
Process the supplied data element.
write(List<? extends T>) - Method in class org.springframework.batch.item.jms.JmsItemWriter
Send the items one-by-one to the default destination of the JMS template.
write(List<? extends V>) - Method in class org.springframework.batch.item.KeyValueItemWriter
 
write(List<? extends MimeMessage>) - Method in class org.springframework.batch.item.mail.javamail.MimeMessageItemWriter
 
write(List<? extends SimpleMailMessage>) - Method in class org.springframework.batch.item.mail.SimpleMailMessageItemWriter
 
write(String) - Method in class org.springframework.batch.item.support.AbstractFileItemWriter.OutputState
 
write(List<? extends T>) - Method in class org.springframework.batch.item.support.AbstractFileItemWriter
Writes out a string followed by a "new line", where the format of the new line separator is determined by the underlying operating system.
write(List<? extends T>) - Method in class org.springframework.batch.item.support.ClassifierCompositeItemWriter
Delegates to injected ItemWriter instances according to their classification by the Classifier.
write(List<? extends T>) - Method in class org.springframework.batch.item.support.CompositeItemWriter
 
write(List<? extends T>) - Method in class org.springframework.batch.item.support.ListItemWriter
 
write(List<? extends T>) - Method in class org.springframework.batch.item.support.SynchronizedItemStreamWriter
This method delegates to the write method of the delegate.
write(List<? extends T>) - Method in class org.springframework.batch.item.xml.StaxEventItemWriter
Write the value objects and flush them to the file.
write(XMLEventWriter) - Method in interface org.springframework.batch.item.xml.StaxWriterCallback
Write contents using the supplied XMLEventWriter.
write(List<? extends T>) - Method in class org.springframework.batch.jsr.item.ItemWriterAdapter
 
write(char[], int, int) - Method in class org.springframework.batch.support.transaction.TransactionAwareBufferedWriter
 
write(String, int, int) - Method in class org.springframework.batch.support.transaction.TransactionAwareBufferedWriter
 
WriteFailedException - Exception in org.springframework.batch.item
Unchecked exception indicating that an error has occurred while trying to clear a buffer on a rollback.
WriteFailedException(String, Throwable) - Constructor for exception org.springframework.batch.item.WriteFailedException
Create a new WriteFailedException based on a message and another exception.
WriteFailedException(String) - Constructor for exception org.springframework.batch.item.WriteFailedException
Create a new WriteFailedException based on a message.
writeFooter(Writer) - Method in interface org.springframework.batch.item.file.FlatFileFooterCallback
Write contents to a file using the supplied Writer.
writeHeader(Writer) - Method in interface org.springframework.batch.item.file.FlatFileHeaderCallback
Write contents to a file using the supplied Writer.
writeItems(List<O>) - Method in class org.springframework.batch.core.step.item.SimpleChunkProcessor
 
writeKeyValue(K, V) - Method in class org.springframework.batch.item.data.GemfireItemWriter
 
writeKeyValue(K, T) - Method in class org.springframework.batch.item.kafka.KafkaItemWriter
 
writeKeyValue(K, V) - Method in class org.springframework.batch.item.KeyValueItemWriter
Subclasses implement this method to write each item to key value store
writer(ItemWriter<? super O>) - Method in class org.springframework.batch.core.step.builder.SimpleStepBuilder
An item writer that writes a chunk of items.
writer(ItemWriter<? super O>) - Method in class org.springframework.batch.integration.chunk.RemoteChunkingManagerStepBuilder
This method will throw a UnsupportedOperationException since the item writer of the manager step in a remote chunking setup will be automatically set to an instance of ChunkMessageChannelItemWriter.
writer(ItemWriter<? super O>) - Method in class org.springframework.batch.integration.chunk.RemoteChunkingMasterStepBuilder
Deprecated.
This method will throw a UnsupportedOperationException since the item writer of the master step in a remote chunking setup will be automatically set to an instance of ChunkMessageChannelItemWriter.
WriterNotOpenException - Exception in org.springframework.batch.item
Exception indicating that an ItemWriter needed to be opened before being written to.
WriterNotOpenException(String) - Constructor for exception org.springframework.batch.item.WriterNotOpenException
Create a new WriterNotOpenException based on a message.
WriterNotOpenException(String, Throwable) - Constructor for exception org.springframework.batch.item.WriterNotOpenException
Create a new WriterNotOpenException based on a message and another exception.

X

xmlInputFactory(XMLInputFactory) - Method in class org.springframework.batch.item.xml.builder.StaxEventItemReaderBuilder
Set the XMLInputFactory.
XStreamExecutionContextStringSerializer - Class in org.springframework.batch.core.repository.dao
Deprecated.
Due to the incompatibilities between current Jettison versions and XStream versions, this serializer is deprecated in favor of Jackson2ExecutionContextStringSerializer
XStreamExecutionContextStringSerializer() - Constructor for class org.springframework.batch.core.repository.dao.XStreamExecutionContextStringSerializer
Deprecated.
 

Z

ZERO - Static variable in class org.springframework.batch.repeat.exception.RethrowOnThresholdExceptionHandler
 
A B C D E F G H I J K L M N O P Q R S T U V W X Z 
Skip navigation links
Spring Batch