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 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
 
AbstractFlowParser - Class in org.springframework.batch.core.configuration.xml
 
AbstractFlowParser() - Constructor for class org.springframework.batch.core.configuration.xml.AbstractFlowParser
 
AbstractHibernateQueryProvider - 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 - 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.
AbstractMethodInvokingDelegator.InvocationTargetThrowableWrapper(Throwable) - Constructor for exception org.springframework.batch.item.adapter.AbstractMethodInvokingDelegator.InvocationTargetThrowableWrapper
 
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
 
addAll(Collection<StepExecution>) - Method in interface org.springframework.batch.core.repository.JobRepository
Save a collection of StepExecutions and each ExecutionContext.
addAll(Collection<StepExecution>) - Method in class org.springframework.batch.core.repository.support.SimpleJobRepository
 
addApplicationContextFactory(ApplicationContextFactory) - Method in class org.springframework.batch.core.configuration.support.AutomaticJobRegistrar
Add some factories to the set that will be used to load contexts and jobs.
addDate(String, Date) - Method in class org.springframework.batch.core.JobParametersBuilder
Add a new identifying Date parameter for the given key.
addDate(String, Date, boolean) - Method in class org.springframework.batch.core.JobParametersBuilder
Add a new Date parameter for the given key.
addDouble(String, Double) - Method in class org.springframework.batch.core.JobParametersBuilder
Add a new identifying Double parameter for the given key.
addDouble(String, Double, boolean) - Method in class org.springframework.batch.core.JobParametersBuilder
Add a new Double parameter for the given key.
addExitDescription(String) - Method in class org.springframework.batch.core.ExitStatus
Add an exit description to an existing ExitStatus.
addExitDescription(Throwable) - Method in class org.springframework.batch.core.ExitStatus
Extract the stack trace from the throwable provided and append it to the exist description.
addExitStatus(String) - Method in interface org.springframework.batch.core.job.flow.FlowExecutor
 
addExitStatus(String) - Method in class org.springframework.batch.core.job.flow.JobFlowExecutor
 
addFailureException(Throwable) - Method in class org.springframework.batch.core.JobExecution
Add the provided throwable to the failure exception list.
addFailureException(Throwable) - Method in class org.springframework.batch.core.StepExecution
 
ADDITIONAL_SHIPPING_INFO_COLUMN - Static variable in class org.springframework.batch.sample.domain.order.internal.mapper.ShippingFieldSetMapper
 
addJobExecutionListener(JobExecutionListener) - Method in class org.springframework.batch.core.job.builder.JobBuilderHelper.CommonJobProperties
 
addLong(String, Long) - Method in class org.springframework.batch.core.JobParametersBuilder
Add a new identifying Long parameter for the given key.
addLong(String, Long, boolean) - Method in class org.springframework.batch.core.JobParametersBuilder
Add a new Long parameter for the given key.
addParameter(String, JobParameter) - Method in class org.springframework.batch.core.JobParametersBuilder
Add a new JobParameter for the given key.
Address - Class in org.springframework.batch.sample.domain.order
 
Address() - Constructor for class org.springframework.batch.sample.domain.order.Address
 
ADDRESS_LINE1_COLUMN - Static variable in class org.springframework.batch.sample.domain.order.internal.mapper.AddressFieldSetMapper
 
ADDRESS_LINE2_COLUMN - Static variable in class org.springframework.batch.sample.domain.order.internal.mapper.AddressFieldSetMapper
 
ADDRESSEE_COLUMN - Static variable in class org.springframework.batch.sample.domain.order.internal.mapper.AddressFieldSetMapper
 
AddressFieldExtractor - Class in org.springframework.batch.sample.domain.order.internal.extractor
 
AddressFieldExtractor() - Constructor for class org.springframework.batch.sample.domain.order.internal.extractor.AddressFieldExtractor
 
AddressFieldSetMapper - Class in org.springframework.batch.sample.domain.order.internal.mapper
 
AddressFieldSetMapper() - Constructor for class org.springframework.batch.sample.domain.order.internal.mapper.AddressFieldSetMapper
 
addStep(Step) - Method in class org.springframework.batch.core.job.SimpleJob
Convenience method for adding a single step to the job.
addStepExecutionListener(StepExecutionListener) - Method in class org.springframework.batch.core.step.builder.StepBuilderHelper.CommonStepProperties
 
addStepExecutionListeners(List<JobExecutionListener>) - Method in class org.springframework.batch.core.job.builder.JobBuilderHelper.CommonJobProperties
 
addStepExecutionListeners(List<StepExecutionListener>) - Method in class org.springframework.batch.core.step.builder.StepBuilderHelper.CommonStepProperties
 
addStepExecutions(List<StepExecution>) - Method in class org.springframework.batch.core.JobExecution
Add some step executions.
addStepExecutions(JobExecution) - Method in class org.springframework.batch.core.repository.dao.JdbcStepExecutionDao
 
addStepExecutions(JobExecution) - Method in class org.springframework.batch.core.repository.dao.MapStepExecutionDao
 
addStepExecutions(JobExecution) - Method in interface org.springframework.batch.core.repository.dao.StepExecutionDao
Retrieve all the StepExecution for the parent JobExecution.
addString(String, String) - Method in class org.springframework.batch.core.JobParametersBuilder
Add a new identifying String parameter for the given key.
addString(String, String, boolean) - Method in class org.springframework.batch.core.JobParametersBuilder
Add a new String parameter for the given key.
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.
after(RepeatContext, RepeatStatus) - Method in class org.springframework.batch.sample.domain.trade.internal.HibernateCreditDao
 
after(JoinPoint, StepExecution) - Method in class org.springframework.batch.sample.jmx.StepExecutionApplicationEventAdvice
 
AfterChunk - Annotation Type in org.springframework.batch.core.annotation
Marks a method to be called after a chunk is executed.

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

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

Expected signature: void afterProcess(T item, S result)
afterProcess(T, S) - Method in interface org.springframework.batch.core.ItemProcessListener
Called after ItemProcessor.process(Object) returns.
afterProcess(T, S) - Method in class org.springframework.batch.core.listener.CompositeItemProcessListener
Call the registered listeners in reverse order, respecting and prioritising those that implement Ordered.
afterProcess(I, O) - Method in class org.springframework.batch.core.listener.ItemListenerSupport
 
afterProcess(T, S) - Method in class org.springframework.batch.core.listener.MulticasterBatchListener
 
afterProcess(T, S) - Method in class org.springframework.batch.core.listener.StepListenerSupport
 
afterPropertiesSet() - Method in class org.springframework.batch.core.configuration.support.AutomaticJobRegistrar
 
afterPropertiesSet() - Method in class org.springframework.batch.core.configuration.support.DefaultJobLoader
 
afterPropertiesSet() - Method in class org.springframework.batch.core.configuration.support.JobRegistryBeanPostProcessor
Make sure the registry is set before use.
afterPropertiesSet() - Method in class org.springframework.batch.core.configuration.xml.SimpleFlowFactoryBean
Check mandatory properties (name).
afterPropertiesSet() - Method in class org.springframework.batch.core.explore.support.JobExplorerFactoryBean
 
afterPropertiesSet() - Method in class org.springframework.batch.core.explore.support.MapJobExplorerFactoryBean
 
afterPropertiesSet() - Method in class org.springframework.batch.core.job.AbstractJob
Assert mandatory properties: JobRepository.
afterPropertiesSet() - Method in class org.springframework.batch.core.job.CompositeJobParametersValidator
 
afterPropertiesSet() - Method in class org.springframework.batch.core.job.DefaultJobParametersValidator
Check that there are no overlaps between required and optional keys.
afterPropertiesSet() - Method in class org.springframework.batch.core.job.flow.FlowStep
Ensure that the flow is set.
afterPropertiesSet() - Method in class org.springframework.batch.core.job.flow.support.SimpleFlow
Locate start state and pre-populate data structures needed for execution.
afterPropertiesSet() - Method in class org.springframework.batch.core.job.SimpleStepHandler
Check mandatory properties (jobRepository).
afterPropertiesSet() - Method in class org.springframework.batch.core.launch.support.SimpleJobLauncher
Ensure the required dependencies of a JobRepository have been set.
afterPropertiesSet() - Method in class org.springframework.batch.core.launch.support.SimpleJobOperator
Check mandatory properties.
afterPropertiesSet() - Method in class org.springframework.batch.core.listener.AbstractListenerFactoryBean
 
afterPropertiesSet() - Method in class org.springframework.batch.core.listener.ExecutionContextPromotionListener
 
afterPropertiesSet() - Method in class org.springframework.batch.core.partition.support.PartitionStep
Assert that mandatory properties are set (stepExecutionSplitter, partitionHandler) and delegate top superclass.
afterPropertiesSet() - Method in class org.springframework.batch.core.partition.support.RemoteStepExecutionAggregator
 
afterPropertiesSet() - Method in class org.springframework.batch.core.partition.support.SimpleStepExecutionSplitter
Check mandatory properties (step name, job repository and partitioner).
afterPropertiesSet() - Method in class org.springframework.batch.core.partition.support.TaskExecutorPartitionHandler
 
afterPropertiesSet() - Method in class org.springframework.batch.core.repository.dao.AbstractJdbcBatchMetadataDao
 
afterPropertiesSet() - Method in class org.springframework.batch.core.repository.dao.JdbcExecutionContextDao
 
afterPropertiesSet() - Method in class org.springframework.batch.core.repository.dao.JdbcJobExecutionDao
 
afterPropertiesSet() - Method in class org.springframework.batch.core.repository.dao.JdbcJobInstanceDao
 
afterPropertiesSet() - Method in class org.springframework.batch.core.repository.dao.JdbcStepExecutionDao
 
afterPropertiesSet() - Method in class org.springframework.batch.core.repository.dao.XStreamExecutionContextStringSerializer
 
afterPropertiesSet() - Method in class org.springframework.batch.core.repository.support.AbstractJobRepositoryFactoryBean
 
afterPropertiesSet() - Method in class org.springframework.batch.core.repository.support.JobRepositoryFactoryBean
 
afterPropertiesSet() - Method in class org.springframework.batch.core.resource.ListPreparedStatementSetter
 
afterPropertiesSet() - Method in class org.springframework.batch.core.step.AbstractStep
 
afterPropertiesSet() - Method in class org.springframework.batch.core.step.item.SimpleChunkProcessor
Check mandatory properties.
afterPropertiesSet() - Method in class org.springframework.batch.core.step.job.JobStep
 
afterPropertiesSet() - Method in class org.springframework.batch.core.step.tasklet.CallableTaskletAdapter
Assert that the callable is set.
afterPropertiesSet() - Method in class org.springframework.batch.core.step.tasklet.SystemCommandTasklet
 
afterPropertiesSet() - Method in class org.springframework.batch.core.step.tasklet.TaskletStep
 
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.MongoItemReader
Checks mandatory properties
afterPropertiesSet() - Method in class org.springframework.batch.item.data.MongoItemWriter
 
afterPropertiesSet() - Method in class org.springframework.batch.item.data.Neo4jItemReader
Checks mandatory properties
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 hibernateTemplate.
afterPropertiesSet() - Method in class org.springframework.batch.item.database.HibernatePagingItemReader
 
afterPropertiesSet() - Method in class org.springframework.batch.item.database.IbatisBatchItemWriter
Check mandatory properties - there must be an SqlMapClient and a statementId.
afterPropertiesSet() - Method in class org.springframework.batch.item.database.IbatisPagingItemReader
Check mandatory properties.
afterPropertiesSet() - Method in class org.springframework.batch.item.database.JdbcBatchItemWriter
Check mandatory properties - there must be a SimpleJdbcTemplate 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.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.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.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.PatternMatchingCompositeLineTokenizer
 
afterPropertiesSet() - Method in class org.springframework.batch.item.jms.JmsItemReader
 
afterPropertiesSet() - Method in class org.springframework.batch.item.KeyValueItemWriter
 
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.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.sample.common.StagingItemListener
 
afterPropertiesSet() - Method in class org.springframework.batch.sample.common.StagingItemProcessor
 
afterPropertiesSet() - Method in class org.springframework.batch.sample.common.StagingItemReader
 
afterPropertiesSet() - Method in class org.springframework.batch.sample.domain.multiline.AggregateItemFieldSetMapper
Check mandatory properties (delegate).
afterPropertiesSet() - Method in class org.springframework.batch.sample.domain.trade.internal.HibernateAwareCustomerCreditItemWriter
 
afterPropertiesSet() - Method in class org.springframework.batch.sample.loop.GeneratingTradeResettingListener
 
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.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
 
afterRead(Long) - Method in class org.springframework.batch.sample.common.StagingItemListener
 
AfterStep - Annotation Type in org.springframework.batch.core.annotation
Marks a method to be called after a Step has completed.
afterStep(StepExecution) - Method in class org.springframework.batch.core.listener.CompositeStepExecutionListener
Call the registered listeners in reverse order, respecting and prioritizing those that implement Ordered.
afterStep(StepExecution) - Method in class org.springframework.batch.core.listener.ExecutionContextPromotionListener
 
afterStep(StepExecution) - Method in class org.springframework.batch.core.listener.MulticasterBatchListener
 
afterStep(StepExecution) - Method in class org.springframework.batch.core.listener.StepExecutionListenerSupport
 
afterStep(StepExecution) - Method in class org.springframework.batch.core.listener.StepListenerSupport
 
afterStep(StepExecution) - Method in class org.springframework.batch.core.step.NoWorkFoundStepExecutionListener
 
afterStep(StepExecution) - Method in interface org.springframework.batch.core.StepExecutionListener
Give a listener a chance to modify the exit status from a step.
afterStep(StepExecution) - Method in class org.springframework.batch.sample.common.StagingItemReader
 
afterStep(StepExecution) - Method in class org.springframework.batch.sample.common.StagingItemWriter
 
afterStep(StepExecution) - Method in class org.springframework.batch.sample.loop.GeneratingTradeResettingListener
 
afterTestClass(TestContext) - Method in class org.springframework.batch.test.StepScopeTestExecutionListener
 
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.listener.CompositeItemWriteListener
Call the registered listeners in reverse order, respecting and prioritising those that implement Ordered.
afterWrite(List<? extends O>) - Method in class org.springframework.batch.core.listener.ItemListenerSupport
 
afterWrite(List<? extends S>) - Method in class org.springframework.batch.core.listener.MulticasterBatchListener
 
afterWrite(List<? extends S>) - Method in class org.springframework.batch.core.listener.StepListenerSupport
 
aggregate(Collection<FlowExecution>) - Method in interface org.springframework.batch.core.job.flow.support.state.FlowExecutionAggregator
 
aggregate(Collection<FlowExecution>) - Method in class org.springframework.batch.core.job.flow.support.state.MaxValueFlowExecutionAggregator
Aggregate all of the FlowExecutionStatuses of the FlowExecutions into one status.
aggregate(StepExecution, Collection<StepExecution>) - Method in class org.springframework.batch.core.partition.support.DefaultStepExecutionAggregator
Aggregates the input executions into the result StepExecution.
aggregate(StepExecution, Collection<StepExecution>) - Method in class org.springframework.batch.core.partition.support.RemoteStepExecutionAggregator
Aggregates the input executions into the result StepExecution delegating to the delegate aggregator once the input has been refreshed from the JobExplorer.
aggregate(StepExecution, Collection<StepExecution>) - Method in interface org.springframework.batch.core.partition.support.StepExecutionAggregator
Take the inputs and aggregate, putting the aggregates into the result.
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
 
aggregate(Order) - Method in class org.springframework.batch.sample.domain.order.internal.OrderLineAggregator
 
AggregateItem<T> - Class in org.springframework.batch.sample.domain.multiline
A wrapper type for an item that is used by AggregateItemReader to identify the start and end of an aggregate record.
AggregateItem(T) - Constructor for class org.springframework.batch.sample.domain.multiline.AggregateItem
 
AggregateItem(boolean, boolean) - Constructor for class org.springframework.batch.sample.domain.multiline.AggregateItem
 
AggregateItemFieldSetMapper<T> - Class in org.springframework.batch.sample.domain.multiline
Delegating mapper to convert form a vanilla FieldSetMapper to one that returns AggregateItem instances for consumption by the AggregateItemReader.
AggregateItemFieldSetMapper() - Constructor for class org.springframework.batch.sample.domain.multiline.AggregateItemFieldSetMapper
 
AggregateItemReader<T> - Class in org.springframework.batch.sample.domain.multiline
An ItemReader that delivers a list as its item, storing up objects from the injected ItemReader until they are ready to be packed out as a collection.
AggregateItemReader() - Constructor for class org.springframework.batch.sample.domain.multiline.AggregateItemReader
 
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.
Alignment - Enum in org.springframework.batch.item.file.transform
 
allowStartIfComplete(boolean) - Method in class org.springframework.batch.core.step.builder.StepBuilderHelper
 
AlwaysSkipItemSkipPolicy - Class in org.springframework.batch.core.step.skip
Implementation of the SkipPolicy interface that will always return that an item should be skipped.
AlwaysSkipItemSkipPolicy() - Constructor for class org.springframework.batch.core.step.skip.AlwaysSkipItemSkipPolicy
 
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
 
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
 
AmqpMessageProducer - Class in org.springframework.batch.sample.rabbitmq.amqp
Simple producer class that sends String messages to the configured queue to be processed.
AmqpMessageProducer() - Constructor for class org.springframework.batch.sample.rabbitmq.amqp.AmqpMessageProducer
 
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
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
 
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.
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
 
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
 

B

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

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

Expected signature: void beforeRead()
beforeRead() - Method in interface org.springframework.batch.core.ItemReadListener
Called before ItemReader.read()
beforeRead() - Method in class org.springframework.batch.core.listener.CompositeItemReadListener
Call the registered listeners in order, respecting and prioritising those that implement Ordered.
beforeRead() - Method in class org.springframework.batch.core.listener.ItemListenerSupport
 
beforeRead() - Method in class org.springframework.batch.core.listener.MulticasterBatchListener
 
beforeRead() - Method in class org.springframework.batch.core.listener.StepListenerSupport
 
BeforeStep - Annotation Type in org.springframework.batch.core.annotation
Marks a method to be called before a Step is executed, which comes after a StepExecution is created and persisted, but before the first item is read.
beforeStep(StepExecution) - Method in class org.springframework.batch.core.listener.CompositeStepExecutionListener
Call the registered listeners in order, respecting and prioritizing those that implement Ordered.
beforeStep(StepExecution) - Method in class org.springframework.batch.core.listener.JobParameterExecutionContextCopyListener
Copy attributes from the JobParameters to the Step ExecutionContext, if not already present.
beforeStep(StepExecution) - Method in class org.springframework.batch.core.listener.MulticasterBatchListener
 
beforeStep(StepExecution) - Method in class org.springframework.batch.core.listener.StepExecutionListenerSupport
 
beforeStep(StepExecution) - Method in class org.springframework.batch.core.listener.StepListenerSupport
 
beforeStep(StepExecution) - Method in class org.springframework.batch.core.resource.StepExecutionSimpleCompletionPolicy
Set up a SimpleCompletionPolicy with a commit interval taken from the JobParameters.
beforeStep(StepExecution) - Method in class org.springframework.batch.core.step.tasklet.SystemCommandTasklet
Get a reference to StepExecution for interrupt checks during system command execution.
beforeStep(StepExecution) - Method in interface org.springframework.batch.core.StepExecutionListener
Initialize the state of the listener with the StepExecution from the current scope.
beforeStep(StepExecution) - Method in class org.springframework.batch.sample.common.InfiniteLoopWriter
 
beforeStep(StepExecution) - Method in class org.springframework.batch.sample.common.StagingItemReader
 
beforeStep(StepExecution) - Method in class org.springframework.batch.sample.common.StagingItemWriter
 
beforeStep(StepExecution) - Method in class org.springframework.batch.sample.domain.trade.CompositeCustomerUpdateLineTokenizer
 
beforeStep(StepExecution) - Method in class org.springframework.batch.sample.support.SummaryFooterCallback
 
beforeTestClass(TestContext) - Method in class org.springframework.batch.test.StepScopeTestExecutionListener
 
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.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.
BillingFieldSetMapper - Class in org.springframework.batch.sample.domain.order.internal.mapper
 
BillingFieldSetMapper() - Constructor for class org.springframework.batch.sample.domain.order.internal.mapper.BillingFieldSetMapper
 
BillingInfo - Class in org.springframework.batch.sample.domain.order
 
BillingInfo() - Constructor for class org.springframework.batch.sample.domain.order.BillingInfo
 
BillingInfoFieldExtractor - Class in org.springframework.batch.sample.domain.order.internal.extractor
 
BillingInfoFieldExtractor() - Constructor for class org.springframework.batch.sample.domain.order.internal.extractor.BillingInfoFieldExtractor
 
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.
build() - Method in class org.springframework.batch.core.job.builder.FlowBuilder
Validate the current state of the builder and build a flow.
build() - Method in class org.springframework.batch.core.job.builder.FlowJobBuilder
Build a job that executes the flow provided, normally composed of other steps.
build() - Method in class org.springframework.batch.core.job.builder.JobFlowBuilder
Build a flow and inject it into the parent builder.
build() - Method in class org.springframework.batch.core.job.builder.SimpleJobBuilder
 
build() - Method in class org.springframework.batch.core.step.builder.AbstractTaskletStepBuilder
Build the step from the components collected by the fluent setters.
build() - Method in class org.springframework.batch.core.step.builder.FaultTolerantStepBuilder
 
build() - Method in class org.springframework.batch.core.step.builder.FlowStepBuilder
Build a step that executes the flow provided, normally composed of other steps.
build() - Method in class org.springframework.batch.core.step.builder.JobStepBuilder
Build a step from the job provided.
build() - Method in class org.springframework.batch.core.step.builder.PartitionStepBuilder
 
build() - Method in class org.springframework.batch.core.step.builder.SimpleStepBuilder
Build a step with the reader, writer, processor as provided.
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

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.
Child - Class in org.springframework.batch.sample.domain.person
 
Child() - Constructor for class org.springframework.batch.sample.domain.person.Child
 
chunk(int) - Method in class org.springframework.batch.core.step.builder.SimpleStepBuilder
Sets the chunk size or commit interval for this step.
chunk(CompletionPolicy) - Method in class org.springframework.batch.core.step.builder.SimpleStepBuilder
Sets a completion policy for the chunk processing.
chunk(int) - Method in class org.springframework.batch.core.step.builder.StepBuilder
Build a step that processes items in chunks with the size provided.
chunk(CompletionPolicy) - Method in class org.springframework.batch.core.step.builder.StepBuilder
Build a step that processes items in chunks with the completion policy provided.
Chunk<W> - Class in org.springframework.batch.core.step.item
Encapsulation of a list of items to be processed and possibly a list of failed items to be skipped.
Chunk() - Constructor for class org.springframework.batch.core.step.item.Chunk
 
Chunk(Collection<? extends W>) - Constructor for class org.springframework.batch.core.step.item.Chunk
 
Chunk(Collection<? extends W>, List<SkipWrapper<W>>) - Constructor for class org.springframework.batch.core.step.item.Chunk
 
Chunk.ChunkIterator - Class in org.springframework.batch.core.step.item
Special iterator for a chunk providing the Chunk.ChunkIterator.remove(Throwable) method for dynamically removing an item and adding it to the skips.
Chunk.ChunkIterator(List<W>) - Constructor for class org.springframework.batch.core.step.item.Chunk.ChunkIterator
 
ChunkContext - Class in org.springframework.batch.core.scope.context
Context object for weakly typed data stored for the duration of a chunk (usually a group of items processed together in a transaction).
ChunkContext(StepContext) - Constructor for class org.springframework.batch.core.scope.context.ChunkContext
 
ChunkElementParser - Class in org.springframework.batch.core.configuration.xml
Internal parser for the <chunk/> element inside a step.
ChunkElementParser() - Constructor for class org.springframework.batch.core.configuration.xml.ChunkElementParser
 
ChunkListener - Interface in org.springframework.batch.core
Listener interface for the lifecycle of a chunk.
chunkListeners - Variable in class org.springframework.batch.core.step.builder.AbstractTaskletStepBuilder
 
ChunkListenerSupport - Class in org.springframework.batch.core.listener
Basic support implementation of ChunkListener
ChunkListenerSupport() - Constructor for class org.springframework.batch.core.listener.ChunkListenerSupport
 
ChunkMonitor - Class in org.springframework.batch.core.step.item
Manage the offset data between the last successful commit and updates made to an input chunk.
ChunkMonitor() - Constructor for class org.springframework.batch.core.step.item.ChunkMonitor
 
ChunkMonitor.ChunkMonitorData - Class in org.springframework.batch.core.step.item
 
ChunkMonitor.ChunkMonitorData(int, int) - Constructor for class org.springframework.batch.core.step.item.ChunkMonitor.ChunkMonitorData
 
chunkOperations(RepeatOperations) - Method in class org.springframework.batch.core.step.builder.SimpleStepBuilder
Instead of a chunk size or completion policy you can provide a complete repeat operations instance that handles the iteration over the item reader.
ChunkOrientedTasklet<I> - Class in org.springframework.batch.core.step.item
A Tasklet implementing variations on read-process-write item handling.
ChunkOrientedTasklet(ChunkProvider<I>, ChunkProcessor<I>) - Constructor for class org.springframework.batch.core.step.item.ChunkOrientedTasklet
 
ChunkProcessor<I> - Interface in org.springframework.batch.core.step.item
Interface defined for processing Chunks.
ChunkProvider<T> - Interface in org.springframework.batch.core.step.item
Interface for providing Chunks to be processed, used by the ChunkOrientedTasklet
chunkSize - Variable in class org.springframework.batch.core.step.item.ChunkMonitor.ChunkMonitorData
 
CITY_COLUMN - Static variable in class org.springframework.batch.sample.domain.order.internal.mapper.AddressFieldSetMapper
 
Classifier - Annotation Type in org.springframework.batch.support.annotation
Mark a method as capable of classifying its input to an instance of its output.
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
 
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
 
cleanupOnClose() - 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
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
 
clear() - Method in class org.springframework.batch.core.repository.dao.MapJobExecutionDao
 
clear() - Method in class org.springframework.batch.core.repository.dao.MapJobInstanceDao
 
clear() - Method in class org.springframework.batch.core.repository.dao.MapStepExecutionDao
 
clear() - Method in class org.springframework.batch.core.repository.support.MapJobRepositoryFactoryBean
Convenience method to clear all the map daos globally, removing all entities.
clear() - Method in class org.springframework.batch.core.step.item.Chunk
Clear the items down to signal that we are done.
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.
clear() - Method in class org.springframework.batch.sample.domain.mail.internal.TestMailErrorHandler
 
clear() - Method in class org.springframework.batch.sample.domain.mail.internal.TestMailSender
 
clearDirtyFlag() - Method in class org.springframework.batch.item.ExecutionContext
Clears the dirty flag.
clearSkips() - Method in class org.springframework.batch.core.step.item.Chunk
Clear only the skips list.
close(FlowExecution) - Method in interface org.springframework.batch.core.job.flow.FlowExecutor
Chance to clean up resources at the end of a flow (whether it completed successfully or not).
close(FlowExecution) - Method in class org.springframework.batch.core.job.flow.JobFlowExecutor
 
close() - Method in class org.springframework.batch.core.scope.context.StepContext
Clean up the context at the end of a step execution.
close() - Static method in class org.springframework.batch.core.scope.context.StepSynchronizationManager
Method for de-registering the current context - should always and only be used by in conjunction with a matching StepSynchronizationManager.register(StepExecution) to ensure that StepSynchronizationManager.getContext() always returns the correct value.
close(ExecutionContext) - Method in class org.springframework.batch.core.step.AbstractStep
Extension point for subclasses to provide callbacks to their collaborators at the end of a step (right at the end of the finally block), to close or release resources.
close() - Method in class org.springframework.batch.core.step.item.ChunkMonitor
 
close(RetryContext, RetryCallback<T>, Throwable) - Method in class org.springframework.batch.core.step.item.SimpleRetryExceptionHandler
If retry is exhausted set up some state in the context that can be used to signal that the exception should be handled.
close(ExecutionContext) - Method in class org.springframework.batch.core.step.tasklet.TaskletStep
 
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.FlatFileItemWriter
 
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.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.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.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.sample.domain.trade.internal.FlatFileCustomerCreditDao
 
close(RepeatContext) - Method in class org.springframework.batch.sample.domain.trade.internal.HibernateCreditDao
 
close() - Method in class org.springframework.batch.sample.domain.trade.internal.IbatisCustomerCreditDao
 
close() - Method in class org.springframework.batch.support.transaction.TransactionAwareBufferedWriter
 
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
 
ColumnRangePartitioner - Class in org.springframework.batch.sample.common
Simple minded partitioner for a range of values of a column in a database table.
ColumnRangePartitioner() - Constructor for class org.springframework.batch.sample.common.ColumnRangePartitioner
 
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
 
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.
CommonsLoggingInvalidCustomerLogger - Class in org.springframework.batch.sample.domain.trade.internal
 
CommonsLoggingInvalidCustomerLogger() - Constructor for class org.springframework.batch.sample.domain.trade.internal.CommonsLoggingInvalidCustomerLogger
 
COMPANY_NAME_COLUMN - Static variable in class org.springframework.batch.sample.domain.order.internal.mapper.CustomerFieldSetMapper
 
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.
compareTo(StateTransition) - Method in class org.springframework.batch.core.job.flow.support.StateTransition
Sorts by decreasing specificity of pattern, based on just counting wildcards (with * taking precedence over ?).
COMPLETED - Static variable in class org.springframework.batch.core.ExitStatus
Convenient constant value representing finished processing.
COMPLETED - Static variable in class org.springframework.batch.core.job.flow.FlowExecutionStatus
Special well-known status value.
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
 
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 concensus.
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.
CompositeCompletionPolicy.CompositeBatchContext(RepeatContext, List<RepeatContext>) - Constructor for class org.springframework.batch.repeat.policy.CompositeCompletionPolicy.CompositeBatchContext
 
CompositeCustomerUpdateLineTokenizer - Class in org.springframework.batch.sample.domain.trade
Composite LineTokenizer that delegates the tokenization of a line to one of two potential tokenizers.
CompositeCustomerUpdateLineTokenizer() - Constructor for class org.springframework.batch.sample.domain.trade.CompositeCustomerUpdateLineTokenizer
 
CompositeExceptionHandler - Class in org.springframework.batch.repeat.exception
Composiste 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
 
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
 
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
 
CompositeRepeatListener() - Constructor for class org.springframework.batch.repeat.listener.CompositeRepeatListener
 
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
 
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.
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
 
CountingCompletionPolicy.CountingBatchContext(RepeatContext) - Constructor for class org.springframework.batch.repeat.policy.CountingCompletionPolicy.CountingBatchContext
 
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.
COUNTRY_COLUMN - Static variable in class org.springframework.batch.sample.domain.order.internal.mapper.AddressFieldSetMapper
 
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
 
createApplicationContext() - Method in class org.springframework.batch.core.configuration.support.OsgiBundleXmlApplicationContextFactory
Create an application context from the provided path, using the current OSGi BundleContext and the enclosing Spring ApplicationContext as a parent context.
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
 
createEndStateTransition(State) - Static method in class org.springframework.batch.core.job.flow.support.StateTransition
Create a new end state StateTransition specification.
createEndStateTransition(State, String) - Static method in class org.springframework.batch.core.job.flow.support.StateTransition
Create a new end state StateTransition specification.
createExecutionContextDao() - Method in class org.springframework.batch.core.explore.support.AbstractJobExplorerFactoryBean
 
createExecutionContextDao() - Method in class org.springframework.batch.core.explore.support.JobExplorerFactoryBean
 
createExecutionContextDao() - Method in class org.springframework.batch.core.explore.support.MapJobExplorerFactoryBean
 
createExecutionContextDao() - Method in class org.springframework.batch.core.repository.support.AbstractJobRepositoryFactoryBean
 
createExecutionContextDao() - Method in class org.springframework.batch.core.repository.support.JobRepositoryFactoryBean
 
