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

A

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
 
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
 
AbstractPagingItemReader<T> - Class in org.springframework.batch.item.database
Abstract ItemReader for to extend when reading database records in a paging fashion.
AbstractPagingItemReader() - Constructor for class org.springframework.batch.item.database.AbstractPagingItemReader
 
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
 
add(StepExecution) - Method in interface org.springframework.batch.core.repository.JobRepository
Save the StepExecution and its ExecutionContext.
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
 
addDate(String, Date) - 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 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
 
addLong(String, Long) - Method in class org.springframework.batch.core.JobParametersBuilder
Add a new Long parameter for the given key.
addParameter(String, JobParameter) - Method in class org.springframework.batch.core.JobParametersBuilder
Add a new JobParameter for the given key.
addStep(Step) - Method in class org.springframework.batch.core.job.SimpleJob
Convenience method for adding a single step to the job.
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 String parameter for the given key.
after(RepeatContext, RepeatStatus) - Method in class org.springframework.batch.repeat.listener.CompositeRepeatListener
 
after(RepeatContext, RepeatStatus) - Method in class org.springframework.batch.repeat.listener.RepeatListenerSupport
 
after(RepeatContext, RepeatStatus) - Method in interface org.springframework.batch.repeat.RepeatListener
Called by the framework after each item has been processed, unless the item processing results in an exception.
AfterChunk - Annotation Type in org.springframework.batch.core.annotation
Marks a method to be called after a chunk is executed.
afterChunk() - Method in interface org.springframework.batch.core.ChunkListener
Callback after the chunk is executed, outside the transaction.
afterChunk() - Method in class org.springframework.batch.core.listener.ChunkListenerSupport
 
afterChunk() - Method in class org.springframework.batch.core.listener.CompositeChunkListener
Call the registered listeners in order, respecting and prioritising those that implement Ordered.
afterChunk() - Method in class org.springframework.batch.core.listener.MulticasterBatchListener
 
afterChunk() - 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.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.scope.util.PlaceholderTargetSource
 
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.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.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.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
 
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 prioritising 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.
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<?
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()
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
 
Alignment - Class in org.springframework.batch.item.file.transform
 
Alignment(String, String) - Constructor for class org.springframework.batch.item.file.transform.Alignment
 
AlwaysRetryPolicy - Class in org.springframework.batch.retry.policy
A RetryPolicy that always permits a retry.
AlwaysRetryPolicy() - Constructor for class org.springframework.batch.retry.policy.AlwaysRetryPolicy
 
AlwaysSkipItemSkipPolicy - Class in org.springframework.batch.core.step.skip
Implementation of the SkipPolicy interface that will always return that an item should be skipped.
AlwaysSkipItemSkipPolicy() - Constructor for class org.springframework.batch.core.step.skip.AlwaysSkipItemSkipPolicy
 
and(ExitStatus) - Method in class org.springframework.batch.core.ExitStatus
Create a new ExitStatus with a logical combination of the exit code, and a concatenation of the descriptions.
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(TaskletStep) - Method in class org.springframework.batch.core.step.item.FaultTolerantStepFactoryBean
 
applyConfiguration(TaskletStep) - Method in class org.springframework.batch.core.step.item.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

backOff(BackOffContext) - Method in interface org.springframework.batch.retry.backoff.BackOffPolicy
Back off/pause in an implementation-specific fashion.
backOff(BackOffContext) - Method in class org.springframework.batch.retry.backoff.ExponentialBackOffPolicy
Pause for a length of time equal to ' exp(backOffContext.expSeed)'.
backOff(BackOffContext) - Method in class org.springframework.batch.retry.backoff.StatelessBackOffPolicy
Delegates directly to the StatelessBackOffPolicy.doBackOff() method without passing on the BackOffContext argument which is not needed for stateless implementations.
BackOffContext - Interface in org.springframework.batch.retry.backoff
 
BackOffInterruptedException - Exception in org.springframework.batch.retry.backoff
Exception class signifiying that an attempt to back off using a BackOffPolicy was interrupted, most likely by an InterruptedException during a call to Thread.sleep(long).
BackOffInterruptedException(String) - Constructor for exception org.springframework.batch.retry.backoff.BackOffInterruptedException
 
BackOffInterruptedException(String, Throwable) - Constructor for exception org.springframework.batch.retry.backoff.BackOffInterruptedException
 
BackOffPolicy - Interface in org.springframework.batch.retry.backoff
Strategy interface to control back off between attempts in a single retry operation.
BackToBackPatternClassifier<C,T> - Class in org.springframework.batch.classify
A special purpose Classifier with easy configuration options for mapping from one arbitrary type of object to another via a pattern matcher.
BackToBackPatternClassifier() - Constructor for class org.springframework.batch.classify.BackToBackPatternClassifier
Default constructor, provided as a convenience for people using setter injection.
BackToBackPatternClassifier(Classifier<C, String>, Classifier<String, T>) - Constructor for class org.springframework.batch.classify.BackToBackPatternClassifier
Set up a classifier with input to the router and output from the matcher.
BatchRetryTemplate - Class in org.springframework.batch.core.step.item
A special purpose retry template that deals specifically with multi-valued stateful retry.
BatchRetryTemplate() - Constructor for class org.springframework.batch.core.step.item.BatchRetryTemplate
 
BatchStatus - Enum in org.springframework.batch.core
Enumeration representing the status of a an Execution.
BeanDefinitionUtils - Class in org.springframework.batch.core.configuration.xml
 
BeanDefinitionUtils() - Constructor for class org.springframework.batch.core.configuration.xml.BeanDefinitionUtils
 
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.
BeforeChunk - Annotation Type in org.springframework.batch.core.annotation
Marks a method to be called before a chunk is executed.
beforeChunk() - Method in interface org.springframework.batch.core.ChunkListener
Callback before the chunk is executed, but inside the transaction.
beforeChunk() - Method in class org.springframework.batch.core.listener.ChunkListenerSupport
 
beforeChunk() - Method in class org.springframework.batch.core.listener.CompositeChunkListener
Call the registered listeners in reverse order.
beforeChunk() - Method in class org.springframework.batch.core.listener.MulticasterBatchListener
 
beforeChunk() - 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
Called before ItemProcessor.process(Object).
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 prioritising 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.
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<?
beforeWrite(List<? extends S>) - Method in interface org.springframework.batch.core.ItemWriteListener
Called before ItemWriter.write(java.util.List)
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.
BinaryExceptionClassifier - Class in org.springframework.batch.classify
A Classifier for exceptions that has only two classes (true and false).
BinaryExceptionClassifier(boolean) - Constructor for class org.springframework.batch.classify.BinaryExceptionClassifier
Create a binary exception classifier with the provided default value.
BinaryExceptionClassifier(Collection<Class<? extends Throwable>>, boolean) - Constructor for class org.springframework.batch.classify.BinaryExceptionClassifier
Create a binary exception classifier with the provided classes and their subclasses.
BinaryExceptionClassifier(Collection<Class<? extends Throwable>>) - Constructor for class org.springframework.batch.classify.BinaryExceptionClassifier
Create a binary exception classifier with the default value false and value mapping true for the provided classes and their subclasses.
BinaryExceptionClassifier(Map<Class<? extends Throwable>, Boolean>) - Constructor for class org.springframework.batch.classify.BinaryExceptionClassifier
Create a binary exception classifier using the given classification map and a default classification of false.
BinaryExceptionClassifier(Map<Class<? extends Throwable>, Boolean>, boolean) - Constructor for class org.springframework.batch.classify.BinaryExceptionClassifier
Create a binary exception classifier using the given classification map and a default classification of false.
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.

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
 
canRetry(RetryContext) - Method in class org.springframework.batch.retry.policy.AlwaysRetryPolicy
Always returns true.
canRetry(RetryContext) - Method in class org.springframework.batch.retry.policy.CompositeRetryPolicy
Delegate to the policies that were in operation when the context was created.
canRetry(RetryContext) - Method in class org.springframework.batch.retry.policy.ExceptionClassifierRetryPolicy
Delegate to the policy currently activated in the context.
canRetry(RetryContext) - Method in class org.springframework.batch.retry.policy.NeverRetryPolicy
Returns false after the first exception.
canRetry(RetryContext) - Method in class org.springframework.batch.retry.policy.SimpleRetryPolicy
Test for retryable operation based on the status.
canRetry(RetryContext) - Method in class org.springframework.batch.retry.policy.TimeoutRetryPolicy
Only permits a retry if the timeout has not expired.
canRetry(RetryContext) - Method in interface org.springframework.batch.retry.RetryPolicy
 
canRetry(RetryPolicy, RetryContext) - Method in class org.springframework.batch.retry.support.RetryTemplate
Decide whether to proceed with the ongoing retry attempt.
CENTER - Static variable in class org.springframework.batch.item.file.transform.Alignment
 