createExecutionContextDao() - Method in class org.springframework.batch.core.repository.support.MapJobRepositoryFactoryBean
 
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(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() - 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
 
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
 
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.
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
 
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
 
createJobInstanceDao() - Method in class org.springframework.batch.core.repository.support.AbstractJobRepositoryFactoryBean
 
createJobInstanceDao() - Method in class org.springframework.batch.core.repository.support.JobRepositoryFactoryBean
 
createJobInstanceDao() - Method in class org.springframework.batch.core.repository.support.MapJobRepositoryFactoryBean
 
createJobRepository() - Method in class org.springframework.batch.core.configuration.annotation.DefaultBatchConfigurer
 
createNewFile(File) - Static method in class org.springframework.batch.item.util.FileUtils
Create a new file if it doesn't already exist.
createOutputNameFromInput(StepExecution) - Method in class org.springframework.batch.sample.common.OutputFileListener
 
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 SQLQuery 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.JpaNativeQueryProvider
 
createQuery() - Method in interface org.springframework.batch.item.database.orm.JpaQueryProvider
Create the query object.
createSemaphore() - Method in class org.springframework.batch.core.step.tasklet.TaskletStep
Extension point mainly for test purposes so that the behaviour of the lock can be manipulated to simulate various pathologies.
createSkipPolicy() - Method in class org.springframework.batch.core.step.builder.FaultTolerantStepBuilder
 
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
 
createStepExecutionDao() - Method in class org.springframework.batch.core.repository.support.AbstractJobRepositoryFactoryBean
 
createStepExecutionDao() - Method in class org.springframework.batch.core.repository.support.JobRepositoryFactoryBean
 
createStepExecutionDao() - Method in class org.springframework.batch.core.repository.support.MapJobRepositoryFactoryBean
 
createTask(Step, StepExecution) - Method in class org.springframework.batch.core.partition.support.TaskExecutorPartitionHandler
Creates the task executing the given step in the context of the given execution.
createTasklet() - Method in class org.springframework.batch.core.step.builder.AbstractTaskletStepBuilder
 
createTasklet() - Method in class org.springframework.batch.core.step.builder.FaultTolerantStepBuilder
Create a new chunk oriented tasklet with reader, writer and processor as provided.
createTasklet() - Method in class org.springframework.batch.core.step.builder.SimpleStepBuilder
 
createTasklet() - Method in class org.springframework.batch.core.step.builder.TaskletStepBuilder
 
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
 
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.
createXmlOutputFactory() - Method in class org.springframework.batch.item.xml.StaxEventItemWriter
Subclasses can override to customize the factory.
CREDIT_COLUMN - Static variable in class org.springframework.batch.sample.domain.trade.internal.CustomerCreditFieldSetMapper
 
CREDIT_COLUMN - Static variable in class org.springframework.batch.sample.domain.trade.internal.CustomerCreditRowMapper
 
Customer - Class in org.springframework.batch.sample.domain.order
 
Customer() - Constructor for class org.springframework.batch.sample.domain.order.Customer
 
Customer - Class in org.springframework.batch.sample.domain.order.internal.xml
An XML customer.
Customer() - Constructor for class org.springframework.batch.sample.domain.order.internal.xml.Customer
 
CUSTOMER_COLUMN - Static variable in class org.springframework.batch.sample.domain.trade.internal.CustomerDebitRowMapper
 
CUSTOMER_COLUMN - Static variable in class org.springframework.batch.sample.domain.trade.internal.TradeFieldSetMapper
 
CUSTOMER_COLUMN - Static variable in class org.springframework.batch.sample.domain.trade.internal.TradeRowMapper
 
CustomerCredit - Class in org.springframework.batch.sample.domain.trade
 
CustomerCredit() - Constructor for class org.springframework.batch.sample.domain.trade.CustomerCredit
 
CustomerCredit(int, String, BigDecimal) - Constructor for class org.springframework.batch.sample.domain.trade.CustomerCredit
 
CustomerCreditDao - Interface in org.springframework.batch.sample.domain.trade
Interface for writing customer's credit information to output.
CustomerCreditFieldSetMapper - Class in org.springframework.batch.sample.domain.trade.internal
 
CustomerCreditFieldSetMapper() - Constructor for class org.springframework.batch.sample.domain.trade.internal.CustomerCreditFieldSetMapper
 
CustomerCreditIncreaseProcessor - Class in org.springframework.batch.sample.domain.trade.internal
Increases customer's credit by a fixed amount.
CustomerCreditIncreaseProcessor() - Constructor for class org.springframework.batch.sample.domain.trade.internal.CustomerCreditIncreaseProcessor
 
CustomerCreditItemWriter - Class in org.springframework.batch.sample.domain.trade.internal
Delegates actual writing to a custom DAO.
CustomerCreditItemWriter() - Constructor for class org.springframework.batch.sample.domain.trade.internal.CustomerCreditItemWriter
 
CustomerCreditRepository - Interface in org.springframework.batch.sample.data
 
CustomerCreditRowMapper - Class in org.springframework.batch.sample.domain.trade.internal
 
CustomerCreditRowMapper() - Constructor for class org.springframework.batch.sample.domain.trade.internal.CustomerCreditRowMapper
 
CustomerCreditUpdatePreparedStatementSetter - Class in org.springframework.batch.sample.domain.trade.internal
 
CustomerCreditUpdatePreparedStatementSetter() - Constructor for class org.springframework.batch.sample.domain.trade.internal.CustomerCreditUpdatePreparedStatementSetter
 
CustomerCreditUpdateWriter - Class in org.springframework.batch.sample.domain.trade.internal
 
CustomerCreditUpdateWriter() - Constructor for class org.springframework.batch.sample.domain.trade.internal.CustomerCreditUpdateWriter
 
CustomerDao - Interface in org.springframework.batch.sample.domain.trade
 
CustomerDebit - Class in org.springframework.batch.sample.domain.trade
 
CustomerDebit() - Constructor for class org.springframework.batch.sample.domain.trade.CustomerDebit
 
CustomerDebitDao - Interface in org.springframework.batch.sample.domain.trade
Interface for writing CustomerDebitDao object to arbitrary output.
CustomerDebitRowMapper - Class in org.springframework.batch.sample.domain.trade.internal
 
CustomerDebitRowMapper() - Constructor for class org.springframework.batch.sample.domain.trade.internal.CustomerDebitRowMapper
 
CustomerFieldExtractor - Class in org.springframework.batch.sample.domain.order.internal.extractor
 
CustomerFieldExtractor() - Constructor for class org.springframework.batch.sample.domain.order.internal.extractor.CustomerFieldExtractor
 
CustomerFieldSetMapper - Class in org.springframework.batch.sample.domain.order.internal.mapper
 
CustomerFieldSetMapper() - Constructor for class org.springframework.batch.sample.domain.order.internal.mapper.CustomerFieldSetMapper
 
CustomerOperation - Enum in org.springframework.batch.sample.domain.trade
Enum representing on of 3 possible actions on a customer update: Add, update, or delete
CustomerUpdate - Class in org.springframework.batch.sample.domain.trade
Immutable Value Object representing an update to the customer as stored in the database.
CustomerUpdate(CustomerOperation, String, BigDecimal) - Constructor for class org.springframework.batch.sample.domain.trade.CustomerUpdate
 
CustomerUpdateFieldSetMapper - Class in org.springframework.batch.sample.domain.trade
FieldSetMapper for mapping to a CustomerUpdate.
CustomerUpdateFieldSetMapper() - Constructor for class org.springframework.batch.sample.domain.trade.CustomerUpdateFieldSetMapper
 
CustomerUpdateProcessor - Class in org.springframework.batch.sample.domain.trade
 
CustomerUpdateProcessor() - Constructor for class org.springframework.batch.sample.domain.trade.CustomerUpdateProcessor
 
CustomerUpdateWriter - Class in org.springframework.batch.sample.domain.trade
 
CustomerUpdateWriter() - Constructor for class org.springframework.batch.sample.domain.trade.CustomerUpdateWriter
 
CustomerUpdateWriter - Class in org.springframework.batch.sample.domain.trade.internal
Transforms Trade to a CustomerDebit and asks DAO delegate to write the result.
CustomerUpdateWriter() - Constructor for class org.springframework.batch.sample.domain.trade.internal.CustomerUpdateWriter
 

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.
dataSource() - Method in class org.springframework.batch.sample.config.DataSourceConfiguration
 
DataSourceConfiguration - Class in org.springframework.batch.sample.config
 
DataSourceConfiguration() - Constructor for class org.springframework.batch.sample.config.DataSourceConfiguration
 
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.
decide(JobExecution, StepExecution) - Method in class org.springframework.batch.sample.loop.LimitDecider
 
DecisionParser - Class in org.springframework.batch.core.configuration.xml
Internal parser for the <decision/> elements inside a job.
DecisionParser() - Constructor for class org.springframework.batch.core.configuration.xml.DecisionParser
 
DecisionState - Class in org.springframework.batch.core.job.flow.support.state
State that requires a decider to make the status decision.
DecisionState(JobExecutionDecider, String) - Constructor for class org.springframework.batch.core.job.flow.support.state.DecisionState
 
DEFAULT_CHARSET - Static variable in class org.springframework.batch.item.file.FlatFileItemReader
 
DEFAULT_CHUNK_SIZE - Static variable in class org.springframework.batch.repeat.policy.SimpleCompletionPolicy
 
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_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_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 millisecs (the value equivalent to 30 seconds).
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 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.
DefaultJobLoader - Class in org.springframework.batch.sample.launch
 
DefaultJobLoader() - Constructor for class org.springframework.batch.sample.launch.DefaultJobLoader
 
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
 
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
 
delete - Variable in class org.springframework.batch.item.KeyValueItemWriter
 
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_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.XStreamExecutionContextStringSerializer
Deserializes the supplied input stream into a new execution context.
deserialize(byte[]) - Static method in class org.springframework.batch.support.SerializationUtils
 
destroy() - Method in class org.springframework.batch.core.configuration.support.JobRegistryBeanPostProcessor
De-register all the Job instances that were regsistered by this post processor.
destroy() - Method in class org.springframework.batch.sample.common.StagingItemReader
 
destroy() - Method in class org.springframework.batch.sample.domain.trade.internal.FlatFileCustomerCreditDao
 
destroy() - Method in class org.springframework.batch.test.DataSourceInitializer
 
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
 
DISCOUNT_AMOUNT_COLUMN - Static variable in class org.springframework.batch.sample.domain.order.internal.mapper.OrderItemFieldSetMapper
 
DISCOUNT_PERC_COLUMN - Static variable in class org.springframework.batch.sample.domain.order.internal.mapper.OrderItemFieldSetMapper
 
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
 
doBasicLogging(JoinPoint) - Method in class org.springframework.batch.sample.common.LogAdvice
 
doBegin(Object, TransactionDefinition) - Method in class org.springframework.batch.support.transaction.ResourcelessTransactionManager
 
doCleanupAfterCompletion(Object) - Method in class org.springframework.batch.support.transaction.ResourcelessTransactionManager
 
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.JpaPagingItemReader
 
doClose() - Method in class org.springframework.batch.item.file.FlatFileItemReader
 
doClose() - Method in class org.springframework.batch.item.support.AbstractItemCountingItemStreamItemReader
doClose() - Method in class org.springframework.batch.item.xml.StaxEventItemReader
 
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(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.
doGetResult(Object) - Method in class org.springframework.batch.sample.domain.order.internal.valang.FutureDateFunction
 
doGetResult(Object) - Method in class org.springframework.batch.sample.domain.order.internal.valang.TotalOrderItemsFunction
 
doGetResult(Object) - Method in class org.springframework.batch.sample.domain.order.internal.valang.ValidateDiscountsFunction
 
doGetResult(Object) - Method in class org.springframework.batch.sample.domain.order.internal.valang.ValidateHandlingPricesFunction
 
doGetResult(Object) - Method in class org.springframework.batch.sample.domain.order.internal.valang.ValidateIdsFunction
 
doGetResult(Object) - Method in class org.springframework.batch.sample.domain.order.internal.valang.ValidatePricesFunction
 
doGetResult(Object) - Method in class org.springframework.batch.sample.domain.order.internal.valang.ValidateQuantitiesFunction
 
doGetResult(Object) - Method in class org.springframework.batch.sample.domain.order.internal.valang.ValidateShippingPricesFunction
 
doGetResult(Object) - Method in class org.springframework.batch.sample.domain.order.internal.valang.ValidateTotalPricesFunction
 
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.
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.IbatisPagingItemReader
 
doJumpToPage(int) - Method in class org.springframework.batch.item.database.JdbcPagingItemReader
 
doJumpToPage(int) - Method in class org.springframework.batch.item.database.JpaPagingItemReader
 
DONE - Static variable in class org.springframework.batch.sample.common.StagingItemWriter
 
doOnWriteError(Exception, List<O>) - Method in class org.springframework.batch.core.step.item.SimpleChunkProcessor
 
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.JpaPagingItemReader
 
doOpen() - Method in class org.springframework.batch.item.file.FlatFileItemReader
 
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
 
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
 
doProcess(I) - Method in class org.springframework.batch.core.step.item.SimpleChunkProcessor
 
doRead() - Method in class org.springframework.batch.core.step.item.SimpleChunkProvider
Surrounds the read call with listener callbacks.
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.file.FlatFileItemReader
 
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.IbatisPagingItemReader
 
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
 
doStronglyTypedLogging(Object) - Method in class org.springframework.batch.sample.common.LogAdvice
 
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
 
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) - 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.
DummyItemWriter - Class in org.springframework.batch.sample.support
 
DummyItemWriter() - Constructor for class org.springframework.batch.sample.support.DummyItemWriter
 
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).
EnableBatchProcessing - Annotation Type in org.springframework.batch.core.configuration.annotation
Enable Spring Batch features and provide a base configuration for setting up batch jobs in an @Configuration class, roughly equivalent to using the <batch:*> XML namespace.
end() - Method in class org.springframework.batch.core.job.builder.FlowBuilder
A synonym for FlowBuilder.build() which callers might find useful.
end() - Method in class org.springframework.batch.core.job.builder.FlowBuilder.TransitionBuilder
Signal the successful end of the flow.
end(String) - Method in class org.springframework.batch.core.job.builder.FlowBuilder.TransitionBuilder
Signal the end of the flow with the status provided.
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
 
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
 
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.configuration.support.OsgiBundleXmlApplicationContextFactory
 
equals(Object) - Method in class org.springframework.batch.core.Entity
Attempt to establish identity based on id if both exist.
equals(Object) - Method in class org.springframework.batch.core.ExitStatus
Compare the fields one by one.
equals(Object) - Method in class org.springframework.batch.core.job.flow.FlowExecutionStatus
Check the equality of the statuses.
equals(Object) - Method in class org.springframework.batch.core.JobParameter
 
equals(Object) - Method in class org.springframework.batch.core.JobParameters
 