checkInterrupted(StepExecution) - Method in interface org.springframework.batch.core.step.StepInterruptionPolicy
Has the job been interrupted?
checkInterrupted(StepExecution) - Method in class org.springframework.batch.core.step.ThreadStepInterruptionPolicy
Returns if the current job lifecycle has been interrupted by checking if the current thread is interrupted.
Chunk<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 #remove(Exception) 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.
ChunkListenerSupport - Class in org.springframework.batch.core.listener
Basic support implementation of ChunkListener
ChunkListenerSupport() - Constructor for class org.springframework.batch.core.listener.ChunkListenerSupport
 
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
Classifier<C,T> - Interface in org.springframework.batch.classify
Interface for a classifier.
Classifier - Annotation Type in org.springframework.batch.support.annotation
Mark a method as capable of classifying its input to an instance of its output.
ClassifierAdapter<C,T> - Class in org.springframework.batch.classify
Wrapper for an object to adapt it to the Classifier interface.
ClassifierAdapter() - Constructor for class org.springframework.batch.classify.ClassifierAdapter
Default constructor for use with setter injection.
ClassifierAdapter(Object) - Constructor for class org.springframework.batch.classify.ClassifierAdapter
Create a new Classifier from the delegate provided.
ClassifierAdapter(Classifier<C, T>) - Constructor for class org.springframework.batch.classify.ClassifierAdapter
Create a new Classifier from the delegate provided.
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
 
ClassifierSupport<C,T> - Class in org.springframework.batch.classify
Base class for Classifier implementations.
ClassifierSupport(T) - Constructor for class org.springframework.batch.classify.ClassifierSupport
 
classify(C) - Method in class org.springframework.batch.classify.BackToBackPatternClassifier
Classify the input and map to a String, then take that and put it into a pattern matcher to match to an output value.
classify(C) - Method in interface org.springframework.batch.classify.Classifier
Classify the given object and return an object of a different type, possibly an enumerated type.
classify(C) - Method in class org.springframework.batch.classify.ClassifierAdapter
Classify the given object and return an object of a different type, possibly an enumerated type.
classify(C) - Method in class org.springframework.batch.classify.ClassifierSupport
Always returns the default value.
classify(String) - Method in class org.springframework.batch.classify.PatternMatchingClassifier
Classify the input by matching it against the patterns provided in PatternMatchingClassifier.setPatternMap(Map).
classify(T) - Method in class org.springframework.batch.classify.SubclassClassifier
Return the value from the type map whose key is the class of the given Throwable, or its nearest ancestor if a subclass.
ClassPathXmlApplicationContextFactory - Class in org.springframework.batch.core.configuration.support
ApplicationContextFactory implementation that takes a parent context and a path to the context to create.
ClassPathXmlApplicationContextFactory() - Constructor for class org.springframework.batch.core.configuration.support.ClassPathXmlApplicationContextFactory
Convenient constructor for configuration purposes.
ClassPathXmlApplicationContextFactory(Resource) - Constructor for class org.springframework.batch.core.configuration.support.ClassPathXmlApplicationContextFactory
Create a factory instance with 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() - Static method in class org.springframework.batch.retry.support.RetrySynchronizationManager
Clear the current context at the end of a batch - should only be used by RepeatOperations implementations.
clearDirtyFlag() - Method in class org.springframework.batch.item.ExecutionContext
Clears the dirty flag.
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(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 class org.springframework.batch.item.file.ResourcesItemReader
 
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.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. even after an exception).
close(RetryContext, RetryCallback<T>, Throwable) - Method in class org.springframework.batch.retry.listener.RetryListenerSupport
 
close(RetryContext) - Method in class org.springframework.batch.retry.policy.CompositeRetryPolicy
Delegate to the policies that were in operation when the context was created.
close(RetryContext) - Method in class org.springframework.batch.retry.policy.ExceptionClassifierRetryPolicy
Delegate to the policy currently activated in the context.
close(RetryContext) - Method in class org.springframework.batch.retry.policy.NeverRetryPolicy
Do nothing.
close(RetryContext) - Method in class org.springframework.batch.retry.policy.SimpleRetryPolicy
 
close(RetryContext) - Method in class org.springframework.batch.retry.policy.TimeoutRetryPolicy
 
close(RetryContext, RetryCallback<T>, Throwable) - Method in interface org.springframework.batch.retry.RetryListener
Called after the final attempt (successful or not).
close(RetryContext) - Method in interface org.springframework.batch.retry.RetryPolicy
 
close(RetryPolicy, RetryContext, RetryState, boolean) - Method in class org.springframework.batch.retry.support.RetryTemplate
Clean up the cache if necessary and close the context provided (if the flag indicates that processing was successful).
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
 
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.
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
 
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).
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.
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
 
CompositeRetryPolicy - Class in org.springframework.batch.retry.policy
A RetryPolicy that composes a list of other policies and delegates calls to them in order.
CompositeRetryPolicy() - Constructor for class org.springframework.batch.retry.policy.CompositeRetryPolicy
 
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
 
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
 
configureChunkProcessor() - Method in class org.springframework.batch.core.step.item.FaultTolerantStepFactoryBean
 
configureChunkProcessor() - Method in class org.springframework.batch.core.step.item.SimpleStepFactoryBean
Extension point for creating appropriate ChunkProcessor.
configureChunkProvider() - Method in class org.springframework.batch.core.step.item.FaultTolerantStepFactoryBean
 
configureChunkProvider() - Method in class org.springframework.batch.core.step.item.SimpleStepFactoryBean
Extension point for creating appropriate ChunkProvider.
containsKey(String) - Method in class org.springframework.batch.item.ExecutionContext
Indicates whether or not a key is represented in this context.
containsKey(Object) - Method in class org.springframework.batch.retry.policy.MapRetryContextCache
 
containsKey(Object) - Method in interface org.springframework.batch.retry.policy.RetryContextCache
 
containsKey(Object) - Method in class org.springframework.batch.retry.policy.SoftReferenceMapRetryContextCache
 
containsValue(Object) - Method in class org.springframework.batch.item.ExecutionContext
Indicates whether or not a value is represented in this context.
ContextFactory - Interface in org.springframework.batch.core.scope.util
Interface to allow the context root for placeholder resolution to be switched at runtime.
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
 
convertToString(Object, TypeConverter) - Method in class org.springframework.batch.core.scope.util.PlaceholderTargetSource
 
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. an exception type in the context), and terminate based on a limit for the counter.
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.
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 interface org.springframework.batch.core.configuration.support.ApplicationContextFactory
 
createApplicationContext() - Method in class org.springframework.batch.core.configuration.support.ClassPathXmlApplicationContextFactory
Creates an ApplicationContext from the provided path.
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.
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, String) - Static method in class org.springframework.batch.test.MetaDataInstanceFactory
Create a JobInstance with the parameters provided.
createJobInstance(String, Long, JobParameters) - Static method in class org.springframework.batch.test.MetaDataInstanceFactory
Create a JobInstance with the parameters provided.
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
 
createJobKey(JobParameters) - Method in class org.springframework.batch.core.repository.dao.JdbcJobInstanceDao
 
createNewFile(File) - Static method in class org.springframework.batch.item.util.FileUtils
Create a new file if it doesn't already exist.
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.
createScopedProxy(BeanDefinitionHolder, BeanDefinitionRegistry, boolean) - Static method in class org.springframework.batch.core.scope.util.PlaceholderProxyFactoryBean
Convenience method to create a BeanDefinition for a target wrapped in a placeholder tarrget source, able to defer binding of placeholders until the bean is used.
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.item.FaultTolerantStepFactoryBean
 
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
 
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.

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.
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.
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_CAPACITY - Static variable in class org.springframework.batch.retry.policy.MapRetryContextCache
Default value for maximum capacity of the cache.
DEFAULT_CAPACITY - Static variable in class org.springframework.batch.retry.policy.SoftReferenceMapRetryContextCache
Default value for maximum capacity of the cache.
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_INITIAL_INTERVAL - Static variable in class org.springframework.batch.retry.backoff.ExponentialBackOffPolicy
The default 'initialInterval' value - 100 millisecs.
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_ATTEMPTS - Static variable in class org.springframework.batch.retry.policy.SimpleRetryPolicy
The default limit to the number of attempts for a new policy.
DEFAULT_MAX_INTERVAL - Static variable in class org.springframework.batch.retry.backoff.ExponentialBackOffPolicy
The default maximum backoff time (30 seconds).
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_MULTIPLIER - Static variable in class org.springframework.batch.retry.backoff.ExponentialBackOffPolicy
The default 'multiplier' value - value 2 (100% increase per backoff).
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).
DEFAULT_TIMEOUT - Static variable in class org.springframework.batch.retry.policy.TimeoutRetryPolicy
Default value for timeout (milliseconds).
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
 
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
 
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
Create a job loader with the job registry provided.
DefaultJobParametersConverter - Class in org.springframework.batch.core.converter
Converter for JobParameters instances using a simple naming convention for property keys.
DefaultJobParametersConverter() - Constructor for class org.springframework.batch.core.converter.DefaultJobParametersConverter
 
DefaultJobParametersExtractor - Class in org.springframework.batch.core.step.job
Simple implementation of JobParametersExtractor which pulls parameters with named keys out of the step execution context and the job parameters of the surrounding job.
DefaultJobParametersExtractor() - Constructor for class org.springframework.batch.core.step.job.DefaultJobParametersExtractor
 
DefaultJobParametersValidator - Class in org.springframework.batch.core.job
Default implementation of JobParametersValidator.
DefaultJobParametersValidator() - Constructor for class org.springframework.batch.core.job.DefaultJobParametersValidator
Convenient default constructor for unconstrained validation.
DefaultJobParametersValidator(String[], String[]) - Constructor for class org.springframework.batch.core.job.DefaultJobParametersValidator
Create a new validator with the required and optional job parameter keys provided.
DefaultLineMapper<T> - Class in org.springframework.batch.item.file.mapping
Two-phase LineMapper implementation consisting of tokenization of the line into FieldSet followed by mapping to item.
DefaultLineMapper() - Constructor for class org.springframework.batch.item.file.mapping.DefaultLineMapper
 
DefaultMailErrorHandler - Class in org.springframework.batch.item.mail
This MailErrorHandler implementation simply rethrows the exception it receives.
DefaultMailErrorHandler() - Constructor for class org.springframework.batch.item.mail.DefaultMailErrorHandler
 
DefaultPropertyEditorRegistrar - Class in org.springframework.batch.support
A re-usable PropertyEditorRegistrar that can be used wherever one needs to register custom PropertyEditor instances with a PropertyEditorRegistry (like a bean wrapper, or a type converter).
DefaultPropertyEditorRegistrar() - Constructor for class org.springframework.batch.support.DefaultPropertyEditorRegistrar
 
DefaultRecordSeparatorPolicy - Class in org.springframework.batch.item.file.separator
A RecordSeparatorPolicy that treats all lines as record endings, as long as they do not have unterminated quotes, and do not end in a continuation marker.
DefaultRecordSeparatorPolicy() - Constructor for class org.springframework.batch.item.file.separator.DefaultRecordSeparatorPolicy
Default constructor.
DefaultRecordSeparatorPolicy(String) - Constructor for class org.springframework.batch.item.file.separator.DefaultRecordSeparatorPolicy
Convenient constructor with quote character as parameter.
DefaultRecordSeparatorPolicy(String, String) - Constructor for class org.springframework.batch.item.file.separator.DefaultRecordSeparatorPolicy
Convenient constructor with quote character and continuation marker as parameters.
DefaultResultCompletionPolicy - Class in org.springframework.batch.repeat.policy
Very simple CompletionPolicy that bases its decision on the result of a batch operation.
DefaultResultCompletionPolicy() - Constructor for class org.springframework.batch.repeat.policy.DefaultResultCompletionPolicy
 
DefaultRetryState - Class in org.springframework.batch.retry.support
 
DefaultRetryState(Object, boolean, Classifier<? super Throwable, Boolean>) - Constructor for class org.springframework.batch.retry.support.DefaultRetryState
Create a DefaultRetryState representing the state for a new retry attempt.
DefaultRetryState(Object, Classifier<? super Throwable, Boolean>) - Constructor for class org.springframework.batch.retry.support.DefaultRetryState
Defaults the force refresh flag to false.
DefaultRetryState(Object, boolean) - Constructor for class org.springframework.batch.retry.support.DefaultRetryState
Defaults the rollback classifier to null.
DefaultRetryState(Object) - Constructor for class org.springframework.batch.retry.support.DefaultRetryState
Defaults the force refresh flag (to false) and the rollback classifier (to null).
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
 
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(char) - 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(String) - Method in interface org.springframework.batch.core.repository.dao.ExecutionContextStringSerializer
De-serialize the context from a string representation
deserialize(String) - Method in class org.springframework.batch.core.repository.dao.XStreamExecutionContextStringSerializer
 
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.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
 
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
 
doBackOff() - Method in class org.springframework.batch.retry.backoff.FixedBackOffPolicy
Pause for the FixedBackOffPolicy.setBackOffPeriod(long).
doBackOff() - Method in class org.springframework.batch.retry.backoff.NoBackOffPolicy
 
doBackOff() - Method in class org.springframework.batch.retry.backoff.StatelessBackOffPolicy
Sub-classes should implement this method to perform the actual back off.
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.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
Close the resources opened in AbstractItemCountingItemStreamItemReader.doOpen().
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.
doExecute(RetryCallback<T>, RecoveryCallback<T>, RetryState) - Method in class org.springframework.batch.retry.support.RetryTemplate
Execute the callback once if the policy dictates that we can, otherwise execute the recovery callback.
doGetTransaction() - Method in class org.springframework.batch.support.transaction.ResourcelessTransactionManager
 
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. there is a data source that is not yet exhausted.
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
 
doOnWriteError(Exception, List<O>) - Method in class org.springframework.batch.core.step.item.SimpleChunkProcessor
 
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
 
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.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
 
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.
doWithRetry(RetryContext) - Method in interface org.springframework.batch.retry.RetryCallback
Execute an operation with retry semantics.
doWrite(List<O>) - Method in class org.springframework.batch.core.step.item.SimpleChunkProcessor
Surrounds the actual write call with listener callbacks.
doWrite(HibernateOperations, List<? extends T>) - Method in class org.springframework.batch.item.database.HibernateItemWriter
Do perform the actual write operation.
doWrite(EntityManager, List<? extends T>) - Method in class org.springframework.batch.item.database.JpaItemWriter
Do perform the actual write operation.
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. using MethodInvoker.
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).
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
 
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.ClassPathXmlApplicationContextFactory
 
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. two contexts are only equal if their step executions are the same).
equals(Object) - Method in class org.springframework.batch.core.StepContribution
 
equals(Object) - Method in class org.springframework.batch.core.StepExecution
 
equals(Object) - Method in class org.springframework.batch.item.ExecutionContext
 
equals(Object) - Method in class org.springframework.batch.item.file.transform.DefaultFieldSet
 
equals(Object) - Method in class org.springframework.batch.repeat.context.SynchronizedAttributeAccessor
 
equals(Object) - Method in class org.springframework.batch.support.SimpleMethodInvoker
 
ExceptionClassifierRetryPolicy - Class in org.springframework.batch.retry.policy
A RetryPolicy that dynamically adapts to one of a set of injected policies according to the value of the latest exception.
ExceptionClassifierRetryPolicy() - Constructor for class org.springframework.batch.retry.policy.ExceptionClassifierRetryPolicy
 
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 - Interface in org.springframework.batch.repeat.exception
Handler to allow strategies for re-throwing exceptions.
execute(JobExecution) - Method in class org.springframework.batch.core.configuration.support.GroupAwareJob
 