equals(Object) - Method in class org.springframework.batch.core.listener.MethodInvokerMethodInterceptor
equals(Object) - Method in class org.springframework.batch.core.scope.context.StepContext
Extend the base class method to include the step execution itself as a key (i.e.
equals(Object) - Method in class org.springframework.batch.core.StepContribution
 
equals(Object) - Method in class org.springframework.batch.core.StepExecution
 
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.sample.domain.football.Game
 
equals(Object) - Method in class org.springframework.batch.sample.domain.football.PlayerSummary
 
equals(Object) - Method in class org.springframework.batch.sample.domain.order.Address
 
equals(Object) - Method in class org.springframework.batch.sample.domain.order.BillingInfo
 
equals(Object) - Method in class org.springframework.batch.sample.domain.order.Customer
 
equals(Object) - Method in class org.springframework.batch.sample.domain.order.LineItem
 
equals(Object) - Method in class org.springframework.batch.sample.domain.order.Order
 
equals(Object) - Method in class org.springframework.batch.sample.domain.order.ShippingInfo
 
equals(Object) - Method in class org.springframework.batch.sample.domain.person.Child
 
equals(Object) - Method in class org.springframework.batch.sample.domain.person.Person
 
equals(Object) - Method in class org.springframework.batch.sample.domain.trade.CustomerCredit
 
equals(Object) - Method in class org.springframework.batch.sample.domain.trade.CustomerDebit
 
equals(Object) - Method in class org.springframework.batch.sample.domain.trade.Trade
 
equals(Object) - Method in class org.springframework.batch.support.SimpleMethodInvoker
 
example - package example
 
ExceptionClassifierSkipPolicy - Class in org.springframework.batch.core.step.skip
A SkipPolicy that depends on an exception classifier to make its decision, and then delegates to the classifier result.
ExceptionClassifierSkipPolicy() - Constructor for class org.springframework.batch.core.step.skip.ExceptionClassifierSkipPolicy
 
exceptionHandler(ExceptionHandler) - Method in class org.springframework.batch.core.step.builder.AbstractTaskletStepBuilder
Sets the exception handler to use in the case of tasklet failures.
ExceptionHandler - Interface in org.springframework.batch.repeat.exception
Handler to allow strategies for re-throwing exceptions.
ExceptionThrowingItemReaderProxy<T> - Class in org.springframework.batch.sample.support
Hacked ItemReader that throws exception on a given record number (useful for testing restart).
ExceptionThrowingItemReaderProxy() - Constructor for class org.springframework.batch.sample.support.ExceptionThrowingItemReaderProxy
 
execute(JobExecution) - Method in class org.springframework.batch.core.configuration.support.GroupAwareJob
 
execute(JobExecution) - Method in class org.springframework.batch.core.job.AbstractJob
Run the specified job, handling all listener and repository calls, and delegating the actual processing to AbstractJob.doExecute(JobExecution).
execute(JobExecution) - Method in interface org.springframework.batch.core.Job
Run the JobExecution and update the meta information like status and statistics as necessary.
execute(Step, StepExecution) - Method in class org.springframework.batch.core.scope.context.StepScopeManager
 
execute(StepExecution) - Method in class org.springframework.batch.core.step.AbstractStep
Template method for step execution logic - calls abstract methods for resource initialization ( AbstractStep.open(ExecutionContext)), execution logic (AbstractStep.doExecute(StepExecution)) and resource closing ( AbstractStep.close(ExecutionContext)).
execute(StepExecution) - Method in interface org.springframework.batch.core.Step
Process the step and assign progress and status meta information to the StepExecution provided.
execute(RetryCallback<T>, Collection<RetryState>) - Method in class org.springframework.batch.core.step.item.BatchRetryTemplate
 
execute(RetryCallback<T>, RecoveryCallback<T>, Collection<RetryState>) - Method in class org.springframework.batch.core.step.item.BatchRetryTemplate
 
execute(RetryCallback<T>, RecoveryCallback<T>, RetryState) - Method in class org.springframework.batch.core.step.item.BatchRetryTemplate
 
execute(RetryCallback<T>, RecoveryCallback<T>) - Method in class org.springframework.batch.core.step.item.BatchRetryTemplate
 
execute(RetryCallback<T>, RetryState) - Method in class org.springframework.batch.core.step.item.BatchRetryTemplate
 
execute(RetryCallback<T>) - Method in class org.springframework.batch.core.step.item.BatchRetryTemplate
 
execute(StepContribution, ChunkContext) - Method in class org.springframework.batch.core.step.item.ChunkOrientedTasklet
 
execute(StepContribution, ChunkContext) - Method in class org.springframework.batch.core.step.tasklet.CallableTaskletAdapter
Execute the provided Callable and return its RepeatStatus.
execute(StepContribution, ChunkContext) - Method in class org.springframework.batch.core.step.tasklet.MethodInvokingTaskletAdapter
Delegate execution to the target object and translate the return value to an ExitStatus by invoking a method in the delegate POJO.
execute(StepContribution, ChunkContext) - Method in class org.springframework.batch.core.step.tasklet.SystemCommandTasklet
Execute system command and map its exit code to ExitStatus using SystemProcessExitCodeMapper.
execute(StepContribution, ChunkContext) - Method in interface org.springframework.batch.core.step.tasklet.Tasklet
Given the current context in the form of a step contribution, do whatever is necessary to process this unit inside a transaction.
executeAfterInterceptors(RepeatContext, RepeatStatus) - Method in class org.springframework.batch.repeat.support.RepeatTemplate
Convenience method to execute after interceptors on a callback result.
executeInternal(JobExecutionContext) - Method in class org.springframework.batch.sample.quartz.JobLauncherDetails
 
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
 
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.
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
 
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.
ExportedJobLoader - Interface in org.springframework.batch.sample.launch
 
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 {&link DataSource} to be wrapped.
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.
extract(Order) - Method in class org.springframework.batch.sample.domain.order.internal.extractor.AddressFieldExtractor
 
extract(Order) - Method in class org.springframework.batch.sample.domain.order.internal.extractor.BillingInfoFieldExtractor
 
extract(Order) - Method in class org.springframework.batch.sample.domain.order.internal.extractor.CustomerFieldExtractor
 
extract(Order) - Method in class org.springframework.batch.sample.domain.order.internal.extractor.FooterFieldExtractor
 
extract(Order) - Method in class org.springframework.batch.sample.domain.order.internal.extractor.HeaderFieldExtractor
 
extract(LineItem) - Method in class org.springframework.batch.sample.domain.order.internal.extractor.LineItemFieldExtractor
 
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.
FAILED - Static variable in class org.springframework.batch.core.ExitStatus
Convenient constant value representing finished processing with an error.
FAILED - Static variable in class org.springframework.batch.core.job.flow.FlowExecutionStatus
Special well-known status value.
FatalStepExecutionException - Exception in org.springframework.batch.core.step
 
FatalStepExecutionException(String, Throwable) - Constructor for exception org.springframework.batch.core.step.FatalStepExecutionException
 
faultTolerant() - Method in class org.springframework.batch.core.step.builder.SimpleStepBuilder
 
FaultTolerantChunkProcessor<I,O> - Class in org.springframework.batch.core.step.item
FaultTolerant implementation of the ChunkProcessor interface, that allows for skipping or retry of items that cause exceptions during writing.
FaultTolerantChunkProcessor(ItemProcessor<? super I, ? extends O>, ItemWriter<? super O>, BatchRetryTemplate) - Constructor for class org.springframework.batch.core.step.item.FaultTolerantChunkProcessor
 
FaultTolerantChunkProvider<I> - Class in org.springframework.batch.core.step.item
FaultTolerant implementation of the ChunkProcessor interface, that allows for skipping or retry of items that cause exceptions during reading or processing.
FaultTolerantChunkProvider(ItemReader<? extends I>, RepeatOperations) - Constructor for class org.springframework.batch.core.step.item.FaultTolerantChunkProvider
 
FaultTolerantStepBuilder<I,O> - Class in org.springframework.batch.core.step.builder
A step builder for fully fault tolerant chunk-oriented item processing steps.
FaultTolerantStepBuilder(StepBuilderHelper<?>) - Constructor for class org.springframework.batch.core.step.builder.FaultTolerantStepBuilder
Create a new builder initialized with any properties in the parent.
FaultTolerantStepBuilder(SimpleStepBuilder<I, O>) - Constructor for class org.springframework.batch.core.step.builder.FaultTolerantStepBuilder
Create a new builder initialized with any properties in the parent.
FaultTolerantStepFactoryBean<T,S> - Class in org.springframework.batch.core.step.factory
Factory bean for step that provides options for configuring skip behavior.
FaultTolerantStepFactoryBean() - Constructor for class org.springframework.batch.core.step.factory.FaultTolerantStepFactoryBean
 
FieldExtractor<T> - Interface in org.springframework.batch.item.file.transform
This class will convert an object to an array of its parts.
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 - Interface in org.springframework.batch.item.file.transform
Factory interface for creating FieldSet instances.
FieldSetMapper<T> - Interface in org.springframework.batch.item.file.mapping
Interface that is used to map data obtained from a FieldSet into an object.
FieldSetResultSetExtractor - Class in org.springframework.batch.sample.common
ResultSetExtractor implementation that returns list of FieldSets for given ResultSet.
FileUtils - Class in org.springframework.batch.item.util
Utility methods for files used in batch processing.
findByCreditGreaterThan(BigDecimal, Pageable) - Method in interface org.springframework.batch.sample.data.CustomerCreditRepository
 
findJobExecutions(JobInstance) - Method in class org.springframework.batch.core.repository.dao.JdbcJobExecutionDao
 
findJobExecutions(JobInstance) - Method in interface org.springframework.batch.core.repository.dao.JobExecutionDao
Return all JobExecution for given JobInstance, sorted backwards by creation order (so the first element is the most recent).
findJobExecutions(JobInstance) - Method in class org.springframework.batch.core.repository.dao.MapJobExecutionDao
 
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
 
FIRST_NAME_COLUMN - Static variable in class org.springframework.batch.sample.domain.order.internal.mapper.CustomerFieldSetMapper
 
FIXED_AMOUNT - Static variable in class org.springframework.batch.sample.domain.trade.internal.CustomerCreditIncreaseProcessor
 
FIXED_AMOUNT - Static variable in class org.springframework.batch.sample.domain.trade.internal.CustomerCreditUpdatePreparedStatementSetter
 
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
 
FlatFileCustomerCreditDao - Class in org.springframework.batch.sample.domain.trade.internal
Writes customer's credit information in a file.
FlatFileCustomerCreditDao() - Constructor for class org.springframework.batch.sample.domain.trade.internal.FlatFileCustomerCreditDao
 
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 occured 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 to 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
 
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
 
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(Flow) - Method in class org.springframework.batch.core.step.builder.FlowStepBuilder
Provide a flow to execute during the step.
flow(Flow) - Method in class org.springframework.batch.core.step.builder.StepBuilder
Create a new step builder that will execute a flow.
FlowBuilder<Q> - Class in org.springframework.batch.core.job.builder
A builder for a flow of steps that can be executed as a job or as part of a job.
FlowBuilder(String) - Constructor for class org.springframework.batch.core.job.builder.FlowBuilder
 
FlowBuilder.SplitBuilder<Q> - Class in org.springframework.batch.core.job.builder
A builder for building a split state.
FlowBuilder.SplitBuilder(FlowBuilder<Q>, TaskExecutor) - Constructor for class org.springframework.batch.core.job.builder.FlowBuilder.SplitBuilder
 
FlowBuilder.TransitionBuilder<Q> - Class in org.springframework.batch.core.job.builder
A builder for transitions within a flow.
FlowBuilder.TransitionBuilder(FlowBuilder<Q>, String) - Constructor for class org.springframework.batch.core.job.builder.FlowBuilder.TransitionBuilder
 
FlowBuilder.UnterminatedFlowBuilder<Q> - Class in org.springframework.batch.core.job.builder
A builder for continuing a flow from a decision state.
FlowBuilder.UnterminatedFlowBuilder(FlowBuilder<Q>) - Constructor for class org.springframework.batch.core.job.builder.FlowBuilder.UnterminatedFlowBuilder
 
FlowBuilderException - Exception in org.springframework.batch.core.job.builder
 
FlowBuilderException(String, Exception) - Constructor for exception org.springframework.batch.core.job.builder.FlowBuilderException
 
FlowBuilderException(Exception) - Constructor for exception org.springframework.batch.core.job.builder.FlowBuilderException
 
FlowBuilderException(String) - Constructor for exception org.springframework.batch.core.job.builder.FlowBuilderException
 
FlowElementParser - Class in org.springframework.batch.core.configuration.xml
Internal parser for the <flow/> elements inside a job..
FlowElementParser() - Constructor for class org.springframework.batch.core.configuration.xml.FlowElementParser
 
FlowExecution - Class in org.springframework.batch.core.job.flow
 
FlowExecution(String, FlowExecutionStatus) - Constructor for class org.springframework.batch.core.job.flow.FlowExecution
 
FlowExecutionAggregator - Interface in org.springframework.batch.core.job.flow.support.state
Strategy interface for aggregating FlowExecution instances into a single exit status.
FlowExecutionException - Exception in org.springframework.batch.core.job.flow
 
FlowExecutionException(String) - Constructor for exception org.springframework.batch.core.job.flow.FlowExecutionException
 
FlowExecutionException(String, Throwable) - Constructor for exception org.springframework.batch.core.job.flow.FlowExecutionException
 
FlowExecutionStatus - Class in org.springframework.batch.core.job.flow
Represents the status of FlowExecution.
FlowExecutionStatus(String) - Constructor for class org.springframework.batch.core.job.flow.FlowExecutionStatus
 
FlowExecutor - Interface in org.springframework.batch.core.job.flow
Context and execution strategy for FlowJob to allow it to delegate its execution step by step.
FlowHolder - Interface in org.springframework.batch.core.job.flow
Convenient interface for components that contain nested flows.
FlowJob - Class in org.springframework.batch.core.job.flow
Implementation of the Job interface that allows for complex flows of steps, rather than requiring sequential execution.
FlowJob() - Constructor for class org.springframework.batch.core.job.flow.FlowJob
Create a FlowJob with null name and no flow (invalid state).
FlowJob(String) - Constructor for class org.springframework.batch.core.job.flow.FlowJob
Create a FlowJob with provided name and no flow (invalid state).
FlowJobBuilder - Class in org.springframework.batch.core.job.builder
A job builder for FlowJob instances.
FlowJobBuilder(JobBuilderHelper<?>) - Constructor for class org.springframework.batch.core.job.builder.FlowJobBuilder
Create a new builder initialized with any properties in the parent.
FlowState - Class in org.springframework.batch.core.job.flow.support.state
State that delegates to a Flow
FlowState(Flow, String) - Constructor for class org.springframework.batch.core.job.flow.support.state.FlowState
 
FlowStep - Class in org.springframework.batch.core.job.flow
A Step implementation that delegates to a Flow.
FlowStep() - Constructor for class org.springframework.batch.core.job.flow.FlowStep
Default constructor convenient for configuration purposes.
FlowStep(Flow) - Constructor for class org.springframework.batch.core.job.flow.FlowStep
Constructor for a FlowStep that sets the flow and of the step explicitly.
FlowStepBuilder - Class in org.springframework.batch.core.step.builder
A step builder for FlowStep instances.
FlowStepBuilder(StepBuilderHelper<?>) - Constructor for class org.springframework.batch.core.step.builder.FlowStepBuilder
Create a new builder initialized with any properties in the parent.
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.
FootballExceptionHandler - Class in org.springframework.batch.sample.domain.football.internal
 
FootballExceptionHandler() - Constructor for class org.springframework.batch.sample.domain.football.internal.FootballExceptionHandler
 
FooterFieldExtractor - Class in org.springframework.batch.sample.domain.order.internal.extractor
 
FooterFieldExtractor() - Constructor for class org.springframework.batch.sample.domain.order.internal.extractor.FooterFieldExtractor
 
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
 
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.
fromCode(char) - Static method in enum org.springframework.batch.sample.domain.trade.CustomerOperation
 
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.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.
FutureDateFunction - Class in org.springframework.batch.sample.domain.order.internal.valang
Returns Boolean.TRUE if given value is future date, else it returns Boolean.FALSE
FutureDateFunction(Function[], int, int) - Constructor for class org.springframework.batch.sample.domain.order.internal.valang.FutureDateFunction
 

G

Game - Class in org.springframework.batch.sample.domain.football
 
Game() - Constructor for class org.springframework.batch.sample.domain.football.Game
 
GameFieldSetMapper - Class in org.springframework.batch.sample.domain.football.internal
 
GameFieldSetMapper() - Constructor for class org.springframework.batch.sample.domain.football.internal.GameFieldSetMapper
 
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
 
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.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.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.
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.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
GeneratingTradeItemReader - Class in org.springframework.batch.sample.domain.trade.internal
Generates configurable number of Trade items.
GeneratingTradeItemReader() - Constructor for class org.springframework.batch.sample.domain.trade.internal.GeneratingTradeItemReader
 
GeneratingTradeResettingListener - Class in org.springframework.batch.sample.loop
This listener resets the count of its GeneratingTradeItemReader after the step.
GeneratingTradeResettingListener() - Constructor for class org.springframework.batch.sample.loop.GeneratingTradeResettingListener
 
GenericApplicationContextFactory - Class in org.springframework.batch.core.configuration.support
ApplicationContextFactory implementation that takes a parent context and a path to the context to create.
GenericApplicationContextFactory(Object...) - Constructor for class org.springframework.batch.core.configuration.support.GenericApplicationContextFactory
Create an application context factory for the resource specified.
get(String) - Method in class org.springframework.batch.core.configuration.annotation.JobBuilderFactory
Creates a job builder and initializes its job repository.
get(String) - Method in class org.springframework.batch.core.configuration.annotation.StepBuilderFactory
Creates a step builder and initializes its job repository and transaction manager.
get(String, ObjectFactory) - Method in class org.springframework.batch.core.scope.StepScope
 
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
 
getAddress() - Method in class org.springframework.batch.sample.domain.order.internal.xml.Customer
 
getAddress() - Method in class org.springframework.batch.sample.domain.person.Person
 
getAddressee() - Method in class org.springframework.batch.sample.domain.order.Address
 
getAddrLine1() - Method in class org.springframework.batch.sample.domain.order.Address
 
getAddrLine2() - Method in class org.springframework.batch.sample.domain.order.Address
 
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.
getAge() - Method in class org.springframework.batch.sample.domain.order.internal.xml.Customer
 
getAge() - Method in class org.springframework.batch.sample.domain.person.Person
 
getAllFailureExceptions() - Method in class org.springframework.batch.core.JobExecution
Return all failure causing exceptions for this JobExecution, including step executions.
getAllowStartIfComplete() - Method in class org.springframework.batch.core.step.builder.StepBuilderHelper.CommonStepProperties
 
getAnnotation() - Method in enum org.springframework.batch.core.listener.JobListenerMetaData
 
getAnnotation() - Method in interface org.springframework.batch.core.listener.ListenerMetaData
 
getAnnotation() - Method in enum org.springframework.batch.core.listener.StepListenerMetaData
 
getApplicationContext() - Method in class org.springframework.batch.test.AbstractJobTests
Deprecated.
 
getAsText() - Method in class org.springframework.batch.item.file.transform.RangeArrayPropertyEditor
 
getAttempts() - Method in class org.springframework.batch.sample.domain.football.Game
 
getAttempts() - Method in class org.springframework.batch.sample.domain.football.PlayerSummary
 
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
 
getBeanClass(Element) - Method in class org.springframework.batch.core.configuration.xml.AbstractFlowParser
 
getBeanClass() - Method in class org.springframework.batch.core.configuration.xml.AbstractListenerParser
 
getBeanClass() - Method in class org.springframework.batch.core.configuration.xml.JobExecutionListenerParser
 
getBeanClass(Element) - Method in class org.springframework.batch.core.configuration.xml.JobParser
 
getBeanClass() - Method in class org.springframework.batch.core.configuration.xml.StepListenerParser
 
getBeanClass(Element) - Method in class org.springframework.batch.core.configuration.xml.TopLevelJobListenerParser
 
getBeanClass(Element) - Method in class org.springframework.batch.core.configuration.xml.TopLevelStepListenerParser
 
getBeanClassName(Element) - Method in class org.springframework.batch.core.configuration.xml.JobRepositoryParser
 
getBeanFactoryPostProcessorClasses() - Method in class org.springframework.batch.core.configuration.support.AbstractApplicationContextFactory
Protected access to the list of bean factory post processor classes that should be copied over to the context from the parent.
getBilling() - Method in class org.springframework.batch.sample.domain.order.Order
 
getBillingAddress() - Method in class org.springframework.batch.sample.domain.order.Order
 
getBirthYear() - Method in class org.springframework.batch.sample.domain.football.Player
 
getBufferSize() - Method in class org.springframework.batch.support.transaction.TransactionAwareBufferedWriter
Convenience method for clients to determine if there is any unflushed data.
getChildren() - Method in class org.springframework.batch.sample.domain.person.Person
 
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
 
getCity() - Method in class org.springframework.batch.sample.domain.order.Address
 
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 enum org.springframework.batch.item.file.transform.Alignment
 
getCode() - Method in enum org.springframework.batch.sample.domain.trade.CustomerOperation
 
getCommitCount() - Method in class org.springframework.batch.core.StepExecution
Returns the current number of commits for this execution
getCompanyName() - Method in class org.springframework.batch.sample.domain.order.Customer
 
getCompletes() - Method in class org.springframework.batch.sample.domain.football.Game
 
getCompletes() - Method in class org.springframework.batch.sample.domain.football.PlayerSummary
 
getCompositeListener() - Method in class org.springframework.batch.core.step.AbstractStep
 
getConfigurations() - Method in class org.springframework.batch.sample.launch.DefaultJobLoader
 
getConfigurations() - Method in interface org.springframework.batch.sample.launch.ExportedJobLoader
 
getConfigurations() - Method in interface org.springframework.batch.sample.launch.JobLoader
 
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() - Static method in class org.springframework.batch.core.scope.context.StepSynchronizationManager
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.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
 
getCounter() - Method in class org.springframework.batch.sample.domain.trade.internal.GeneratingTradeItemReader
 
getCounter() - Method in class org.springframework.batch.sample.support.RetrySampleItemWriter
 
getCountry() - Method in class org.springframework.batch.sample.domain.order.Address
 
getCreateTime() - Method in class org.springframework.batch.core.JobExecution
 
getCredit() - Method in class org.springframework.batch.sample.domain.trade.CustomerCredit
 
getCredit() - Method in class org.springframework.batch.sample.domain.trade.CustomerUpdate
 
getCurrentItemCount() - Method in class org.springframework.batch.item.support.AbstractItemCountingItemStreamItemReader
 
getCurrentResource() - Method in class org.springframework.batch.item.file.MultiResourceItemReader
 
getCustomer() - Method in class org.springframework.batch.sample.domain.order.internal.xml.Order
 
getCustomer() - Method in class org.springframework.batch.sample.domain.order.Order
 
getCustomer() - Method in class org.springframework.batch.sample.domain.trade.Trade
 
getCustomerByName(String) - Method in interface org.springframework.batch.sample.domain.trade.CustomerDao
 
getCustomerByName(String) - Method in class org.springframework.batch.sample.domain.trade.internal.JdbcCustomerDao
 
getCustomerName() - Method in class org.springframework.batch.sample.domain.trade.CustomerUpdate
 
getData() - Method in class org.springframework.batch.sample.domain.person.PersonService
 
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.
getDate() - Method in class org.springframework.batch.sample.domain.order.internal.xml.Order
 
getDebit() - Method in class org.springframework.batch.sample.domain.trade.CustomerDebit
 
getDebutYear() - Method in class org.springframework.batch.sample.domain.football.Player
 
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
 
getDescription() - Method in class org.springframework.batch.sample.domain.order.internal.xml.LineItem
 
getDiscountAmount() - Method in class org.springframework.batch.sample.domain.order.LineItem
 
getDiscountPerc() - Method in class org.springframework.batch.sample.domain.order.LineItem
 
getDouble(String) - Method in class org.springframework.batch.core.JobParameters
Typesafe Getter for the Long represented by the provided key.
getDouble(String, double) - Method in class org.springframework.batch.core.JobParameters
Typesafe Getter for the Double represented by the provided key.
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.
getEmail() - Method in class org.springframework.batch.sample.domain.mail.User
 
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.StepExecution
Returns the time that this execution ended
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
 
getErrors() - Method in class org.springframework.batch.sample.domain.trade.internal.HibernateCreditDao
Public accessor for the errors property.
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
Return the exception translator for this instance.
getExecutionContext() - Method in class org.springframework.batch.core.JobExecution
Returns the ExecutionContext for this execution.
getExecutionContext(JobExecution) - Method in interface org.springframework.batch.core.repository.dao.ExecutionContextDao
 
getExecutionContext(StepExecution) - Method in interface org.springframework.batch.core.repository.dao.ExecutionContextDao
 
getExecutionContext(JobExecution) - Method in class org.springframework.batch.core.repository.dao.JdbcExecutionContextDao
 
getExecutionContext(StepExecution) - Method in class org.springframework.batch.core.repository.dao.JdbcExecutionContextDao
 
getExecutionContext(StepExecution) - Method in class org.springframework.batch.core.repository.dao.MapExecutionContextDao
 
getExecutionContext(JobExecution) - Method in class org.springframework.batch.core.repository.dao.MapExecutionContextDao
 
getExecutionContext() - Method in class org.springframework.batch.core.StepExecution
Returns the ExecutionContext for this execution
getExecutionContextDao() - Method in class org.springframework.batch.core.repository.support.MapJobRepositoryFactoryBean
 
getExecutionContextKey(String) - Method in class org.springframework.batch.item.ItemStreamSupport
 
getExecutions(long) - Method in interface org.springframework.batch.core.launch.JobOperator
List the JobExecutions associated with a particular JobInstance, in reverse order of creation (and therefore usually of execution).
getExecutions(long) - Method in class org.springframework.batch.core.launch.support.SimpleJobOperator
 
getExitCode() - Method in class org.springframework.batch.core.ExitStatus
Getter for the exit code (defaults to blank).
getExitDescription() - Method in class org.springframework.batch.core.ExitStatus
Getter for the exit description (defaults to blank)
getExitStatus() - Method in class org.springframework.batch.core.JobExecution
 
getExitStatus(int) - Method in class org.springframework.batch.core.step.tasklet.ConfigurableSystemProcessExitCodeMapper
 
getExitStatus(int) - Method in class org.springframework.batch.core.step.tasklet.SimpleSystemProcessExitCodeMapper
 
getExitStatus(int) - Method in interface org.springframework.batch.core.step.tasklet.SystemProcessExitCodeMapper
 
getExitStatus() - Method in class org.springframework.batch.core.StepContribution
Public getter for the status.
getExitStatus() - Method in class org.springframework.batch.core.StepExecution
 
getExpectedCount() - Method in exception org.springframework.batch.item.file.transform.IncorrectTokenCountException
 
getExpectedLength() - Method in exception org.springframework.batch.item.file.transform.IncorrectLineLengthException
 
getFailedMessages() - Method in class org.springframework.batch.sample.domain.mail.internal.TestMailErrorHandler
 
getFailureExceptions() - Method in class org.springframework.batch.core.JobExecution
 
getFailureExceptions() - Method in class org.springframework.batch.core.StepExecution
 
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'.
getFieldSet(ResultSet) - Static method in class org.springframework.batch.sample.common.FieldSetResultSetExtractor
Processes single row in ResultSet and returns its FieldSet representation.
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
getFirstName() - Method in class example.Person
 
getFirstName() - Method in class org.springframework.batch.sample.domain.football.Player
 
getFirstName() - Method in class org.springframework.batch.sample.domain.order.Customer
 
getFirstName() - Method in class org.springframework.batch.sample.domain.person.Person
 
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
 
getFooter() - Static method in class org.springframework.batch.sample.domain.multiline.AggregateItem
 
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.
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.
getHandlingPrice() - Method in class org.springframework.batch.sample.domain.order.LineItem
 
getHeader() - Static method in class org.springframework.batch.sample.domain.multiline.AggregateItem
 
getId() - Method in class org.springframework.batch.core.Entity
 
getId() - Method in class org.springframework.batch.core.scope.context.StepContext
 
getId() - Method in class org.springframework.batch.sample.common.ProcessIndicatorItemWrapper
 
getId() - Method in class org.springframework.batch.sample.domain.football.Game
 
getId() - Method in class org.springframework.batch.sample.domain.football.Player
 
getId() - Method in class org.springframework.batch.sample.domain.football.PlayerSummary
 
getId() - Method in class org.springframework.batch.sample.domain.mail.User
 
getId() - Method in class org.springframework.batch.sample.domain.trade.CustomerCredit
 
getId() - Method in class org.springframework.batch.sample.domain.trade.Trade
 
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
 
getInput() - Method in exception org.springframework.batch.item.file.transform.IncorrectTokenCountException
 
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.
getInterceptions() - Method in class org.springframework.batch.sample.domain.football.Game
 
getInterceptions() - Method in class org.springframework.batch.sample.domain.football.PlayerSummary
 
getIsin() - Method in class org.springframework.batch.sample.domain.trade.Trade
 
getItem() - Method in class org.springframework.batch.core.step.item.SkipWrapper
Public getter for the item.
getItem() - Method in class org.springframework.batch.sample.common.ProcessIndicatorItemWrapper
 
getItem() - Method in class org.springframework.batch.sample.domain.multiline.AggregateItem
Accessor for the wrapped item.
getItemId() - Method in class org.springframework.batch.sample.domain.order.LineItem
 
getItemListeners() - Method in class org.springframework.batch.core.step.builder.SimpleStepBuilder
 
getItemProcessor() - Method in class org.springframework.batch.core.step.factory.SimpleStepFactoryBean
Protected getter for the ItemProcessor for subclasses to use
getItemReader() - Method in class org.springframework.batch.core.step.factory.SimpleStepFactoryBean
Protected getter for the ItemReader for subclasses to use.
getItems() - Method in class org.springframework.batch.core.step.item.Chunk
 
getItemWriter() - Method in class org.springframework.batch.core.step.factory.SimpleStepFactoryBean
Protected getter for the ItemWriter for subclasses to use
getJdbcTemplate() - Method in class org.springframework.batch.core.repository.dao.AbstractJdbcBatchMetadataDao
 
getJob(String) - Method in interface org.springframework.batch.core.configuration.JobLocator
Locates a Job at runtime.
getJob(String) - Method in class org.springframework.batch.core.configuration.support.MapJobRegistry
 
getJob(String) - Method in interface org.springframework.batch.sample.launch.ExportedJobLoader
 
getJob() - Method in class org.springframework.batch.test.AbstractJobTests
Deprecated.
 
getJob() - Method in class org.springframework.batch.test.JobLauncherTestUtils
 
getJobConfiguration(String) - Method in class org.springframework.batch.sample.launch.DefaultJobLoader
 
getJobConfiguration(String) - Method in interface org.springframework.batch.sample.launch.JobLoader
 
getJobExecution(Long) - Method in interface org.springframework.batch.core.explore.JobExplorer
Retrieve a JobExecution by its id.
getJobExecution(Long) - Method in class org.springframework.batch.core.explore.support.SimpleJobExplorer
 
getJobExecution() - Method in interface org.springframework.batch.core.job.flow.FlowExecutor
 
getJobExecution() - Method in class org.springframework.batch.core.job.flow.JobFlowExecutor
 
getJobExecution(Long) - Method in class org.springframework.batch.core.repository.dao.JdbcJobExecutionDao
 
getJobExecution(Long) - Method in interface org.springframework.batch.core.repository.dao.JobExecutionDao
 
getJobExecution(Long) - Method in class org.springframework.batch.core.repository.dao.MapJobExecutionDao
 
getJobExecution() - Method in class org.springframework.batch.core.StepExecution
Accessor for the execution context information of the enclosing job.
getJobExecutionContext() - Method in class org.springframework.batch.core.scope.context.StepContext
 
getJobExecutionDao() - Method in class org.springframework.batch.core.repository.support.MapJobRepositoryFactoryBean
 
getJobExecutionId() - Method in class org.springframework.batch.core.StepExecution
Accessor for the job execution id.
getJobExecutionListeners() - Method in class org.springframework.batch.core.job.builder.JobBuilderHelper.CommonJobProperties
 
getJobExecutions(JobInstance) - Method in interface org.springframework.batch.core.explore.JobExplorer
Retrieve job executions by their job instance.
getJobExecutions(JobInstance) - Method in class org.springframework.batch.core.explore.support.SimpleJobExplorer
 
getJobId() - Method in class org.springframework.batch.core.JobExecution
Convenience getter for for the id of the enclosing job.
getJobInstance(Long) - Method in interface org.springframework.batch.core.explore.JobExplorer
 
getJobInstance(Long) - Method in class org.springframework.batch.core.explore.support.SimpleJobExplorer
 
getJobInstance() - Method in class org.springframework.batch.core.JobExecution
 
getJobInstance(String, JobParameters) - Method in class org.springframework.batch.core.repository.dao.JdbcJobInstanceDao
The job table is queried for any jobs that match the given identifier, adding them to a list via the RowMapper callback.
getJobInstance(Long) - Method in class org.springframework.batch.core.repository.dao.JdbcJobInstanceDao
 
getJobInstance(JobExecution) - Method in class org.springframework.batch.core.repository.dao.JdbcJobInstanceDao
 
getJobInstance(String, JobParameters) - Method in interface org.springframework.batch.core.repository.dao.JobInstanceDao
Find the job instance that matches the given name and parameters.
getJobInstance(Long) - Method in interface org.springframework.batch.core.repository.dao.JobInstanceDao
Fetch the job instance with the provided identifier.
getJobInstance(JobExecution) - Method in interface org.springframework.batch.core.repository.dao.JobInstanceDao
Fetch the JobInstance for the provided JobExecution.
getJobInstance(String, JobParameters) - Method in class org.springframework.batch.core.repository.dao.MapJobInstanceDao
 
getJobInstance(Long) - Method in class org.springframework.batch.core.repository.dao.MapJobInstanceDao
 
getJobInstance(JobExecution) - Method in class org.springframework.batch.core.repository.dao.MapJobInstanceDao
 
getJobInstanceDao() - Method in class org.springframework.batch.core.repository.support.MapJobRepositoryFactoryBean
 
getJobInstances(String, int, int) - Method in interface org.springframework.batch.core.explore.JobExplorer
Fetch JobInstance values in descending order of creation (and therefore usually of first execution).
getJobInstances(String, int, int) - Method in class org.springframework.batch.core.explore.support.SimpleJobExplorer
 
getJobInstances(String, int, int) - Method in interface org.springframework.batch.core.launch.JobOperator
List the JobInstances for a given job name, in reverse order of creation (and therefore usually of first execution).
getJobInstances(String, int, int) - Method in class org.springframework.batch.core.launch.support.SimpleJobOperator
 
getJobInstances(String, int, int) - Method in class org.springframework.batch.core.repository.dao.JdbcJobInstanceDao
 
getJobInstances(String, int, int) - Method in interface org.springframework.batch.core.repository.dao.JobInstanceDao
Fetch the last job instances with the provided name, sorted backwards by primary key.
getJobInstances(String, int, int) - Method in class org.springframework.batch.core.repository.dao.MapJobInstanceDao
 
getJobLauncher() - Method in interface org.springframework.batch.core.configuration.annotation.BatchConfigurer
 
getJobLauncher() - Method in class org.springframework.batch.core.configuration.annotation.DefaultBatchConfigurer
 
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.scope.context.StepContext
Convenient accessor for current job name identifier.
getJobNames() - Method in interface org.springframework.batch.core.configuration.ListableJobLocator
Provides the currently registered job names.
getJobNames() - Method in class org.springframework.batch.core.configuration.support.MapJobRegistry
Provides an unmodifiable view of the job names.
getJobNames() - Method in interface org.springframework.batch.core.explore.JobExplorer
Query the repository for all unique JobInstance names (sorted alphabetically).
getJobNames() - Method in class org.springframework.batch.core.explore.support.SimpleJobExplorer
 
getJobNames() - Method in interface org.springframework.batch.core.launch.JobOperator
List the available job names that can be launched with JobOperator.start(String, String).
getJobNames() - Method in class org.springframework.batch.core.launch.support.SimpleJobOperator
 
getJobNames() - Method in class org.springframework.batch.core.repository.dao.JdbcJobInstanceDao
 
getJobNames() - Method in interface org.springframework.batch.core.repository.dao.JobInstanceDao
Retrieve the names of all job instances sorted alphabetically - i.e.
getJobNames() - Method in class org.springframework.batch.core.repository.dao.MapJobInstanceDao
 
getJobParameters(Properties) - Method in class org.springframework.batch.core.converter.DefaultJobParametersConverter
Check for suffix on keys and use those to decide how to convert the value.
getJobParameters(Properties) - Method in interface org.springframework.batch.core.converter.JobParametersConverter
Get a new JobParameters instance.
getJobParameters() - Method in class org.springframework.batch.core.JobExecution
 
getJobParameters(Properties) - Method in class org.springframework.batch.core.launch.support.ScheduledJobParametersFactory
 
getJobParameters(Long) - Method in class org.springframework.batch.core.repository.dao.JdbcJobExecutionDao
 
getJobParameters() - Method in class org.springframework.batch.core.scope.context.StepContext
 
getJobParameters(Job, StepExecution) - Method in class org.springframework.batch.core.step.job.DefaultJobParametersExtractor
 
getJobParameters(Job, StepExecution) - Method in interface org.springframework.batch.core.step.job.JobParametersExtractor
Extract job parameters from the step execution, for example from the execution context or other properties.
getJobParameters() - Method in class org.springframework.batch.core.StepExecution
Convenience method to get the current job parameters.
getJobParametersIncrementer() - Method in class org.springframework.batch.core.configuration.support.GroupAwareJob
 
getJobParametersIncrementer() - Method in class org.springframework.batch.core.job.AbstractJob
 
getJobParametersIncrementer() - Method in class org.springframework.batch.core.job.builder.JobBuilderHelper.CommonJobProperties
 
getJobParametersIncrementer() - Method in interface org.springframework.batch.core.Job
If clients need to generate new parameters for the next execution in a sequence they can use this incrementer.
getJobParametersValidator() - Method in class org.springframework.batch.core.configuration.support.GroupAwareJob
 
getJobParametersValidator() - Method in class org.springframework.batch.core.job.AbstractJob
 
getJobParametersValidator() - Method in class org.springframework.batch.core.job.builder.JobBuilderHelper.CommonJobProperties
 
getJobParametersValidator() - Method in interface org.springframework.batch.core.Job
A validator for the job parameters of a JobExecution.
getJobRepository() - Method in interface org.springframework.batch.core.configuration.annotation.BatchConfigurer
 
getJobRepository() - Method in class org.springframework.batch.core.configuration.annotation.DefaultBatchConfigurer
 
getJobRepository() - Method in class org.springframework.batch.core.job.AbstractJob
Convenience method for subclasses to access the job repository.
getJobRepository() - Method in class org.springframework.batch.core.job.builder.JobBuilderHelper.CommonJobProperties
 
getJobRepository() - Method in class org.springframework.batch.core.job.builder.JobBuilderHelper
 
getJobRepository() - Method in class org.springframework.batch.core.repository.support.AbstractJobRepositoryFactoryBean
Convenience method for clients to grab the JobRepository without a cast.
getJobRepository() - Method in class org.springframework.batch.core.step.AbstractStep
 
getJobRepository() - Method in class org.springframework.batch.core.step.builder.StepBuilderHelper.CommonStepProperties
 
getJobRepository() - Method in class org.springframework.batch.core.step.builder.StepBuilderHelper
 
getJobRepository() - Method in class org.springframework.batch.test.AbstractJobTests
Deprecated.
 
getJobRepository() - Method in class org.springframework.batch.test.JobLauncherTestUtils
 
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
 
getLast_name() - Method in class org.springframework.batch.sample.domain.person.Person
Intentionally non-standard method name for testing purposes
getLastJobExecution(JobInstance) - Method in class org.springframework.batch.core.repository.dao.JdbcJobExecutionDao
 
getLastJobExecution(JobInstance) - Method in interface org.springframework.batch.core.repository.dao.JobExecutionDao
Find the last JobExecution to have been created for a given JobInstance.
getLastJobExecution(JobInstance) - Method in class org.springframework.batch.core.repository.dao.MapJobExecutionDao
 
getLastJobExecution(String, JobParameters) - Method in interface org.springframework.batch.core.repository.JobRepository
 
getLastJobExecution(String, JobParameters) - Method in class org.springframework.batch.core.repository.support.SimpleJobRepository
 
getLastName() - Method in class example.Person
 
getLastName() - Method in class org.springframework.batch.sample.domain.football.Player
 
getLastName() - Method in class org.springframework.batch.sample.domain.order.Customer
 
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
 
getLimit() - Method in class org.springframework.batch.sample.domain.trade.internal.GeneratingTradeItemReader
 
getLineItems() - Method in class org.springframework.batch.sample.domain.order.internal.xml.Order
 
getLineItems() - Method in class org.springframework.batch.sample.domain.order.Order
 
getLineNumber() - Method in exception org.springframework.batch.item.file.FlatFileParseException
 
getLineNumber() - Method in exception org.springframework.batch.item.file.NonTransientFlatFileException
 
getListener(Object) - Static method in class org.springframework.batch.core.listener.JobListenerFactoryBean
Convenience method to wrap any object and expose the appropriate JobExecutionListener interfaces.
getListener(Object) - Static method in class org.springframework.batch.core.listener.StepListenerFactoryBean
Convenience method to wrap any object and expose the appropriate StepListener interfaces.
getListener() - Method in class org.springframework.batch.core.step.item.SimpleChunkProcessor
 
getListener() - Method in class org.springframework.batch.core.step.item.SimpleChunkProvider
 
getListenerInterface() - Method in enum org.springframework.batch.core.listener.JobListenerMetaData
 
getListenerInterface() - Method in interface org.springframework.batch.core.listener.ListenerMetaData
 
getListenerInterface() - Method in enum org.springframework.batch.core.listener.StepListenerMetaData
 
getListeners() - Method in class org.springframework.batch.core.step.factory.SimpleStepFactoryBean
Protected getter for the StepListeners.
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
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
 
getMetaDataFromPropertyName(String) - Method in class org.springframework.batch.core.listener.AbstractListenerFactoryBean
 
getMetaDataFromPropertyName(String) - Method in class org.springframework.batch.core.listener.JobListenerFactoryBean
 
getMetaDataFromPropertyName(String) - Method in class org.springframework.batch.core.listener.StepListenerFactoryBean
 
getMetaDataValues() - Method in class org.springframework.batch.core.configuration.xml.AbstractListenerParser
 
getMetaDataValues() - Method in class org.springframework.batch.core.configuration.xml.JobExecutionListenerParser
 
getMetaDataValues() - Method in class org.springframework.batch.core.configuration.xml.StepListenerParser
 
getMetaDataValues() - Method in class org.springframework.batch.core.listener.AbstractListenerFactoryBean
 
getMetaDataValues() - Method in class org.springframework.batch.core.listener.JobListenerFactoryBean
 
getMetaDataValues() - Method in class org.springframework.batch.core.listener.StepListenerFactoryBean
 
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.listener.JobListenerMetaData
 
getMethodName() - Method in interface org.springframework.batch.core.listener.ListenerMetaData
 
getMethodName() - Method in enum org.springframework.batch.core.listener.StepListenerMetaData
 
getMiddleName() - Method in class org.springframework.batch.sample.domain.order.Customer
 
getMin() - Method in class org.springframework.batch.item.file.transform.Range
 
getMoo() - Method in class org.springframework.batch.sample.domain.order.internal.xml.Customer
 
getName() - Method in class org.springframework.batch.core.configuration.support.GroupAwareJob
Concatenates the group name and the delegate job name (joining with a ".").
getName() - Method in class org.springframework.batch.core.job.AbstractJob
 
getName() - Method in class org.springframework.batch.core.job.builder.JobBuilderHelper.CommonJobProperties
 
getName() - Method in class org.springframework.batch.core.job.builder.JobBuilderHelper
 
getName() - Method in interface org.springframework.batch.core.job.flow.Flow
 
getName() - Method in class org.springframework.batch.core.job.flow.FlowExecution
 
getName() - Method in class org.springframework.batch.core.job.flow.FlowExecutionStatus
 
getName() - Method in interface org.springframework.batch.core.job.flow.State
The name of the state.
getName() - Method in class org.springframework.batch.core.job.flow.support.SimpleFlow
Get the name for this flow.
getName() - Method in class org.springframework.batch.core.job.flow.support.state.AbstractState
 
getName() - Method in interface org.springframework.batch.core.Job
 
getName() - Method in class org.springframework.batch.core.step.AbstractStep
 
getName() - Method in class org.springframework.batch.core.step.builder.StepBuilderHelper.CommonStepProperties
 
getName() - Method in class org.springframework.batch.core.step.builder.StepBuilderHelper
 
getName() - Method in class org.springframework.batch.core.step.factory.SimpleStepFactoryBean
Public getter for the name of the step.
getName() - Method in interface org.springframework.batch.core.Step
 
getName() - Method in class org.springframework.batch.item.util.ExecutionContextUserSupport
 
getName() - Method in class org.springframework.batch.sample.domain.mail.User
 
getName() - Method in class org.springframework.batch.sample.domain.order.internal.xml.Customer
 
getName() - Method in class org.springframework.batch.sample.domain.order.internal.xml.Shipper
 
getName() - Method in class org.springframework.batch.sample.domain.person.Child
 
getName() - Method in class org.springframework.batch.sample.domain.trade.CustomerCredit
 
getName() - Method in class org.springframework.batch.sample.domain.trade.CustomerDebit
 
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.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
 
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.SimpleFlowFactoryBean
 
getObject() - Method in class org.springframework.batch.core.explore.support.JobExplorerFactoryBean
 
getObject() - Method in class org.springframework.batch.core.explore.support.MapJobExplorerFactoryBean
 
getObject() - Method in class org.springframework.batch.core.listener.AbstractListenerFactoryBean
 
getObject() - Method in class org.springframework.batch.core.repository.support.AbstractJobRepositoryFactoryBean
 
getObject() - Method in class org.springframework.batch.core.step.factory.SimpleStepFactoryBean
Create a Step from the configuration provided.
getObject() - Method in class org.springframework.batch.core.step.StepLocatorStepFactoryBean
 
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.SimpleFlowFactoryBean
 
getObjectType() - Method in class org.springframework.batch.core.explore.support.AbstractJobExplorerFactoryBean
The type of object to be returned from FactoryBean.getObject().
getObjectType() - Method in class org.springframework.batch.core.listener.JobListenerFactoryBean
 
getObjectType() - Method in class org.springframework.batch.core.listener.StepListenerFactoryBean
 
getObjectType() - Method in class org.springframework.batch.core.repository.support.AbstractJobRepositoryFactoryBean
The type of object to be returned from AbstractJobRepositoryFactoryBean.getObject().
getObjectType() - Method in class org.springframework.batch.core.step.factory.SimpleStepFactoryBean
 
getObjectType() - Method in class org.springframework.batch.core.step.StepLocatorStepFactoryBean
Tell clients that we are a factory for Step instances.
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
 
getOperation() - Method in class org.springframework.batch.sample.domain.trade.CustomerUpdate
 
getOpponent() - Method in class org.springframework.batch.sample.domain.football.Game
 
getOrder() - Method in class org.springframework.batch.core.configuration.support.AutomaticJobRegistrar
 
getOrder() - Method in class org.springframework.batch.core.scope.StepScope
 
getOrderDate() - Method in class org.springframework.batch.sample.domain.order.Order
 
getOrderedQueryAlias() - Method in class org.springframework.batch.item.database.support.DerbyPagingQueryProvider
 
getOrderedQueryAlias() - Method in class org.springframework.batch.item.database.support.SqlWindowingPagingQueryProvider
 
getOrderId() - Method in class org.springframework.batch.sample.domain.order.Order
 
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 interface org.springframework.batch.core.launch.JobOperator
Get the JobParameters as an easily readable String.
getParameters(long) - Method in class org.springframework.batch.core.launch.support.SimpleJobOperator
 
getParamTypes() - Method in enum org.springframework.batch.core.listener.JobListenerMetaData
 
getParamTypes() - Method in interface org.springframework.batch.core.listener.ListenerMetaData
 
getParamTypes() - Method in enum org.springframework.batch.core.listener.StepListenerMetaData
 
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.
getPartitionNames(int) - Method in interface org.springframework.batch.core.partition.support.PartitionNameProvider
 
getPassingTd() - Method in class org.springframework.batch.sample.domain.football.Game
 
getPassingTd() - Method in class org.springframework.batch.sample.domain.football.PlayerSummary
 
getPassingYards() - Method in class org.springframework.batch.sample.domain.football.Game
 
getPassingYards() - Method in class org.springframework.batch.sample.domain.football.PlayerSummary
 
getPaymentDesc() - Method in class org.springframework.batch.sample.domain.order.BillingInfo
 
getPaymentId() - Method in class org.springframework.batch.sample.domain.order.BillingInfo
 
getPerOunceRate() - Method in class org.springframework.batch.sample.domain.order.internal.xml.Shipper
 
getPerUnitOunces() - Method in class org.springframework.batch.sample.domain.order.internal.xml.LineItem
 
getPoo() - Method in class org.springframework.batch.sample.domain.order.internal.xml.Customer
 
getPosition() - Method in class org.springframework.batch.sample.domain.football.Player
 
getPrice() - Method in class org.springframework.batch.sample.domain.order.internal.xml.LineItem
 
getPrice() - Method in class org.springframework.batch.sample.domain.order.LineItem
 
getPrice() - Method in class org.springframework.batch.sample.domain.trade.Trade
 
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(JobParameters) - Method in class org.springframework.batch.core.launch.support.ScheduledJobParametersFactory
Convert schedule date to Date, and assume all other parameters can be represented by their default string value.
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.
getProperty(String) - Method in class org.springframework.batch.sample.launch.DefaultJobLoader
 
getProperty(String) - Method in interface org.springframework.batch.sample.launch.ExportedJobLoader
 
getProperty(String) - Method in interface org.springframework.batch.sample.launch.JobLoader
 
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
 
getQuantity() - Method in class org.springframework.batch.sample.domain.order.internal.xml.LineItem
 
getQuantity() - Method in class org.springframework.batch.sample.domain.order.LineItem
 
getQuantity() - Method in class org.springframework.batch.sample.domain.trade.Trade
 
getQuery(String) - Method in class org.springframework.batch.core.repository.dao.AbstractJdbcBatchMetadataDao
 
getReadCount() - Method in class org.springframework.batch.core.StepContribution
Public access to the read counter.
getReadCount() - Method in class org.springframework.batch.core.StepExecution
Returns the current number of items read for this execution
getReader() - Method in class org.springframework.batch.core.step.builder.SimpleStepBuilder
 
getReadSkipCount() - Method in class org.springframework.batch.core.StepContribution
 
getReadSkipCount() - Method in class org.springframework.batch.core.StepExecution
 
getReceivedCount() - Method in class org.springframework.batch.sample.domain.person.PersonService
 
getReceivedMessages() - Method in class org.springframework.batch.sample.domain.mail.internal.TestMailSender
 
getReceptions() - Method in class org.springframework.batch.sample.domain.football.Game
 
getReceptions() - Method in class org.springframework.batch.sample.domain.football.PlayerSummary
 
getReceptionYards() - Method in class org.springframework.batch.sample.domain.football.Game
 
getReceptionYards() - Method in class org.springframework.batch.sample.domain.football.PlayerSummary
 
getRegistrationId() - Method in class org.springframework.batch.sample.domain.order.Customer
 
getRestartable() - Method in class org.springframework.batch.core.job.builder.JobBuilderHelper.CommonJobProperties
 
getResult(XMLEventWriter) - Static method in class org.springframework.batch.item.xml.StaxUtils
 
getReturnedCount() - Method in class org.springframework.batch.sample.domain.person.PersonService
 
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 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
 
getRushes() - Method in class org.springframework.batch.sample.domain.football.Game
 
getRushes() - Method in class org.springframework.batch.sample.domain.football.PlayerSummary
 
getRushYards() - Method in class org.springframework.batch.sample.domain.football.Game
 
getRushYards() - Method in class org.springframework.batch.sample.domain.football.PlayerSummary
 
getSelectClause() - Method in class org.springframework.batch.item.database.support.AbstractSqlPagingQueryProvider
 
getShipper() - Method in class org.springframework.batch.sample.domain.order.internal.xml.Order
 
getShipperId() - Method in class org.springframework.batch.sample.domain.order.ShippingInfo
 
getShipping() - Method in class org.springframework.batch.sample.domain.order.Order
 
getShippingAddress() - Method in class org.springframework.batch.sample.domain.order.Order
 
getShippingInfo() - Method in class org.springframework.batch.sample.domain.order.ShippingInfo
 
getShippingPrice() - Method in class org.springframework.batch.sample.domain.order.LineItem
 
getShippingTypeId() - Method in class org.springframework.batch.sample.domain.order.ShippingInfo
 
getSkipCount() - Method in class org.springframework.batch.core.StepContribution
 
getSkipCount() - Method in class org.springframework.batch.core.StepExecution
 
getSkipLimit() - Method in exception org.springframework.batch.core.step.skip.SkipLimitExceededException
 
getSkips() - Method in class org.springframework.batch.core.step.item.Chunk
 
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 of sort columns as the key and boolean for ascending/descending (assending = true).
getSource(XMLEventReader) - Static method in class org.springframework.batch.item.xml.StaxUtils
 
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
 
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
 
getStartTime() - Method in class org.springframework.batch.core.JobExecution
 
getStartTime() - Method in class org.springframework.batch.core.StepExecution
Gets the time this execution started
getState(String) - Method in interface org.springframework.batch.core.job.flow.Flow
Retrieve the State with the given name.
getState(String) - Method in class org.springframework.batch.core.job.flow.support.SimpleFlow
Retrieve the State with the given name.
getState() - Method in class org.springframework.batch.core.job.flow.support.StateTransition
Public getter for the State.
getState() - Method in class org.springframework.batch.sample.domain.order.Address
 
getStatefulSession() - Method in class org.springframework.batch.item.database.orm.AbstractHibernateQueryProvider
 
getStatelessSession() - Method in class org.springframework.batch.item.database.orm.AbstractHibernateQueryProvider
 
getStates() - Method in interface org.springframework.batch.core.job.flow.Flow
Convenient accessor for clients needing to explore the states of this flow.
getStates() - Method in class org.springframework.batch.core.job.flow.support.SimpleFlow
Convenient accessor for clients needing to explore the states of this flow.
getStateTransitionReference(ParserContext, BeanDefinition, String, String) - Static method in class org.springframework.batch.core.configuration.xml.AbstractFlowParser
 
getStatus() - Method in class org.springframework.batch.core.job.flow.FlowExecution
 
getStatus() - Method in class org.springframework.batch.core.JobExecution
 
getStatus() - Method in exception org.springframework.batch.core.JobInterruptedException
The desired status of the surrounding execution after the interruption.
getStatus() - Method in class org.springframework.batch.core.StepExecution
Returns the current status of this step
getStep(String, String) - Method in interface org.springframework.batch.core.configuration.StepRegistry
Returns the Step of the specified job based on its name.
getStep(String, String) - Method in class org.springframework.batch.core.configuration.support.MapStepRegistry
 
getStep(String) - Method in class org.springframework.batch.core.job.AbstractJob
Retrieve the step with the given name.
getStep(String) - Method in class org.springframework.batch.core.job.flow.FlowJob
Retrieve the step with the given name.
getStep() - Method in class org.springframework.batch.core.job.flow.support.state.StepState
 
getStep(String) - Method in class org.springframework.batch.core.job.SimpleJob
 
getStep() - Method in class org.springframework.batch.core.partition.support.TaskExecutorPartitionHandler
The step instance that will be executed in parallel by this handler.
getStep() - Method in interface org.springframework.batch.core.step.StepHolder
 
getStep(String) - Method in interface org.springframework.batch.core.step.StepLocator
 
getStepContext() - Method in class org.springframework.batch.core.scope.context.ChunkContext
 
getStepExecution(Long, Long) - Method in interface org.springframework.batch.core.explore.JobExplorer
Retrieve a StepExecution by its id and parent JobExecution id.
getStepExecution(Long, Long) - Method in class org.springframework.batch.core.explore.support.SimpleJobExplorer
 
getStepExecution() - Method in interface org.springframework.batch.core.job.flow.FlowExecutor
 
getStepExecution() - Method in class org.springframework.batch.core.job.flow.JobFlowExecutor
 
getStepExecution(JobExecution, Long) - Method in class org.springframework.batch.core.repository.dao.JdbcStepExecutionDao
 
getStepExecution(JobExecution, Long) - Method in class org.springframework.batch.core.repository.dao.MapStepExecutionDao
 
getStepExecution(JobExecution, Long) - Method in interface org.springframework.batch.core.repository.dao.StepExecutionDao
Retrieve a StepExecution from its id.
getStepExecution() - Method in class org.springframework.batch.core.scope.context.StepContext
The current StepExecution that is active in this context.
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.
getStepExecutionContext() - Method in class org.springframework.batch.core.scope.context.StepContext
 
getStepExecutionCount(JobInstance, String) - Method in interface org.springframework.batch.core.repository.JobRepository
 
getStepExecutionCount(JobInstance, String) - Method in class org.springframework.batch.core.repository.support.SimpleJobRepository
 
getStepExecutionDao() - Method in class org.springframework.batch.core.repository.support.MapJobRepositoryFactoryBean
 
getStepExecutionListeners() - Method in class org.springframework.batch.core.step.builder.StepBuilderHelper.CommonStepProperties
 
getStepExecutions() - Method in class org.springframework.batch.core.JobExecution
Accessor for the step executions.
getStepExecutionSummaries(long) - Method in interface org.springframework.batch.core.launch.JobOperator
Summarise the StepExecution instances belonging to the JobExecution with the supplied id, giving details of status, start and end times etc.
getStepExecutionSummaries(long) - Method in class org.springframework.batch.core.launch.support.SimpleJobOperator
 
getStepName() - Method in interface org.springframework.batch.core.partition.StepExecutionSplitter
The name of the step configuration that will be executed remotely.
getStepName() - Method in class org.springframework.batch.core.partition.support.SimpleStepExecutionSplitter
 
getStepName() - Method in class org.springframework.batch.core.scope.context.StepContext
Convenient accessor for current step name identifier.
getStepName() - Method in class org.springframework.batch.core.StepExecution
 
getStepNames() - Method in class org.springframework.batch.core.job.AbstractJob
Retrieve the step names.
getStepNames() - Method in class org.springframework.batch.core.job.flow.FlowJob
Retrieve the step names.
getStepNames() - Method in class org.springframework.batch.core.job.SimpleJob
Convenience method for clients to inspect the steps for this job.
getStepNames() - Method in interface org.springframework.batch.core.step.StepLocator
 
getStepOperations() - Method in class org.springframework.batch.core.step.builder.AbstractTaskletStepBuilder
Convenience method for subclasses to access the step operations that were injected by user.
getStepOperations() - Method in class org.springframework.batch.core.step.factory.SimpleStepFactoryBean
Protected getter for the step operations to make them available in subclasses.
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
 
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
 
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.StepContext
Convenient accessor for System properties to make it easy to access them from placeholder expressions.
getTablePrefix() - Method in class org.springframework.batch.core.repository.dao.AbstractJdbcBatchMetadataDao
 
getTaskExecutor() - Method in class org.springframework.batch.core.step.factory.SimpleStepFactoryBean
Mkae the TaskExecutor available to subclasses
getTeam() - Method in class org.springframework.batch.sample.domain.football.Game
 
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
 
getTitle() - Method in class org.springframework.batch.sample.domain.person.Person
 
getTotalItems() - Method in class org.springframework.batch.sample.domain.order.Order
 
getTotalLines() - Method in class org.springframework.batch.sample.domain.order.Order
 
getTotalPrice() - Method in class org.springframework.batch.sample.domain.order.LineItem
 
getTotalPrice() - Method in class org.springframework.batch.sample.domain.order.Order
 
getTotalPrice() - Method in class org.springframework.batch.sample.domain.trade.internal.TradeWriter
 
getTotalTd() - Method in class org.springframework.batch.sample.domain.football.Game
 
getTotalTd() - Method in class org.springframework.batch.sample.domain.football.PlayerSummary
 
getTransactionAttribute() - Method in class org.springframework.batch.core.step.factory.SimpleStepFactoryBean
Getter for the TransactionAttribute for subclasses only.
getTransactionManager() - Method in interface org.springframework.batch.core.configuration.annotation.BatchConfigurer
 
getTransactionManager() - Method in class org.springframework.batch.core.configuration.annotation.DefaultBatchConfigurer
 
getTransactionManager() - Method in class org.springframework.batch.core.repository.support.AbstractJobRepositoryFactoryBean
The transaction manager used in this factory.
getTransactionManager() - Method in class org.springframework.batch.core.step.builder.StepBuilderHelper.CommonStepProperties
 
getTransactionManager() - Method in class org.springframework.batch.core.step.builder.StepBuilderHelper
 
getType() - Method in class org.springframework.batch.core.JobParameter
 
getUniqueJobParameters() - Method in class org.springframework.batch.test.AbstractJobTests
Deprecated.
 
getUniqueJobParameters() - 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
 
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.
getVersion() - Method in class org.springframework.batch.sample.domain.trade.Trade
 
getWeek() - Method in class org.springframework.batch.sample.domain.football.Game
 
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
 
getXmlEventReader(Source) - Static method in class org.springframework.batch.item.xml.StaxUtils
 
getXmlEventWriter(Result) - Static method in class org.springframework.batch.item.xml.StaxUtils
 
getYear() - Method in class org.springframework.batch.sample.domain.football.Game
 
getYear() - Method in class org.springframework.batch.sample.domain.football.PlayerSummary
 
getZipCode() - Method in class org.springframework.batch.sample.domain.order.Address
 
gridSize(int) - Method in class org.springframework.batch.core.step.builder.PartitionStepBuilder
A hint to the PartitionStepBuilder.splitter(StepExecutionSplitter) about how many step executions are required.
GroupAwareJob - Class in org.springframework.batch.core.configuration.support
A Job that can optionally prepend a group name to another job's name, to make it fit a naming convention for type or origin.
GroupAwareJob(Job) - Constructor for class org.springframework.batch.core.configuration.support.GroupAwareJob
Create a new Job with the delegate and no group name.
GroupAwareJob(String, Job) - Constructor for class org.springframework.batch.core.configuration.support.GroupAwareJob
Create a new Job with the given group name and delegate.

H

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 interface org.springframework.batch.core.job.flow.State
Handle some business or processing logic and return a status that can be used to drive a flow to the next State.
handle(FlowExecutor) - Method in class org.springframework.batch.core.job.flow.support.state.AbstractState
 
handle(FlowExecutor) - Method in class org.springframework.batch.core.job.flow.support.state.DecisionState
 
handle(FlowExecutor) - Method in class org.springframework.batch.core.job.flow.support.state.EndState
Return the FlowExecutionStatus stored.
handle(FlowExecutor) - Method in class org.springframework.batch.core.job.flow.support.state.FlowState
 
handle(FlowExecutor) - Method in class org.springframework.batch.core.job.flow.support.state.SplitState
Execute the flows in parallel by passing them to the TaskExecutor and wait for all of them to finish before proceeding.
handle(FlowExecutor) - Method in class org.springframework.batch.core.job.flow.support.state.StepState
 
handle(StepExecutionSplitter, StepExecution) - Method in interface org.springframework.batch.core.partition.PartitionHandler
Main entry point for PartitionHandler interface.
handle(StepExecutionSplitter, StepExecution) - Method in class org.springframework.batch.core.partition.support.AbstractPartitionHandler
 
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.
handle(MailMessage, Exception) - Method in class org.springframework.batch.sample.domain.mail.internal.TestMailErrorHandler
 
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.
handleException(RepeatContext, Throwable) - Method in class org.springframework.batch.sample.domain.football.internal.FootballExceptionHandler
 
handleLine(String) - Method in interface org.springframework.batch.item.file.LineCallbackHandler
 
handleLine(String) - Method in class org.springframework.batch.sample.support.HeaderCopyCallback
 
handleListenersElement(Element, BeanDefinition, ParserContext) - Method in class org.springframework.batch.core.configuration.xml.StepListenerParser
 
handleStep(Step, JobExecution) - Method in class org.springframework.batch.core.job.AbstractJob
Convenience method for subclasses to delegate the handling of a specific step in the context of the current JobExecution.
handleStep(Step, JobExecution) - Method in class org.springframework.batch.core.job.SimpleStepHandler
 
handleStep(Step, JobExecution) - Method in interface org.springframework.batch.core.job.StepHandler
Handle a step and return the execution for it.
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).
HANDLING_PRICE_COLUMN - Static variable in class org.springframework.batch.sample.domain.order.internal.mapper.OrderItemFieldSetMapper
 