execute(JobExecution) - Method in class org.springframework.batch.core.job.AbstractJob
Run the specified job, handling all listener and repository calls, and delegating the actual processing to AbstractJob.doExecute(JobExecution).
execute(JobExecution) - Method in interface org.springframework.batch.core.Job
Run the JobExecution and update the meta information like status and statistics as necessary.
execute(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.
execute(RetryCallback<T>) - Method in interface org.springframework.batch.retry.RetryOperations
Execute the supplied RetryCallback with the configured retry semantics.
execute(RetryCallback<T>, RecoveryCallback<T>) - Method in interface org.springframework.batch.retry.RetryOperations
Execute the supplied RetryCallback with a fallback on exhausted retry to the RecoveryCallback.
execute(RetryCallback<T>, RetryState) - Method in interface org.springframework.batch.retry.RetryOperations
A simple stateful retry.
execute(RetryCallback<T>, RecoveryCallback<T>, RetryState) - Method in interface org.springframework.batch.retry.RetryOperations
A stateful retry with a recovery path.
execute(RetryCallback<T>) - Method in class org.springframework.batch.retry.support.RetryTemplate
Keep executing the callback until it either succeeds or the policy dictates that we stop, in which case the most recent exception thrown by the callback will be rethrown.
execute(RetryCallback<T>, RecoveryCallback<T>) - Method in class org.springframework.batch.retry.support.RetryTemplate
Keep executing the callback until it either succeeds or the policy dictates that we stop, in which case the recovery callback will be executed.
execute(RetryCallback<T>, RetryState) - Method in class org.springframework.batch.retry.support.RetryTemplate
Execute the callback once if the policy dictates that we can, re-throwing any exception encountered so that clients can re-present the same task later.
execute(RetryCallback<T>, RecoveryCallback<T>, RetryState) - Method in class org.springframework.batch.retry.support.RetryTemplate
Execute the callback once if the policy dictates that we can, re-throwing any exception encountered so that clients can re-present the same task later.
executeAfterInterceptors(RepeatContext, RepeatStatus) - Method in class org.springframework.batch.repeat.support.RepeatTemplate
Convenience method to execute after interceptors on a callback result.
executeStep(Step) - Method in interface org.springframework.batch.core.job.flow.FlowExecutor
 
executeStep(Step) - Method in class org.springframework.batch.core.job.flow.JobFlowExecutor
 
EXECUTING - Static variable in class org.springframework.batch.core.ExitStatus
Convenient constant value representing continuable state where processing is still taking place, so no further action is required.
ExecutionContext - Class in org.springframework.batch.item
Object representing a context for an ItemStream.
ExecutionContext() - Constructor for class org.springframework.batch.item.ExecutionContext
Default constructor.
ExecutionContext(Map<String, Object>) - Constructor for class org.springframework.batch.item.ExecutionContext
Initializes a new execution context with the contents of another map.
ExecutionContext(ExecutionContext) - Constructor for class org.springframework.batch.item.ExecutionContext
 
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
 
ExecutionContextStringSerializer - Interface in org.springframework.batch.core.repository.dao
Interface defining serialization support for execution context Map in the form of a String.
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
 
ExhaustedRetryException - Exception in org.springframework.batch.retry
 
ExhaustedRetryException(String, Throwable) - Constructor for exception org.springframework.batch.retry.ExhaustedRetryException
 
ExhaustedRetryException(String) - Constructor for exception org.springframework.batch.retry.ExhaustedRetryException
 
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.
ExponentialBackOffPolicy - Class in org.springframework.batch.retry.backoff
Implementation of BackOffPolicy that increases the back off period for each retry attempt in a given set using the exponential function.
ExponentialBackOffPolicy() - Constructor for class org.springframework.batch.retry.backoff.ExponentialBackOffPolicy
 
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.
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

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
 
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
 
FaultTolerantStepFactoryBean<T,S> - Class in org.springframework.batch.core.step.item
Factory bean for step that provides options for configuring skip behaviour.
FaultTolerantStepFactoryBean() - Constructor for class org.springframework.batch.core.step.item.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.
FileUtils - Class in org.springframework.batch.item.util
Utility methods for files used in batch processing.
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.
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
 
FixedBackOffPolicy - Class in org.springframework.batch.retry.backoff
Implementation of BackOffPolicy that pauses for a fixed period of time before continuing.
FixedBackOffPolicy() - Constructor for class org.springframework.batch.retry.backoff.FixedBackOffPolicy
 
FixedLengthTokenizer - Class in org.springframework.batch.item.file.transform
Tokenizer used to process data obtained from files with fixed-length format.
FixedLengthTokenizer() - Constructor for class org.springframework.batch.item.file.transform.FixedLengthTokenizer
 
FlatFileFooterCallback - Interface in org.springframework.batch.item.file
Callback interface for writing a footer to a file.
FlatFileFormatException - Exception in org.springframework.batch.item.file.transform
Exception indicating that some type of error has occured while attempting to parse a line of input into tokens.
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 - Interface in org.springframework.batch.core.job.flow
 
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).
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 XPath.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.
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.
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.
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.

G

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
 
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
 
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
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.
get(Object) - Method in class org.springframework.batch.retry.policy.MapRetryContextCache
 
get(Object) - Method in interface org.springframework.batch.retry.policy.RetryContextCache
 
get(Object) - Method in class org.springframework.batch.retry.policy.SoftReferenceMapRetryContextCache
 
getAbortCount() - Method in interface org.springframework.batch.retry.RetryStatistics
Get the number of times a block failed to complete successfully, even after retry.
getActualCount() - Method in exception org.springframework.batch.item.file.transform.IncorrectTokenCountException
 
getActualLength() - Method in exception org.springframework.batch.item.file.transform.IncorrectLineLengthException
 
getAdjustedOutputs(Chunk<I>, Chunk<O>) - Method in class org.springframework.batch.core.step.item.FaultTolerantChunkProcessor
 
getAdjustedOutputs(Chunk<I>, Chunk<O>) - Method in class org.springframework.batch.core.step.item.SimpleChunkProcessor
Extension point for subclasses that want to adjust the outputs based on additional saved data in the inputs.
getAllFailureExceptions() - Method in class org.springframework.batch.core.JobExecution
Return all failure causing exceptions for this JobExecution, including step executions.
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
 
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
 
getBackOffPeriod() - Method in class org.springframework.batch.retry.backoff.FixedBackOffPolicy
The backoff period in milliseconds.
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.ClassPathXmlApplicationContextFactory
Protected access to the list of bean factory post processor classes that should be copied over to the context from the parent.
getBufferSize() - Method in class org.springframework.batch.support.transaction.TransactionAwareBufferedWriter
Convenience method for clients to determine if there is any unflushed data.
getChunkOperations() - Method in class org.springframework.batch.core.step.item.SimpleStepFactoryBean
Protected getter for the chunk operations to make them available in subclasses.
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.
getCommitCount() - Method in class org.springframework.batch.core.StepExecution
Returns the current number of commits for this execution
getCommitInterval() - Method in class org.springframework.batch.core.step.item.SimpleStepFactoryBean
Accessor for commit interval if needed in sub classes.
getCompleteCount() - Method in interface org.springframework.batch.retry.RetryStatistics
 
getCompositeListener() - Method in class org.springframework.batch.core.step.AbstractStep
 
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() - Method in interface org.springframework.batch.core.scope.util.ContextFactory
 
getContext() - Method in class org.springframework.batch.core.scope.util.StepContextFactory
 
getContext() - Static method in class org.springframework.batch.repeat.support.RepeatSynchronizationManager
Getter for the current context.
getContext() - Static method in class org.springframework.batch.retry.support.RetrySynchronizationManager
Public accessor for the locally enclosing RetryContext.
getContextId() - Method in interface org.springframework.batch.core.scope.util.ContextFactory
 
getContextId() - Method in class org.springframework.batch.core.scope.util.StepContextFactory
 
getConversationId() - Method in class org.springframework.batch.core.scope.StepScope
 
getCount() - Method in class org.springframework.batch.repeat.context.RepeatContextCounter
 
getCount(RepeatContext) - Method in class org.springframework.batch.repeat.policy.CountingCompletionPolicy
Extension point for subclasses.
getCounter() - Method in class org.springframework.batch.repeat.policy.CountingCompletionPolicy.CountingBatchContext
 
getCreateTime() - Method in class org.springframework.batch.core.JobExecution
 
getCurrentItemCount() - Method in class org.springframework.batch.item.support.AbstractItemCountingItemStreamItemReader
 
getCurrentResource() - Method in class org.springframework.batch.item.file.MultiResourceItemReader
 
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.
getDefault() - Method in class org.springframework.batch.classify.SubclassClassifier
Return the default value supplied in the constructor (default false).
getDefaultListenerClass() - Method in class org.springframework.batch.core.listener.AbstractListenerFactoryBean
 
getDefaultListenerClass() - Method in class org.springframework.batch.core.listener.JobListenerFactoryBean
 
getDefaultListenerClass() - Method in class org.springframework.batch.core.listener.StepListenerFactoryBean
 
getDouble(String) - Method in class org.springframework.batch.core.JobParameters
Typesafe Getter for the Long represented by the provided key.
getDouble(String, double) - Method in class org.springframework.batch.core.JobParameters
Typesafe Getter for the Double represented by the provided key.
getDouble(String) - Method in class org.springframework.batch.item.ExecutionContext
Typesafe Getter for the Double represented by the provided key.
getDouble(String, double) - Method in class org.springframework.batch.item.ExecutionContext
Typesafe Getter for the Double represented by the provided key with default value to return if key is not represented.
getEncoding() - Method in class org.springframework.batch.item.xml.StaxEventItemWriter
Get used encoding.
getEndTime() - Method in class org.springframework.batch.core.JobExecution
 
getEndTime() - Method in class org.springframework.batch.core.StepExecution
Returns the time that this execution ended
getEntityManager() - Method in class org.springframework.batch.item.database.orm.AbstractJpaQueryProvider
Getter for EntityManager
getErrorCount() - Method in interface org.springframework.batch.retry.RetryStatistics
Get the number of errors detected, whether or not they resulted in a retry.
getErrorMessage() - Static method in class org.springframework.batch.core.launch.support.CommandLineJobRunner
Retrieve the error message set by an instance of CommandLineJobRunner as it exits.
getErrors() - Static method in class org.springframework.batch.core.launch.support.JobRegistryBackgroundJobRunner
Public getter for the startup errors encountered during parent context creation.
getErrors() - Method in class org.springframework.batch.core.step.item.Chunk
 
getException() - Method in class org.springframework.batch.core.step.item.SkipWrapper
Public getter for the exception.
getExceptionHandler() - Method in class org.springframework.batch.core.step.item.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
 
getExecutionContextUserSupport() - Method in class org.springframework.batch.item.support.AbstractItemCountingItemStreamItemReader
 
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
 
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'.
getFilterCount(Chunk<I>, Chunk<O>) - Method in class org.springframework.batch.core.step.item.FaultTolerantChunkProcessor
 