hasAttribute(String) - Method in class org.springframework.batch.repeat.context.SynchronizedAttributeAccessor
 
hashCode() - Method in class org.springframework.batch.core.configuration.support.AbstractApplicationContextFactory
 
hashCode() - Method in class org.springframework.batch.core.configuration.support.GroupAwareJob
 
hashCode() - Method in class org.springframework.batch.core.configuration.support.OsgiBundleXmlApplicationContextFactory
 
hashCode() - Method in class org.springframework.batch.core.Entity
Use ID if it exists to establish hash code, otherwise fall back to Object.hashCode().
hashCode() - Method in class org.springframework.batch.core.ExitStatus
Compatible with the equals implementation.
hashCode() - Method in class org.springframework.batch.core.job.flow.FlowExecutionStatus
 
hashCode() - Method in class org.springframework.batch.core.JobParameter
 
hashCode() - Method in class org.springframework.batch.core.JobParameters
 
hashCode() - Method in class org.springframework.batch.core.listener.MethodInvokerMethodInterceptor
hashCode() - Method in class org.springframework.batch.core.scope.context.StepContext
Overrides the default behaviour to provide a hash code based only on the step execution.
hashCode() - Method in class org.springframework.batch.core.StepContribution
 
hashCode() - Method in class org.springframework.batch.core.StepExecution
 
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.sample.domain.football.Game
 
hashCode() - Method in class org.springframework.batch.sample.domain.football.PlayerSummary
 
hashCode() - Method in class org.springframework.batch.sample.domain.order.Address
 
hashCode() - Method in class org.springframework.batch.sample.domain.order.BillingInfo
 
hashCode() - Method in class org.springframework.batch.sample.domain.order.Customer
 
hashCode() - Method in class org.springframework.batch.sample.domain.order.LineItem
 
hashCode() - Method in class org.springframework.batch.sample.domain.order.Order
 
hashCode() - Method in class org.springframework.batch.sample.domain.order.ShippingInfo
 
hashCode() - Method in class org.springframework.batch.sample.domain.person.Child
 
hashCode() - Method in class org.springframework.batch.sample.domain.person.Person
 
hashCode() - Method in class org.springframework.batch.sample.domain.trade.CustomerCredit
 
hashCode() - Method in class org.springframework.batch.sample.domain.trade.CustomerDebit
 
hashCode() - Method in class org.springframework.batch.sample.domain.trade.Trade
 
hashCode() - Method in class org.springframework.batch.support.SimpleMethodInvoker
 
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
 
HeaderCopyCallback - Class in org.springframework.batch.sample.support
Designed to be registered with both FlatFileItemReader and FlatFileItemWriter and copy header line from input file to output file.
HeaderCopyCallback() - Constructor for class org.springframework.batch.sample.support.HeaderCopyCallback
 
HeaderFieldExtractor - Class in org.springframework.batch.sample.domain.order.internal.extractor
 
HeaderFieldExtractor() - Constructor for class org.springframework.batch.sample.domain.order.internal.extractor.HeaderFieldExtractor
 
HeaderFieldSetMapper - Class in org.springframework.batch.sample.domain.order.internal.mapper
 
HeaderFieldSetMapper() - Constructor for class org.springframework.batch.sample.domain.order.internal.mapper.HeaderFieldSetMapper
 
HibernateAwareCustomerCreditItemWriter - Class in org.springframework.batch.sample.domain.trade.internal
Delegates writing to a custom DAO and flushes + clears hibernate session to fulfill the ItemWriter contract.
HibernateAwareCustomerCreditItemWriter() - Constructor for class org.springframework.batch.sample.domain.trade.internal.HibernateAwareCustomerCreditItemWriter
 
HibernateCreditDao - Class in org.springframework.batch.sample.domain.trade.internal
 
HibernateCreditDao() - Constructor for class org.springframework.batch.sample.domain.trade.internal.HibernateCreditDao
 
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
 
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
 
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
 
HibernateQueryProvider - 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.
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

IbatisBatchItemWriter<T> - Class in org.springframework.batch.item.database
ItemWriter that uses the batching features from SqlMapClientTemplate to execute a batch of statements for all items provided.
The user must provide an iBATIS statement id that points to the SQL statement defined in the iBATIS SqlMap configuration.
It is expected that IbatisBatchItemWriter.write(List) is called inside a transaction.
The writer is thread safe after its properties are set (normal singleton behavior), so it can be used to write in multiple concurrent transactions.
IbatisBatchItemWriter() - Constructor for class org.springframework.batch.item.database.IbatisBatchItemWriter
 
IbatisCustomerCreditDao - Class in org.springframework.batch.sample.domain.trade.internal
 
IbatisCustomerCreditDao() - Constructor for class org.springframework.batch.sample.domain.trade.internal.IbatisCustomerCreditDao
 
IbatisPagingItemReader<T> - Class in org.springframework.batch.item.database
ItemReader for reading database records using iBATIS in a paging fashion.
IbatisPagingItemReader() - Constructor for class org.springframework.batch.item.database.IbatisPagingItemReader
 
ID_ATTR - Static variable in class org.springframework.batch.core.configuration.xml.AbstractStepParser
 
ID_COLUMN - Static variable in class org.springframework.batch.sample.domain.trade.internal.CustomerCreditFieldSetMapper
 
ID_COLUMN - Static variable in class org.springframework.batch.sample.domain.trade.internal.CustomerCreditRowMapper
 
ID_COLUMN - Static variable in class org.springframework.batch.sample.domain.trade.internal.TradeRowMapper
 
ID_KEY - Static variable in class org.springframework.batch.core.scope.StepScope
Context key for clients to use for conversation identifier.
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
 
increaseCreditBy(BigDecimal) - Method in class org.springframework.batch.sample.domain.trade.CustomerCredit
 
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.
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
Read and trim the String value from column with given ' name.
InfiniteLoopReader - Class in org.springframework.batch.sample.common
ItemReader implementation that will continually return a new object.
InfiniteLoopReader() - Constructor for class org.springframework.batch.sample.common.InfiniteLoopReader
 
InfiniteLoopWriter - Class in org.springframework.batch.sample.common
Simple module implementation that will always return true to indicate that processing should continue.
InfiniteLoopWriter() - Constructor for class org.springframework.batch.sample.common.InfiniteLoopWriter
 
init() - Method in class org.springframework.batch.core.configuration.xml.CoreNamespaceHandler
 
init() - Method in class org.springframework.batch.core.repository.dao.XStreamExecutionContextStringSerializer
 
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.KeyValueItemWriter
afterPropertiesSet() hook
initBinder(DataBinder) - Method in class org.springframework.batch.item.file.mapping.BeanWrapperFieldSetMapper
Initialize a new binder instance.
initDao() - Method in class org.springframework.batch.sample.common.StagingItemWriter
Check mandatory properties.
initDao() - Method in class org.springframework.batch.sample.domain.football.internal.JdbcGameDao
 
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.
initialize() - Method in class org.springframework.batch.sample.config.DataSourceConfiguration
 
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
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
 
INSERT_PLAYER - Static variable in class org.springframework.batch.sample.domain.football.internal.JdbcPlayerDao
 
insertCustomer(String, BigDecimal) - Method in interface org.springframework.batch.sample.domain.trade.CustomerDao
 
insertCustomer(String, BigDecimal) - Method in class org.springframework.batch.sample.domain.trade.internal.JdbcCustomerDao
 
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 Exitcode
InvalidCustomerLogger - Interface in org.springframework.batch.sample.domain.trade
Interface for logging invalid customers.
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
 
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
 
isBusinessCustomer() - Method in class org.springframework.batch.sample.domain.order.Customer
 
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
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 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.
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 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
 
isFooter() - Method in class org.springframework.batch.sample.domain.multiline.AggregateItem
Responds true if this record is a footer in an aggregate.
isGreaterThan(BatchStatus) - Method in enum org.springframework.batch.core.BatchStatus
 
isHeader() - Method in class org.springframework.batch.sample.domain.multiline.AggregateItem
Responds true if this record is a header in an aggregate.
isIdentifying() - Method in class org.springframework.batch.core.JobParameter
 
ISIN_COLUMN - Static variable in class org.springframework.batch.sample.domain.trade.internal.TradeFieldSetMapper
 
ISIN_COLUMN - Static variable in class org.springframework.batch.sample.domain.trade.internal.TradeRowMapper
 
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.
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.
isRegistered() - Method in class org.springframework.batch.sample.domain.order.Customer
 
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.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.SimpleFlowFactoryBean
 
isSingleton() - Method in class org.springframework.batch.core.explore.support.AbstractJobExplorerFactoryBean
 
isSingleton() - Method in class org.springframework.batch.core.listener.AbstractListenerFactoryBean
 
isSingleton() - Method in class org.springframework.batch.core.repository.support.AbstractJobRepositoryFactoryBean
 
isSingleton() - Method in class org.springframework.batch.core.step.factory.SimpleStepFactoryBean
Returns true by default, but in most cases a Step should not be treated as thread safe.
isSingleton() - Method in class org.springframework.batch.core.step.StepLocatorStepFactoryBean
Always return true as optimization for bean factory.
isSingleton() - Method in class org.springframework.batch.item.database.support.SqlPagingQueryProviderFactoryBean
Always returns true.
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.
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
 
isVip() - Method in class org.springframework.batch.sample.domain.order.Customer
 
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.
ITEM_ID_COLUMN - Static variable in class org.springframework.batch.sample.domain.order.internal.mapper.OrderItemFieldSetMapper
 
ItemCountAware - Interface in org.springframework.batch.item
Marker interface indicating that an item should have the item count set on it.
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<T> - Interface in org.springframework.batch.item.database
A convenient strategy for SQL updates, acting effectively as the inverse of RowMapper.
ItemProcessListener<T,S> - Interface in org.springframework.batch.core
Listener interface for the processing of an item.
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
 
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
 
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.
ItemSqlParameterSourceProvider<T> - Interface in org.springframework.batch.item.database
A convenient strategy for providing SqlParameterSource for named parameter SQL updates.
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 - Variable in class org.springframework.batch.item.jms.JmsItemReader
 
ItemWriteListener<S> - Interface in org.springframework.batch.core
Listener interface for the writing of items.
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
 
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

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
 
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
 
JdbcCustomerDao - Class in org.springframework.batch.sample.domain.trade.internal
 
JdbcCustomerDao() - Constructor for class org.springframework.batch.sample.domain.trade.internal.JdbcCustomerDao
 
JdbcCustomerDebitDao - Class in org.springframework.batch.sample.domain.trade.internal
Reduces customer's credit by the provided amount.
JdbcCustomerDebitDao() - Constructor for class org.springframework.batch.sample.domain.trade.internal.JdbcCustomerDebitDao
 
JdbcExecutionContextDao - Class in org.springframework.batch.core.repository.dao
JDBC DAO for ExecutionContext.
JdbcExecutionContextDao() - Constructor for class org.springframework.batch.core.repository.dao.JdbcExecutionContextDao
 
JdbcGameDao - Class in org.springframework.batch.sample.domain.football.internal
 
JdbcGameDao() - Constructor for class org.springframework.batch.sample.domain.football.internal.JdbcGameDao
 
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
 
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
 
JdbcPlayerDao - Class in org.springframework.batch.sample.domain.football.internal
 
JdbcPlayerDao() - Constructor for class org.springframework.batch.sample.domain.football.internal.JdbcPlayerDao
 
JdbcPlayerSummaryDao - Class in org.springframework.batch.sample.domain.football.internal
 
JdbcPlayerSummaryDao() - Constructor for class org.springframework.batch.sample.domain.football.internal.JdbcPlayerSummaryDao
 
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
 
JdbcTradeDao - Class in org.springframework.batch.sample.domain.trade.internal
Writes a Trade object to a database
JdbcTradeDao() - Constructor for class org.springframework.batch.sample.domain.trade.internal.JdbcTradeDao
 
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
 
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
 
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
 
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_NOT_PROVIDED - Static variable in interface org.springframework.batch.core.launch.support.ExitCodeMapper
 
JobBuilder - Class in org.springframework.batch.core.job.builder
Convenience for building jobs of various kinds.
JobBuilder(String) - Constructor for class org.springframework.batch.core.job.builder.JobBuilder
Create a new builder for a job with the given name.
JobBuilderException - Exception in org.springframework.batch.core.job.builder
 
JobBuilderException(Exception) - Constructor for exception org.springframework.batch.core.job.builder.JobBuilderException
 
JobBuilderFactory - Class in org.springframework.batch.core.configuration.annotation
Convenient factory for a JobBuilder which sets the JobRepository automatically.
JobBuilderFactory(JobRepository) - Constructor for class org.springframework.batch.core.configuration.annotation.JobBuilderFactory
 
JobBuilderHelper<B extends JobBuilderHelper<B>> - Class in org.springframework.batch.core.job.builder
A base class and utility for other job builders providing access to common properties like job repository.
JobBuilderHelper(String) - Constructor for class org.springframework.batch.core.job.builder.JobBuilderHelper
 
JobBuilderHelper(JobBuilderHelper<?>) - Constructor for class org.springframework.batch.core.job.builder.JobBuilderHelper
Create a new builder initialized with any properties in the parent.
JobBuilderHelper.CommonJobProperties - Class in org.springframework.batch.core.job.builder
 
JobBuilderHelper.CommonJobProperties() - Constructor for class org.springframework.batch.core.job.builder.JobBuilderHelper.CommonJobProperties
 
JobBuilderHelper.CommonJobProperties(JobBuilderHelper.CommonJobProperties) - Constructor for class org.springframework.batch.core.job.builder.JobBuilderHelper.CommonJobProperties
 
jobBuilders() - Method in class org.springframework.batch.core.configuration.annotation.AbstractBatchConfiguration
 
JobExecution - Class in org.springframework.batch.core
Batch domain object representing the execution of a job.
JobExecution(JobInstance, Long, JobParameters) - Constructor for class org.springframework.batch.core.JobExecution
Because a JobExecution isn't valid unless the job is set, this constructor is the only valid one from a modeling point of view.
JobExecution(JobInstance, JobParameters) - Constructor for class org.springframework.batch.core.JobExecution
Constructor for transient (unsaved) instances.
JobExecution(Long, JobParameters) - Constructor for class org.springframework.batch.core.JobExecution
 
JobExecution(Long) - Constructor for class org.springframework.batch.core.JobExecution
 
JobExecutionAlreadyRunningException - Exception in org.springframework.batch.core.repository
 
JobExecutionAlreadyRunningException(String) - Constructor for exception org.springframework.batch.core.repository.JobExecutionAlreadyRunningException
 
JobExecutionAlreadyRunningException(String, Throwable) - Constructor for exception org.springframework.batch.core.repository.JobExecutionAlreadyRunningException
 
JobExecutionDao - Interface in org.springframework.batch.core.repository.dao
Data Access Object for job executions.
JobExecutionDecider - Interface in org.springframework.batch.core.job.flow
Interface allowing for programmatic access to the decision on what the status of a flow should be.
JobExecutionException - Exception in org.springframework.batch.core
Root of exception hierarchy for checked exceptions in job and step execution.
JobExecutionException(String) - Constructor for exception org.springframework.batch.core.JobExecutionException
Construct a JobExecutionException with a generic message.
JobExecutionException(String, Throwable) - Constructor for exception org.springframework.batch.core.JobExecutionException
Construct a JobExecutionException with a generic message and a cause.
JobExecutionListener - Interface in org.springframework.batch.core
Provide callbacks at specific points in the lifecycle of a Job.
JobExecutionListenerParser - Class in org.springframework.batch.core.configuration.xml
Parser for a step listener element.
JobExecutionListenerParser() - Constructor for class org.springframework.batch.core.configuration.xml.JobExecutionListenerParser
 
JobExecutionListenerSupport - Class in org.springframework.batch.core.listener
 
JobExecutionListenerSupport() - Constructor for class org.springframework.batch.core.listener.JobExecutionListenerSupport
 
JobExecutionNotFailedException - Exception in org.springframework.batch.core.launch
Checked exception to indicate that user asked for a job execution to be resumed when actually it didn't fail.
JobExecutionNotFailedException(String) - Constructor for exception org.springframework.batch.core.launch.JobExecutionNotFailedException
Create an exception with the given message.
JobExecutionNotFailedException(String, Throwable) - Constructor for exception org.springframework.batch.core.launch.JobExecutionNotFailedException
 
JobExecutionNotificationPublisher - Class in org.springframework.batch.sample.jmx
JMX notification broadcaster
JobExecutionNotificationPublisher() - Constructor for class org.springframework.batch.sample.jmx.JobExecutionNotificationPublisher
 
JobExecutionNotRunningException - Exception in org.springframework.batch.core.launch
Execution indicating that a JobExecution that is not currently running has been requested to stop.
JobExecutionNotRunningException(String) - Constructor for exception org.springframework.batch.core.launch.JobExecutionNotRunningException
Create a JobExecutionNotRunningException with a message.
JobExecutionNotStoppedException - Exception in org.springframework.batch.core.launch
Checked exception to indicate that user asked for a job execution to be aborted when hasn't been stopped.
JobExecutionNotStoppedException(String) - Constructor for exception org.springframework.batch.core.launch.JobExecutionNotStoppedException
Create an exception with the given message.
JobExplorer - Interface in org.springframework.batch.core.explore
Entry point for browsing executions of running or historical jobs and steps.
JobExplorerFactoryBean - Class in org.springframework.batch.core.explore.support
A FactoryBean that automates the creation of a SimpleJobExplorer using JDBC DAO implementations.
JobExplorerFactoryBean() - Constructor for class org.springframework.batch.core.explore.support.JobExplorerFactoryBean
 
JobFactory - Interface in org.springframework.batch.core.configuration
Strategy for creating a single job.
JobFactoryRegistrationListener - Class in org.springframework.batch.core.configuration.support
Generic service that can bind and unbind a JobFactory in a JobRegistry.
JobFactoryRegistrationListener() - Constructor for class org.springframework.batch.core.configuration.support.JobFactoryRegistrationListener
 
JobFlowBuilder - Class in org.springframework.batch.core.job.builder
 
JobFlowBuilder(FlowJobBuilder) - Constructor for class org.springframework.batch.core.job.builder.JobFlowBuilder
 
JobFlowBuilder(FlowJobBuilder, Step) - Constructor for class org.springframework.batch.core.job.builder.JobFlowBuilder
 
JobFlowBuilder(FlowJobBuilder, JobExecutionDecider) - Constructor for class org.springframework.batch.core.job.builder.JobFlowBuilder
 
JobFlowBuilder(FlowJobBuilder, Flow) - Constructor for class org.springframework.batch.core.job.builder.JobFlowBuilder
 
JobFlowExecutor - Class in org.springframework.batch.core.job.flow
Implementation of FlowExecutor for use in components that need to execute a flow related to a JobExecution.
JobFlowExecutor(JobRepository, StepHandler, JobExecution) - Constructor for class org.springframework.batch.core.job.flow.JobFlowExecutor
 
JobInstance - Class in org.springframework.batch.core
Batch domain object representing a uniquely identifiable job run.
JobInstance(Long, String) - Constructor for class org.springframework.batch.core.JobInstance
 
JobInstanceAlreadyCompleteException - Exception in org.springframework.batch.core.repository
An exception indicating an illegal attempt to restart a job that was already completed successfully.
JobInstanceAlreadyCompleteException(String) - Constructor for exception org.springframework.batch.core.repository.JobInstanceAlreadyCompleteException
 
JobInstanceAlreadyCompleteException(String, Throwable) - Constructor for exception org.springframework.batch.core.repository.JobInstanceAlreadyCompleteException
 
JobInstanceAlreadyExistsException - Exception in org.springframework.batch.core.launch
Checked exception to indicate that a required Job is not available.
JobInstanceAlreadyExistsException(String) - Constructor for exception org.springframework.batch.core.launch.JobInstanceAlreadyExistsException
Create an exception with the given message.
JobInstanceAlreadyExistsException(String, Throwable) - Constructor for exception org.springframework.batch.core.launch.JobInstanceAlreadyExistsException
 
JobInstanceDao - Interface in org.springframework.batch.core.repository.dao
Data Access Object for job instances.
JobInterruptedException - Exception in org.springframework.batch.core
Exception to indicate the the job has been interrupted.
JobInterruptedException(String) - Constructor for exception org.springframework.batch.core.JobInterruptedException
 
JobInterruptedException(String, BatchStatus) - Constructor for exception org.springframework.batch.core.JobInterruptedException
 
JobKeyGenerator<T> - Interface in org.springframework.batch.core
Strategy interface for the generation of the key used in identifying unique JobInstance.
jobLauncher() - Method in class org.springframework.batch.core.configuration.annotation.AbstractBatchConfiguration
 
jobLauncher() - Method in class org.springframework.batch.core.configuration.annotation.ModularBatchConfiguration
 
jobLauncher() - Method in class org.springframework.batch.core.configuration.annotation.SimpleBatchConfiguration
 
JobLauncher - Interface in org.springframework.batch.core.launch
Simple interface for controlling jobs, including possible ad-hoc executions, based on different runtime identifiers.
JobLauncherDetails - Class in org.springframework.batch.sample.quartz
 
JobLauncherDetails() - Constructor for class org.springframework.batch.sample.quartz.JobLauncherDetails
 
JobLauncherTestUtils - Class in org.springframework.batch.test
Utility class for testing batch jobs.
JobLauncherTestUtils() - Constructor for class org.springframework.batch.test.JobLauncherTestUtils
 
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
 
JobLoader - Interface in org.springframework.batch.sample.launch
 
JobLocator - Interface in org.springframework.batch.core.configuration
A runtime service locator interface for retrieving job configurations by name.
JobOperator - Interface in org.springframework.batch.core.launch
Low level interface for inspecting and controlling jobs with access only to primitive and collection types.
JobParameter - Class in org.springframework.batch.core
Domain representation of a parameter to a batch job.
JobParameter(String, boolean) - Constructor for class org.springframework.batch.core.JobParameter
Construct a new JobParameter as a String.
JobParameter(Long, boolean) - Constructor for class org.springframework.batch.core.JobParameter
Construct a new JobParameter as a Long.
JobParameter(Date, boolean) - Constructor for class org.springframework.batch.core.JobParameter
Construct a new JobParameter as a Date.
JobParameter(Double, boolean) - Constructor for class org.springframework.batch.core.JobParameter
Construct a new JobParameter as a Double.
JobParameter(String) - Constructor for class org.springframework.batch.core.JobParameter
Construct a new JobParameter as a String.
JobParameter(Long) - Constructor for class org.springframework.batch.core.JobParameter
Construct a new JobParameter as a Long.
JobParameter(Date) - Constructor for class org.springframework.batch.core.JobParameter
Construct a new JobParameter as a Date.
JobParameter(Double) - Constructor for class org.springframework.batch.core.JobParameter
Construct a new JobParameter as a Double.
JobParameter.ParameterType - Enum in org.springframework.batch.core
Enumeration representing the type of a JobParameter.
JobParameterExecutionContextCopyListener - Class in org.springframework.batch.core.listener
This class can be used to automatically copy items from the JobParameters to the Step ExecutionContext.
JobParameterExecutionContextCopyListener() - Constructor for class org.springframework.batch.core.listener.JobParameterExecutionContextCopyListener
 
JobParameters - Class in org.springframework.batch.core
Value object representing runtime parameters to a batch job.
JobParameters() - Constructor for class org.springframework.batch.core.JobParameters
 
JobParameters(Map<String, JobParameter>) - Constructor for class org.springframework.batch.core.JobParameters
 
JobParametersBuilder - Class in org.springframework.batch.core
Helper class for creating JobParameters.
JobParametersBuilder() - Constructor for class org.springframework.batch.core.JobParametersBuilder
Default constructor.
JobParametersBuilder(JobParameters) - Constructor for class org.springframework.batch.core.JobParametersBuilder
Copy constructor.
JobParametersConverter - Interface in org.springframework.batch.core.converter
A factory for JobParameters instances.
JobParametersExtractor - Interface in org.springframework.batch.core.step.job
Strategy interface for translating a StepExecution into JobParameters.
JobParametersIncrementer - Interface in org.springframework.batch.core
Interface for obtaining the next JobParameters in a sequence.
JobParametersInvalidException - Exception in org.springframework.batch.core
Exception for Job to signal that some JobParameters are invalid.
JobParametersInvalidException(String) - Constructor for exception org.springframework.batch.core.JobParametersInvalidException
 
JobParametersNotFoundException - Exception in org.springframework.batch.core.launch
Checked exception to indicate that a required JobParametersIncrementer is not available.
JobParametersNotFoundException(String) - Constructor for exception org.springframework.batch.core.launch.JobParametersNotFoundException
Create an exception with the given message.
JobParametersNotFoundException(String, Throwable) - Constructor for exception org.springframework.batch.core.launch.JobParametersNotFoundException
 
JobParametersValidator - Interface in org.springframework.batch.core
Strategy interface for a Job to use in validating its parameters for an execution.
JobParser - Class in org.springframework.batch.core.configuration.xml
Parser for the lt;job/gt; element in the Batch namespace.
JobParser() - Constructor for class org.springframework.batch.core.configuration.xml.JobParser
 
jobRegistrar() - Method in class org.springframework.batch.core.configuration.annotation.ModularBatchConfiguration
 
jobRegistry() - Method in class org.springframework.batch.core.configuration.annotation.AbstractBatchConfiguration
 
jobRegistry() - Method in class org.springframework.batch.core.configuration.annotation.SimpleBatchConfiguration
 
JobRegistry - Interface in org.springframework.batch.core.configuration
A runtime service registry interface for registering job configurations by name.
JobRegistryBackgroundJobRunner - Class in org.springframework.batch.core.launch.support
Command line launcher for registering jobs with a JobRegistry.
JobRegistryBackgroundJobRunner(String) - Constructor for class org.springframework.batch.core.launch.support.JobRegistryBackgroundJobRunner
 
JobRegistryBeanPostProcessor - Class in org.springframework.batch.core.configuration.support
A BeanPostProcessor that registers Job beans with a JobRegistry.
JobRegistryBeanPostProcessor() - Constructor for class org.springframework.batch.core.configuration.support.JobRegistryBeanPostProcessor
 
jobRepository() - Method in class org.springframework.batch.core.configuration.annotation.AbstractBatchConfiguration
 
jobRepository() - Method in class org.springframework.batch.core.configuration.annotation.ModularBatchConfiguration
 
jobRepository() - Method in class org.springframework.batch.core.configuration.annotation.SimpleBatchConfiguration
 
JobRepository - Interface in org.springframework.batch.core.repository
Repository responsible for persistence of batch meta-data entities.
JobRepositoryFactoryBean - Class in org.springframework.batch.core.repository.support
A FactoryBean that automates the creation of a SimpleJobRepository using JDBC DAO implementations which persist batch metadata in database.
JobRepositoryFactoryBean() - Constructor for class org.springframework.batch.core.repository.support.JobRepositoryFactoryBean
 
JobRepositoryParser - Class in org.springframework.batch.core.configuration.xml
Parser for the lt;job-repository/gt; element in the Batch namespace.
JobRepositoryParser() - Constructor for class org.springframework.batch.core.configuration.xml.JobRepositoryParser
 
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
 
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.
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
 
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
 
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.
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
 
JsonRecordSeparatorPolicy - Class in org.springframework.batch.item.file.separator
JSON-based record separator.
JsonRecordSeparatorPolicy() - Constructor for class org.springframework.batch.item.file.separator.JsonRecordSeparatorPolicy
 
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

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.
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

LAST_NAME_COLUMN - Static variable in class org.springframework.batch.sample.domain.order.internal.mapper.CustomerFieldSetMapper
 
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
 
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.
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
 
LimitDecider - Class in org.springframework.batch.sample.loop
This decider will return "CONTINUE" until the limit it reached, at which point it will return "COMPLETE".
LimitDecider() - Constructor for class org.springframework.batch.sample.loop.LimitDecider
 
LINE_ID_BILLING_ADDR - Static variable in class org.springframework.batch.sample.domain.order.Address
 
LINE_ID_BILLING_INFO - Static variable in class org.springframework.batch.sample.domain.order.BillingInfo
 
LINE_ID_BUSINESS_CUST - Static variable in class org.springframework.batch.sample.domain.order.Customer
 
LINE_ID_COLUMN - Static variable in class org.springframework.batch.sample.domain.order.internal.mapper.CustomerFieldSetMapper
 
LINE_ID_FOOTER - Static variable in class org.springframework.batch.sample.domain.order.Order
 
LINE_ID_HEADER - Static variable in class org.springframework.batch.sample.domain.order.Order
 
LINE_ID_ITEM - Static variable in class org.springframework.batch.sample.domain.order.LineItem
 
LINE_ID_NON_BUSINESS_CUST - Static variable in class org.springframework.batch.sample.domain.order.Customer
 
LINE_ID_SHIPPING_ADDR - Static variable in class org.springframework.batch.sample.domain.order.Address
 
LINE_ID_SHIPPING_INFO - Static variable in class org.springframework.batch.sample.domain.order.ShippingInfo
 
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.
LineItem - Class in org.springframework.batch.sample.domain.order.internal.xml
An XML line-item.
LineItem() - Constructor for class org.springframework.batch.sample.domain.order.internal.xml.LineItem
 
LineItem - Class in org.springframework.batch.sample.domain.order
 
LineItem() - Constructor for class org.springframework.batch.sample.domain.order.LineItem
 
LineItemFieldExtractor - Class in org.springframework.batch.sample.domain.order.internal.extractor
 
LineItemFieldExtractor() - Constructor for class org.springframework.batch.sample.domain.order.internal.extractor.LineItemFieldExtractor
 
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.
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(JobExecutionListener) - Method in class org.springframework.batch.core.job.builder.JobBuilderHelper
Register a job execution listener.
listener(ChunkListener) - Method in class org.springframework.batch.core.step.builder.AbstractTaskletStepBuilder
Register a chunk listener.
listener(Object) - Method in class org.springframework.batch.core.step.builder.FaultTolerantStepBuilder
Registers objects using the annotation based listener configuration.
listener(SkipListener<? super I, ? super O>) - Method in class org.springframework.batch.core.step.builder.FaultTolerantStepBuilder
Register a skip listener.
listener(ChunkListener) - Method in class org.springframework.batch.core.step.builder.FaultTolerantStepBuilder
 
listener(RetryListener) - Method in class org.springframework.batch.core.step.builder.FaultTolerantStepBuilder
Register a retry listener.
listener(Object) - Method in class org.springframework.batch.core.step.builder.SimpleStepBuilder
Registers objects using the annotation based listener configuration.
listener(ItemReadListener<? super I>) - Method in class org.springframework.batch.core.step.builder.SimpleStepBuilder
Register an item reader listener.
listener(ItemWriteListener<? super O>) - Method in class org.springframework.batch.core.step.builder.SimpleStepBuilder
Register an item writer listener.
listener(ItemProcessListener<? super I, ? super O>) - Method in class org.springframework.batch.core.step.builder.SimpleStepBuilder
Register an item processor listener.
listener(Object) - Method in class org.springframework.batch.core.step.builder.StepBuilderHelper
Registers objects using the annotation based listener configuration.
listener(StepExecutionListener) - Method in class org.springframework.batch.core.step.builder.StepBuilderHelper
 
ListenerMetaData - Interface in org.springframework.batch.core.listener
A common interface for listener meta data enumerations.
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
 
ListPreparedStatementSetter - Class in org.springframework.batch.core.resource
Implementation of the PreparedStatementSetter interface that accepts a list of values to be set on a PreparedStatement.
ListPreparedStatementSetter() - Constructor for class org.springframework.batch.core.resource.ListPreparedStatementSetter
 
load(ApplicationContextFactory) - Method in class org.springframework.batch.core.configuration.support.DefaultJobLoader
 
load(ApplicationContextFactory) - Method in interface org.springframework.batch.core.configuration.support.JobLoader
Load an application context and register all the jobs.
loadResource(String) - Method in class org.springframework.batch.sample.launch.DefaultJobLoader
 
loadResource(String) - Method in interface org.springframework.batch.sample.launch.ExportedJobLoader
 
loadResource(String) - Method in interface org.springframework.batch.sample.launch.JobLoader
 
log - Variable in class org.springframework.batch.item.database.AbstractCursorItemReader
Logger available to subclasses
log(CustomerUpdate) - Method in class org.springframework.batch.sample.domain.trade.internal.CommonsLoggingInvalidCustomerLogger
 
log(CustomerUpdate) - Method in interface org.springframework.batch.sample.domain.trade.InvalidCustomerLogger
 
LogAdvice - Class in org.springframework.batch.sample.common
Wraps calls for 'Processing' methods which output a single Object to write the string representation of the object to the log.
LogAdvice() - Constructor for class org.springframework.batch.sample.common.LogAdvice
 
logger - Static variable in class org.springframework.batch.core.job.AbstractJob
 
logger - Variable in class org.springframework.batch.core.job.builder.JobBuilderHelper
 
logger - Static variable in class org.springframework.batch.core.launch.support.CommandLineJobRunner
 
logger - Static variable in class org.springframework.batch.core.launch.support.SimpleJobLauncher
 
logger - Variable in class org.springframework.batch.core.launch.support.SimpleJvmExitCodeMapper
 
logger - Static variable in class org.springframework.batch.core.repository.support.JobRepositoryFactoryBean
 
logger - Variable in class org.springframework.batch.core.step.builder.StepBuilderHelper
 
logger - Variable in class org.springframework.batch.core.step.factory.SimpleStepFactoryBean
 
logger - Static variable in class org.springframework.batch.core.step.item.DefaultItemFailureHandler
 
logger - Variable in class org.springframework.batch.core.step.item.SimpleChunkProvider
 
logger - Static variable in class org.springframework.batch.core.step.tasklet.SystemCommandTasklet
 
logger - Static variable in class org.springframework.batch.core.step.ThreadStepInterruptionPolicy
 
logger - Variable in class org.springframework.batch.item.data.Neo4jItemReader
 
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.IbatisBatchItemWriter
 
logger - Static variable in class org.springframework.batch.item.database.JdbcBatchItemWriter
 
logger - Static variable in class org.springframework.batch.item.database.JpaItemWriter
 
logger - Static variable in class org.springframework.batch.item.file.FlatFileItemWriter
 
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.repeat.exception.LogOrRethrowExceptionHandler
 
logger - Variable in class org.springframework.batch.repeat.exception.RethrowOnThresholdExceptionHandler
 
logger - Variable in class org.springframework.batch.repeat.support.RepeatTemplate
 
logger - Static variable in class org.springframework.batch.sample.domain.trade.internal.CommonsLoggingInvalidCustomerLogger
 
logger - Static variable in class org.springframework.batch.sample.jmx.JobExecutionNotificationPublisher
 
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 - Interface in org.springframework.batch.item.mail
This class is used to handle errors that occur when email messages are unable to be sent.
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.sample.rabbitmq.amqp.AmqpMessageProducer
 
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
In-memory implementation of ExecutionContextDao backed by maps.
MapExecutionContextDao() - Constructor for class org.springframework.batch.core.repository.dao.MapExecutionContextDao
 
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.sample.domain.football.internal.GameFieldSetMapper
 
mapFieldSet(FieldSet) - Method in class org.springframework.batch.sample.domain.football.internal.PlayerFieldSetMapper
 
mapFieldSet(FieldSet) - Method in class org.springframework.batch.sample.domain.multiline.AggregateItemFieldSetMapper
Build an AggregateItem based on matching the first column in the input FieldSet to check for begin and end delimiters.
mapFieldSet(FieldSet) - Method in class org.springframework.batch.sample.domain.order.internal.mapper.AddressFieldSetMapper
 
mapFieldSet(FieldSet) - Method in class org.springframework.batch.sample.domain.order.internal.mapper.BillingFieldSetMapper
 
mapFieldSet(FieldSet) - Method in class org.springframework.batch.sample.domain.order.internal.mapper.CustomerFieldSetMapper
 
mapFieldSet(FieldSet) - Method in class org.springframework.batch.sample.domain.order.internal.mapper.HeaderFieldSetMapper
 
mapFieldSet(FieldSet) - Method in class org.springframework.batch.sample.domain.order.internal.mapper.OrderItemFieldSetMapper
 
mapFieldSet(FieldSet) - Method in class org.springframework.batch.sample.domain.order.internal.mapper.ShippingFieldSetMapper
 
mapFieldSet(FieldSet) - Method in class org.springframework.batch.sample.domain.trade.CustomerUpdateFieldSetMapper
 
mapFieldSet(FieldSet) - Method in class org.springframework.batch.sample.domain.trade.internal.CustomerCreditFieldSetMapper
 
mapFieldSet(FieldSet) - Method in class org.springframework.batch.sample.domain.trade.internal.TradeFieldSetMapper
 
MapJobExecutionDao - Class in org.springframework.batch.core.repository.dao
In-memory implementation of JobExecutionDao.
MapJobExecutionDao() - Constructor for class org.springframework.batch.core.repository.dao.MapJobExecutionDao
 
MapJobExplorerFactoryBean - Class in org.springframework.batch.core.explore.support
A FactoryBean that automates the creation of a SimpleJobExplorer using in-memory DAO implementations.
MapJobExplorerFactoryBean(MapJobRepositoryFactoryBean) - Constructor for class org.springframework.batch.core.explore.support.MapJobExplorerFactoryBean
Create an instance with the provided MapJobRepositoryFactoryBean as a source of Dao instances.
MapJobExplorerFactoryBean() - Constructor for class org.springframework.batch.core.explore.support.MapJobExplorerFactoryBean
Create a factory with no MapJobRepositoryFactoryBean.
MapJobInstanceDao - Class in org.springframework.batch.core.repository.dao
In-memory implementation of JobInstanceDao.
MapJobInstanceDao() - Constructor for class org.springframework.batch.core.repository.dao.MapJobInstanceDao
 
MapJobRegistry - Class in org.springframework.batch.core.configuration.support
Simple, thread-safe, map-based implementation of JobRegistry.
MapJobRegistry() - Constructor for class org.springframework.batch.core.configuration.support.MapJobRegistry
 
MapJobRepositoryFactoryBean - Class in org.springframework.batch.core.repository.support
A FactoryBean that automates the creation of a SimpleJobRepository using non-persistent in-memory DAO implementations.
MapJobRepositoryFactoryBean() - Constructor for class org.springframework.batch.core.repository.support.MapJobRepositoryFactoryBean
Create a new instance with a ResourcelessTransactionManager.
MapJobRepositoryFactoryBean(PlatformTransactionManager) - Constructor for class org.springframework.batch.core.repository.support.MapJobRepositoryFactoryBean
Create a new instance with the provided transaction manager.
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
 
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.
mapRow(ResultSet, int) - Method in class org.springframework.batch.sample.domain.football.internal.PlayerSummaryMapper
 
mapRow(ResultSet, int) - Method in class org.springframework.batch.sample.domain.football.internal.PlayerSummaryRowMapper
 
mapRow(ResultSet, int) - Method in class org.springframework.batch.sample.domain.trade.internal.CustomerCreditRowMapper
 
mapRow(ResultSet, int) - Method in class org.springframework.batch.sample.domain.trade.internal.CustomerDebitRowMapper
 
mapRow(ResultSet, int) - Method in class org.springframework.batch.sample.domain.trade.internal.TradeRowMapper
 
MapStepExecutionDao - Class in org.springframework.batch.core.repository.dao
In-memory implementation of StepExecutionDao.
MapStepExecutionDao() - Constructor for class org.springframework.batch.core.repository.dao.MapStepExecutionDao
 
MapStepRegistry - Class in org.springframework.batch.core.configuration.support
Simple map-based implementation of StepRegistry.
MapStepRegistry() - Constructor for class org.springframework.batch.core.configuration.support.MapStepRegistry
 
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.
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.
max(BatchStatus, BatchStatus) - Static method in enum org.springframework.batch.core.BatchStatus
 
MaxValueFlowExecutionAggregator - Class in org.springframework.batch.core.job.flow.support.state
Implementation of the FlowExecutionAggregator interface that aggregates FlowExecutionStatus', using the status with the high precedence as the aggregate status.
MaxValueFlowExecutionAggregator() - Constructor for class org.springframework.batch.core.job.flow.support.state.MaxValueFlowExecutionAggregator
 
MessageProcessor - Class in org.springframework.batch.sample.rabbitmq.processor
Simple ItemProcessor implementation to append a "processed on" Date to a received message.
MessageProcessor() - Constructor for class org.springframework.batch.sample.rabbitmq.processor.MessageProcessor
 
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
 
MethodResolver - Interface in org.springframework.batch.support
Strategy interface for detecting a single Method on a Class.
MIDDLE_NAME_COLUMN - Static variable in class org.springframework.batch.sample.domain.order.internal.mapper.CustomerFieldSetMapper
 
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
 
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
 
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
 
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
Initialise 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
 
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
 
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_COLUMN - Static variable in class org.springframework.batch.sample.domain.trade.internal.CustomerCreditFieldSetMapper
 
NAME_COLUMN - Static variable in class org.springframework.batch.sample.domain.trade.internal.CustomerCreditRowMapper
 
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.
Neo4jItemReader<T> - Class in org.springframework.batch.item.data
Restartable ItemReader that reads objects from the graph database Neo4j via a paging technique.
Neo4jItemReader() - Constructor for class org.springframework.batch.item.data.Neo4jItemReader
 
Neo4jItemWriter<T> - Class in org.springframework.batch.item.data
A ItemWriter implementation that writes to a Neo4j database using an implementation of Spring Data's Neo4jOperations.
Neo4jItemWriter() - Constructor for class org.springframework.batch.item.data.Neo4jItemWriter
 
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
 
NEW - Static variable in class org.springframework.batch.sample.common.StagingItemWriter
 
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
 
nextEvent() - Method in class org.springframework.batch.item.xml.stax.DefaultFragmentEventReader
 
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.
noRollback(Class<? extends Throwable>) - Method in class org.springframework.batch.core.step.builder.FaultTolerantStepBuilder
Mark this exception as ignorable during item read or processing operations.
noSkip(Class<? extends Throwable>) - Method in class org.springframework.batch.core.step.builder.FaultTolerantStepBuilder
Explicitly prevent certain exceptions (and subclasses) from being skipped.
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.
onApplicationEvent(ApplicationEvent) - Method in class org.springframework.batch.core.configuration.support.AutomaticJobRegistrar
Creates all the application contexts required and set up job registry entries with all the instances of Job found therein.
onApplicationEvent(ApplicationEvent) - Method in class org.springframework.batch.sample.jmx.JobExecutionNotificationPublisher
If the event is a SimpleMessageApplicationEvent for open and close we log the event at INFO level and send a JMX notification if we are also an MBean.
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.
onError(RepeatContext, Throwable) - Method in class org.springframework.batch.sample.domain.trade.internal.HibernateCreditDao
 
onError(JoinPoint, StepExecution, Throwable) - Method in class org.springframework.batch.sample.jmx.StepExecutionApplicationEventAdvice
 
OnProcessError - Annotation Type in org.springframework.batch.core.annotation
Marks a method to be called if an exception is thrown by an ItemProcessor

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

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

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

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

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

Expected signature: void onWriteError(Exception exception, List<? extends S> items)
onWriteError(Exception, List<? extends S>) - Method in interface org.springframework.batch.core.ItemWriteListener
Called if an error occurs while trying to write.
onWriteError(Exception, List<? extends S>) - Method in class org.springframework.batch.core.listener.CompositeItemWriteListener
Call the registered listeners in reverse order, respecting and prioritising those that implement Ordered.
onWriteError(Exception, List<? extends O>) - Method in class org.springframework.batch.core.listener.ItemListenerSupport
 
onWriteError(Exception, List<? extends S>) - Method in class org.springframework.batch.core.listener.MulticasterBatchListener
 
onWriteError(Exception, List<? extends S>) - Method in class org.springframework.batch.core.listener.StepListenerSupport
 
onWriteError(Exception, List<? extends Object>) - Method in class org.springframework.batch.core.step.item.DefaultItemFailureHandler
 
open(ExecutionContext) - Method in class org.springframework.batch.core.step.AbstractStep
Extension point for subclasses to provide callbacks to their collaborators at the beginning of a step, to open or acquire resources.
open(ExecutionContext) - Method in class org.springframework.batch.core.step.item.ChunkMonitor
 
open(ExecutionContext) - Method in class org.springframework.batch.core.step.tasklet.TaskletStep
 
open(ExecutionContext) - Method in class org.springframework.batch.item.database.JdbcPagingItemReader
 