getFilterCount(Chunk<I>, Chunk<O>) - Method in class org.springframework.batch.core.step.item.SimpleChunkProcessor
Extension point for subclasses to calculate the filter count.
getFilterCount() - Method in class org.springframework.batch.core.StepContribution
Public getter for the filter counter.
getFilterCount() - Method in class org.springframework.batch.core.StepExecution
Returns the current number of items filtered out of this execution
getFlows() - Method in interface org.springframework.batch.core.job.flow.FlowHolder
 
getFlows() - Method in class org.springframework.batch.core.job.flow.support.state.FlowState
 
getFlows() - Method in class org.springframework.batch.core.job.flow.support.state.SplitState
 
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
 
getGroupName(BeanDefinition, Job) - Method in class org.springframework.batch.core.configuration.support.JobRegistryBeanPostProcessor
Determine a group name for the job to be registered.
getId() - Method in class org.springframework.batch.core.Entity
 
getId() - Method in class org.springframework.batch.core.scope.context.StepContext
 
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
 
getInitialInterval() - Method in class org.springframework.batch.retry.backoff.ExponentialBackOffPolicy
The initial period to sleep on the first backoff.
getInput() - Method in exception org.springframework.batch.item.file.FlatFileParseException
 
getInput() - Method in exception org.springframework.batch.item.file.NonTransientFlatFileException
 
getInt(String) - Method in class org.springframework.batch.item.ExecutionContext
Typesafe Getter for the Integer represented by the provided key.
getInt(String, int) - Method in class org.springframework.batch.item.ExecutionContext
Typesafe Getter for the Integer represented by the provided key with default value to return if key is not represented.
getItem() - Method in class org.springframework.batch.core.step.item.SkipWrapper
Public getter for the item.
getItemProcessor() - Method in class org.springframework.batch.core.step.item.SimpleStepFactoryBean
Protected getter for the ItemProcessor for subclasses to use
getItemReader() - Method in class org.springframework.batch.core.step.item.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.item.SimpleStepFactoryBean
Protected getter for the ItemWriter for subclasses to use
getJdbcTemplate() - Method in class org.springframework.batch.core.repository.dao.AbstractJdbcBatchMetadataDao
 
getJob(String) - Method in interface org.springframework.batch.core.configuration.JobLocator
Locates a Job at runtime.
getJob(String) - Method in class org.springframework.batch.core.configuration.support.MapJobRegistry
 
getJob() - Method in class org.springframework.batch.test.AbstractJobTests
Deprecated.  
getJob() - Method in class org.springframework.batch.test.JobLauncherTestUtils
 
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.
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 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. jobs that have ever been executed.
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.JobInstance
 
getJobParameters(Properties) - Method in class org.springframework.batch.core.launch.support.ScheduledJobParametersFactory
 
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 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 interface org.springframework.batch.core.Job
A validator for the job parameters of a JobExecution.
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.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.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.
getKey(Object[]) - Method in interface org.springframework.batch.retry.interceptor.MethodArgumentsKeyGenerator
Get a unique identifier for the item that can be used to cache it between calls if necessary, and then identify it later.
getKey() - Method in interface org.springframework.batch.retry.RetryState
Key representing the state for a retry attempt.
getKey() - Method in class org.springframework.batch.retry.support.DefaultRetryState
 
getLastJobExecution(JobInstance) - Method in class org.springframework.batch.core.repository.dao.JdbcJobExecutionDao
 
getLastJobExecution(JobInstance) - Method in interface org.springframework.batch.core.repository.dao.JobExecutionDao
Find the last JobExecution to have been created for a given JobInstance.
getLastJobExecution(JobInstance) - Method in class org.springframework.batch.core.repository.dao.MapJobExecutionDao
 
getLastJobExecution(String, JobParameters) - Method in interface org.springframework.batch.core.repository.JobRepository
 
getLastJobExecution(String, JobParameters) - Method in class org.springframework.batch.core.repository.support.SimpleJobRepository
 
getLastStepExecution(JobInstance, String) - Method in interface org.springframework.batch.core.repository.JobRepository
 
getLastStepExecution(JobInstance, String) - Method in class org.springframework.batch.core.repository.support.SimpleJobRepository
 
getLastThrowable() - Method in class org.springframework.batch.retry.context.RetryContextSupport
 
getLastThrowable() - Method in interface org.springframework.batch.retry.RetryContext
Accessor for the exception object that caused the current retry.
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
 
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.item.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
 
getMaxAttempts() - Method in class org.springframework.batch.retry.policy.SimpleRetryPolicy
The maximum number of retry attempts before failure.
getMaxInterval() - Method in class org.springframework.batch.retry.backoff.ExponentialBackOffPolicy
The maximum interval to sleep for.
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
 
getMin() - Method in class org.springframework.batch.item.file.transform.Range
 
getMultiplier() - Method in class org.springframework.batch.retry.backoff.ExponentialBackOffPolicy
The multiplier to use to generate the next backoff interval from the last.
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 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 interface org.springframework.batch.core.Step
 
getName() - Method in class org.springframework.batch.core.step.item.SimpleStepFactoryBean
Public getter for the name of the step.
getName() - Method in class org.springframework.batch.item.util.ExecutionContextUserSupport
 
getName() - Method in interface org.springframework.batch.retry.RetryStatistics
Get an identifier for the retry block for reporting purposes.
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
Use the TaskExecutorRepeatTemplate.setTaskExecutor(TaskExecutor) to generate a result.
getObject() - Method in class org.springframework.batch.core.configuration.support.ClasspathXmlApplicationContextsFactoryBean
Create an ApplicationContextFactory from each resource provided in ClasspathXmlApplicationContextsFactoryBean.setResources(Resource[]).
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.scope.util.PlaceholderProxyFactoryBean
 
getObject() - Method in class org.springframework.batch.core.step.item.SimpleStepFactoryBean
Create a Step from the configuration provided.
getObject() - Method in class org.springframework.batch.item.database.support.SqlPagingQueryProviderFactoryBean
Get a PagingQueryProvider instance using the provided properties and appropriate for the given database type.
getObjectType() - Method in class org.springframework.batch.core.configuration.support.ClasspathXmlApplicationContextsFactoryBean
The type of object returned by this factory - an array of ApplicationContextFactory.
getObjectType() - Method in class org.springframework.batch.core.configuration.xml.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.scope.util.PlaceholderProxyFactoryBean
 
getObjectType() - Method in class org.springframework.batch.core.step.item.SimpleStepFactoryBean
 
getObjectType() - Method in class org.springframework.batch.item.database.support.SqlPagingQueryProviderFactoryBean
Always returns PagingQueryProvider.
getOrder() - Method in class org.springframework.batch.core.configuration.support.AutomaticJobRegistrar
 
getOrder() - Method in class org.springframework.batch.core.scope.StepScope
 
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.
getParent() - Method in class org.springframework.batch.retry.context.RetryContextSupport
 
getParent() - Method in interface org.springframework.batch.retry.RetryContext
Accessor for the parent context if retry blocks are nested.
getParentLogger() - Method in class org.springframework.batch.item.database.ExtendedConnectionDataSourceProxy
Added due to JDK 7 compatibility, sadly a proper implementation that would throw SqlFeatureNotSupportedException is not possible in Java 5 (the class was added in Java 6).
getPartitionNames(int) - Method in interface org.springframework.batch.core.partition.support.PartitionNameProvider
 
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.
getPropertyName() - Method in enum org.springframework.batch.core.listener.JobListenerMetaData
 
getPropertyName() - Method in interface org.springframework.batch.core.listener.ListenerMetaData
 
getPropertyName() - Method in enum org.springframework.batch.core.listener.StepListenerMetaData
 
getPropertyValue(String, String, ConfigurableListableBeanFactory) - Static method in class org.springframework.batch.core.configuration.xml.BeanDefinitionUtils
 
getQuery(String) - Method in class org.springframework.batch.core.repository.dao.AbstractJdbcBatchMetadataDao
 
getReadCount() - Method in class org.springframework.batch.core.StepContribution
Public access to the read counter.
getReadCount() - Method in class org.springframework.batch.core.StepExecution
Returns the current number of items read for this execution
getReadSkipCount() - Method in class org.springframework.batch.core.StepContribution
 
getReadSkipCount() - Method in class org.springframework.batch.core.StepExecution
 
getResult(XMLEventWriter) - Static method in class org.springframework.batch.item.xml.StaxUtils
 
getRetryCount() - Method in class org.springframework.batch.retry.context.RetryContextSupport
 
getRetryCount() - Method in interface org.springframework.batch.retry.RetryContext
Counts the number of retry attempts.
getRollbackClassifier() - Method in class org.springframework.batch.core.step.item.FaultTolerantStepFactoryBean
Convenience method for subclasses to get an exception classifier based on the provided transaction attributes.
getRollbackCount() - Method in class org.springframework.batch.core.StepExecution
Returns the current number of rollbacks for this execution
getRootElementAttributes() - Method in class org.springframework.batch.item.xml.StaxEventItemWriter
Get attributes of the root element.
getRootTagName() - Method in class org.springframework.batch.item.xml.StaxEventItemWriter
Get the tag name of the root element.
getRootTagNamespace() - Method in class org.springframework.batch.item.xml.StaxEventItemWriter
Get the namespace of the root element.
getRootTagNamespacePrefix() - Method in class org.springframework.batch.item.xml.StaxEventItemWriter
Get the namespace prefix of the root element.
getRunningExecutions(String) - Method in interface org.springframework.batch.core.launch.JobOperator
Get the id values of all the running JobExecutions with the given job name.
getRunningExecutions(String) - Method in class org.springframework.batch.core.launch.support.SimpleJobOperator
 