open(ExecutionContext) - Method in class org.springframework.batch.item.file.FlatFileItemWriter
Initialize the reader.
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(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.xml.StaxEventItemWriter
Open the output source
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.
open(ExecutionContext) - Method in class org.springframework.batch.sample.domain.trade.internal.FlatFileCustomerCreditDao
 
open(RepeatContext) - Method in class org.springframework.batch.sample.domain.trade.internal.HibernateCreditDao
 
open() - Method in class org.springframework.batch.sample.domain.trade.internal.IbatisCustomerCreditDao
 
open(ExecutionContext) - Method in class org.springframework.batch.sample.domain.trade.internal.TradeWriter
 
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.
Order - Class in org.springframework.batch.sample.domain.order.internal.xml
An XML order.
Order() - Constructor for class org.springframework.batch.sample.domain.order.internal.xml.Order
 
Order - Class in org.springframework.batch.sample.domain.order
 
Order() - Constructor for class org.springframework.batch.sample.domain.order.Order
 
ORDER_DATE_COLUMN - Static variable in class org.springframework.batch.sample.domain.order.internal.mapper.HeaderFieldSetMapper
 
ORDER_ID_COLUMN - Static variable in class org.springframework.batch.sample.domain.order.internal.mapper.HeaderFieldSetMapper
 
OrderDao - Interface in org.springframework.batch.sample.domain.order
Interface for writing Order objects.
OrderItemFieldSetMapper - Class in org.springframework.batch.sample.domain.order.internal.mapper
 
OrderItemFieldSetMapper() - Constructor for class org.springframework.batch.sample.domain.order.internal.mapper.OrderItemFieldSetMapper
 
OrderItemReader - Class in org.springframework.batch.sample.domain.order.internal
 
OrderItemReader() - Constructor for class org.springframework.batch.sample.domain.order.internal.OrderItemReader
 
OrderLineAggregator - Class in org.springframework.batch.sample.domain.order.internal
Converts Order object to a list of strings.
OrderLineAggregator() - Constructor for class org.springframework.batch.sample.domain.order.internal.OrderLineAggregator
 
org.springframework.batch.core - package org.springframework.batch.core
Core domain context for Spring Batch covering jobs, steps, configuration and execution abstractions.
org.springframework.batch.core.annotation - package org.springframework.batch.core.annotation
 
org.springframework.batch.core.configuration - package org.springframework.batch.core.configuration
Interfaces for registration and location of job configurations.
org.springframework.batch.core.configuration.annotation - package org.springframework.batch.core.configuration.annotation
 
org.springframework.batch.core.configuration.support - package org.springframework.batch.core.configuration.support
Specific implementations of configuration concerns.
org.springframework.batch.core.configuration.xml - package org.springframework.batch.core.configuration.xml
 
org.springframework.batch.core.converter - package org.springframework.batch.core.converter
Support classes for implementations of the batch APIs.
org.springframework.batch.core.explore - package org.springframework.batch.core.explore
Interfaces and related classes to support meta data browsing.
org.springframework.batch.core.explore.support - package org.springframework.batch.core.explore.support
Specific implementations of explorer concerns.
org.springframework.batch.core.job - package org.springframework.batch.core.job
Specific implementations of job concerns.
org.springframework.batch.core.job.builder - package org.springframework.batch.core.job.builder
 
org.springframework.batch.core.job.flow - package org.springframework.batch.core.job.flow
 
org.springframework.batch.core.job.flow.support - package org.springframework.batch.core.job.flow.support
 
org.springframework.batch.core.job.flow.support.state - package org.springframework.batch.core.job.flow.support.state
 
org.springframework.batch.core.launch - package org.springframework.batch.core.launch
Interfaces and simple implementations of launch concerns.
org.springframework.batch.core.launch.support - package org.springframework.batch.core.launch.support
Support classes for use in bootstrap and launch implementations or configurations.
org.springframework.batch.core.listener - package org.springframework.batch.core.listener
Generic implementations of core batch listener interfaces.
org.springframework.batch.core.partition - package org.springframework.batch.core.partition
 
org.springframework.batch.core.partition.support - package org.springframework.batch.core.partition.support
 
org.springframework.batch.core.repository - package org.springframework.batch.core.repository
Interfaces and generic implementations of repository concerns.
org.springframework.batch.core.repository.dao - package org.springframework.batch.core.repository.dao
Specific implementations of dao concerns.
org.springframework.batch.core.repository.support - package org.springframework.batch.core.repository.support
Specific implementations of repository concerns.
org.springframework.batch.core.resource - package org.springframework.batch.core.resource
 
org.springframework.batch.core.scope - package org.springframework.batch.core.scope
 
org.springframework.batch.core.scope.context - package org.springframework.batch.core.scope.context
 
org.springframework.batch.core.step - package org.springframework.batch.core.step
Specific implementations of step concerns.
org.springframework.batch.core.step.builder - package org.springframework.batch.core.step.builder
 
org.springframework.batch.core.step.factory - package org.springframework.batch.core.step.factory
 
org.springframework.batch.core.step.item - package org.springframework.batch.core.step.item
Specific implementations of step concerns for item-oriented approach.
org.springframework.batch.core.step.job - package org.springframework.batch.core.step.job
 
org.springframework.batch.core.step.skip - package org.springframework.batch.core.step.skip
Specific implementations of skip concerns for items in a step.
org.springframework.batch.core.step.tasklet - package org.springframework.batch.core.step.tasklet
Interfaces and generic implementations of tasklet concerns.
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
 
org.springframework.batch.item.data - package org.springframework.batch.item.data
 
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.orm - package org.springframework.batch.item.database.orm
 
org.springframework.batch.item.database.support - package org.springframework.batch.item.database.support
 
org.springframework.batch.item.file - package org.springframework.batch.item.file
Infrastructure implementations of io file concerns.
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.jms - package org.springframework.batch.item.jms
 
org.springframework.batch.item.mail - package org.springframework.batch.item.mail
 
org.springframework.batch.item.mail.javamail - package org.springframework.batch.item.mail.javamail
 
org.springframework.batch.item.support - package org.springframework.batch.item.support
Internal support package
org.springframework.batch.item.util - package org.springframework.batch.item.util
 
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.stax - package org.springframework.batch.item.xml.stax
 
org.springframework.batch.poller - package org.springframework.batch.poller
 
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.sample.common - package org.springframework.batch.sample.common
 
org.springframework.batch.sample.config - package org.springframework.batch.sample.config
 
org.springframework.batch.sample.data - package org.springframework.batch.sample.data
 
org.springframework.batch.sample.domain.football - package org.springframework.batch.sample.domain.football
 
org.springframework.batch.sample.domain.football.internal - package org.springframework.batch.sample.domain.football.internal
 
org.springframework.batch.sample.domain.mail - package org.springframework.batch.sample.domain.mail
 
org.springframework.batch.sample.domain.mail.internal - package org.springframework.batch.sample.domain.mail.internal
 
org.springframework.batch.sample.domain.multiline - package org.springframework.batch.sample.domain.multiline
 
org.springframework.batch.sample.domain.order - package org.springframework.batch.sample.domain.order
 
org.springframework.batch.sample.domain.order.internal - package org.springframework.batch.sample.domain.order.internal
 
org.springframework.batch.sample.domain.order.internal.extractor - package org.springframework.batch.sample.domain.order.internal.extractor
 
org.springframework.batch.sample.domain.order.internal.mapper - package org.springframework.batch.sample.domain.order.internal.mapper
 
org.springframework.batch.sample.domain.order.internal.valang - package org.springframework.batch.sample.domain.order.internal.valang
 
org.springframework.batch.sample.domain.order.internal.xml - package org.springframework.batch.sample.domain.order.internal.xml
 
org.springframework.batch.sample.domain.person - package org.springframework.batch.sample.domain.person
 
org.springframework.batch.sample.domain.person.internal - package org.springframework.batch.sample.domain.person.internal
 
org.springframework.batch.sample.domain.trade - package org.springframework.batch.sample.domain.trade
 
org.springframework.batch.sample.domain.trade.internal - package org.springframework.batch.sample.domain.trade.internal
 
org.springframework.batch.sample.jmx - package org.springframework.batch.sample.jmx
 
org.springframework.batch.sample.launch - package org.springframework.batch.sample.launch
 
org.springframework.batch.sample.loop - package org.springframework.batch.sample.loop
 
org.springframework.batch.sample.quartz - package org.springframework.batch.sample.quartz
 
org.springframework.batch.sample.rabbitmq.amqp - package org.springframework.batch.sample.rabbitmq.amqp
 
org.springframework.batch.sample.rabbitmq.processor - package org.springframework.batch.sample.rabbitmq.processor
 
org.springframework.batch.sample.support - package org.springframework.batch.sample.support
 
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
 
OsgiBundleXmlApplicationContextFactory - Class in org.springframework.batch.core.configuration.support
ApplicationContextFactory that can be used to load a context from an XML location in a bundle.
OsgiBundleXmlApplicationContextFactory() - Constructor for class org.springframework.batch.core.configuration.support.OsgiBundleXmlApplicationContextFactory
 
OutputFileListener - Class in org.springframework.batch.sample.common
 
OutputFileListener() - Constructor for class org.springframework.batch.sample.common.OutputFileListener
 
OutputFileNameListener - Class in org.springframework.batch.sample.common
 
OutputFileNameListener() - Constructor for class org.springframework.batch.sample.common.OutputFileNameListener
 

P

page - Variable in class org.springframework.batch.item.data.AbstractPaginatedDataItemReader
 
pageSize - Variable in class org.springframework.batch.item.data.AbstractPaginatedDataItemReader
 
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.
parametersExtractor(JobParametersExtractor) - Method in class org.springframework.batch.core.step.builder.JobStepBuilder
Provide a job parameters extractor.
parse(Element, ParserContext) - Method in class org.springframework.batch.core.configuration.xml.AbstractListenerParser
 
parse(Element, AbstractBeanDefinition, ParserContext, boolean) - Method in class org.springframework.batch.core.configuration.xml.ChunkElementParser
 
parse(Element, ParserContext) - Method in class org.springframework.batch.core.configuration.xml.DecisionParser
Parse the decision and turn it into a list of transitions.
parse(Element, ParserContext) - Method in class org.springframework.batch.core.configuration.xml.FlowElementParser
Parse the flow and turn it into a list of transitions.
parse(Element, ParserContext, String) - Method in class org.springframework.batch.core.configuration.xml.InlineStepParser
Parse the step and turn it into a list of transitions.
parse(Element, ParserContext) - Method in class org.springframework.batch.core.configuration.xml.SplitParser
Parse the split and turn it into a list of transitions.
parse(Element, ParserContext) - Method in class org.springframework.batch.core.configuration.xml.StandaloneStepParser
Parse the step and turn it into a list of transitions.
parseBeanElement(Element, ParserContext) - Method in class org.springframework.batch.core.configuration.xml.JobParser
 
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.
parseInternal(Element, ParserContext) - Method in class org.springframework.batch.core.configuration.xml.TopLevelStepParser
 
parseListenerElement(Element, ParserContext, BeanDefinition) - Static method in class org.springframework.batch.core.configuration.xml.AbstractListenerParser
 
parseStep(Element, ParserContext, String) - Method in class org.springframework.batch.core.configuration.xml.AbstractStepParser
 
parseTasklet(Element, Element, AbstractBeanDefinition, ParserContext, boolean) - Method in class org.springframework.batch.core.configuration.xml.TaskletParser
 
partition(int) - Method in class org.springframework.batch.core.partition.support.MultiResourcePartitioner
Assign the filename of each of the injected resources to an ExecutionContext.
partition(int) - Method in interface org.springframework.batch.core.partition.support.Partitioner
Create a set of distinct ExecutionContext instances together with a unique identifier for each one.
partition(int) - Method in class org.springframework.batch.core.partition.support.SimplePartitioner
 
partition(int) - Method in class org.springframework.batch.sample.common.ColumnRangePartitioner
Partition a database table assuming that the data in the column specified are uniformly distributed.
Partitioner - Interface in org.springframework.batch.core.partition.support
Central strategy interface for creating input parameters for a partitioned step in the form of ExecutionContext instances.
partitioner(String, Partitioner) - Method in class org.springframework.batch.core.step.builder.PartitionStepBuilder
Add a partitioner which can be used to create a StepExecutionSplitter.
partitioner(String, Partitioner) - Method in class org.springframework.batch.core.step.builder.StepBuilder
Create a partition step builder for a remote (or local) step.
partitioner(Step) - Method in class org.springframework.batch.core.step.builder.StepBuilder
Create a partition step builder for a remote (or local) step.
PartitionHandler - Interface in org.springframework.batch.core.partition
Interface defining the responsibilities of controlling the execution of a partitioned StepExecution.
partitionHandler(PartitionHandler) - Method in class org.springframework.batch.core.step.builder.PartitionStepBuilder
Provide an explicit partition handler that will carry out the work of the partition step.
PartitionNameProvider - Interface in org.springframework.batch.core.partition.support
Optional interface for Partitioner implementations that need to use a custom naming scheme for partitions.
PartitionStep - Class in org.springframework.batch.core.partition.support
Implementation of Step which partitions the execution and spreads the load using a PartitionHandler.
PartitionStep() - Constructor for class org.springframework.batch.core.partition.support.PartitionStep
 
PartitionStepBuilder - Class in org.springframework.batch.core.step.builder
Step builder for PartitionStep instances.
PartitionStepBuilder(StepBuilderHelper<?>) - Constructor for class org.springframework.batch.core.step.builder.PartitionStepBuilder
Create a new builder initialized with any properties in the parent.
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
 
PAYMENT_DESC_COLUMN - Static variable in class org.springframework.batch.sample.domain.order.internal.mapper.BillingFieldSetMapper
 
PAYMENT_TYPE_ID_COLUMN - Static variable in class org.springframework.batch.sample.domain.order.internal.mapper.BillingFieldSetMapper
 
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.
Person - Class in example
Domain object representing information about a person.
Person() - Constructor for class example.Person
 
Person - Class in org.springframework.batch.sample.domain.person
 
Person() - Constructor for class org.springframework.batch.sample.domain.person.Person
 
PersonItemProcessor - Class in example
An example ItemProcessor implementation that upper cases attributes on the provided Person object.
PersonItemProcessor() - Constructor for class example.PersonItemProcessor
 
PersonService - Class in org.springframework.batch.sample.domain.person
Custom class that contains logic that would normally be be contained in ItemReader and ItemWriter.
PersonService() - Constructor for class org.springframework.batch.sample.domain.person.PersonService
 
PersonWriter - Class in org.springframework.batch.sample.domain.person.internal
 
PersonWriter() - Constructor for class org.springframework.batch.sample.domain.person.internal.PersonWriter
 
Player - Class in org.springframework.batch.sample.domain.football
 
Player() - Constructor for class org.springframework.batch.sample.domain.football.Player
 
PlayerDao - Interface in org.springframework.batch.sample.domain.football
Interface for writing Player objects to arbitrary output.
PlayerFieldSetMapper - Class in org.springframework.batch.sample.domain.football.internal
 
PlayerFieldSetMapper() - Constructor for class org.springframework.batch.sample.domain.football.internal.PlayerFieldSetMapper
 
PlayerItemWriter - Class in org.springframework.batch.sample.domain.football.internal
 
PlayerItemWriter() - Constructor for class org.springframework.batch.sample.domain.football.internal.PlayerItemWriter
 
PlayerSummary - Class in org.springframework.batch.sample.domain.football
Domain object representing the summary of a given Player's year.
PlayerSummary() - Constructor for class org.springframework.batch.sample.domain.football.PlayerSummary
 
PlayerSummaryMapper - Class in org.springframework.batch.sample.domain.football.internal
RowMapper used to map a ResultSet to a PlayerSummary
PlayerSummaryMapper() - Constructor for class org.springframework.batch.sample.domain.football.internal.PlayerSummaryMapper
 
PlayerSummaryRowMapper - Class in org.springframework.batch.sample.domain.football.internal
RowMapper used to map a ResultSet to a PlayerSummary
PlayerSummaryRowMapper() - Constructor for class org.springframework.batch.sample.domain.football.internal.PlayerSummaryRowMapper
 
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.
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 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
 
postProcessBeanFactory(ConfigurableListableBeanFactory) - Method in class org.springframework.batch.core.configuration.xml.CoreNamespacePostProcessor
 
postProcessBeanFactory(ConfigurableListableBeanFactory) - Method in class org.springframework.batch.core.scope.StepScope
Register this scope with the enclosing BeanFactory.
postProcessBeforeInitialization(Object, String) - Method in class org.springframework.batch.core.configuration.support.JobRegistryBeanPostProcessor
Do nothing.
postProcessBeforeInitialization(Object, String) - Method in class org.springframework.batch.core.configuration.xml.CoreNamespacePostProcessor
 
prepareBeanFactory(ConfigurableListableBeanFactory, ConfigurableListableBeanFactory) - Method in class org.springframework.batch.core.configuration.support.AbstractApplicationContextFactory
Extension point for special subclasses that want to do more complex things with the bean factory prior to refresh.
prepareContext(ConfigurableApplicationContext, ConfigurableApplicationContext) - Method in class org.springframework.batch.core.configuration.support.AbstractApplicationContextFactory
Extension point for special subclasses that want to do more complex things with the context prior to refresh.
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.
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.
PRICE_COLUMN - Static variable in class org.springframework.batch.sample.domain.order.internal.mapper.OrderItemFieldSetMapper
 
PRICE_COLUMN - Static variable in class org.springframework.batch.sample.domain.trade.internal.CustomerDebitRowMapper
 
PRICE_COLUMN - Static variable in class org.springframework.batch.sample.domain.trade.internal.TradeFieldSetMapper
 
PRICE_COLUMN - Static variable in class org.springframework.batch.sample.domain.trade.internal.TradeRowMapper
 
process(Person) - Method in class example.PersonItemProcessor
 
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.item.adapter.ItemProcessorAdapter
Invoke the delegate method and return the result.
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.CompositeItemProcessor
 
process(T) - Method in class org.springframework.batch.item.support.PassThroughItemProcessor
Just returns the item back to the caller.
process(T) - Method in class org.springframework.batch.item.validator.ValidatingItemProcessor
Validate the item and return it unmodified
process(ProcessIndicatorItemWrapper<T>) - Method in class org.springframework.batch.sample.common.StagingItemProcessor
Use the technical identifier to mark the input row as processed and return unwrapped item.
process(User) - Method in class org.springframework.batch.sample.domain.mail.internal.UserMailItemProcessor
 
process(CustomerUpdate) - Method in class org.springframework.batch.sample.domain.trade.CustomerUpdateProcessor
 
process(CustomerCredit) - Method in class org.springframework.batch.sample.domain.trade.internal.CustomerCreditIncreaseProcessor
 
process(Trade) - Method in class org.springframework.batch.sample.domain.trade.internal.TradeProcessor
 
process(String) - Method in class org.springframework.batch.sample.rabbitmq.processor.MessageProcessor
 
ProcessIndicatorItemWrapper<T> - Class in org.springframework.batch.sample.common
Item wrapper useful in "process indicator" usecase, where input is marked as processed by the processor/writer.
ProcessIndicatorItemWrapper(long, T) - Constructor for class org.springframework.batch.sample.common.ProcessIndicatorItemWrapper
 
processor(ItemProcessor<? super I, ? extends O>) - Method in class org.springframework.batch.core.step.builder.SimpleStepBuilder
An item processor that processes or transforms a stream of items.
processorNonTransactional() - Method in class org.springframework.batch.core.step.builder.FaultTolerantStepBuilder
Mark the item processor as non-transactional (default is the opposite).
processPerson(String, String) - Method in class org.springframework.batch.sample.domain.person.PersonService
 
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
 
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

QUANTITY_COLUMN - Static variable in class org.springframework.batch.sample.domain.order.internal.mapper.OrderItemFieldSetMapper
 
QUANTITY_COLUMN - Static variable in class org.springframework.batch.sample.domain.trade.internal.TradeFieldSetMapper
 
QUANTITY_COLUMN - Static variable in class org.springframework.batch.sample.domain.trade.internal.TradeRowMapper
 
QUERY - Static variable in class org.springframework.batch.sample.domain.trade.internal.CustomerCreditUpdatePreparedStatementSetter
 

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.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.sample.common.InfiniteLoopReader
 
read() - Method in class org.springframework.batch.sample.common.StagingItemReader
 
read() - Method in class org.springframework.batch.sample.domain.multiline.AggregateItemReader
Get the next list of records.
read() - Method in class org.springframework.batch.sample.domain.order.internal.OrderItemReader
 
read() - Method in class org.springframework.batch.sample.domain.trade.internal.GeneratingTradeItemReader
 
read() - Method in class org.springframework.batch.sample.support.ExceptionThrowingItemReaderProxy
 
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() - Method in class org.springframework.batch.sample.config.RetrySampleConfiguration
 
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.
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'.
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.
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
 
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
REG_ID_COLUMN - Static variable in class org.springframework.batch.sample.domain.order.internal.mapper.CustomerFieldSetMapper
 
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(SkipListener<? super T, ? super S>) - Method in class org.springframework.batch.core.listener.CompositeSkipListener
Register additional listener.
register(StepExecutionListener) - Method in class org.springframework.batch.core.listener.CompositeStepExecutionListener
Register additional listener.
register(StepListener) - Method in class org.springframework.batch.core.listener.MulticasterBatchListener
Register the listener for callbacks on the appropriate interfaces implemented.
register(StepExecution) - Static method in class org.springframework.batch.core.scope.context.StepSynchronizationManager
Register a context with the current thread - always put a matching StepSynchronizationManager.close() call in a finally block to ensure that the correct context is available in the enclosing block.
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.
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.StepContext
Allow clients to register callbacks for clean up on close.
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.
REGISTERED_COLUMN - Static variable in class org.springframework.batch.sample.domain.order.internal.mapper.CustomerFieldSetMapper
 
registerItemStream(ItemStream) - Method in class org.springframework.batch.core.step.item.ChunkMonitor
 
registerJobExecutionListener(JobExecutionListener) - Method in class org.springframework.batch.core.job.AbstractJob
Register a single listener for the JobExecutionListener callbacks.
registerListener(RetryListener) - Method in class org.springframework.batch.core.step.item.BatchRetryTemplate
 
registerListener(StepListener) - Method in class org.springframework.batch.core.step.item.SimpleChunkProcessor
Register a listener for callbacks at the appropriate stages in a process.
registerListener(StepListener) - Method in class org.springframework.batch.core.step.item.SimpleChunkProvider
Register a listener for callbacks at the appropriate stages in a process.
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.
registerStream(ItemStream) - Method in class org.springframework.batch.core.step.tasklet.TaskletStep
Register a single ItemStream for callbacks to the stream interface.
release() - Static method in class org.springframework.batch.core.scope.context.StepSynchronizationManager
A convenient "deep" close operation.
reload(ApplicationContextFactory) - Method in class org.springframework.batch.core.configuration.support.DefaultJobLoader
 
reload(ApplicationContextFactory) - Method in interface org.springframework.batch.core.configuration.support.JobLoader
Load an application context and register all the jobs, having first unregistered them if already registered.
RemoteStepExecutionAggregator - Class in org.springframework.batch.core.partition.support
Convenience class for aggregating a set of StepExecution instances when the input comes from remote steps, so the data need to be refreshed from the repository.
RemoteStepExecutionAggregator() - Constructor for class org.springframework.batch.core.partition.support.RemoteStepExecutionAggregator
Create a new instance (useful for configuration purposes).
RemoteStepExecutionAggregator(JobExplorer) - Constructor for class org.springframework.batch.core.partition.support.RemoteStepExecutionAggregator
Create a new instance with a job explorer that can be used to refresh the data when aggregating.
remove(String) - Method in class org.springframework.batch.core.scope.StepScope
 
remove(Throwable) - Method in class org.springframework.batch.core.step.item.Chunk.ChunkIterator
 
remove() - Method in class org.springframework.batch.core.step.item.Chunk.ChunkIterator
 
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.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
 
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
 
RepositoryItemWriter - Class in org.springframework.batch.item.data
A ItemReader wrapper for a CrudRepository from Spring Data.
RepositoryItemWriter() - Constructor for class org.springframework.batch.item.data.RepositoryItemWriter
 
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.
resetCounter() - Method in class org.springframework.batch.sample.domain.trade.internal.GeneratingTradeItemReader
 
resetOffset() - Method in class org.springframework.batch.core.step.item.ChunkMonitor
 
resolveContextualObject(String) - Method in class org.springframework.batch.core.scope.StepScope
This will be used to resolve expressions in step-scoped beans.
resolveId(Element, AbstractBeanDefinition, ParserContext) - Method in class org.springframework.batch.core.configuration.xml.JobRepositoryParser
 
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
 
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 - Interface in org.springframework.batch.item.file
Strategy interface for translating resource index into unique filename suffix.
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
 
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.
retryContextCache(RetryContextCache) - Method in class org.springframework.batch.core.step.builder.FaultTolerantStepBuilder
Provide an explicit retry context cache.
retryLimit(int) - Method in class org.springframework.batch.core.step.builder.FaultTolerantStepBuilder
The maximum number of times to try a failed item.
retryPolicy(RetryPolicy) - Method in class org.springframework.batch.core.step.builder.FaultTolerantStepBuilder
Provide an explicit retry policy instead of using the FaultTolerantStepBuilder.retryLimit(int) and retryable exceptions provided elsewhere.
retrySample() - Method in class org.springframework.batch.sample.config.RetrySampleConfiguration
 
RetrySampleConfiguration - Class in org.springframework.batch.sample.config
 
RetrySampleConfiguration() - Constructor for class org.springframework.batch.sample.config.RetrySampleConfiguration
 
RetrySampleItemWriter<T> - Class in org.springframework.batch.sample.support
Simulates temporary output trouble - requires to retry 3 times to pass successfully.
RetrySampleItemWriter() - Constructor for class org.springframework.batch.sample.support.RetrySampleItemWriter
 
ROLLBACK_EXCEPTION_KEY - Static variable in interface org.springframework.batch.core.ChunkListener
 
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
 
RunIdIncrementer() - Constructor for class org.springframework.batch.core.launch.support.RunIdIncrementer
 
RuntimeExceptionTranslator - Class in org.springframework.batch.core.launch.support
 
RuntimeExceptionTranslator() - Constructor for class org.springframework.batch.core.launch.support.RuntimeExceptionTranslator
 

S

saveExecutionContext(JobExecution) - Method in interface org.springframework.batch.core.repository.dao.ExecutionContextDao
Persist the execution context associated with the given jobExecution, persistent entry for the context should not exist yet.
saveExecutionContext(StepExecution) - Method in interface org.springframework.batch.core.repository.dao.ExecutionContextDao
Persist the execution context associated with the given stepExecution, persistent entry for the context should not exist yet.
saveExecutionContext(JobExecution) - Method in class org.springframework.batch.core.repository.dao.JdbcExecutionContextDao
 
saveExecutionContext(StepExecution) - Method in class org.springframework.batch.core.repository.dao.JdbcExecutionContextDao
 
saveExecutionContext(JobExecution) - Method in class org.springframework.batch.core.repository.dao.MapExecutionContextDao
 
saveExecutionContext(StepExecution) - Method in class org.springframework.batch.core.repository.dao.MapExecutionContextDao
 
saveExecutionContexts(Collection<StepExecution>) - Method in interface org.springframework.batch.core.repository.dao.ExecutionContextDao
Persist the execution context associated with each stepExecution in a given collection, persistent entry for the context should not exist yet.
saveExecutionContexts(Collection<StepExecution>) - Method in class org.springframework.batch.core.repository.dao.JdbcExecutionContextDao
 
saveExecutionContexts(Collection<StepExecution>) - Method in class org.springframework.batch.core.repository.dao.MapExecutionContextDao
 
saveJobExecution(JobExecution) - Method in class org.springframework.batch.core.repository.dao.JdbcJobExecutionDao
SQL implementation using Sequences via the Spring incrementer abstraction.
saveJobExecution(JobExecution) - Method in interface org.springframework.batch.core.repository.dao.JobExecutionDao
Save a new JobExecution.
saveJobExecution(JobExecution) - Method in class org.springframework.batch.core.repository.dao.MapJobExecutionDao
 
savePlayer(Player) - Method in class org.springframework.batch.sample.domain.football.internal.JdbcPlayerDao
 
savePlayer(Player) - Method in interface org.springframework.batch.sample.domain.football.PlayerDao
 
saveStepExecution(StepExecution) - Method in class org.springframework.batch.core.repository.dao.JdbcStepExecutionDao
Save a StepExecution.
saveStepExecution(StepExecution) - Method in class org.springframework.batch.core.repository.dao.MapStepExecutionDao
 
saveStepExecution(StepExecution) - Method in interface org.springframework.batch.core.repository.dao.StepExecutionDao
Save the given StepExecution.
saveStepExecutions(Collection<StepExecution>) - Method in class org.springframework.batch.core.repository.dao.JdbcStepExecutionDao
Batch insert StepExecutions
saveStepExecutions(Collection<StepExecution>) - Method in class org.springframework.batch.core.repository.dao.MapStepExecutionDao
 
saveStepExecutions(Collection<StepExecution>) - Method in interface org.springframework.batch.core.repository.dao.StepExecutionDao
Save the given collection of StepExecution as a batch.
SCHEDULE_DATE_KEY - Static variable in class org.springframework.batch.core.launch.support.ScheduledJobParametersFactory
 
ScheduledJobParametersFactory - Class in org.springframework.batch.core.launch.support
 
ScheduledJobParametersFactory() - Constructor for class org.springframework.batch.core.launch.support.ScheduledJobParametersFactory
 
selectImports(AnnotationMetadata) - Method in class org.springframework.batch.core.configuration.annotation.BatchConfigurationSelector
 
send(SimpleMailMessage) - Method in class org.springframework.batch.sample.domain.mail.internal.TestMailSender
 
send(SimpleMailMessage[]) - Method in class org.springframework.batch.sample.domain.mail.internal.TestMailSender
 
SEND_MESSAGE_COUNT - Static variable in class org.springframework.batch.sample.rabbitmq.amqp.AmqpMessageProducer
 
SerializationUtils - Class in org.springframework.batch.support
Static utility to help with serialization.
SerializationUtils() - Constructor for class org.springframework.batch.support.SerializationUtils
 
serialize(Object, OutputStream) - Method in class org.springframework.batch.core.repository.dao.DefaultExecutionContextSerializer
Serializes an execution context to the provided OutputStream.
serialize(Object, OutputStream) - Method in class org.springframework.batch.core.repository.dao.XStreamExecutionContextStringSerializer
Serializes the passed execution context to the supplied OutputStream.
serialize(Object) - Static method in class org.springframework.batch.support.SerializationUtils
Serialize the object provided.
setAddress(String) - Method in class org.springframework.batch.sample.domain.order.internal.xml.Customer
 
setAddress(Address) - Method in class org.springframework.batch.sample.domain.person.Person
 
setAddressee(String) - Method in class org.springframework.batch.sample.domain.order.Address
 
setAddressMapper(FieldSetMapper<Address>) - Method in class org.springframework.batch.sample.domain.order.internal.OrderItemReader
 
setAddrLine1(String) - Method in class org.springframework.batch.sample.domain.order.Address
 
setAddrLine2(String) - Method in class org.springframework.batch.sample.domain.order.Address
 
setAge(int) - Method in class org.springframework.batch.sample.domain.order.internal.xml.Customer
 
setAge(int) - Method in class org.springframework.batch.sample.domain.person.Person
 
setAggregators(Map<String, LineAggregator<Object>>) - Method in class org.springframework.batch.sample.domain.order.internal.OrderLineAggregator
Set aggregators for all types of lines in the output file
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.file.FlatFileItemWriter
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.support.OsgiBundleXmlApplicationContextFactory
Setter for the parent application context.
setApplicationContext(ApplicationContext) - Method in class org.springframework.batch.core.configuration.xml.CoreNamespacePostProcessor
 
setApplicationContext(ApplicationContext) - Method in class org.springframework.batch.sample.launch.DefaultJobLoader
 
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.
setApplicationEventPublisher(ApplicationEventPublisher) - Method in class org.springframework.batch.sample.jmx.StepExecutionApplicationEventAdvice
 
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.
setAssertUpdates(boolean) - Method in class org.springframework.batch.item.database.IbatisBatchItemWriter
Public setter for the flag that determines whether an assertion is made that all items cause at least one row to be updated.
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
 
setAttempts(int) - Method in class org.springframework.batch.sample.domain.football.Game
 
setAttempts(int) - Method in class org.springframework.batch.sample.domain.football.PlayerSummary
 
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.StepScope
Flag to indicate that bean definitions need not be auto proxied.
setBackOffPolicy(BackOffPolicy) - Method in class org.springframework.batch.core.step.factory.FaultTolerantStepFactoryBean
Public setter for the BackOffPolicy.
setBackOffPolicy(BackOffPolicy) - Method in class org.springframework.batch.core.step.item.BatchRetryTemplate
 
setBeanFactory(BeanFactory) - Method in class org.springframework.batch.core.configuration.support.JobRegistryBeanPostProcessor
 
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.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.
setBegin(String) - Method in class org.springframework.batch.sample.domain.multiline.AggregateItemFieldSetMapper
Public setter for the begin value.
setBilling(BillingInfo) - Method in class org.springframework.batch.sample.domain.order.Order
 
setBillingAddress(Address) - Method in class org.springframework.batch.sample.domain.order.Order
 
setBillingMapper(FieldSetMapper<BillingInfo>) - Method in class org.springframework.batch.sample.domain.order.internal.OrderItemReader
 
setBirthYear(int) - Method in class org.springframework.batch.sample.domain.football.Player
 
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.
setBundleContext(BundleContext) - Method in class org.springframework.batch.core.configuration.support.OsgiBundleXmlApplicationContextFactory
Stash the BundleContext for creating a job application context later.
setBusinessCustomer(boolean) - Method in class org.springframework.batch.sample.domain.order.Customer
 
setBusy(boolean) - Method in class org.springframework.batch.core.step.item.Chunk
Register an interest in the chunk to prevent it from being cleaned up before the flag is reset to false.
setCacheCapacity(int) - Method in class org.springframework.batch.core.step.factory.FaultTolerantStepFactoryBean
Public setter for the capacity of the cache in the retry policy.
setCallable(Callable<RepeatStatus>) - Method in class org.springframework.batch.core.step.tasklet.CallableTaskletAdapter
Public setter for the Callable.
setChildren(List<Child>) - Method in class org.springframework.batch.sample.domain.person.Person
 
setChunkCompletionPolicy(CompletionPolicy) - Method in class org.springframework.batch.core.step.factory.SimpleStepFactoryBean
Public setter for the CompletionPolicy applying to the chunk level.
setChunkListeners(ChunkListener[]) - Method in class org.springframework.batch.core.step.tasklet.TaskletStep
Register each of the objects as listeners.
setChunkMonitor(ChunkMonitor) - Method in class org.springframework.batch.core.step.item.FaultTolerantChunkProcessor
 
setChunkOperations(RepeatOperations) - Method in class org.springframework.batch.core.step.factory.SimpleStepFactoryBean
Public setter for the chunkOperations.
setChunkSize(int) - Method in class org.springframework.batch.core.step.item.ChunkMonitor
 
setChunkSize(int) - Method in class org.springframework.batch.repeat.policy.SimpleCompletionPolicy
 
setCity(String) - Method in class org.springframework.batch.sample.domain.order.Address
 
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.
setColumn(String) - Method in class org.springframework.batch.sample.common.ColumnRangePartitioner
The name of the column to partition.
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.step.factory.SimpleStepFactoryBean
Set the commit interval.
setCompanyName(String) - Method in class org.springframework.batch.sample.domain.order.Customer
 
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.
setCompletes(int) - Method in class org.springframework.batch.sample.domain.football.Game
 
setCompletes(int) - Method in class org.springframework.batch.sample.domain.football.PlayerSummary
 
setCompletionPolicy(CompletionPolicy) - Method in class org.springframework.batch.repeat.support.RepeatTemplate
Setter for policy to decide when the batch is complete.
setContinuation(String) - Method in class org.springframework.batch.item.file.separator.DefaultRecordSeparatorPolicy
Public setter for the continuation.
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.
setCountry(String) - Method in class org.springframework.batch.sample.domain.order.Address
 
setCreateTime(Date) - Method in class org.springframework.batch.core.JobExecution
 
setCredit(BigDecimal) - Method in class org.springframework.batch.sample.domain.trade.CustomerCredit
 
setCreditFilter(double) - Method in class org.springframework.batch.sample.domain.trade.internal.CustomerCreditUpdateWriter
 
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.support.DefaultPropertyEditorRegistrar
Specify the custom editors to register.
setCustomer(Customer) - Method in class org.springframework.batch.sample.domain.order.internal.xml.Order
 
setCustomer(Customer) - Method in class org.springframework.batch.sample.domain.order.Order
 
setCustomer(String) - Method in class org.springframework.batch.sample.domain.trade.Trade
 
setCustomerCreditDao(CustomerCreditDao) - Method in class org.springframework.batch.sample.domain.trade.internal.CustomerCreditItemWriter
Public setter for the CustomerCreditDao.
setCustomerDao(CustomerDao) - Method in class org.springframework.batch.sample.domain.trade.CustomerUpdateProcessor
 
setCustomerDao(CustomerDao) - Method in class org.springframework.batch.sample.domain.trade.CustomerUpdateWriter
 
setCustomerMapper(FieldSetMapper<Customer>) - Method in class org.springframework.batch.sample.domain.order.internal.OrderItemReader
 
setCustomerTokenizer(LineTokenizer) - Method in class org.springframework.batch.sample.domain.trade.CompositeCustomerUpdateLineTokenizer
Set the LineTokenizer that will be used to tokenize any lines that begin with A, U, or D, and are thus a customer operation.
setDao(CustomerCreditDao) - Method in class org.springframework.batch.sample.domain.trade.internal.CustomerCreditUpdateWriter
 
setDao(CustomerDebitDao) - Method in class org.springframework.batch.sample.domain.trade.internal.CustomerUpdateWriter
 
setDao(CustomerCreditDao) - Method in class org.springframework.batch.sample.domain.trade.internal.HibernateAwareCustomerCreditItemWriter
 
setDao(TradeDao) - Method in class org.springframework.batch.sample.domain.trade.internal.TradeWriter
 
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
 
setDataSource(DataSource) - Method in class org.springframework.batch.core.configuration.annotation.DefaultBatchConfigurer
 
setDataSource(DataSource) - Method in class org.springframework.batch.core.explore.support.JobExplorerFactoryBean
Public setter for the DataSource.
setDataSource(DataSource) - Method in class org.springframework.batch.core.repository.support.JobRepositoryFactoryBean
Public setter for the DataSource.
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 {&link 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.sample.common.ColumnRangePartitioner
The data source for connecting to the database.
setDataSource(DataSource) - Method in class org.springframework.batch.sample.common.StagingItemListener
 
setDataSource(DataSource) - Method in class org.springframework.batch.sample.common.StagingItemProcessor
 
setDataSource(DataSource) - Method in class org.springframework.batch.sample.common.StagingItemReader
 
setDataSource(DataSource) - Method in class org.springframework.batch.sample.domain.football.internal.JdbcPlayerDao
 
setDataSource(DataSource) - Method in class org.springframework.batch.sample.domain.football.internal.JdbcPlayerSummaryDao
 
setDataSource(DataSource) - Method in class org.springframework.batch.sample.domain.trade.internal.JdbcCustomerDebitDao
 
setDataSource(DataSource) - Method in class org.springframework.batch.sample.domain.trade.internal.JdbcTradeDao
 
setDataSource(DataSource) - Method in class org.springframework.batch.test.DataSourceInitializer
 
setDataSource(DataSource) - Method in class org.springframework.batch.test.JobRepositoryTestUtils
 
setDate(Date) - Method in class org.springframework.batch.sample.domain.order.internal.xml.Order
 
setDateFormat(DateFormat) - Method in class org.springframework.batch.core.converter.DefaultJobParametersConverter
Public setter for injecting a date format.
setDateFormat(DateFormat) - Method in class org.springframework.batch.core.launch.support.ScheduledJobParametersFactory
Public setter for injecting a date format.
setDateFormat(DateFormat) - Method in class org.springframework.batch.item.file.transform.DefaultFieldSet
The DateFormat to use for parsing numbers.
setDateFormat(DateFormat) - Method in class org.springframework.batch.item.file.transform.DefaultFieldSetFactory
The DateFormat to use for parsing numbers.
setDebit(BigDecimal) - Method in class org.springframework.batch.sample.domain.trade.CustomerDebit
 
setDebutYear(int) - Method in class org.springframework.batch.sample.domain.football.Player
 
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(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(FieldSetMapper<T>) - Method in class org.springframework.batch.sample.domain.multiline.AggregateItemFieldSetMapper
Public setter for the delegate.
setDelegate(ItemReader<T>) - Method in class org.springframework.batch.sample.support.ExceptionThrowingItemReaderProxy
 
setDelegates(List<? extends ItemProcessor<?, ?>>) - Method in class org.springframework.batch.item.support.CompositeItemProcessor
 
setDelegates(List<ItemWriter<? super T>>) - Method in class org.springframework.batch.item.support.CompositeItemWriter
 
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
 
setDelete(boolean) - Method in class org.springframework.batch.item.KeyValueItemWriter
Sets the delete flag to have the item writer perform deletes
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.
setDescription(String) - Method in class org.springframework.batch.sample.domain.order.internal.xml.LineItem
 
setDestroyScripts(Resource[]) - Method in class org.springframework.batch.test.DataSourceInitializer
 
setDiscountAmount(BigDecimal) - Method in class org.springframework.batch.sample.domain.order.LineItem
 
setDiscountPerc(BigDecimal) - Method in class org.springframework.batch.sample.domain.order.LineItem
 
setDisplayName(String) - Method in class org.springframework.batch.core.configuration.support.OsgiBundleXmlApplicationContextFactory
 
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.
setEmail(String) - Method in class org.springframework.batch.sample.domain.mail.User
 
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.file.FlatFileItemWriter
Sets encoding for output template.
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).
setEnd(String) - Method in class org.springframework.batch.sample.domain.multiline.AggregateItemFieldSetMapper
Public setter for the end field value.
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.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.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(ExitStatus) - Method in class org.springframework.batch.core.JobExecution
 
setExitStatus(ExitStatus) - Method in class org.springframework.batch.core.StepContribution
Set the ExitStatus for this contribution.
setExitStatus(ExitStatus) - Method in class org.springframework.batch.core.StepExecution
 
setFailingCustomers(List<String>) - Method in class org.springframework.batch.sample.domain.trade.internal.TradeWriter
Public setter for the the customers on which failure should occur.
setFailOnFlush(int) - Method in class org.springframework.batch.sample.domain.trade.internal.HibernateCreditDao
Public setter for the failOnFlush property.
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
 
setFieldSetReader(ItemReader<FieldSet>) - Method in class org.springframework.batch.sample.domain.order.internal.OrderItemReader
 
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.
setFirstName(String) - Method in class example.Person
 
setFirstName(String) - Method in class org.springframework.batch.sample.domain.football.Player
 
setFirstName(String) - Method in class org.springframework.batch.sample.domain.order.Customer
 
setFirstName(String) - Method in class org.springframework.batch.sample.domain.person.Person
 
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.
setFooterCallback(FlatFileFooterCallback) - Method in class org.springframework.batch.item.file.FlatFileItemWriter
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
setFooterTokenizer(LineTokenizer) - Method in class org.springframework.batch.sample.domain.trade.CompositeCustomerUpdateLineTokenizer
Set the LineTokenizer that will be used to tokenize any lines that being with F and is thus a footer record.
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.file.FlatFileItemWriter
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
 
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.partition.support.AbstractPartitionHandler
Passed to the StepExecutionSplitter in the AbstractPartitionHandler.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.
setHandlers(ExceptionHandler[]) - Method in class org.springframework.batch.repeat.exception.CompositeExceptionHandler
 
setHandlingPrice(BigDecimal) - Method in class org.springframework.batch.sample.domain.order.LineItem
 
setHeaderCallback(FlatFileHeaderCallback) - Method in class org.springframework.batch.item.file.FlatFileItemWriter
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.
setHeaderMapper(FieldSetMapper<Order>) - Method in class org.springframework.batch.sample.domain.order.internal.OrderItemReader
 
setHibernateTemplate(HibernateOperations) - Method in class org.springframework.batch.item.database.HibernateItemWriter
Deprecated.
As of 2.2 in favor of using Hibernate's session management APIs directly
setHierarchicalStreamDriver(HierarchicalStreamDriver) - Method in class org.springframework.batch.core.repository.dao.XStreamExecutionContextStringSerializer
 
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
 
setId(String) - Method in class org.springframework.batch.sample.domain.football.Game
 
setId(String) - Method in class org.springframework.batch.sample.domain.football.Player
 
setId(String) - Method in class org.springframework.batch.sample.domain.football.PlayerSummary
 
setId(int) - Method in class org.springframework.batch.sample.domain.mail.User
 
setId(int) - Method in class org.springframework.batch.sample.domain.trade.CustomerCredit
 
setId(long) - Method in class org.springframework.batch.sample.domain.trade.Trade
 
setIgnoreFailedDrop(boolean) - Method in class org.springframework.batch.test.DataSourceInitializer
 
setIgnoreItemStream(boolean) - Method in class org.springframework.batch.item.support.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).
setIncrementer(DataFieldMaxValueIncrementer) - Method in class org.springframework.batch.sample.common.StagingItemWriter
Setter for the key generator for the staging table.
setIncrementer(DataFieldMaxValueIncrementer) - Method in class org.springframework.batch.sample.domain.trade.internal.JdbcCustomerDao
 
setIncrementer(DataFieldMaxValueIncrementer) - Method in class org.springframework.batch.sample.domain.trade.internal.JdbcTradeDao
 
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
 
setInputKeyName(String) - Method in class org.springframework.batch.sample.common.OutputFileListener
 
setInterceptions(int) - Method in class org.springframework.batch.sample.domain.football.Game
 
setInterceptions(int) - Method in class org.springframework.batch.sample.domain.football.PlayerSummary
 
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.
setInvalidCustomerLogger(InvalidCustomerLogger) - Method in class org.springframework.batch.sample.domain.trade.CustomerUpdateProcessor
 
setIsin(String) - Method in class org.springframework.batch.sample.domain.trade.Trade
 
setIsolation(Isolation) - Method in class org.springframework.batch.core.step.factory.SimpleStepFactoryBean
 
setIsolationLevelForCreate(String) - Method in class org.springframework.batch.core.repository.support.AbstractJobRepositoryFactoryBean
public setter for the isolation level to be used for the transaction when job execution entities are initially created.
setIsReaderTransactionalQueue(boolean) - Method in class org.springframework.batch.core.step.factory.SimpleStepFactoryBean
Flag to signal that the reader is transactional (usually a JMS consumer) so that items are re-presented after a rollback.
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.
setItemId(long) - Method in class org.springframework.batch.sample.domain.order.LineItem
 
setItemKeyMapper(Converter<V, K>) - Method in class org.springframework.batch.item.KeyValueItemWriter
Set the Converter to use to derive the key from the item
setItemMapper(FieldSetMapper<LineItem>) - Method in class org.springframework.batch.sample.domain.order.internal.OrderItemReader
 
setItemPreparedStatementSetter(ItemPreparedStatementSetter<T>) - Method in class org.springframework.batch.item.database.JdbcBatchItemWriter
Public setter for the ItemPreparedStatementSetter.
setItemProcessor(ItemProcessor<? super T, ? extends S>) - Method in class org.springframework.batch.core.step.factory.SimpleStepFactoryBean
 
setItemProcessor(ItemProcessor<? super I, ? extends O>) - Method in class org.springframework.batch.core.step.item.SimpleChunkProcessor
 
setItemReader(ItemReader<? extends T>) - Method in class org.springframework.batch.core.step.factory.SimpleStepFactoryBean
 
setItemReader(ItemReader<?>) - Method in class org.springframework.batch.core.step.item.ChunkMonitor
 
setItemReader(ItemReader<AggregateItem<T>>) - Method in class org.springframework.batch.sample.domain.multiline.AggregateItemReader
 
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
 
setItemType(Class<? extends T>) - Method in class org.springframework.batch.item.jms.JmsItemReader
Set the expected type of incoming message payloads.
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
 
setItemWriter(ItemWriter<String>) - Method in class org.springframework.batch.sample.domain.trade.internal.FlatFileCustomerCreditDao
 
setJavaMailSender(JavaMailSender) - Method in class org.springframework.batch.item.mail.javamail.MimeMessageItemWriter
A JavaMailSender to be used to send messages in MimeMessageItemWriter.write(List).
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.
setJdbcTemplate(JdbcOperations) - Method in class org.springframework.batch.sample.common.StagingItemProcessor
 
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.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.
setJobExecutionIncrementer(DataFieldMaxValueIncrementer) - Method in class org.springframework.batch.core.repository.dao.JdbcJobExecutionDao
Setter for DataFieldMaxValueIncrementer to be used when generating primary keys for JobExecution instances.
setJobExecutionListeners(JobExecutionListener[]) - Method in class org.springframework.batch.core.job.AbstractJob
Public setter for injecting JobExecutionListeners.
setJobExplorer(JobExplorer) - Method in class org.springframework.batch.core.launch.support.CommandLineJobRunner
Injection setter for JobExplorer.
setJobExplorer(JobExplorer) - Method in class org.springframework.batch.core.launch.support.SimpleJobOperator
Public setter for the JobExplorer.
setJobExplorer(JobExplorer) - Method in class org.springframework.batch.core.partition.support.RemoteStepExecutionAggregator
 
setJobFactoryRef(String) - Method in class org.springframework.batch.core.configuration.xml.AbstractFlowParser
Convenience method for subclasses to set the job factory reference if it is available (null is fine, but the quality of error reports is better if it is available).
setJobIncrementer(DataFieldMaxValueIncrementer) - Method in class org.springframework.batch.core.repository.dao.JdbcJobInstanceDao
Setter for DataFieldMaxValueIncrementer to be used when generating primary keys for JobInstance instances.
setJobInstance(JobInstance) - Method in class org.springframework.batch.core.JobExecution
 
setJobLauncher(JobLauncher) - Method in class org.springframework.batch.core.launch.support.SimpleJobOperator
Public setter for the JobLauncher.
setJobLauncher(JobLauncher) - Method in class org.springframework.batch.core.step.job.JobStep
A JobLauncher is required to be able to run the enclosed Job.
setJobLauncher(JobLauncher) - Method in class org.springframework.batch.sample.quartz.JobLauncherDetails
Public setter for the JobLauncher.
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.
setJobLocator(JobLocator) - Method in class org.springframework.batch.sample.quartz.JobLauncherDetails
Public setter for the JobLocator.
setJobParametersConverter(JobParametersConverter) - Method in class org.springframework.batch.core.launch.support.CommandLineJobRunner
Injection setter for JobParametersConverter.
setJobParametersConverter(JobParametersConverter) - Method in class org.springframework.batch.core.launch.support.SimpleJobOperator
Public setter for the JobParametersConverter.
setJobParametersExtractor(JobParametersExtractor) - Method in class org.springframework.batch.core.step.job.JobStep
The JobParametersExtractor is used to extract JobParametersExtractor from the StepExecution to run the Job.
setJobParametersIncrementer(JobParametersIncrementer) - Method in class org.springframework.batch.core.job.AbstractJob
Public setter for the JobParametersIncrementer.
setJobParametersIncrementer(JobParametersIncrementer) - Method in class org.springframework.batch.core.job.builder.JobBuilderHelper.CommonJobProperties
 
setJobParametersIncrementer(JobParametersIncrementer) - Method in class org.springframework.batch.test.JobRepositoryTestUtils
 
setJobParametersValidator(JobParametersValidator) - Method in class org.springframework.batch.core.job.AbstractJob
A validator for job parameters.
setJobParametersValidator(JobParametersValidator) - Method in class org.springframework.batch.core.job.builder.JobBuilderHelper.CommonJobProperties
 
setJobRegistry(JobRegistry) - Method in class org.springframework.batch.core.configuration.support.DefaultJobLoader
The JobRegistry to use for jobs created.
setJobRegistry(JobRegistry) - Method in class org.springframework.batch.core.configuration.support.JobFactoryRegistrationListener
Public setter for a JobRegistry to use for all the bind and unbind events.
setJobRegistry(JobRegistry) - Method in class org.springframework.batch.core.configuration.support.JobRegistryBeanPostProcessor
Injection setter for JobRegistry.
setJobRegistry(JobRegistry) - Method in class org.springframework.batch.core.launch.support.JobRegistryBackgroundJobRunner
A job registry that can be used to create a job loader (if none is provided).
setJobRegistry(ListableJobLocator) - Method in class org.springframework.batch.core.launch.support.SimpleJobOperator
Public setter for the ListableJobLocator.
setJobRepository(JobRepository) - Method in class org.springframework.batch.core.job.AbstractJob
Public setter for the JobRepository that is needed to manage the state of the batch meta domain (jobs, steps, executions) during the life of a job.
setJobRepository(JobRepository) - Method in class org.springframework.batch.core.job.builder.JobBuilderHelper.CommonJobProperties
 
setJobRepository(JobRepository) - Method in class org.springframework.batch.core.job.SimpleStepHandler
 
setJobRepository(JobRepository) - Method in class org.springframework.batch.core.launch.support.CommandLineJobRunner
 
setJobRepository(JobRepository) - Method in class org.springframework.batch.core.launch.support.SimpleJobLauncher
Set the JobRepsitory.
setJobRepository(JobRepository) - Method in class org.springframework.batch.core.launch.support.SimpleJobOperator
 
setJobRepository(JobRepository) - Method in class org.springframework.batch.core.partition.support.SimpleStepExecutionSplitter
The job repository that will be used to manage the persistence of the delegate step executions.
setJobRepository(JobRepository) - Method in class org.springframework.batch.core.step.AbstractStep
Public setter for JobRepository.
setJobRepository(JobRepository) - Method in class org.springframework.batch.core.step.builder.StepBuilderHelper.CommonStepProperties
 
setJobRepository(JobRepository) - Method in class org.springframework.batch.core.step.factory.SimpleStepFactoryBean
Public setter for JobRepository.
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
 
setKey(String) - Method in class org.springframework.batch.core.launch.support.RunIdIncrementer
The name of the run id in the job parameters.
setKeyGenerator(KeyGenerator) - Method in class org.springframework.batch.core.step.factory.FaultTolerantStepFactoryBean
The KeyGenerator to use to identify failed items across rollback.
setKeyGenerator(KeyGenerator) - Method in class org.springframework.batch.core.step.item.FaultTolerantChunkProcessor
The KeyGenerator to use to identify failed items across rollback.
setKeyName(String) - Method in class org.springframework.batch.core.partition.support.MultiResourcePartitioner
The name of the key for the file name in each ExecutionContext.
setKeyName(String) - Method in class org.springframework.batch.core.resource.StepExecutionSimpleCompletionPolicy
Public setter for the key name of a Long value in the JobParameters that will contain a commit interval.
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.
setLast_name(String) - Method in class org.springframework.batch.sample.domain.person.Person
Intentionally non-standard method name for testing purposes
setLastName(String) - Method in class example.Person
 
setLastName(String) - Method in class org.springframework.batch.sample.domain.football.Player
 
setLastName(String) - Method in class org.springframework.batch.sample.domain.order.Customer
 
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.
setLimit(int) - Method in class org.springframework.batch.sample.domain.trade.internal.GeneratingTradeItemReader
 
setLimit(int) - Method in class org.springframework.batch.sample.loop.LimitDecider
 
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
 
setLineItems(List<LineItem>) - Method in class org.springframework.batch.sample.domain.order.internal.xml.Order
 
setLineItems(List<LineItem>) - Method in class org.springframework.batch.sample.domain.order.Order
 
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.file.FlatFileItemWriter
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.
setLineTokenizer(LineTokenizer) - Method in class org.springframework.batch.item.file.mapping.DefaultLineMapper
 
setListeners(List<? extends ChunkListener>) - Method in class org.springframework.batch.core.listener.CompositeChunkListener
Public setter for the listeners.
setListeners(List<? extends ItemProcessListener<? super T, ? super S>>) - Method in class org.springframework.batch.core.listener.CompositeItemProcessListener
Public setter for the listeners.
setListeners(List<? extends ItemReadListener<? super T>>) - Method in class org.springframework.batch.core.listener.CompositeItemReadListener
Public setter for the listeners.
setListeners(List<? extends ItemWriteListener<? super S>>) - Method in class org.springframework.batch.core.listener.CompositeItemWriteListener
Public setter for the listeners.
setListeners(List<? extends JobExecutionListener>) - Method in class org.springframework.batch.core.listener.CompositeJobExecutionListener
Public setter for the listeners.
setListeners(List<? extends SkipListener<? super T, ? super S>>) - Method in class org.springframework.batch.core.listener.CompositeSkipListener
Public setter for the listeners.
setListeners(StepExecutionListener[]) - Method in class org.springframework.batch.core.listener.CompositeStepExecutionListener
Public setter for the listeners.
setListeners(List<? extends StepListener>) - Method in class org.springframework.batch.core.listener.MulticasterBatchListener
Register each of the objects as listeners.
setListeners(StepListener[]) - Method in class org.springframework.batch.core.step.factory.SimpleStepFactoryBean
The listeners to inject into the Step.
setListeners(RetryListener[]) - Method in class org.springframework.batch.core.step.item.BatchRetryTemplate
 
setListeners(List<? extends StepListener>) - Method in class org.springframework.batch.core.step.item.SimpleChunkProcessor
Register some StepListeners with the handler.
setListeners(List<? extends StepListener>) - Method in class org.springframework.batch.core.step.item.SimpleChunkProvider
Register some StepListeners with the handler.
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).
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.Neo4jItemReader
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.
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.
setMiddleName(String) - Method in class org.springframework.batch.sample.domain.order.Customer
 
setMinimumLength(int) - Method in class org.springframework.batch.item.file.transform.FormatterLineAggregator
Public setter for the minimum length of the formatted string.
setMoo(int) - Method in class org.springframework.batch.sample.domain.order.internal.xml.Customer
 
setName(String) - Method in class org.springframework.batch.core.configuration.xml.SimpleFlowFactoryBean
The name of the flow that is created by this factory.
setName(String) - Method in class org.springframework.batch.core.job.AbstractJob
Set the name property.
setName(String) - Method in class org.springframework.batch.core.job.builder.JobBuilderHelper.CommonJobProperties
 
setName(String) - Method in class org.springframework.batch.core.scope.StepScope
Public setter for the name property.
setName(String) - Method in class org.springframework.batch.core.step.AbstractStep
Set the name property.
setName(String) - Method in class org.springframework.batch.core.step.builder.StepBuilderHelper.CommonStepProperties
 
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
 
setName(String) - Method in class org.springframework.batch.sample.domain.mail.User
 
setName(String) - Method in class org.springframework.batch.sample.domain.order.internal.xml.Customer
 
setName(String) - Method in class org.springframework.batch.sample.domain.order.internal.xml.Shipper
 
setName(String) - Method in class org.springframework.batch.sample.domain.person.Child
 
setName(String) - Method in class org.springframework.batch.sample.domain.trade.CustomerCredit
 
setName(String) - Method in class org.springframework.batch.sample.domain.trade.CustomerDebit
 
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.step.factory.FaultTolerantStepFactoryBean
Exception classes that are candidates for no rollback.
setNotificationPublisher(NotificationPublisher) - Method in class org.springframework.batch.sample.jmx.JobExecutionNotificationPublisher
Injection setter.
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.
setOpponent(String) - Method in class org.springframework.batch.sample.domain.football.Game
 
setOptionalKeys(String[]) - Method in class org.springframework.batch.core.job.DefaultJobParametersValidator
The keys that are optional in the parameters.
setOrder(int) - Method in class org.springframework.batch.core.configuration.support.AutomaticJobRegistrar
The order to start up and shutdown.
setOrder(int) - Method in class org.springframework.batch.core.scope.StepScope
 
setOrderByStatement(String) - Method in class org.springframework.batch.item.data.Neo4jItemReader
A list of properties to order the results by.
setOrderDate(Date) - Method in class org.springframework.batch.sample.domain.order.Order
 
setOrderId(long) - Method in class org.springframework.batch.sample.domain.order.Order
 
setOutputKeyName(String) - Method in class org.springframework.batch.sample.common.OutputFileListener
 
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(List<?>) - Method in class org.springframework.batch.core.resource.ListPreparedStatementSetter
The parameter values that will be set on the PreparedStatement.
setParameters(SqlParameter[]) - Method in class org.springframework.batch.item.database.StoredProcedureItemReader
Add one or more declared parameters.
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.IbatisPagingItemReader
The parameter values to be used for the query execution.
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.JpaPagingItemReader
The parameter values to be used for the query execution.
setPartitioner(Partitioner) - Method in class org.springframework.batch.core.partition.support.SimpleStepExecutionSplitter
The Partitioner that will be used to generate step execution meta data for the target step.
setPartitionHandler(PartitionHandler) - Method in class org.springframework.batch.core.partition.support.PartitionStep
A PartitionHandler which can send out step executions for remote processing and bring back the results.
setPassingTd(int) - Method in class org.springframework.batch.sample.domain.football.Game
 
setPassingTd(int) - Method in class org.springframework.batch.sample.domain.football.PlayerSummary
 
setPassingYards(int) - Method in class org.springframework.batch.sample.domain.football.Game
 
setPassingYards(int) - Method in class org.springframework.batch.sample.domain.football.PlayerSummary
 
setPath(String) - Method in class org.springframework.batch.core.configuration.support.OsgiBundleXmlApplicationContextFactory
 
setPath(String) - Method in class org.springframework.batch.sample.common.OutputFileListener
 
setPattern(Pattern) - Method in class org.springframework.batch.item.file.transform.RegexLineTokenizer
Sets the regex pattern to use.
setPaymentDesc(String) - Method in class org.springframework.batch.sample.domain.order.BillingInfo
 
setPaymentId(String) - Method in class org.springframework.batch.sample.domain.order.BillingInfo
 
setPerOunceRate(double) - Method in class org.springframework.batch.sample.domain.order.internal.xml.Shipper
 
setPerUnitOunces(double) - Method in class org.springframework.batch.sample.domain.order.internal.xml.LineItem
 
setPlayerDao(PlayerDao) - Method in class org.springframework.batch.sample.domain.football.internal.PlayerItemWriter
 
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.
setPoo(int) - Method in class org.springframework.batch.sample.domain.order.internal.xml.Customer
 
setPosition(String) - Method in class org.springframework.batch.sample.domain.football.Player
 
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.
setPrice(double) - Method in class org.springframework.batch.sample.domain.order.internal.xml.LineItem
 
setPrice(BigDecimal) - Method in class org.springframework.batch.sample.domain.order.LineItem
 
setPrice(BigDecimal) - Method in class org.springframework.batch.sample.domain.trade.Trade
 
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.step.factory.FaultTolerantStepFactoryBean
 
setProcessorTransactional(boolean) - Method in class org.springframework.batch.core.step.item.FaultTolerantChunkProcessor
Flag to say that the ItemProcessor is transactional (defaults to true).
setProcessSkipCount(int) - Method in class org.springframework.batch.core.StepExecution
Set the number of records skipped during processing.
setProcessSkipPolicy(SkipPolicy) - Method in class org.springframework.batch.core.step.item.FaultTolerantChunkProcessor
 
setPropagation(Propagation) - Method in class org.springframework.batch.core.step.factory.SimpleStepFactoryBean
 
setProperty(String, String) - Method in class org.springframework.batch.sample.launch.DefaultJobLoader
 
setProperty(String, String) - Method in interface org.springframework.batch.sample.launch.ExportedJobLoader
 
setProperty(String, String) - Method in interface org.springframework.batch.sample.launch.JobLoader
 
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.StepScope
Flag to indicate that proxies should use dynamic subclassing.
setQuantity(int) - Method in class org.springframework.batch.sample.domain.order.internal.xml.LineItem
 
setQuantity(int) - Method in class org.springframework.batch.sample.domain.order.LineItem
 
setQuantity(long) - Method in class org.springframework.batch.sample.domain.trade.Trade
 
setQuery(String) - Method in class org.springframework.batch.item.data.MongoItemReader
A JSON formatted MongoDB query.
setQueryId(String) - Method in class org.springframework.batch.item.database.IbatisPagingItemReader
 
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) - Method in class org.springframework.batch.item.database.HibernateCursorItemReader
A query provider.
setQueryProvider(HibernateQueryProvider) - Method in class org.springframework.batch.item.database.HibernateItemReaderHelper
 
setQueryProvider(HibernateQueryProvider) - 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.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.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
setReader(GeneratingTradeItemReader) - Method in class org.springframework.batch.sample.loop.GeneratingTradeResettingListener
 
setReadSkipCount(int) - Method in class org.springframework.batch.core.StepExecution
Set the number of records skipped on read
setReceptions(int) - Method in class org.springframework.batch.sample.domain.football.Game
 
setReceptions(int) - Method in class org.springframework.batch.sample.domain.football.PlayerSummary
 
setReceptionYards(int) - Method in class org.springframework.batch.sample.domain.football.Game
 
setReceptionYards(int) - Method in class org.springframework.batch.sample.domain.football.PlayerSummary
 
setRecordSeparatorPolicy(RecordSeparatorPolicy) - Method in class org.springframework.batch.item.file.FlatFileItemReader
Public setter for the recordSeparatorPolicy.
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
 
setRegex(String) - Method in class org.springframework.batch.item.file.transform.RegexLineTokenizer
Sets the regular expression to use.
setRegistered(boolean) - Method in class org.springframework.batch.sample.domain.order.Customer
 
setRegistrationId(long) - Method in class org.springframework.batch.sample.domain.order.Customer
 
setRegistry(ListableJobLocator) - Method in class org.springframework.batch.sample.launch.DefaultJobLoader
 
setRepeatOperations(RepeatOperations) - Method in class org.springframework.batch.repeat.interceptor.RepeatOperationsInterceptor
Setter for the RepeatOperations.
setRepository(PagingAndSortingRepository) - Method in class org.springframework.batch.item.data.RepositoryItemReader
The PagingAndSortingRepository implementation used to read input from.
setRepository(CrudRepository) - 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
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.FlatFileItemWriter
Setter for 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 interface org.springframework.batch.item.ResourceAware
 
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.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
 
setResultConverter(ResultConverter) - Method in class org.springframework.batch.item.data.Neo4jItemReader
Set the converter used to convert node to the targetType.
setRetryableExceptionClasses(Map<Class<? extends Throwable>, Boolean>) - Method in class org.springframework.batch.core.step.factory.FaultTolerantStepFactoryBean
Public setter for the retryable exceptions classifier map (from throwable class to boolean, true is retryable).
setRetryContextCache(RetryContextCache) - Method in class org.springframework.batch.core.step.factory.FaultTolerantStepFactoryBean
Override the default retry context cache for retry of chunk processing.
setRetryContextCache(RetryContextCache) - Method in class org.springframework.batch.core.step.item.BatchRetryTemplate
 
setRetryLimit(int) - Method in class org.springframework.batch.core.step.factory.FaultTolerantStepFactoryBean
Public setter for the retry limit.
setRetryListeners(RetryListener...) - Method in class org.springframework.batch.core.step.factory.FaultTolerantStepFactoryBean
Public setter for the RetryListeners.
setRetryPolicy(RetryPolicy) - Method in class org.springframework.batch.core.step.factory.FaultTolerantStepFactoryBean
Setter for the retry policy.
setRetryPolicy(RetryPolicy) - Method in class org.springframework.batch.core.step.item.BatchRetryTemplate
 
setReturnStatement(String) - Method in class org.springframework.batch.item.data.Neo4jItemReader
The return statement of the cypher query.
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) - Method in class org.springframework.batch.item.database.JdbcCursorItemReader
Set the RowMapper to be used for all calls to read().
setRowMapper(RowMapper) - Method in class org.springframework.batch.item.database.JdbcPagingItemReader
The row mapper implementation to be used by this reader.
setRowMapper(RowMapper) - Method in class org.springframework.batch.item.database.StoredProcedureItemReader
Set the RowMapper to be used for all calls to read().
setRushes(int) - Method in class org.springframework.batch.sample.domain.football.Game
 
setRushes(int) - Method in class org.springframework.batch.sample.domain.football.PlayerSummary
 
setRushYards(int) - Method in class org.springframework.batch.sample.domain.football.Game
 
setRushYards(int) - Method in class org.springframework.batch.sample.domain.football.PlayerSummary
 
setSaveState(boolean) - Method in class org.springframework.batch.item.file.FlatFileItemWriter
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.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
 
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
 
setSelectClause(String) - Method in class org.springframework.batch.item.database.support.AbstractSqlPagingQueryProvider
 
setSelectClause(String) - Method in class org.springframework.batch.item.database.support.SqlPagingQueryProviderFactoryBean
 
setSeparator(String) - Method in class org.springframework.batch.sample.domain.trade.internal.FlatFileCustomerCreditDao
 
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.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.
setSessionFactory(SessionFactory) - Method in class org.springframework.batch.sample.domain.trade.internal.HibernateAwareCustomerCreditItemWriter
 
setSessionFactory(SessionFactory) - Method in class org.springframework.batch.sample.domain.trade.internal.HibernateCreditDao
 
setShipper(Shipper) - Method in class org.springframework.batch.sample.domain.order.internal.xml.Order
 
setShipperId(String) - Method in class org.springframework.batch.sample.domain.order.ShippingInfo
 
setShipping(ShippingInfo) - Method in class org.springframework.batch.sample.domain.order.Order
 
setShippingAddress(Address) - Method in class org.springframework.batch.sample.domain.order.Order
 
setShippingInfo(String) - Method in class org.springframework.batch.sample.domain.order.ShippingInfo
 
setShippingMapper(FieldSetMapper<ShippingInfo>) - Method in class org.springframework.batch.sample.domain.order.internal.OrderItemReader
 
setShippingPrice(BigDecimal) - Method in class org.springframework.batch.sample.domain.order.LineItem
 
setShippingTypeId(String) - Method in class org.springframework.batch.sample.domain.order.ShippingInfo
 
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.file.FlatFileItemWriter
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.file.FlatFileItemWriter
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.step.factory.FaultTolerantStepFactoryBean
A limit that determines skip policy.
setSkipLimit(int) - Method in class org.springframework.batch.core.step.skip.LimitCheckingItemSkipPolicy
The absolute number of skips (of skippable exceptions) that can be tolerated before a failure.
setSkippableExceptionClasses(Map<Class<? extends Throwable>, Boolean>) - Method in class org.springframework.batch.core.step.factory.FaultTolerantStepFactoryBean
Exception classes that when raised won't crash the job but will result in the item which handling caused the exception being skipped.
setSkippableExceptionClassifier(Classifier<Throwable, Boolean>) - Method in class org.springframework.batch.core.step.skip.LimitCheckingItemSkipPolicy
The classifier that will be used to decide on skippability.
setSkippableExceptionMap(Map<Class<? extends Throwable>, Boolean>) - Method in class org.springframework.batch.core.step.skip.LimitCheckingItemSkipPolicy
Set up the classifier through a convenient map from throwable class to boolean (true if skippable).
setSkippedLinesCallback(LineCallbackHandler) - Method in class org.springframework.batch.item.file.FlatFileItemReader
 
setSkipPolicies(SkipPolicy[]) - Method in class org.springframework.batch.core.step.skip.CompositeSkipPolicy
 
setSkipPolicy(SkipPolicy) - Method in class org.springframework.batch.core.step.factory.FaultTolerantStepFactoryBean
A SkipPolicy that determines the outcome of an exception when processing an item.
setSkipPolicy(SkipPolicy) - Method in class org.springframework.batch.core.step.item.FaultTolerantChunkProvider
The policy that determines whether exceptions can be skipped on read.
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.
setSqlMapClient(SqlMapClient) - Method in class org.springframework.batch.item.database.IbatisBatchItemWriter
Public setter for SqlMapClient for injection purposes.
setSqlMapClient(SqlMapClient) - Method in class org.springframework.batch.item.database.IbatisPagingItemReader
 
setSqlMapClientTemplate(SqlMapClientTemplate) - Method in class org.springframework.batch.item.database.IbatisBatchItemWriter
Public setter for the SqlMapClientTemplate.
setSqlQuery(String) - Method in class org.springframework.batch.item.database.orm.HibernateNativeQueryProvider
 
setSqlQuery(String) - Method in class org.springframework.batch.item.database.orm.JpaNativeQueryProvider
 
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.Neo4jItemReader
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
setState(String) - Method in class org.springframework.batch.sample.domain.order.Address
 
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.
setStatementId(String) - Method in class org.springframework.batch.item.database.IbatisBatchItemWriter
Public setter for the statement id identifying the statement in the SqlMap configuration file.
setStatementId(String) - Method in class org.springframework.batch.sample.domain.trade.internal.IbatisCustomerCreditDao
 
setStateTransitions(List<StateTransition>) - Method in class org.springframework.batch.core.configuration.xml.SimpleFlowFactoryBean
The raw state transitions for the flow.
setStateTransitions(List<StateTransition>) - Method in class org.springframework.batch.core.job.flow.support.SimpleFlow
Public setter for the stateTransitions.
setStatus(BatchStatus) - Method in class org.springframework.batch.core.JobExecution
Set the value of the status field.
setStatus(BatchStatus) - Method in class org.springframework.batch.core.StepExecution
Sets the current status of this step
setStatuses(String[]) - Method in class org.springframework.batch.core.listener.ExecutionContextPromotionListener
 
setStep(Step) - Method in class org.springframework.batch.core.partition.support.TaskExecutorPartitionHandler
Setter for the Step that will be used to execute the partitioned StepExecution.
setStepExecutionAggregator(StepExecutionAggregator) - Method in class org.springframework.batch.core.partition.support.PartitionStep
A StepExecutionAggregator that can aggregate step executions when they come back from the handler.
setStepExecutionIncrementer(DataFieldMaxValueIncrementer) - Method in class org.springframework.batch.core.repository.dao.JdbcStepExecutionDao
 
setStepExecutionListeners(StepExecutionListener[]) - Method in class org.springframework.batch.core.step.AbstractStep
Register each of the objects as listeners.
setStepExecutionSplitter(StepExecutionSplitter) - Method in class org.springframework.batch.core.partition.support.PartitionStep
Public setter for mandatory property StepExecutionSplitter.
setStepLocator(StepLocator) - Method in class org.springframework.batch.core.step.StepLocatorStepFactoryBean
 
setStepName(String) - Method in class org.springframework.batch.core.partition.support.SimpleStepExecutionSplitter
The name of the target step that will be executed across the partitions.
setStepName(String) - Method in class org.springframework.batch.core.step.StepLocatorStepFactoryBean
 
setStepOperations(RepeatOperations) - Method in class org.springframework.batch.core.step.factory.SimpleStepFactoryBean
Public setter for the stepOperations.
setStepOperations(RepeatOperations) - Method in class org.springframework.batch.core.step.tasklet.TaskletStep
The RepeatOperations to use for the outer loop of the batch processing.
setStepRegistry(StepRegistry) - Method in class org.springframework.batch.core.configuration.support.DefaultJobLoader
The StepRegistry to use for the steps of created jobs.
setSteps(List<Step>) - Method in class org.springframework.batch.core.job.SimpleJob
Public setter for the steps in this job.
setStreams(ItemStream[]) - Method in class org.springframework.batch.core.step.factory.SimpleStepFactoryBean
The streams to inject into the Step.
setStreams(ItemStream[]) - Method in class org.springframework.batch.core.step.tasklet.TaskletStep
Register each of the streams for callbacks at the appropriate time in the step.
setStreams(ItemStream[]) - Method in class org.springframework.batch.item.support.CompositeItemStream
Public setter for the listeners.
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.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.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.
setSubjectsToFail(List<String>) - Method in class org.springframework.batch.sample.domain.mail.internal.TestMailSender
 
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
 
setTable(String) - Method in class org.springframework.batch.sample.common.ColumnRangePartitioner
The name of the SQL table the data are in.
setTablePrefix(String) - Method in class org.springframework.batch.core.explore.support.JobExplorerFactoryBean
Sets the table prefix for all the batch meta-data tables.
setTablePrefix(String) - Method in class org.springframework.batch.core.repository.dao.AbstractJdbcBatchMetadataDao
Public setter for the table prefix property.
setTablePrefix(String) - Method in class org.springframework.batch.core.repository.support.JobRepositoryFactoryBean
Sets the table prefix for all the batch meta-data tables.
setTargetMethod(String) - Method in class org.springframework.batch.item.adapter.AbstractMethodInvokingDelegator
 
setTargetObject(Object) - Method in class org.springframework.batch.item.adapter.AbstractMethodInvokingDelegator
 
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) - Method in class org.springframework.batch.item.data.Neo4jItemReader
The object type to be returned from each call to AbstractItemCountingItemStreamItemReader.read()
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.job.flow.support.state.SplitState
Public setter for the taskExecutor.
setTaskExecutor(TaskExecutor) - Method in class org.springframework.batch.core.launch.support.SimpleJobLauncher
Set the TaskExecutor.
setTaskExecutor(TaskExecutor) - Method in class org.springframework.batch.core.partition.support.TaskExecutorPartitionHandler
Setter for the TaskExecutor that is used to farm out step executions to multiple threads.
setTaskExecutor(TaskExecutor) - Method in class org.springframework.batch.core.step.factory.SimpleStepFactoryBean
Public setter for the TaskExecutor.
setTaskExecutor(TaskExecutor) - Method in class org.springframework.batch.core.step.tasklet.SystemCommandTasklet
Sets the task executor that will be used to execute the system command NB! Avoid using a synchronous task executor
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.step.tasklet.TaskletStep
Public setter for the Tasklet.
setTeam(String) - Method in class org.springframework.batch.sample.domain.football.Game
 
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.
setTemplate(Neo4jOperations) - Method in class org.springframework.batch.item.data.Neo4jItemReader
Used to perform operations against the Neo4J database.
setTemplate(Neo4jOperations) - Method in class org.springframework.batch.item.data.Neo4jItemWriter
Set the Neo4jOperations to be used to save items
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.
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(int) - Method in class org.springframework.batch.core.step.factory.SimpleStepFactoryBean
Public setter for the throttle limit.
setThrottleLimit(int) - Method in class org.springframework.batch.repeat.support.TaskExecutorRepeatTemplate
Public setter for the throttle limit.
setThrowExceptionOnRecordNumber(int) - Method in class org.springframework.batch.sample.support.ExceptionThrowingItemReaderProxy
 
setTimeout(long) - Method in class org.springframework.batch.core.step.tasklet.SystemCommandTasklet
Timeout in milliseconds.
setTitle(String) - Method in class org.springframework.batch.sample.domain.person.Person
 
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
 
setTotalItems(int) - Method in class org.springframework.batch.sample.domain.order.Order
 
setTotalLines(int) - Method in class org.springframework.batch.sample.domain.order.Order
 
setTotalPrice(BigDecimal) - Method in class org.springframework.batch.sample.domain.order.LineItem
 
setTotalPrice(BigDecimal) - Method in class org.springframework.batch.sample.domain.order.Order
 
setTotalTd(int) - Method in class org.springframework.batch.sample.domain.football.Game
 
setTotalTd(int) - Method in class org.springframework.batch.sample.domain.football.PlayerSummary
 
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.file.FlatFileItemWriter
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.repository.support.AbstractJobRepositoryFactoryBean
Public setter for the PlatformTransactionManager.
setTransactionManager(PlatformTransactionManager) - Method in class org.springframework.batch.core.step.builder.StepBuilderHelper.CommonStepProperties
 
setTransactionManager(PlatformTransactionManager) - Method in class org.springframework.batch.core.step.factory.SimpleStepFactoryBean
Public setter for the PlatformTransactionManager.
setTransactionManager(PlatformTransactionManager) - Method in class org.springframework.batch.core.step.tasklet.TaskletStep
Public setter for the PlatformTransactionManager.
setTransactionTimeout(int) - Method in class org.springframework.batch.core.step.factory.SimpleStepFactoryBean
The timeout for an individual transaction in the step.
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.
setUseParent(boolean) - Method in class org.springframework.batch.repeat.exception.RethrowOnThresholdExceptionHandler
Flag to indicate the 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 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.
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.
setValidationFailure(int) - Method in class org.springframework.batch.sample.domain.trade.internal.TradeProcessor
Public setter for the the index on which failure should occur.
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(PreparedStatement) - Method in class org.springframework.batch.core.resource.ListPreparedStatementSetter
 
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(CustomerCredit, PreparedStatement) - Method in class org.springframework.batch.sample.domain.trade.internal.CustomerCreditUpdatePreparedStatementSetter
 
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.
setVersion(long) - Method in class org.springframework.batch.sample.domain.trade.Trade
 
setVip(boolean) - Method in class org.springframework.batch.sample.domain.order.Customer
 
setWeek(int) - Method in class org.springframework.batch.sample.domain.football.Game
 
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.Neo4jItemReader
An optional where fragement 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
 
setYear(int) - Method in class org.springframework.batch.sample.domain.football.Game
 
setYear(int) - Method in class org.springframework.batch.sample.domain.football.PlayerSummary
 
setZipCode(String) - Method in class org.springframework.batch.sample.domain.order.Address
 
Shipper - Class in org.springframework.batch.sample.domain.order.internal.xml
An XML shipper.
Shipper() - Constructor for class org.springframework.batch.sample.domain.order.internal.xml.Shipper
 
SHIPPER_ID_COLUMN - Static variable in class org.springframework.batch.sample.domain.order.internal.mapper.ShippingFieldSetMapper
 
SHIPPING_PRICE_COLUMN - Static variable in class org.springframework.batch.sample.domain.order.internal.mapper.OrderItemFieldSetMapper
 
SHIPPING_TYPE_ID_COLUMN - Static variable in class org.springframework.batch.sample.domain.order.internal.mapper.ShippingFieldSetMapper
 
ShippingFieldSetMapper - Class in org.springframework.batch.sample.domain.order.internal.mapper
 
ShippingFieldSetMapper() - Constructor for class org.springframework.batch.sample.domain.order.internal.mapper.ShippingFieldSetMapper
 
ShippingInfo - Class in org.springframework.batch.sample.domain.order
 
ShippingInfo() - Constructor for class org.springframework.batch.sample.domain.order.ShippingInfo
 
shouldClose(Connection) - Method in class org.springframework.batch.item.database.ExtendedConnectionDataSourceProxy
 
shouldSkip(Throwable, int) - Method in class org.springframework.batch.core.step.skip.AlwaysSkipItemSkipPolicy
 
shouldSkip(Throwable, int) - Method in class org.springframework.batch.core.step.skip.CompositeSkipPolicy
 
shouldSkip(Throwable, int) - Method in class org.springframework.batch.core.step.skip.ExceptionClassifierSkipPolicy
Consult the classifier and find a delegate policy, and then use that to determine the outcome.
shouldSkip(Throwable, int) - Method in class org.springframework.batch.core.step.skip.LimitCheckingItemSkipPolicy
Given the provided exception and skip count, determine whether or not processing should continue for the given exception.
shouldSkip(Throwable, int) - Method in class org.springframework.batch.core.step.skip.NeverSkipItemSkipPolicy
 
shouldSkip(Throwable, int) - Method in interface org.springframework.batch.core.step.skip.SkipPolicy
Returns true or false, indicating whether or not processing should continue with the given throwable.
SimpleBatchConfiguration - Class in org.springframework.batch.core.configuration.annotation
Base Configuration class providing common structure for enabling and using Spring Batch.
SimpleBatchConfiguration() - Constructor for class org.springframework.batch.core.configuration.annotation.SimpleBatchConfiguration
 
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
 
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
 
SimpleCompletionPolicy.SimpleTerminationContext(RepeatContext) - Constructor for class org.springframework.batch.repeat.policy.SimpleCompletionPolicy.SimpleTerminationContext
 
SimpleFlow - Class in org.springframework.batch.core.job.flow.support
A Flow that branches conditionally depending on the exit status of the last State.
SimpleFlow(String) - Constructor for class org.springframework.batch.core.job.flow.support.SimpleFlow
Create a flow with the given name.
SimpleFlowFactoryBean - Class in org.springframework.batch.core.configuration.xml
Convenience factory for SimpleFlow instances for use in XML namespace.
SimpleFlowFactoryBean() - Constructor for class org.springframework.batch.core.configuration.xml.SimpleFlowFactoryBean
 
SimpleJob - Class in org.springframework.batch.core.job
Simple implementation of Job interface providing the ability to run a JobExecution.
SimpleJob() - Constructor for class org.springframework.batch.core.job.SimpleJob
Default constructor for job with null name
SimpleJob(String) - Constructor for class org.springframework.batch.core.job.SimpleJob
 
SimpleJobBuilder - Class in org.springframework.batch.core.job.builder
 
SimpleJobBuilder(JobBuilderHelper<?>) - Constructor for class org.springframework.batch.core.job.builder.SimpleJobBuilder
Create a new builder initialized with any properties in the parent.
SimpleJobExplorer - Class in org.springframework.batch.core.explore.support
Implementation of JobExplorer using the injected DAOs.
SimpleJobExplorer(JobInstanceDao, JobExecutionDao, StepExecutionDao, ExecutionContextDao) - Constructor for class org.springframework.batch.core.explore.support.SimpleJobExplorer
 
SimpleJobLauncher - Class in org.springframework.batch.core.launch.support
Simple implementation of the JobLauncher interface.
SimpleJobLauncher() - Constructor for class org.springframework.batch.core.launch.support.SimpleJobLauncher
 
SimpleJobOperator - Class in org.springframework.batch.core.launch.support
Simple implementation of the JobOperator interface.
SimpleJobOperator() - Constructor for class org.springframework.batch.core.launch.support.SimpleJobOperator
 
SimpleJobRepository - Class in org.springframework.batch.core.repository.support
Implementation of JobRepository that stores JobInstances, JobExecutions, and StepExecutions using the injected DAOs.
SimpleJobRepository(JobInstanceDao, JobExecutionDao, StepExecutionDao, ExecutionContextDao) - Constructor for class org.springframework.batch.core.repository.support.SimpleJobRepository
 
SimpleJvmExitCodeMapper - Class in org.springframework.batch.core.launch.support
An implementation of ExitCodeMapper that can be configured through a map from batch exit codes (String) to integer results.
SimpleJvmExitCodeMapper() - Constructor for class org.springframework.batch.core.launch.support.SimpleJvmExitCodeMapper
 
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
 
SimpleMessageApplicationEvent - Class in org.springframework.batch.sample.jmx
 
SimpleMessageApplicationEvent(Object, String) - Constructor for class org.springframework.batch.sample.jmx.SimpleMessageApplicationEvent
 
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
 
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
 
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
 
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.
SkipException - Exception in org.springframework.batch.core.step.skip
Base exception indicating that the skip has failed or caused a failure.
SkipException(String, Throwable) - Constructor for exception org.springframework.batch.core.step.skip.SkipException
 
SkipException(String) - Constructor for exception org.springframework.batch.core.step.skip.SkipException
 
skipLimit(int) - Method in class org.springframework.batch.core.step.builder.FaultTolerantStepBuilder
Sets the maximium number of failed items to skip before the step fails.
SkipLimitExceededException - Exception in org.springframework.batch.core.step.skip
Exception indicating that the skip limit for a particular has been exceeded.
SkipLimitExceededException(int, Throwable) - Constructor for exception org.springframework.batch.core.step.skip.SkipLimitExceededException
 
SkipListener<T,S> - Interface in org.springframework.batch.core
Interface for listener to skipped items.
SkipListenerFailedException - Exception in org.springframework.batch.core.step.skip
Special exception to indicate a failure in a skip listener.
SkipListenerFailedException(String, RuntimeException, Throwable) - Constructor for exception org.springframework.batch.core.step.skip.SkipListenerFailedException
 
SkipListenerSupport<T,S> - Class in org.springframework.batch.core.listener
Basic no-op implementations of all SkipListener implementations.
SkipListenerSupport() - Constructor for class org.springframework.batch.core.listener.SkipListenerSupport
 
SkipOverflowException - Exception in org.springframework.batch.core.step.item
 
SkipOverflowException(String) - Constructor for exception org.springframework.batch.core.step.item.SkipOverflowException
 
skipPolicy(SkipPolicy) - Method in class org.springframework.batch.core.step.builder.FaultTolerantStepBuilder
Provide an explicit policy for managing skips.
SkipPolicy - Interface in org.springframework.batch.core.step.skip
Policy for determining whether or not some processing should be skipped.
SkipPolicyFailedException - Exception in org.springframework.batch.core.step.skip
Special exception to indicate a failure in a skip policy.
SkipPolicyFailedException(String, RuntimeException, Throwable) - Constructor for exception org.springframework.batch.core.step.skip.SkipPolicyFailedException
 