getSelectClause() - Method in class org.springframework.batch.item.database.support.AbstractSqlPagingQueryProvider
 
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
 
getSortKey() - Method in interface org.springframework.batch.item.database.PagingQueryProvider
The sort key (unique single column name).
getSortKey() - Method in class org.springframework.batch.item.database.support.AbstractSqlPagingQueryProvider
 
getSortKeyPlaceHolder() - 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.
getSortKeyWithoutAlias() - Method in interface org.springframework.batch.item.database.PagingQueryProvider
The sort key (unique single column name) without alias.
getSortKeyWithoutAlias() - Method in class org.springframework.batch.item.database.support.AbstractSqlPagingQueryProvider
 
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.
getStartedCount() - Method in interface org.springframework.batch.retry.RetryStatistics
Get the number of times a retry block has been entered, irrespective of how many times the operation was retried.
getStartLimit() - Method in class org.springframework.batch.core.step.AbstractStep
 
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.
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) - 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
 
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.item.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.
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
 
getTarget() - Method in class org.springframework.batch.core.scope.util.PlaceholderTargetSource
 
getTaskExecutor() - Method in class org.springframework.batch.core.step.item.SimpleStepFactoryBean
Mkae the TaskExecutor available to subclasses
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
 
getTimeout() - Method in class org.springframework.batch.retry.policy.TimeoutRetryPolicy
The value of the timeout.
getTransactionAttribute() - Method in class org.springframework.batch.core.step.item.FaultTolerantStepFactoryBean
Getter for the TransactionAttribute for subclasses only.
getTransactionAttribute() - Method in class org.springframework.batch.core.step.item.SimpleStepFactoryBean
Getter for the TransactionAttribute for subclasses only.
getTransactionManager() - Method in class org.springframework.batch.core.repository.support.AbstractJobRepositoryFactoryBean
The transaction manager used in this factory.
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.
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
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
 
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.TaskExecutorPartitionHandler
 
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.
handleException(RepeatContext, Throwable) - Method in class org.springframework.batch.core.step.item.SimpleRetryExceptionHandler
Check if the exception is going to be retried, and veto the handling if it is.
handleException(RepeatContext, Throwable) - Method in class org.springframework.batch.repeat.exception.CompositeExceptionHandler
Iterate over the handlers delegating the call to each in turn.
handleException(RepeatContext, Throwable) - Method in class org.springframework.batch.repeat.exception.DefaultExceptionHandler
Re-throw the throwable.
handleException(RepeatContext, Throwable) - Method in interface org.springframework.batch.repeat.exception.ExceptionHandler
Deal with a Throwable during a batch - decide whether it should be re-thrown in the first place.
handleException(RepeatContext, Throwable) - Method in class org.springframework.batch.repeat.exception.LogOrRethrowExceptionHandler
Classify the throwables and decide whether to rethrow based on the result.
handleException(RepeatContext, Throwable) - Method in class org.springframework.batch.repeat.exception.RethrowOnThresholdExceptionHandler
Classify the throwables and decide whether to re-throw based on the result.
handleException(RepeatContext, Throwable) - Method in class org.springframework.batch.repeat.exception.SimpleLimitExceptionHandler
Rethrows only if the limit is breached for this context on the exception type specified.
handleLine(String) - Method in interface org.springframework.batch.item.file.LineCallbackHandler
 
handleListenersElement(Element, BeanDefinition, ParserContext) - Method in class org.springframework.batch.core.configuration.xml.StepListenerParser
 
handleRetryExhausted(RecoveryCallback<T>, RetryContext, RetryState) - Method in class org.springframework.batch.retry.support.RetryTemplate
Actions to take after final attempt has failed.
handleStep(Step, JobExecution) - Method in class org.springframework.batch.core.job.AbstractJob
Convenience method for subclasses to delegate the handling of a specific step in the context of the current JobExecution.
handleStep(Step, JobExecution) - Method in class org.springframework.batch.core.job.SimpleStepHandler
 
handleStep(Step, JobExecution) - Method in interface org.springframework.batch.core.job.StepHandler
Handle a step and return the execution for it.
handleWarnings(Statement) - Method in class org.springframework.batch.item.database.AbstractCursorItemReader
Throw a SQLWarningException if we're not ignoring warnings, else log the warnings (at debug level).
hasAttribute(String) - Method in class org.springframework.batch.repeat.context.SynchronizedAttributeAccessor
 
hashCode() - Method in class org.springframework.batch.core.configuration.support.ClassPathXmlApplicationContextFactory
 
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.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
 
HibernateCursorItemReader<T> - Class in org.springframework.batch.item.database
ItemReader 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.
IbatisBatchItemWriter() - Constructor for class org.springframework.batch.item.database.IbatisBatchItemWriter
 
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_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) - 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) - Constructor for exception org.springframework.batch.item.file.transform.IncorrectTokenCountException
 
IncorrectTokenCountException(int, int) - Constructor for exception org.springframework.batch.item.file.transform.IncorrectTokenCountException
 
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
incrementFilterCount(int) - Method in class org.springframework.batch.core.StepContribution
Increment the counter for the number of items processed.
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.
init() - Method in class org.springframework.batch.core.configuration.xml.CoreNamespaceHandler
 
init() - Method in class org.springframework.batch.core.repository.dao.XStreamExecutionContextStringSerializer
 
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
 
initBinder(DataBinder) - Method in class org.springframework.batch.item.file.mapping.BeanWrapperFieldSetMapper
Initialize a new binder instance.
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.
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
 
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
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.
invoke(MethodInvocation) - Method in class org.springframework.batch.retry.interceptor.RetryOperationsInterceptor
 
invoke(MethodInvocation) - Method in class org.springframework.batch.retry.interceptor.StatefulRetryOperationsInterceptor
Wrap the method invocation in a stateful retry with the policy and other helpers provided.
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 interface org.springframework.batch.core.Step
 
isAscending() - Method in class org.springframework.batch.item.database.support.AbstractSqlPagingQueryProvider
Get the flag that signals that the sort key is applied ascending.
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.ClassPathXmlApplicationContextFactory
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 a line, being the latest line read from an input source.
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
 
isExhaustedOnly() - Method in class org.springframework.batch.retry.context.RetryContextSupport
 
isExhaustedOnly() - Method in interface org.springframework.batch.retry.RetryContext
Public accessor for the exhausted flag RetryContext.setExhaustedOnly().
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
 
isForceRefresh() - Method in interface org.springframework.batch.retry.RetryState
Indicate whether a cache lookup can be avoided.
isForceRefresh() - Method in class org.springframework.batch.retry.support.DefaultRetryState
 
isGreaterThan(BatchStatus) - Method in enum org.springframework.batch.core.BatchStatus
 
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.
isNew(Object[]) - Method in interface org.springframework.batch.retry.interceptor.NewMethodArgumentsIdentifier
Inspect the arguments and determine if they have never been processed before.
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.item.SimpleStepFactoryBean
Convenience method for subclasses.
isRestart() - Method in interface org.springframework.batch.core.job.flow.FlowExecutor
 
isRestart() - Method in class org.springframework.batch.core.job.flow.JobFlowExecutor
 
isRestartable() - Method in class org.springframework.batch.core.configuration.support.GroupAwareJob
 
isRestartable() - Method in class org.springframework.batch.core.job.AbstractJob
 
isRestartable() - Method in 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.scope.util.PlaceholderProxyFactoryBean
 
isSingleton() - Method in class org.springframework.batch.core.step.item.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.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?
isUnsuccessful() - Method in enum org.springframework.batch.core.BatchStatus
Convenience method to decide if a status indicates execution was unsuccessful.
isUseSharedExtendedConnection() - Method in class org.springframework.batch.item.database.AbstractCursorItemReader
 
isUsingNamedParameters() - Method in interface org.springframework.batch.item.database.PagingQueryProvider
Indicate whether the generated queries use named parameter syntax.
isUsingNamedParameters() - Method in class org.springframework.batch.item.database.support.AbstractSqlPagingQueryProvider
 
isWrapperFor(Class<?>) - Method in class org.springframework.batch.item.database.ExtendedConnectionDataSourceProxy
Performs only a 'shallow' non-recursive check of self's and delegate's class to retain Java 5 compatibility.
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 SimpleJdbcTemplate 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
 
JdbcExecutionContextDao - Class in org.springframework.batch.core.repository.dao
JDBC DAO for ExecutionContext.
JdbcExecutionContextDao() - Constructor for class org.springframework.batch.core.repository.dao.JdbcExecutionContextDao
 
JdbcJobExecutionDao - Class in org.springframework.batch.core.repository.dao
Jdbc implementation of JobExecutionDao.
JdbcJobExecutionDao() - Constructor for class org.springframework.batch.core.repository.dao.JdbcJobExecutionDao
 
JdbcJobInstanceDao - Class in org.springframework.batch.core.repository.dao
Jdbc implementation of JobInstanceDao.
JdbcJobInstanceDao() - Constructor for class org.springframework.batch.core.repository.dao.JdbcJobInstanceDao
 
JdbcPagingItemReader<T> - Class in org.springframework.batch.item.database
ItemReader for reading database records using JDBC in a paging fashion.
JdbcPagingItemReader() - Constructor for class org.springframework.batch.item.database.JdbcPagingItemReader
 
JdbcParameterUtils - Class in org.springframework.batch.item.database
Helper methods for SQL statement parameter parsing.
JdbcParameterUtils() - Constructor for class org.springframework.batch.item.database.JdbcParameterUtils
 
JdbcStepExecutionDao - Class in org.springframework.batch.core.repository.dao
Jdbc implementation of StepExecutionDao.
JdbcStepExecutionDao() - Constructor for class org.springframework.batch.core.repository.dao.JdbcStepExecutionDao
 
JmsItemReader<T> - Class in org.springframework.batch.item.jms
An ItemReader for JMS using a JmsTemplate.
JmsItemReader() - Constructor for class org.springframework.batch.item.jms.JmsItemReader
 
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_NOT_PROVIDED - Static variable in interface org.springframework.batch.core.launch.support.ExitCodeMapper
 
JobExecution - Class in org.springframework.batch.core
Batch domain object representing the execution of a job.
JobExecution(JobInstance, Long) - 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 modelling point of view.
JobExecution(JobInstance) - Constructor for class org.springframework.batch.core.JobExecution
Constructor for transient (unsaved) instances.
JobExecution(Long) - Constructor for class org.springframework.batch.core.JobExecution
 
JobExecutionAlreadyRunningException - Exception in org.springframework.batch.core.repository
 
JobExecutionAlreadyRunningException(String) - Constructor for exception org.springframework.batch.core.repository.JobExecutionAlreadyRunningException
 
JobExecutionAlreadyRunningException(String, Throwable) - Constructor for exception org.springframework.batch.core.repository.JobExecutionAlreadyRunningException
 
JobExecutionDao - Interface in org.springframework.batch.core.repository.dao
Data Access Object for job executions.
JobExecutionDecider - Interface in org.springframework.batch.core.job.flow
Interface allowing for programmatic access to the decision on what the status of a flow should be.
JobExecutionException - Exception in org.springframework.batch.core
Root of exception hierarchy for checked exceptions in job and step execution.
JobExecutionException(String) - Constructor for exception org.springframework.batch.core.JobExecutionException
Construct a JobExecutionException with a generic message.
JobExecutionException(String, Throwable) - Constructor for exception org.springframework.batch.core.JobExecutionException
Construct a JobExecutionException with a generic message and a cause.
JobExecutionListener - Interface in org.springframework.batch.core
Provide callbacks at specific points in the lifecycle of a Job.
JobExecutionListenerParser - Class in org.springframework.batch.core.configuration.xml
Parser for a step listener element.
JobExecutionListenerParser() - Constructor for class org.springframework.batch.core.configuration.xml.JobExecutionListenerParser
 
JobExecutionListenerSupport - Class in org.springframework.batch.core.listener
 
JobExecutionListenerSupport() - Constructor for class org.springframework.batch.core.listener.JobExecutionListenerSupport
 
JobExecutionNotFailedException - Exception in org.springframework.batch.core.launch
Checked exception to indicate that user asked for a job execution to be resumed when actually it didn't fail.
JobExecutionNotFailedException(String) - Constructor for exception org.springframework.batch.core.launch.JobExecutionNotFailedException
Create an exception with the given message.
JobExecutionNotFailedException(String, Throwable) - Constructor for exception org.springframework.batch.core.launch.JobExecutionNotFailedException
 
JobExecutionNotRunningException - Exception in org.springframework.batch.core.launch
Execution indicating that a JobExecution that is not currently running has been requested to stop.
JobExecutionNotRunningException(String) - Constructor for exception org.springframework.batch.core.launch.JobExecutionNotRunningException
Create a JobExecutionNotRunningException with a message.
JobExecutionNotStoppedException - Exception in org.springframework.batch.core.launch
Checked exception to indicate that user asked for a job execution to be aborted when hasn't been stopped.
JobExecutionNotStoppedException(String) - Constructor for exception org.springframework.batch.core.launch.JobExecutionNotStoppedException
Create an exception with the given message.
JobExplorer - Interface in org.springframework.batch.core.explore
Entry point for browsing executions of running or historical jobs and steps.
JobExplorerFactoryBean - Class in org.springframework.batch.core.explore.support
A FactoryBean that automates the creation of a SimpleJobExplorer using JDBC DAO implementations.
JobExplorerFactoryBean() - Constructor for class org.springframework.batch.core.explore.support.JobExplorerFactoryBean
 