SkipWrapper<T> - Class in org.springframework.batch.core.step.item
Wrapper for an item and its exception if it failed processing.
SkipWrapper(T) - Constructor for class org.springframework.batch.core.step.item.SkipWrapper
 
SkipWrapper(Throwable) - Constructor for class org.springframework.batch.core.step.item.SkipWrapper
 
SkipWrapper(T, Throwable) - Constructor for class org.springframework.batch.core.step.item.SkipWrapper
 
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 interface org.springframework.batch.core.partition.StepExecutionSplitter
Partition the provided StepExecution into a set of parallel executable instances with the same parent JobExecution.
split(StepExecution, int) - Method in class org.springframework.batch.core.partition.support.SimpleStepExecutionSplitter
 
SplitParser - Class in org.springframework.batch.core.configuration.xml
Internal parser for the <split/> elements inside a job.
SplitParser(String) - Constructor for class org.springframework.batch.core.configuration.xml.SplitParser
Construct a InlineFlowParser using the provided job repository ref.
SplitState - Class in org.springframework.batch.core.job.flow.support.state
A State implementation that splits a Flow into multiple parallel subflows.
SplitState(Collection<Flow>, String) - Constructor for class org.springframework.batch.core.job.flow.support.state.SplitState
 
splitter(StepExecutionSplitter) - Method in class org.springframework.batch.core.step.builder.PartitionStepBuilder
Provide an explicit StepExecutionSplitter instead of having one build from the PartitionStepBuilder.partitioner(String, Partitioner).
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
 
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
 
StagingItemListener - Class in org.springframework.batch.sample.common
Thread-safe database ItemReader implementing the process indicator pattern.
StagingItemListener() - Constructor for class org.springframework.batch.sample.common.StagingItemListener
 
StagingItemProcessor<T> - Class in org.springframework.batch.sample.common
Marks the input row as 'processed'.
StagingItemProcessor() - Constructor for class org.springframework.batch.sample.common.StagingItemProcessor
 
StagingItemReader<T> - Class in org.springframework.batch.sample.common
Thread-safe database ItemReader implementing the process indicator pattern.
StagingItemReader() - Constructor for class org.springframework.batch.sample.common.StagingItemReader
 
StagingItemWriter<T> - Class in org.springframework.batch.sample.common
Database ItemWriter implementing the process indicator pattern.
StagingItemWriter() - Constructor for class org.springframework.batch.sample.common.StagingItemWriter
 
StandaloneStepParser - Class in org.springframework.batch.core.configuration.xml
Internal parser for the <step/> elements for a job.
StandaloneStepParser() - Constructor for class org.springframework.batch.core.configuration.xml.StandaloneStepParser
 
start() - Method in class org.springframework.batch.core.configuration.support.AutomaticJobRegistrar
Take all the contexts from the factories provided and pass them to the JobLoader.
start(Step) - Method in class org.springframework.batch.core.job.builder.FlowBuilder
Start a flow.
start(JobExecutionDecider) - Method in class org.springframework.batch.core.job.builder.FlowBuilder
If a flow should start with a decision use this as the first state.
start(Flow) - Method in class org.springframework.batch.core.job.builder.FlowBuilder
If a flow should start with a subflow use this as the first state.
start(Flow) - Method in class org.springframework.batch.core.job.builder.FlowJobBuilder
Start a job with this flow, but expect to transition from there to other flows or steps.
start(Step) - Method in class org.springframework.batch.core.job.builder.FlowJobBuilder
Start a job with this step, but expect to transition from there to other flows or steps.
start(Step) - Method in class org.springframework.batch.core.job.builder.JobBuilder
Create a new job builder that will execute a step or sequence of steps.
start(Flow) - Method in class org.springframework.batch.core.job.builder.JobBuilder
Create a new job builder that will execute a flow.
start(Step) - Method in class org.springframework.batch.core.job.builder.SimpleJobBuilder
Start the job with this step.
start(JobExecutionDecider) - Method in class org.springframework.batch.core.job.builder.SimpleJobBuilder
Start with this decider.
start(FlowExecutor) - Method in interface org.springframework.batch.core.job.flow.Flow
 
start(FlowExecutor) - Method in class org.springframework.batch.core.job.flow.support.SimpleFlow
 
start(String, String) - Method in interface org.springframework.batch.core.launch.JobOperator
Start a new instance of a job with the parameters specified.
start(String, String) - Method in class org.springframework.batch.core.launch.support.SimpleJobOperator
 
start(RepeatContext) - Method in class org.springframework.batch.core.resource.StepExecutionSimpleCompletionPolicy
 
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
 
StartLimitExceededException - Exception in org.springframework.batch.core
Indicates the step's start limit has been exceeded.
StartLimitExceededException(String) - Constructor for exception org.springframework.batch.core.StartLimitExceededException
 
startNextInstance(String) - Method in interface org.springframework.batch.core.launch.JobOperator
Launch the next in a sequence of JobInstance determined by the JobParametersIncrementer attached to the specified job.
startNextInstance(String) - Method in class org.springframework.batch.core.launch.support.SimpleJobOperator
 
State - Interface in org.springframework.batch.core.job.flow
 
STATE_COLUMN - Static variable in class org.springframework.batch.sample.domain.order.internal.mapper.AddressFieldSetMapper
 
StateTransition - Class in org.springframework.batch.core.job.flow.support
Value object representing a potential transition from one State to another.
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
 
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
 
StaxUtils - Class in org.springframework.batch.item.xml
This class provides a little bit of indirection to avoid ugly conditional object creation.
StaxUtils() - Constructor for class org.springframework.batch.item.xml.StaxUtils
 
StaxWriterCallback - Interface in org.springframework.batch.item.xml
Callback interface for writing to an XML file - useful e.g.
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() - Method in class org.springframework.batch.sample.config.RetrySampleConfiguration
 
StepBuilder - Class in org.springframework.batch.core.step.builder
Convenient entry point for building all kinds of steps.
StepBuilder(String) - Constructor for class org.springframework.batch.core.step.builder.StepBuilder
Initialize a step builder for a step with the given name.
StepBuilderException - Exception in org.springframework.batch.core.step.builder
Utility exception thrown by builders when they encounter unexpected checked exceptions.
StepBuilderException(Exception) - Constructor for exception org.springframework.batch.core.step.builder.StepBuilderException
 
StepBuilderFactory - Class in org.springframework.batch.core.configuration.annotation
Convenient factory for a StepBuilder which sets the JobRepository and PlatformTransactionManager automatically.
StepBuilderFactory(JobRepository, PlatformTransactionManager) - Constructor for class org.springframework.batch.core.configuration.annotation.StepBuilderFactory
 
StepBuilderHelper<B extends StepBuilderHelper<B>> - Class in org.springframework.batch.core.step.builder
A base class and utility for other step builders providing access to common properties like job repository and transaction manager.
StepBuilderHelper(String) - Constructor for class org.springframework.batch.core.step.builder.StepBuilderHelper
 
StepBuilderHelper(StepBuilderHelper<?>) - Constructor for class org.springframework.batch.core.step.builder.StepBuilderHelper
Create a new builder initialized with any properties in the parent.
StepBuilderHelper.CommonStepProperties - Class in org.springframework.batch.core.step.builder
 
StepBuilderHelper.CommonStepProperties() - Constructor for class org.springframework.batch.core.step.builder.StepBuilderHelper.CommonStepProperties
 
StepBuilderHelper.CommonStepProperties(StepBuilderHelper.CommonStepProperties) - Constructor for class org.springframework.batch.core.step.builder.StepBuilderHelper.CommonStepProperties
 
stepBuilders() - Method in class org.springframework.batch.core.configuration.annotation.AbstractBatchConfiguration
 
StepContext - Class in org.springframework.batch.core.scope.context
A context object that can be used to interrogate the current StepExecution and some of its associated properties using expressions based on bean paths.
StepContext(StepExecution) - Constructor for class org.springframework.batch.core.scope.context.StepContext
Create a new instance of StepContext for this StepExecution.
StepContextRepeatCallback - Class in org.springframework.batch.core.scope.context
Convenient base class for clients who need to do something in a repeat callback inside a Step.
StepContextRepeatCallback(StepExecution) - Constructor for class org.springframework.batch.core.scope.context.StepContextRepeatCallback
 
StepContribution - Class in org.springframework.batch.core
Represents a contribution to a StepExecution, buffering changes until they can be applied at a chunk boundary.
StepContribution(StepExecution) - Constructor for class org.springframework.batch.core.StepContribution
 
StepExecution - Class in org.springframework.batch.core
Batch domain object representation the execution of a step.
StepExecution(String, JobExecution, Long) - Constructor for class org.springframework.batch.core.StepExecution
Constructor with mandatory properties.
StepExecution(String, JobExecution) - Constructor for class org.springframework.batch.core.StepExecution
Constructor that substitutes in null for the execution id
StepExecutionAggregator - Interface in org.springframework.batch.core.partition.support
Strategy for a aggregating step executions, usually when they are the result of partitioned or remote execution.
StepExecutionApplicationEventAdvice - Class in org.springframework.batch.sample.jmx
Wraps calls for methods taking StepExecution as an argument and publishes notifications in the form of ApplicationEvent.
StepExecutionApplicationEventAdvice() - Constructor for class org.springframework.batch.sample.jmx.StepExecutionApplicationEventAdvice
 
StepExecutionDao - Interface in org.springframework.batch.core.repository.dao
 
StepExecutionListener - Interface in org.springframework.batch.core
Listener interface for the lifecycle of a Step.
stepExecutionListenerMetaData() - Static method in enum org.springframework.batch.core.listener.StepListenerMetaData
 
StepExecutionListenerSupport - Class in org.springframework.batch.core.listener
 
StepExecutionListenerSupport() - Constructor for class org.springframework.batch.core.listener.StepExecutionListenerSupport
 
StepExecutionSimpleCompletionPolicy - Class in org.springframework.batch.core.resource
A CompletionPolicy that picks up a commit interval from JobParameters by listening to the start of a step.
StepExecutionSimpleCompletionPolicy() - Constructor for class org.springframework.batch.core.resource.StepExecutionSimpleCompletionPolicy
 
StepExecutionSplitter - Interface in org.springframework.batch.core.partition
Strategy interface for generating input contexts for a partitioned step execution independent from the fabric they are going to run on.
StepHandler - Interface in org.springframework.batch.core.job
Strategy interface for handling a Step on behalf of a Job.
StepHolder - Interface in org.springframework.batch.core.step
Interface for holders of a Step as a convenience for callers who need access to the underlying instance.
StepInterruptionPolicy - Interface in org.springframework.batch.core.step
Strategy interface for an interruption policy.
StepListener - Interface in org.springframework.batch.core
Marker interface that acts as a parent to all step domain listeners, such as: StepExecutionListener, ChunkListener, ItemReadListener and ItemWriteListener
StepListenerFactoryBean - Class in org.springframework.batch.core.listener
This AbstractListenerFactoryBean implementation is used to create a StepListener.
StepListenerFactoryBean() - Constructor for class org.springframework.batch.core.listener.StepListenerFactoryBean
 
StepListenerFailedException - Exception in org.springframework.batch.core.listener
Exception to indicate a problem in a step listener.
StepListenerFailedException(String, Throwable) - Constructor for exception org.springframework.batch.core.listener.StepListenerFailedException
 
StepListenerMetaData - Enum in org.springframework.batch.core.listener
Enumeration for StepListener meta data, which ties together the names of methods, their interfaces, annotation, and expected arguments.
StepListenerParser - Class in org.springframework.batch.core.configuration.xml
Parser for a step listener element.
StepListenerParser() - Constructor for class org.springframework.batch.core.configuration.xml.StepListenerParser
 
StepListenerParser(ListenerMetaData[]) - Constructor for class org.springframework.batch.core.configuration.xml.StepListenerParser
 
StepListenerSupport<T,S> - Class in org.springframework.batch.core.listener
Basic no-op implementations of all StepListener interfaces.
StepListenerSupport() - Constructor for class org.springframework.batch.core.listener.StepListenerSupport
 
StepLocator - Interface in org.springframework.batch.core.step
Interface for locating a Step instance by name.
stepLocator - Variable in class org.springframework.batch.core.step.StepLocatorStepFactoryBean
 
StepLocatorStepFactoryBean - Class in org.springframework.batch.core.step
Convenience factory for Step instances given a StepLocator.
StepLocatorStepFactoryBean() - Constructor for class org.springframework.batch.core.step.StepLocatorStepFactoryBean
 
stepName - Variable in class org.springframework.batch.core.step.StepLocatorStepFactoryBean
 
stepOperations(RepeatOperations) - Method in class org.springframework.batch.core.step.builder.AbstractTaskletStepBuilder
Sets the repeat template used for iterating the tasklet execution.
StepRegistry - Interface in org.springframework.batch.core.configuration
Registry keeping track of all the Step defined in a Job.
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() - Method in class org.springframework.batch.core.job.builder.FlowBuilder.TransitionBuilder
Signal the successful end of the flow.
stop() - Method in class org.springframework.batch.core.JobExecution
Signal the JobExecution to stop.
stop(long) - Method in interface org.springframework.batch.core.launch.JobOperator
Send a stop signal to the JobExecution with the supplied id.
stop() - Static method in class org.springframework.batch.core.launch.support.JobRegistryBackgroundJobRunner
If embedded in a JVM, call this method to terminate the main method.
stop(long) - Method in class org.springframework.batch.core.launch.support.SimpleJobOperator
 
stopAndRestart(Flow) - Method in class org.springframework.batch.core.job.builder.FlowBuilder.TransitionBuilder
Stop the flow and provide a flow to start with if the flow is restarted.
stopAndRestart(JobExecutionDecider) - Method in class org.springframework.batch.core.job.builder.FlowBuilder.TransitionBuilder
Stop the flow and provide a decider to start with if the flow is restarted.
stopAndRestart(Step) - Method in class org.springframework.batch.core.job.builder.FlowBuilder.TransitionBuilder
Stop the flow and provide a step to start with if the flow is restarted.
stopCloseSuppression(Connection) - Method in class org.springframework.batch.item.database.ExtendedConnectionDataSourceProxy
 
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.
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
 
stream(ItemStream) - Method in class org.springframework.batch.core.step.builder.AbstractTaskletStepBuilder
Register a stream for callbacks that manage restart data.
stream(ItemStream) - Method in class org.springframework.batch.core.step.builder.FaultTolerantStepBuilder
 
STRING_TYPE - Static variable in class org.springframework.batch.core.converter.DefaultJobParametersConverter
 
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
 
SummaryFooterCallback - Class in org.springframework.batch.sample.support
Writes summary info in the footer of a file.
SummaryFooterCallback() - Constructor for class org.springframework.batch.sample.support.SummaryFooterCallback
 
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
 
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
 
synchronizeStatus(JobExecution) - Method in class org.springframework.batch.core.repository.dao.JdbcJobExecutionDao
 
synchronizeStatus(JobExecution) - Method in interface org.springframework.batch.core.repository.dao.JobExecutionDao
Because it may be possible that the status of a JobExecution is updated while running, the following method will synchronize only the status and version fields.
synchronizeStatus(JobExecution) - Method in class org.springframework.batch.core.repository.dao.MapJobExecutionDao
 
SystemCommandException - Exception in org.springframework.batch.core.step.tasklet
Exception indicating failed execution of system command.
SystemCommandException(String) - Constructor for exception org.springframework.batch.core.step.tasklet.SystemCommandException
 
SystemCommandException(String, Throwable) - Constructor for exception org.springframework.batch.core.step.tasklet.SystemCommandException
 
SystemCommandTasklet - Class in org.springframework.batch.core.step.tasklet
Tasklet that executes a system command.
SystemCommandTasklet() - Constructor for class org.springframework.batch.core.step.tasklet.SystemCommandTasklet
 
SystemExiter - Interface in org.springframework.batch.core.launch.support
Interface for exiting the JVM.
SystemProcessExitCodeMapper - Interface in org.springframework.batch.core.step.tasklet
Maps the exit code of a system process to ExitStatus value returned by a system command.
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

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
 
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.
taskletListenerMetaData() - Static method in enum org.springframework.batch.core.listener.StepListenerMetaData
 
TaskletParser - Class in org.springframework.batch.core.configuration.xml
Parse a tasklet element for a step.
TaskletParser() - Constructor for class org.springframework.batch.core.configuration.xml.TaskletParser
 
TaskletStep - Class in org.springframework.batch.core.step.tasklet
Simple implementation of executing the step as a call to a Tasklet, possibly repeated, and each call surrounded by a transaction.
TaskletStep() - Constructor for class org.springframework.batch.core.step.tasklet.TaskletStep
Default constructor.
TaskletStep(String) - Constructor for class org.springframework.batch.core.step.tasklet.TaskletStep
 
TaskletStepBuilder - Class in org.springframework.batch.core.step.builder
Builder for tasklet step based on a custom tasklet (not item oriented).
TaskletStepBuilder(StepBuilderHelper<?>) - Constructor for class org.springframework.batch.core.step.builder.TaskletStepBuilder
Create a new builder initialized with any properties in the parent.
testing - Static variable in class org.springframework.batch.core.launch.support.JobRegistryBackgroundJobRunner
 
TestMailErrorHandler - Class in org.springframework.batch.sample.domain.mail.internal
This handler prints out failed messages with their exceptions.
TestMailErrorHandler() - Constructor for class org.springframework.batch.sample.domain.mail.internal.TestMailErrorHandler
 
TestMailSender - Class in org.springframework.batch.sample.domain.mail.internal
 
TestMailSender() - Constructor for class org.springframework.batch.sample.domain.mail.internal.TestMailSender
 
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).
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
 
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
 
TimeoutTerminationPolicy.TimeoutBatchContext(RepeatContext) - Constructor for class org.springframework.batch.repeat.policy.TimeoutTerminationPolicy.TimeoutBatchContext
 
to(Step) - Method in class org.springframework.batch.core.job.builder.FlowBuilder.TransitionBuilder
Specify the next step.
to(Flow) - Method in class org.springframework.batch.core.job.builder.FlowBuilder.TransitionBuilder
Specify the next state as a complete flow.
to(JobExecutionDecider) - Method in class org.springframework.batch.core.job.builder.FlowBuilder.TransitionBuilder
Specify the next state as a decision.
toJobParameters() - Method in class org.springframework.batch.core.JobParametersBuilder
Conversion method that takes the current state of this builder and returns it as a JobruntimeParameters object.
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
 
tokenize(String) - Method in class org.springframework.batch.sample.domain.trade.CompositeCustomerUpdateLineTokenizer
 
TopLevelFlowParser - Class in org.springframework.batch.core.configuration.xml
 
TopLevelFlowParser() - Constructor for class org.springframework.batch.core.configuration.xml.TopLevelFlowParser
 
TopLevelJobListenerParser - Class in org.springframework.batch.core.configuration.xml
Parse <job-listener/> elements in the batch namespace.
TopLevelJobListenerParser() - Constructor for class org.springframework.batch.core.configuration.xml.TopLevelJobListenerParser
 
TopLevelStepListenerParser - Class in org.springframework.batch.core.configuration.xml
Parse <step-listener/> elements in the batch namespace.
TopLevelStepListenerParser() - Constructor for class org.springframework.batch.core.configuration.xml.TopLevelStepListenerParser
 
TopLevelStepParser - Class in org.springframework.batch.core.configuration.xml
Parser for the lt;step/gt; top level element in the Batch namespace.
TopLevelStepParser() - Constructor for class org.springframework.batch.core.configuration.xml.TopLevelStepParser
 
toString() - Method in class example.Person
 
toString() - Method in class org.springframework.batch.core.configuration.support.AbstractApplicationContextFactory
 
toString() - Method in class org.springframework.batch.core.configuration.support.GroupAwareJob
 
toString() - Method in class org.springframework.batch.core.configuration.support.OsgiBundleXmlApplicationContextFactory
 
toString() - Method in class org.springframework.batch.core.Entity
 
toString() - Method in class org.springframework.batch.core.ExitStatus
 
toString() - Method in class org.springframework.batch.core.job.AbstractJob
 
toString() - Method in class org.springframework.batch.core.job.flow.FlowExecution
 
toString() - Method in class org.springframework.batch.core.job.flow.FlowExecutionStatus
 
toString() - Method in class org.springframework.batch.core.job.flow.support.state.AbstractState
 
toString() - Method in class org.springframework.batch.core.job.flow.support.state.EndState
 
toString() - Method in class org.springframework.batch.core.job.flow.support.StateTransition
 
toString() - Method in class org.springframework.batch.core.JobExecution
 
toString() - Method in class org.springframework.batch.core.JobInstance
 
toString() - Method in class org.springframework.batch.core.JobParameter
 
toString() - Method in class org.springframework.batch.core.JobParameters
 
toString() - Method in class org.springframework.batch.core.resource.StepExecutionSimpleCompletionPolicy
Delegates to the wrapped CompletionPolicy if set, otherwise returns the value of StepExecutionSimpleCompletionPolicy.setKeyName(String).
toString() - Method in class org.springframework.batch.core.scope.context.ChunkContext
 
toString() - Method in class org.springframework.batch.core.scope.context.StepContext
 
toString() - Method in class org.springframework.batch.core.step.AbstractStep
 
toString() - Method in class org.springframework.batch.core.step.item.Chunk.ChunkIterator
 
toString() - Method in class org.springframework.batch.core.step.item.Chunk
 
toString() - Method in class org.springframework.batch.core.step.item.SkipWrapper
 
toString() - Method in class org.springframework.batch.core.StepContribution
 
toString() - Method in class org.springframework.batch.core.StepExecution
 
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
 
toString() - Method in class org.springframework.batch.sample.domain.football.Game
 
toString() - Method in class org.springframework.batch.sample.domain.football.Player
 
toString() - Method in class org.springframework.batch.sample.domain.football.PlayerSummary
 
toString() - Method in class org.springframework.batch.sample.domain.order.Address
 
toString() - Method in class org.springframework.batch.sample.domain.order.BillingInfo
 
toString() - Method in class org.springframework.batch.sample.domain.order.Customer
 
toString() - Method in class org.springframework.batch.sample.domain.order.internal.xml.Customer
 
toString() - Method in class org.springframework.batch.sample.domain.order.internal.xml.Order
 
toString() - Method in class org.springframework.batch.sample.domain.order.LineItem
 
toString() - Method in class org.springframework.batch.sample.domain.order.Order
 
toString() - Method in class org.springframework.batch.sample.domain.person.Child
 
toString() - Method in class org.springframework.batch.sample.domain.person.Person
 
toString() - Method in class org.springframework.batch.sample.domain.trade.CustomerCredit
 
toString() - Method in class org.springframework.batch.sample.domain.trade.CustomerDebit
 
toString() - Method in class org.springframework.batch.sample.domain.trade.CustomerUpdate
 
toString() - Method in class org.springframework.batch.sample.domain.trade.Trade
 
toString() - Method in class org.springframework.batch.sample.jmx.SimpleMessageApplicationEvent
 
TOTAL_AMOUNT_KEY - Static variable in class org.springframework.batch.sample.domain.trade.internal.TradeWriter
 
TOTAL_PRICE_COLUMN - Static variable in class org.springframework.batch.sample.domain.order.internal.mapper.OrderItemFieldSetMapper
 
TotalOrderItemsFunction - Class in org.springframework.batch.sample.domain.order.internal.valang
Validates total items count in Order.
TotalOrderItemsFunction(Function[], int, int) - Constructor for class org.springframework.batch.sample.domain.order.internal.valang.TotalOrderItemsFunction
 
Trade - Class in org.springframework.batch.sample.domain.trade
 
Trade() - Constructor for class org.springframework.batch.sample.domain.trade.Trade
 
Trade(String, long, BigDecimal, String) - Constructor for class org.springframework.batch.sample.domain.trade.Trade
 
Trade(long) - Constructor for class org.springframework.batch.sample.domain.trade.Trade
 
TradeDao - Interface in org.springframework.batch.sample.domain.trade
Interface for writing a Trade object to an arbitrary output.
TradeFieldSetMapper - Class in org.springframework.batch.sample.domain.trade.internal
 
TradeFieldSetMapper() - Constructor for class org.springframework.batch.sample.domain.trade.internal.TradeFieldSetMapper
 
TradeProcessor - Class in org.springframework.batch.sample.domain.trade.internal
Processes the Trade - throwing validation errors if necessary.
TradeProcessor() - Constructor for class org.springframework.batch.sample.domain.trade.internal.TradeProcessor
 
TradeRowMapper - Class in org.springframework.batch.sample.domain.trade.internal
 
TradeRowMapper() - Constructor for class org.springframework.batch.sample.domain.trade.internal.TradeRowMapper
 
TradeWriter - Class in org.springframework.batch.sample.domain.trade.internal
Delegates the actual writing to custom DAO delegate.
TradeWriter() - Constructor for class org.springframework.batch.sample.domain.trade.internal.TradeWriter
 
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
 
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
 
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
 
TRUE_SYMBOL - Static variable in class org.springframework.batch.sample.domain.order.internal.mapper.CustomerFieldSetMapper
 

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.
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.
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
 
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.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.file.FlatFileItemWriter
 
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.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.xml.StaxEventItemWriter
Get the restart data.
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.
update(ExecutionContext) - Method in class org.springframework.batch.sample.domain.trade.internal.TradeWriter
 
updateCustomer(String, BigDecimal) - Method in interface org.springframework.batch.sample.domain.trade.CustomerDao
 
updateCustomer(String, BigDecimal) - Method in class org.springframework.batch.sample.domain.trade.internal.JdbcCustomerDao
 
updateExecutionContext(JobExecution) - Method in interface org.springframework.batch.core.repository.dao.ExecutionContextDao
Persist the updates of execution context associated with the given jobExecution.
updateExecutionContext(StepExecution) - Method in interface org.springframework.batch.core.repository.dao.ExecutionContextDao
Persist the updates of execution context associated with the given stepExecution.
updateExecutionContext(JobExecution) - Method in class org.springframework.batch.core.repository.dao.JdbcExecutionContextDao
 
updateExecutionContext(StepExecution) - Method in class org.springframework.batch.core.repository.dao.JdbcExecutionContextDao
 
updateExecutionContext(StepExecution) - Method in class org.springframework.batch.core.repository.dao.MapExecutionContextDao
 
updateExecutionContext(JobExecution) - Method in class org.springframework.batch.core.repository.dao.MapExecutionContextDao
 
updateExecutionContext(StepExecution) - Method in interface org.springframework.batch.core.repository.JobRepository
Persist the updated ExecutionContexts of the given StepExecution.
updateExecutionContext(JobExecution) - Method in interface org.springframework.batch.core.repository.JobRepository
Persist the updated ExecutionContext of the given JobExecution.
updateExecutionContext(StepExecution) - Method in class org.springframework.batch.core.repository.support.SimpleJobRepository
 
updateExecutionContext(JobExecution) - Method in class org.springframework.batch.core.repository.support.SimpleJobRepository
 
updateJobExecution(JobExecution) - Method in class org.springframework.batch.core.repository.dao.JdbcJobExecutionDao
Update given JobExecution using a SQL UPDATE statement.
updateJobExecution(JobExecution) - Method in interface org.springframework.batch.core.repository.dao.JobExecutionDao
Update and existing JobExecution.
updateJobExecution(JobExecution) - Method in class org.springframework.batch.core.repository.dao.MapJobExecutionDao
 
updateJobExecutionStatus(FlowExecutionStatus) - Method in interface org.springframework.batch.core.job.flow.FlowExecutor
Handle any status changes that might be needed in the JobExecution.
updateJobExecutionStatus(FlowExecutionStatus) - Method in class org.springframework.batch.core.job.flow.JobFlowExecutor
 
updateStepExecution(StepExecution) - Method in class org.springframework.batch.core.repository.dao.JdbcStepExecutionDao
 
updateStepExecution(StepExecution) - Method in class org.springframework.batch.core.repository.dao.MapStepExecutionDao
 
updateStepExecution(StepExecution) - Method in interface org.springframework.batch.core.repository.dao.StepExecutionDao
Update the given StepExecution Preconditions: Id must not be null.
updateTotalPrice(List<Trade>) - Method in class org.springframework.batch.sample.domain.trade.internal.TradeWriter
 
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
 
User - Class in org.springframework.batch.sample.domain.mail
 
User() - Constructor for class org.springframework.batch.sample.domain.mail.User
 
User(int, String, String) - Constructor for class org.springframework.batch.sample.domain.mail.User
 
UserMailItemProcessor - Class in org.springframework.batch.sample.domain.mail.internal
 
UserMailItemProcessor() - Constructor for class org.springframework.batch.sample.domain.mail.internal.UserMailItemProcessor
 

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.
ValidateDiscountsFunction - Class in org.springframework.batch.sample.domain.order.internal.valang
 
ValidateDiscountsFunction(Function[], int, int) - Constructor for class org.springframework.batch.sample.domain.order.internal.valang.ValidateDiscountsFunction
 
ValidateHandlingPricesFunction - Class in org.springframework.batch.sample.domain.order.internal.valang
 
ValidateHandlingPricesFunction(Function[], int, int) - Constructor for class org.springframework.batch.sample.domain.order.internal.valang.ValidateHandlingPricesFunction
 
ValidateIdsFunction - Class in org.springframework.batch.sample.domain.order.internal.valang
 
ValidateIdsFunction(Function[], int, int) - Constructor for class org.springframework.batch.sample.domain.order.internal.valang.ValidateIdsFunction
 
ValidatePricesFunction - Class in org.springframework.batch.sample.domain.order.internal.valang
 
ValidatePricesFunction(Function[], int, int) - Constructor for class org.springframework.batch.sample.domain.order.internal.valang.ValidatePricesFunction
 
ValidateQuantitiesFunction - Class in org.springframework.batch.sample.domain.order.internal.valang
 
ValidateQuantitiesFunction(Function[], int, int) - Constructor for class org.springframework.batch.sample.domain.order.internal.valang.ValidateQuantitiesFunction
 
ValidateShippingPricesFunction - Class in org.springframework.batch.sample.domain.order.internal.valang
 
ValidateShippingPricesFunction(Function[], int, int) - Constructor for class org.springframework.batch.sample.domain.order.internal.valang.ValidateShippingPricesFunction
 
ValidateTotalPricesFunction - Class in org.springframework.batch.sample.domain.order.internal.valang
 
ValidateTotalPricesFunction(Function[], int, int) - Constructor for class org.springframework.batch.sample.domain.order.internal.valang.ValidateTotalPricesFunction
 
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.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.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
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.sample.domain.trade.CustomerOperation
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.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
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.sample.domain.trade.CustomerOperation
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.
VERSION_COLUMN - Static variable in class org.springframework.batch.sample.domain.trade.internal.TradeRowMapper
 
VIP_COLUMN - Static variable in class org.springframework.batch.sample.domain.order.internal.mapper.CustomerFieldSetMapper
 

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.
WORKING - Static variable in class org.springframework.batch.sample.common.StagingItemWriter
 
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 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.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) - 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.IbatisBatchItemWriter
 
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.FlatFileItemWriter
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.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(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.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 Object>) - Method in class org.springframework.batch.sample.common.InfiniteLoopWriter
 
write(List<? extends T>) - Method in class org.springframework.batch.sample.common.StagingItemWriter
Serialize the item to the staging table, and add a NEW processed flag.
write(List<? extends Game>) - Method in class org.springframework.batch.sample.domain.football.internal.JdbcGameDao
 
write(List<? extends PlayerSummary>) - Method in class org.springframework.batch.sample.domain.football.internal.JdbcPlayerSummaryDao
 
write(List<? extends Player>) - Method in class org.springframework.batch.sample.domain.football.internal.PlayerItemWriter
 
write(Order) - Method in interface org.springframework.batch.sample.domain.order.OrderDao
 
write(List<? extends Person>) - Method in class org.springframework.batch.sample.domain.person.internal.PersonWriter
 
write(CustomerDebit) - Method in interface org.springframework.batch.sample.domain.trade.CustomerDebitDao
 
write(List<? extends CustomerUpdate>) - Method in class org.springframework.batch.sample.domain.trade.CustomerUpdateWriter
 
write(List<? extends CustomerCredit>) - Method in class org.springframework.batch.sample.domain.trade.internal.CustomerCreditItemWriter
 
write(List<? extends CustomerCredit>) - Method in class org.springframework.batch.sample.domain.trade.internal.CustomerCreditUpdateWriter
 
write(List<? extends Trade>) - Method in class org.springframework.batch.sample.domain.trade.internal.CustomerUpdateWriter
 
write(List<? extends CustomerCredit>) - Method in class org.springframework.batch.sample.domain.trade.internal.HibernateAwareCustomerCreditItemWriter
 
write(Object) - Method in class org.springframework.batch.sample.domain.trade.internal.HibernateCreditDao
 
write(CustomerDebit) - Method in class org.springframework.batch.sample.domain.trade.internal.JdbcCustomerDebitDao
 
write(List<? extends Trade>) - Method in class org.springframework.batch.sample.domain.trade.internal.TradeWriter
 
write(List<? extends Object>) - Method in class org.springframework.batch.sample.support.DummyItemWriter
 
write(List<? extends T>) - Method in class org.springframework.batch.sample.support.RetrySampleItemWriter
 
write(char[], int, int) - Method in class org.springframework.batch.support.transaction.TransactionAwareBufferedWriter
 
writeCredit(CustomerCredit) - Method in interface org.springframework.batch.sample.domain.trade.CustomerCreditDao
 
writeCredit(CustomerCredit) - Method in class org.springframework.batch.sample.domain.trade.internal.FlatFileCustomerCreditDao
 
writeCredit(CustomerCredit) - Method in class org.springframework.batch.sample.domain.trade.internal.HibernateCreditDao
 
writeCredit(CustomerCredit) - Method in class org.springframework.batch.sample.domain.trade.internal.IbatisCustomerCreditDao
 
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.
writeFooter(Writer) - Method in class org.springframework.batch.sample.support.SummaryFooterCallback
 
writeHeader(Writer) - Method in interface org.springframework.batch.item.file.FlatFileHeaderCallback
Write contents to a file using the supplied Writer.
writeHeader(Writer) - Method in class org.springframework.batch.sample.support.HeaderCopyCallback
 
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, 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() - Method in class org.springframework.batch.sample.config.RetrySampleConfiguration
 
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.
writeTrade(Trade) - Method in class org.springframework.batch.sample.domain.trade.internal.JdbcTradeDao
 
writeTrade(Trade) - Method in interface org.springframework.batch.sample.domain.trade.TradeDao
 

X

XStreamExecutionContextStringSerializer - Class in org.springframework.batch.core.repository.dao
Implementation that uses XStream and Jettison to provide serialization.
XStreamExecutionContextStringSerializer() - Constructor for class org.springframework.batch.core.repository.dao.XStreamExecutionContextStringSerializer
 

Z

ZERO - Static variable in class org.springframework.batch.repeat.exception.RethrowOnThresholdExceptionHandler
 
ZIP_CODE_COLUMN - Static variable in class org.springframework.batch.sample.domain.order.internal.mapper.AddressFieldSetMapper
 
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 

Copyright © 2014 Pivotal. All rights reserved.