JobFactory - Interface in org.springframework.batch.core.configuration
Strategy for creating a single job.
JobFactoryRegistrationListener - Class in org.springframework.batch.core.configuration.support
Generic service that can bind and unbind a JobFactory in a JobRegistry.
JobFactoryRegistrationListener() - Constructor for class org.springframework.batch.core.configuration.support.JobFactoryRegistrationListener
 
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 - it's identity is given by the pair Job and JobParameters.
JobInstance(Long, JobParameters, 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
 
JobLauncher - Interface in org.springframework.batch.core.launch
Simple interface for controlling jobs, including possible ad-hoc executions, based on different runtime identifiers.
JobLauncherTestUtils - Class in org.springframework.batch.test
Utility class for testing batch jobs.
JobLauncherTestUtils() - Constructor for class org.springframework.batch.test.JobLauncherTestUtils
 
JobListenerFactoryBean - Class in org.springframework.batch.core.listener
This AbstractListenerFactoryBean implementation is used to create a JobExecutionListener.
JobListenerFactoryBean() - Constructor for class org.springframework.batch.core.listener.JobListenerFactoryBean
 
JobListenerMetaData - Enum in org.springframework.batch.core.listener
Enumeration for JobExecutionListener meta data, which ties together the names of methods, their interfaces, annotation, and expected arguments.
JobLoader - Interface in org.springframework.batch.core.configuration.support
 
JobLocator - Interface in org.springframework.batch.core.configuration
A runtime service locator interface for retrieving job configurations by name.
JobOperator - Interface in org.springframework.batch.core.launch
Low level interface for inspecting and controlling jobs with access only to primitive and collection types.
JobParameter - Class in org.springframework.batch.core
Domain representation of a parameter to a batch job.
JobParameter(String) - 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
 
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 - 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
 
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.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 - Interface in org.springframework.batch.core.step.item
Interface for defining keys to uniquely identify items.

L

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
 
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.
LEFT - Static variable in class org.springframework.batch.item.file.transform.Alignment
 
LimitCheckingItemSkipPolicy - Class in org.springframework.batch.core.step.skip
SkipPolicy that determines whether or not reading should continue based upon how many items have been skipped.
LimitCheckingItemSkipPolicy() - Constructor for class org.springframework.batch.core.step.skip.LimitCheckingItemSkipPolicy
Convenience constructor that assumes all exception types are fatal.
LimitCheckingItemSkipPolicy(int, Map<Class<? extends Throwable>, Boolean>) - Constructor for class org.springframework.batch.core.step.skip.LimitCheckingItemSkipPolicy
 
LimitCheckingItemSkipPolicy(int, Classifier<Throwable, Boolean>) - Constructor for class org.springframework.batch.core.step.skip.LimitCheckingItemSkipPolicy
 
LineAggregator<T> - Interface in org.springframework.batch.item.file.transform
Interface used to create string representing object.
LineCallbackHandler - Interface in org.springframework.batch.item.file
Callback interface for handling a line from file.
LineMapper<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.
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.
log - Variable in class org.springframework.batch.item.database.AbstractCursorItemReader
Logger available to subclasses
logger - Static variable in class org.springframework.batch.core.job.AbstractJob
 
logger - 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 - Static variable in class org.springframework.batch.core.step.item.DefaultItemFailureHandler
 
logger - Variable in class org.springframework.batch.core.step.item.SimpleChunkProvider
 
logger - Variable in class org.springframework.batch.core.step.item.SimpleStepFactoryBean
 
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.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 - Variable in class org.springframework.batch.retry.support.RetryTemplate
 
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.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
 
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.
MapRetryContextCache - Class in org.springframework.batch.retry.policy
Map-based implementation of RetryContextCache.
MapRetryContextCache() - Constructor for class org.springframework.batch.retry.policy.MapRetryContextCache
Create a MapRetryContextCache with default capacity.
MapRetryContextCache(int) - Constructor for class org.springframework.batch.retry.policy.MapRetryContextCache
 
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
 
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
 
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
 
MethodArgumentsKeyGenerator - Interface in org.springframework.batch.retry.interceptor
Interface that allows method parameters to be identified and tagged by a unique key.
MethodInvocationRecoverer<T> - Interface in org.springframework.batch.retry.interceptor
Strategy interface for recovery action when processing of an item fails.
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.
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
 
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

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.
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.
NeverRetryPolicy - Class in org.springframework.batch.retry.policy
A RetryPolicy that allows the first attempt but never permits a retry.
NeverRetryPolicy() - Constructor for class org.springframework.batch.retry.policy.NeverRetryPolicy
 
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
 
NewMethodArgumentsIdentifier - Interface in org.springframework.batch.retry.interceptor
Strategy interface to distinguish new arguments from ones that have been processed before, e.g. by examining a message flag.
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
 
NoBackOffPolicy - Class in org.springframework.batch.retry.backoff
Implementation of BackOffPolicy that performs a no-op and as such all retry operation in a given set proceed one after the other with no pause.
NoBackOffPolicy() - Constructor for class org.springframework.batch.retry.backoff.NoBackOffPolicy
 
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.
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

ObjectWaitSleeper - Class in org.springframework.batch.retry.backoff
Simple Sleeper implementation that just waits on a local Object.
ObjectWaitSleeper() - Constructor for class org.springframework.batch.retry.backoff.ObjectWaitSleeper
 
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.
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(RetryContext, RetryCallback<T>, Throwable) - Method in class org.springframework.batch.retry.listener.RetryListenerSupport
 
onError(RetryContext, RetryCallback<T>, Throwable) - Method in interface org.springframework.batch.retry.RetryListener
Called after every unsuccessful attempt at a retry.
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.
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.
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<?
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.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(RetryContext, RetryCallback<T>) - Method in class org.springframework.batch.retry.listener.RetryListenerSupport
 
open(RetryContext) - Method in class org.springframework.batch.retry.policy.CompositeRetryPolicy
Creates a new context that copies the existing policies and keeps a list of the contexts from each one.
open(RetryContext) - Method in class org.springframework.batch.retry.policy.ExceptionClassifierRetryPolicy
Create an active context that proxies a retry policy by chosing a target from the policy map.
open(RetryContext) - Method in class org.springframework.batch.retry.policy.NeverRetryPolicy
Return a context that can respond to early termination requests, but does nothing else.
open(RetryContext) - Method in class org.springframework.batch.retry.policy.SimpleRetryPolicy
Get a status object that can be used to track the current operation according to this policy.
open(RetryContext) - Method in class org.springframework.batch.retry.policy.TimeoutRetryPolicy
 
open(RetryContext, RetryCallback<T>) - Method in interface org.springframework.batch.retry.RetryListener
Called before the first attempt in a retry.
open(RetryContext) - Method in interface org.springframework.batch.retry.RetryPolicy
Acquire resources needed for the retry operation.
open(RetryPolicy, RetryState) - Method in class org.springframework.batch.retry.support.RetryTemplate
Delegate to the RetryPolicy having checked in the cache for an existing value if the state is not null.
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
 
org.springframework.batch.classify - package org.springframework.batch.classify
 
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.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.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.scope.util - package org.springframework.batch.core.scope.util
 
org.springframework.batch.core.step - package org.springframework.batch.core.step
Specific implementations of step concerns.
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.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.retry - package org.springframework.batch.retry
Infrastructure implementations of retry concerns.
org.springframework.batch.retry.backoff - package org.springframework.batch.retry.backoff
Infrastructure implementations of retry backoff concerns.
org.springframework.batch.retry.context - package org.springframework.batch.retry.context
Infrastructure implementations of retry context concerns.
org.springframework.batch.retry.interceptor - package org.springframework.batch.retry.interceptor
Infrastructure implementations of retry aop concerns.
org.springframework.batch.retry.listener - package org.springframework.batch.retry.listener
Infrastructure implementations of retry interceptor concerns.
org.springframework.batch.retry.policy - package org.springframework.batch.retry.policy
Infrastructure implementations of retry policy concerns.
org.springframework.batch.retry.support - package org.springframework.batch.retry.support
Infrastructure implementations of retry support concerns.
org.springframework.batch.support - package org.springframework.batch.support
Infrastructure implementations of support concerns.
org.springframework.batch.support.annotation - package org.springframework.batch.support.annotation
 
org.springframework.batch.support.transaction - package org.springframework.batch.support.transaction
Infrastructure implementations of support transaction concerns.
org.springframework.batch.test - package org.springframework.batch.test
 
OsgiBundleXmlApplicationContextFactory - Class in org.springframework.batch.core.configuration.support
ApplicationContextFactory that can be used to load a context from an XML location in a bundle.
OsgiBundleXmlApplicationContextFactory() - Constructor for class org.springframework.batch.core.configuration.support.OsgiBundleXmlApplicationContextFactory
 

P

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.
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
 
Partitioner - Interface in org.springframework.batch.core.partition.support
Central strategy interface for creating input parameters for a partitioned step in the form of ExecutionContext instances.
PartitionHandler - Interface in org.springframework.batch.core.partition
Interface defining the responsibilities of controlling the execution of a partitioned StepExecution.
PartitionNameProvider - Interface in org.springframework.batch.core.partition.support
Optional interface for Partitioner implementations that need to use a custom naming scheme for partitions.
PartitionStep - Class in org.springframework.batch.core.partition.support
Implementation of Step which partitions the execution and spreads the load using a PartitionHandler.
PartitionStep() - Constructor for class org.springframework.batch.core.partition.support.PartitionStep
 
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
PatternMatchingClassifier<T> - Class in org.springframework.batch.classify
A Classifier that maps from String patterns with wildcards to a set of values of a given type.
PatternMatchingClassifier() - Constructor for class org.springframework.batch.classify.PatternMatchingClassifier
Default constructor.
PatternMatchingClassifier(Map<String, T>) - Constructor for class org.springframework.batch.classify.PatternMatchingClassifier
Create a classifier from the provided map.
PatternMatchingCompositeLineMapper<T> - Class in org.springframework.batch.item.file.mapping
A LineMapper implementation that stores a mapping of String patterns to delegate LineTokenizers as well as a mapping of String patterns to delegate FieldSetMappers.
PatternMatchingCompositeLineMapper() - Constructor for class org.springframework.batch.item.file.mapping.PatternMatchingCompositeLineMapper
 
PatternMatchingCompositeLineTokenizer - Class in org.springframework.batch.item.file.transform
A LineTokenizer implementation that stores a mapping of String patterns to delegate LineTokenizers.
PatternMatchingCompositeLineTokenizer() - Constructor for class org.springframework.batch.item.file.transform.PatternMatchingCompositeLineTokenizer
 
peek() - Method in interface org.springframework.batch.item.PeekableItemReader
Get the next item that would be returned by ItemReader.read(), without affecting the result of ItemReader.read().
peek() - Method in class org.springframework.batch.item.support.SingleItemPeekableItemReader
Peek at the next item, ensuring that if the delegate is an ItemStream the state is stored for the next call to SingleItemPeekableItemReader.update(ExecutionContext).
peek() - Method in class org.springframework.batch.item.xml.stax.DefaultFragmentEventReader
 
PeekableItemReader<T> - Interface in org.springframework.batch.item
A specialisation of ItemReader that allows the user to look ahead into the stream of items.
PlaceholderProxyFactoryBean - Class in org.springframework.batch.core.scope.util
Factory bean for proxies that can replace placeholders in their target.
PlaceholderProxyFactoryBean(ContextFactory) - Constructor for class org.springframework.batch.core.scope.util.PlaceholderProxyFactoryBean
Create a new FactoryBean instance.
PlaceholderTargetSource - Class in org.springframework.batch.core.scope.util
A TargetSource that lazily initializes its target, replacing bean definition properties dynamically if they are marked as placeholders.
PlaceholderTargetSource() - Constructor for class org.springframework.batch.core.scope.util.PlaceholderTargetSource
 
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. remove a suffix.
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(DefaultListableBeanFactory, DefaultListableBeanFactory) - Method in class org.springframework.batch.core.configuration.support.ClassPathXmlApplicationContextFactory
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.ClassPathXmlApplicationContextFactory
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.
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
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 (must be Serializable).
put(ResultHolder) - Method in class org.springframework.batch.repeat.support.ResultHolderResultQueue
 
put(T) - Method in class org.springframework.batch.repeat.support.ThrottleLimitResultQueue
 
put(Object, RetryContext) - Method in class org.springframework.batch.retry.policy.MapRetryContextCache
 
put(Object, RetryContext) - Method in interface org.springframework.batch.retry.policy.RetryContextCache
 
put(Object, RetryContext) - Method in class org.springframework.batch.retry.policy.SoftReferenceMapRetryContextCache
 
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.

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
Delegates to SimpleChunkProvider.doRead().
read() - Method in class org.springframework.batch.item.adapter.ItemReaderAdapter
 
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).
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.