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

A

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.
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
Base class for testing batch jobs.
AbstractJobTests() - Constructor for class org.springframework.batch.test.AbstractJobTests
 
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
 
AbstractListenerFactoryBean.NullIgnoringSet<E> - Class in org.springframework.batch.core.listener
 
AbstractListenerFactoryBean.NullIgnoringSet() - Constructor for class org.springframework.batch.core.listener.AbstractListenerFactoryBean.NullIgnoringSet
 
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
 
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.
AbstractStep.FatalException - Exception in org.springframework.batch.core.step
Signals a fatal exception - e.g. unable to persist batch metadata or rollback transaction.
AbstractStep.FatalException(String, Throwable) - Constructor for exception org.springframework.batch.core.step.AbstractStep.FatalException
 
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(E) - Method in class org.springframework.batch.core.listener.AbstractListenerFactoryBean.NullIgnoringSet
 
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.
addExitStatus(String) - Method in interface org.springframework.batch.core.job.flow.FlowExecutor
 
addFailureException(Throwable) - Method in class org.springframework.batch.core.JobExecution
Add the provided throwable to the failure exception list.
addFailureException(Throwable) - Method in class org.springframework.batch.core.StepExecution
 
ADDITIONAL_SHIPPING_INFO_COLUMN - Static variable in class org.springframework.batch.sample.domain.order.internal.mapper.ShippingFieldSetMapper
 
addLong(String, Long) - Method in class org.springframework.batch.core.JobParametersBuilder
Add a new Long parameter for the given key.
Address - Class in org.springframework.batch.sample.domain.order
 
Address() - Constructor for class org.springframework.batch.sample.domain.order.Address
 
ADDRESS_LINE1_COLUMN - Static variable in class org.springframework.batch.sample.domain.order.internal.mapper.AddressFieldSetMapper
 
ADDRESS_LINE2_COLUMN - Static variable in class org.springframework.batch.sample.domain.order.internal.mapper.AddressFieldSetMapper
 
ADDRESSEE_COLUMN - Static variable in class org.springframework.batch.sample.domain.order.internal.mapper.AddressFieldSetMapper
 
AddressFieldExtractor - Class in org.springframework.batch.sample.domain.order.internal.extractor
 
AddressFieldExtractor() - Constructor for class org.springframework.batch.sample.domain.order.internal.extractor.AddressFieldExtractor
 
AddressFieldSetMapper - Class in org.springframework.batch.sample.domain.order.internal.mapper
 
AddressFieldSetMapper() - Constructor for class org.springframework.batch.sample.domain.order.internal.mapper.AddressFieldSetMapper
 
addStep(Step) - Method in class org.springframework.batch.core.job.SimpleJob
Convenience method for adding a single step to the job.
addStepExecutions(List<StepExecution>) - Method in class org.springframework.batch.core.JobExecution
Setter for the 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.
after(RepeatContext, RepeatStatus) - Method in class org.springframework.batch.sample.domain.trade.internal.HibernateCreditDao
 
after(JoinPoint, StepExecution) - Method in class org.springframework.batch.sample.jmx.StepExecutionApplicationEventAdvice
 
AfterChunk - Annotation Type in org.springframework.batch.core.annotation
Marks a method to be called after a chunk is executed.
afterChunk() - Method in interface org.springframework.batch.core.ChunkListener
Callback after the chunk is executed, but inside 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.ClassPathXmlJobRegistry
 
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.explore.support.JobExplorerFactoryBean
 
afterPropertiesSet() - Method in class org.springframework.batch.core.job.AbstractJob
Assert mandatory properties: JobRepository.
afterPropertiesSet() - Method in class org.springframework.batch.core.job.flow.support.SimpleFlow
Locate start state and pre-populate data structures needed for execution.
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.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.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.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.HibernateItemWriter
Check mandatory properties - there must be a hibernateTemplate.
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.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.support.CompositeItemProcessor
 
afterPropertiesSet() - Method in class org.springframework.batch.item.validator.SpringValidator
 
afterPropertiesSet() - Method in class org.springframework.batch.item.validator.ValidatingItemProcessor
 
afterPropertiesSet() - Method in class org.springframework.batch.item.xml.StaxEventItemReader
Ensure that all required dependencies for the ItemReader to run are provided after all properties have been set.
afterPropertiesSet() - Method in class org.springframework.batch.item.xml.StaxEventItemWriter
 
afterPropertiesSet() - Method in class org.springframework.batch.repeat.exception.SimpleLimitExceptionHandler
Apply the provided properties to create a delegate handler.
afterPropertiesSet() - Method in class org.springframework.batch.sample.common.StagingItemListener
 
afterPropertiesSet() - Method in class org.springframework.batch.sample.common.StagingItemProcessor
 
afterPropertiesSet() - Method in class org.springframework.batch.sample.common.StagingItemReader
 
afterPropertiesSet() - Method in class org.springframework.batch.sample.domain.multiline.AggregateItemFieldSetMapper
Check mandatory properties (delegate).
afterPropertiesSet() - Method in class org.springframework.batch.sample.domain.trade.internal.HibernateAwareCustomerCreditItemWriter
 
afterPropertiesSet() - Method in class org.springframework.batch.sample.loopFlow.GeneratingTradeResettingListener
 
afterPropertiesSet() - Method in class org.springframework.batch.support.SystemPropertyInitializer
Sets the System property with the provided name and default value.
afterPropertiesSet() - Method in class org.springframework.batch.test.DataSourceInitializer
 
afterPropertiesSet() - Method in class org.springframework.batch.test.JobRepositoryTestUtils
 
afterPropertiesSet() - Method in class test.jdbc.datasource.DataSourceInitializer
 
AfterRead - Annotation Type in org.springframework.batch.core.annotation
Marks a method to be called after an item is read from an ItemReader

Expected signature: void afterRead(T item)
afterRead(T) - Method in interface org.springframework.batch.core.ItemReadListener
Called after ItemReader.read()
afterRead(T) - Method in class org.springframework.batch.core.listener.CompositeItemReadListener
Call the registered listeners in reverse order, respecting and prioritising those that implement Ordered.
afterRead(I) - Method in class org.springframework.batch.core.listener.ItemListenerSupport
 
afterRead(T) - Method in class org.springframework.batch.core.listener.MulticasterBatchListener
 
afterRead(T) - Method in class org.springframework.batch.core.listener.StepListenerSupport
 
afterRead(Long) - Method in class org.springframework.batch.sample.common.StagingItemListener
 
AfterStep - Annotation Type in org.springframework.batch.core.annotation
Marks a method to be called after a Step has completed.
afterStep(StepExecution) - Method in class org.springframework.batch.core.listener.CompositeStepExecutionListener
Call the registered listeners in reverse order, respecting and 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.
afterStep(StepExecution) - Method in class org.springframework.batch.sample.common.StagingItemReader
 
afterStep(StepExecution) - Method in class org.springframework.batch.sample.common.StagingItemWriter
 
afterStep(StepExecution) - Method in class org.springframework.batch.sample.loopFlow.GeneratingTradeResettingListener
 
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.StepExecutionAggregator
Take the inputs and aggregate certain fields, putting the aggregates into the result.
aggregate(T) - Method in class org.springframework.batch.item.file.transform.ExtractorLineAggregator
Extract fields from the given item using the FieldExtractor and then aggregate them.
aggregate(T) - Method in interface org.springframework.batch.item.file.transform.LineAggregator
Create a string from the value provided.
aggregate(T) - Method in class org.springframework.batch.item.file.transform.PassThroughLineAggregator
Simply convert to a String with toString().
aggregate(Collection<T>) - Method in class org.springframework.batch.item.file.transform.RecursiveCollectionLineAggregator
 
aggregate(Order) - Method in class org.springframework.batch.sample.domain.order.internal.OrderLineAggregator
 
AggregateItem<T> - Class in org.springframework.batch.sample.domain.multiline
A wrapper type for an item that is used by AggregateItemReader to identify the start and end of an aggregate record.
AggregateItem(T) - Constructor for class org.springframework.batch.sample.domain.multiline.AggregateItem
 
AggregateItem(boolean, boolean) - Constructor for class org.springframework.batch.sample.domain.multiline.AggregateItem
 
AggregateItemFieldSetMapper<T> - Class in org.springframework.batch.sample.domain.multiline
Delegating mapper to convert form a vanilla FieldSetMapper to one that returns AggregateItem instances for consumption by the AggregateItemReader.
AggregateItemFieldSetMapper() - Constructor for class org.springframework.batch.sample.domain.multiline.AggregateItemFieldSetMapper
 
AggregateItemReader<T> - Class in org.springframework.batch.sample.domain.multiline
An ItemReader that delivers a list as its item, storing up objects from the injected ItemReader until they are ready to be packed out as a collection.
AggregateItemReader() - Constructor for class org.springframework.batch.sample.domain.multiline.AggregateItemReader
 
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 from a path supplied, and pulls a bean out when asked to create a Job.
ApplicationContextJobFactory(ApplicationContextFactory, String) - 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
 
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
 
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.
before(RepeatContext) - Method in class org.springframework.batch.sample.domain.trade.internal.HibernateCreditDao
 
before(JoinPoint, StepExecution) - Method in class org.springframework.batch.sample.jmx.StepExecutionApplicationEventAdvice
 
BeforeChunk - Annotation Type in org.springframework.batch.core.annotation
Marks a method to be called before a chunk is executed.
beforeChunk() - 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.
beforeStep(StepExecution) - Method in class org.springframework.batch.sample.common.InfiniteLoopWriter
 
beforeStep(StepExecution) - Method in class org.springframework.batch.sample.common.StagingItemReader
 
beforeStep(StepExecution) - Method in class org.springframework.batch.sample.common.StagingItemWriter
 
beforeStep(StepExecution) - Method in class org.springframework.batch.sample.domain.trade.CompositeCustomerUpdateLineTokenizer
 
beforeStep(StepExecution) - Method in class org.springframework.batch.sample.support.SummaryFooterCallback
 
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.
BillingFieldSetMapper - Class in org.springframework.batch.sample.domain.order.internal.mapper
 
BillingFieldSetMapper() - Constructor for class org.springframework.batch.sample.domain.order.internal.mapper.BillingFieldSetMapper
 
BillingInfo - Class in org.springframework.batch.sample.domain.order
 
BillingInfo() - Constructor for class org.springframework.batch.sample.domain.order.BillingInfo
 
BillingInfoFieldExtractor - Class in org.springframework.batch.sample.domain.order.internal.extractor
 
BillingInfoFieldExtractor() - Constructor for class org.springframework.batch.sample.domain.order.internal.extractor.BillingInfoFieldExtractor
 
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() - Constructor for class org.springframework.batch.classify.BinaryExceptionClassifier
Create a binary exception classifier with the default value (false).
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.
bind(JobFactory, Map<String, ?>) - Method in class org.springframework.batch.core.configuration.support.JobFactoryRegistrationListener
Take the JobFactory provided and register it with the JobRegistry.
BindingException - Exception in org.springframework.batch.item.file.mapping
 
BindingException(String) - Constructor for exception org.springframework.batch.item.file.mapping.BindingException
 

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.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.
Child - Class in org.springframework.batch.sample.domain.person
 
Child() - Constructor for class org.springframework.batch.sample.domain.person.Child
 
Chunk<W> - Class in org.springframework.batch.core.step.item
Encapsulation of a list of items to be processed and possibly a list of failed items to be skipped.
Chunk() - Constructor for class org.springframework.batch.core.step.item.Chunk
 
Chunk(Collection<? extends W>) - Constructor for class org.springframework.batch.core.step.item.Chunk
 
Chunk(Collection<? extends W>, List<SkipWrapper<W>>) - Constructor for class org.springframework.batch.core.step.item.Chunk
 
Chunk.ChunkIterator - Class in org.springframework.batch.core.step.item
Special iterator for a chunk providing the Chunk.ChunkIterator.remove(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
 
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
CITY_COLUMN - Static variable in class org.springframework.batch.sample.domain.order.internal.mapper.AddressFieldSetMapper
 
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
 
ClassPathXmlJobRegistry - Class in org.springframework.batch.core.configuration.support
Implementation of the ListableJobRegistry interface that assumes all Jobs will be loaded from ClassPathXml resources.
ClassPathXmlJobRegistry() - Constructor for class org.springframework.batch.core.configuration.support.ClassPathXmlJobRegistry
 
clear() - Static method in class org.springframework.batch.core.repository.dao.MapExecutionContextDao
 
clear() - Static method in class org.springframework.batch.core.repository.dao.MapJobExecutionDao
 
clear() - Static method in class org.springframework.batch.core.repository.dao.MapJobInstanceDao
 
clear() - Static method in class org.springframework.batch.core.repository.dao.MapStepExecutionDao
 
clear() - Static 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() - 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() - 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.file.FlatFileItemWriter
 
close() - Method in class org.springframework.batch.item.file.MultiResourceItemReader
Close the MultiResourceItemReader.setDelegate(ResourceAwareItemReaderItemStream) reader and reset instance variable values.
close() - Method in class org.springframework.batch.item.file.MultiResourceItemWriter
 
close() - Method in interface org.springframework.batch.item.ItemStream
If any resources are needed for the stream to operate they need to be destroyed here.
close() - Method in class org.springframework.batch.item.ItemStreamSupport
No-op.
close() - Method in class org.springframework.batch.item.support.AbstractItemCountingItemStreamItemReader
 
close() - Method in class org.springframework.batch.item.support.CompositeItemStream
Broadcast the call to close.
close() - Method in class org.springframework.batch.item.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.sample.domain.trade.internal.FlatFileCustomerCreditDao
 
close(RepeatContext) - Method in class org.springframework.batch.sample.domain.trade.internal.HibernateCreditDao
 
close() - Method in class org.springframework.batch.sample.domain.trade.internal.IbatisCustomerCreditDao
 
close() - Method in class org.springframework.batch.support.transaction.TransactionAwareBufferedWriter
 
ColumnMapItemPreparedStatementSetter - Class in org.springframework.batch.item.database.support
Implementation of the ItemPreparedStatementSetter interface that assumes all keys are contained within a Map with the column name as the key.
ColumnMapItemPreparedStatementSetter() - Constructor for class org.springframework.batch.item.database.support.ColumnMapItemPreparedStatementSetter
 
CommandLineJobRunner - Class in org.springframework.batch.core.launch.support
Basic launcher for starting jobs from the command line.
CommandLineJobRunner() - Constructor for class org.springframework.batch.core.launch.support.CommandLineJobRunner
 
commit(T, T) - Method in class org.springframework.batch.support.transaction.TransactionAwareProxyFactory
Take the working copy state and commit it back to the original target.
CommonsLoggingInvalidCustomerLogger - Class in org.springframework.batch.sample.domain.trade.internal
 
CommonsLoggingInvalidCustomerLogger() - Constructor for class org.springframework.batch.sample.domain.trade.internal.CommonsLoggingInvalidCustomerLogger
 
COMPANY_NAME_COLUMN - Static variable in class org.springframework.batch.sample.domain.order.internal.mapper.CustomerFieldSetMapper
 
compare(Resource, Resource) - Method in class org.springframework.batch.support.LastModifiedResourceComparator
Compare the two resources by last modified time, so that a sorted list of resources will have oldest first.
compareTo(ExitStatus) - Method in class org.springframework.batch.core.ExitStatus
 
compareTo(FlowExecution) - Method in class org.springframework.batch.core.job.flow.FlowExecution
Create an ordering on FlowExecution instances by comparing their statuses.
compareTo(FlowExecutionStatus) - Method in class org.springframework.batch.core.job.flow.FlowExecutionStatus
Create an ordering on FlowExecutionStatus instances by comparing their statuses.
compareTo(StateTransition) - Method in class org.springframework.batch.core.job.flow.support.StateTransition
Sorts by decreasing specificity of pattern, based on just counting wildcards (with * taking precedence over ?).
COMPLETED - Static variable in class org.springframework.batch.core.ExitStatus
Convenient constant value representing finished processing.
COMPLETED - Static variable in class org.springframework.batch.core.job.flow.FlowExecutionStatus
Special well-known status value.
CompletionPolicy - Interface in org.springframework.batch.repeat
Interface for batch completion policies, to enable batch operations to strategise normal completion conditions.
CompletionPolicySupport - Class in org.springframework.batch.repeat.policy
Very simple base class for CompletionPolicy implementations.
CompletionPolicySupport() - Constructor for class org.springframework.batch.repeat.policy.CompletionPolicySupport
 
CompositeChunkListener - Class in org.springframework.batch.core.listener
 
CompositeChunkListener() - Constructor for class org.springframework.batch.core.listener.CompositeChunkListener
 
CompositeCompletionPolicy - Class in org.springframework.batch.repeat.policy
Composite policy that loops through a list of delegate policies and answers calls by a concensus.
CompositeCompletionPolicy() - Constructor for class org.springframework.batch.repeat.policy.CompositeCompletionPolicy
 
CompositeCompletionPolicy.CompositeBatchContext - Class in org.springframework.batch.repeat.policy
Composite context that knows about the policies and contexts is was created with.
CompositeCompletionPolicy.CompositeBatchContext(RepeatContext, List<RepeatContext>) - Constructor for class org.springframework.batch.repeat.policy.CompositeCompletionPolicy.CompositeBatchContext
 
CompositeCustomerUpdateLineTokenizer - Class in org.springframework.batch.sample.domain.trade
Composite LineTokenizer that delegates the tokenization of a line to one of two potential tokenizers.
CompositeCustomerUpdateLineTokenizer() - Constructor for class org.springframework.batch.sample.domain.trade.CompositeCustomerUpdateLineTokenizer
 
CompositeExceptionHandler - Class in org.springframework.batch.repeat.exception
Composiste ExceptionHandler that loops though a list of delegates.
CompositeExceptionHandler() - Constructor for class org.springframework.batch.repeat.exception.CompositeExceptionHandler
 
CompositeItemProcessListener<T,S> - Class in org.springframework.batch.core.listener
 
CompositeItemProcessListener() - Constructor for class org.springframework.batch.core.listener.CompositeItemProcessListener
 
CompositeItemProcessor<I,O> - Class in org.springframework.batch.item.support
Composite ItemProcessor that passes the item through a sequence of injected ItemTransformers (return value of previous transformation is the entry value of the next).
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
 
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
 
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.
COUNTRY_COLUMN - Static variable in class org.springframework.batch.sample.domain.order.internal.mapper.AddressFieldSetMapper
 
create(String[], String[]) - Method in class org.springframework.batch.item.file.transform.DefaultFieldSetFactory
create(String[]) - Method in class org.springframework.batch.item.file.transform.DefaultFieldSetFactory
create(String[], String[]) - Method in interface org.springframework.batch.item.file.transform.FieldSetFactory
 
create(String[]) - Method in interface org.springframework.batch.item.file.transform.FieldSetFactory
 
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
 
createInstance() - Method in class test.jdbc.datasource.DerbyDataSourceFactoryBean
 
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
 
CreateOutputNameFromInput(StepExecution) - Method in class org.springframework.batch.sample.common.OutputFileListener
 
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.
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).
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.
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
 
CREDIT_COLUMN - Static variable in class org.springframework.batch.sample.domain.trade.internal.CustomerCreditFieldSetMapper
 
CREDIT_COLUMN - Static variable in class org.springframework.batch.sample.domain.trade.internal.CustomerCreditRowMapper
 
current - Variable in class org.springframework.batch.item.database.AbstractPagingItemReader
 
Customer - Class in org.springframework.batch.sample.domain.order
 
Customer() - Constructor for class org.springframework.batch.sample.domain.order.Customer
 
Customer - Class in org.springframework.batch.sample.domain.order.internal.xml
An XML customer.
Customer() - Constructor for class org.springframework.batch.sample.domain.order.internal.xml.Customer
 
CUSTOMER_COLUMN - Static variable in class org.springframework.batch.sample.domain.trade.internal.CustomerDebitRowMapper
 
CUSTOMER_COLUMN - Static variable in class org.springframework.batch.sample.domain.trade.internal.TradeFieldSetMapper
 
CUSTOMER_COLUMN - Static variable in class org.springframework.batch.sample.domain.trade.internal.TradeRowMapper
 
CustomerCredit - Class in org.springframework.batch.sample.domain.trade
 
CustomerCredit() - Constructor for class org.springframework.batch.sample.domain.trade.CustomerCredit
 
CustomerCredit(int, String, BigDecimal) - Constructor for class org.springframework.batch.sample.domain.trade.CustomerCredit
 
CustomerCreditDao - Interface in org.springframework.batch.sample.domain.trade
Interface for writing customer's credit information to output.
CustomerCreditFieldSetMapper - Class in org.springframework.batch.sample.domain.trade.internal
 
CustomerCreditFieldSetMapper() - Constructor for class org.springframework.batch.sample.domain.trade.internal.CustomerCreditFieldSetMapper
 
CustomerCreditIncreaseProcessor - Class in org.springframework.batch.sample.domain.trade.internal
Increases customer's credit by a fixed amount.
CustomerCreditIncreaseProcessor() - Constructor for class org.springframework.batch.sample.domain.trade.internal.CustomerCreditIncreaseProcessor
 
CustomerCreditItemWriter - Class in org.springframework.batch.sample.domain.trade.internal
Delegates actual writing to a custom DAO.
CustomerCreditItemWriter() - Constructor for class org.springframework.batch.sample.domain.trade.internal.CustomerCreditItemWriter
 
CustomerCreditRowMapper - Class in org.springframework.batch.sample.domain.trade.internal
 
CustomerCreditRowMapper() - Constructor for class org.springframework.batch.sample.domain.trade.internal.CustomerCreditRowMapper
 
CustomerCreditUpdatePreparedStatementSetter - Class in org.springframework.batch.sample.domain.trade.internal
 
CustomerCreditUpdatePreparedStatementSetter() - Constructor for class org.springframework.batch.sample.domain.trade.internal.CustomerCreditUpdatePreparedStatementSetter
 
CustomerCreditUpdateWriter - Class in org.springframework.batch.sample.domain.trade.internal
 
CustomerCreditUpdateWriter() - Constructor for class org.springframework.batch.sample.domain.trade.internal.CustomerCreditUpdateWriter
 
CustomerDao - Interface in org.springframework.batch.sample.domain.trade
 
CustomerDebit - Class in org.springframework.batch.sample.domain.trade
 
CustomerDebit() - Constructor for class org.springframework.batch.sample.domain.trade.CustomerDebit
 
CustomerDebitDao - Interface in org.springframework.batch.sample.domain.trade
Interface for writing CustomerDebitDao object to arbitrary output.
CustomerDebitRowMapper - Class in org.springframework.batch.sample.domain.trade.internal
 
CustomerDebitRowMapper() - Constructor for class org.springframework.batch.sample.domain.trade.internal.CustomerDebitRowMapper
 
CustomerFieldExtractor - Class in org.springframework.batch.sample.domain.order.internal.extractor
 
CustomerFieldExtractor() - Constructor for class org.springframework.batch.sample.domain.order.internal.extractor.CustomerFieldExtractor
 
CustomerFieldSetMapper - Class in org.springframework.batch.sample.domain.order.internal.mapper
 
CustomerFieldSetMapper() - Constructor for class org.springframework.batch.sample.domain.order.internal.mapper.CustomerFieldSetMapper
 
CustomerOperation - Enum in org.springframework.batch.sample.domain.trade
Enum representing on of 3 possible actions on a customer update: Add, update, or delete
CustomerUpdate - Class in org.springframework.batch.sample.domain.trade
Immutable Value Object representing an update to the customer as stored in the database.
CustomerUpdate(CustomerOperation, String, BigDecimal) - Constructor for class org.springframework.batch.sample.domain.trade.CustomerUpdate
 
CustomerUpdateFieldSetMapper - Class in org.springframework.batch.sample.domain.trade
FieldSetMapper for mapping to a CustomerUpdate.
CustomerUpdateFieldSetMapper() - Constructor for class org.springframework.batch.sample.domain.trade.CustomerUpdateFieldSetMapper
 
CustomerUpdateProcessor - Class in org.springframework.batch.sample.domain.trade
 
CustomerUpdateProcessor() - Constructor for class org.springframework.batch.sample.domain.trade.CustomerUpdateProcessor
 
CustomerUpdateWriter - Class in org.springframework.batch.sample.domain.trade
 
CustomerUpdateWriter() - Constructor for class org.springframework.batch.sample.domain.trade.CustomerUpdateWriter
 
CustomerUpdateWriter - Class in org.springframework.batch.sample.domain.trade.internal
Transforms Trade to a CustomerDebit and asks DAO delegate to write the result.
CustomerUpdateWriter() - Constructor for class org.springframework.batch.sample.domain.trade.internal.CustomerUpdateWriter
 

D

DatabaseType - Enum in org.springframework.batch.support
Enum representing a database type, such as DB2 or oracle.
DataFieldMaxValueIncrementerFactory - Interface in org.springframework.batch.item.database.support
Factory for creating DataFieldMaxValueIncrementer implementations based upon a provided string.
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
 
DataSourceInitializer - Class in test.jdbc.datasource
Wrapper for a DataSource that can run scripts on start up and shut down.
DataSourceInitializer() - Constructor for class test.jdbc.datasource.DataSourceInitializer
 
DATE_TYPE - Static variable in class org.springframework.batch.core.converter.DefaultJobParametersConverter
 
Db2PagingQueryProvider - Class in org.springframework.batch.item.database.support
DB2 implementation of a PagingQueryProvider using database specific features.
Db2PagingQueryProvider() - Constructor for class org.springframework.batch.item.database.support.Db2PagingQueryProvider
 
decide(JobExecution, StepExecution) - Method in interface org.springframework.batch.core.job.flow.JobExecutionDecider
Strategy for branching an execution based on the state of an ongoing JobExecution.
decide(JobExecution, StepExecution) - Method in class org.springframework.batch.sample.loopFlow.LimitDecider
 
DecisionParser - Class in org.springframework.batch.core.configuration.xml
Internal parser for the <decision/> elements inside a job.
DecisionParser() - Constructor for class org.springframework.batch.core.configuration.xml.DecisionParser
 
DecisionState - Class in org.springframework.batch.core.job.flow.support.state
State that requires a decider to make the status decision.
DecisionState(JobExecutionDecider, String) - Constructor for class org.springframework.batch.core.job.flow.support.state.DecisionState
 
DEFAULT_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_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_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_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).
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
 
DefaultFieldSet(String[], String[]) - Constructor for class org.springframework.batch.item.file.transform.DefaultFieldSet
 
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.sample.launch
 
DefaultJobLoader() - Constructor for class org.springframework.batch.sample.launch.DefaultJobLoader
 
DefaultJobParametersConverter - Class in org.springframework.batch.core.converter
Converter for JobParameters instances using a simple naming convention for property keys.
DefaultJobParametersConverter() - Constructor for class org.springframework.batch.core.converter.DefaultJobParametersConverter
 
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
 
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).
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.
DerbyDataSourceFactoryBean - Class in test.jdbc.datasource
 
DerbyDataSourceFactoryBean() - Constructor for class test.jdbc.datasource.DerbyDataSourceFactoryBean
 
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
 
destroy() - Method in class org.springframework.batch.core.configuration.support.JobRegistryBeanPostProcessor
De-register all the Job instances that were regsistered by this post processor.
destroy() - Method in class org.springframework.batch.sample.common.StagingItemReader
 
destroy() - Method in class org.springframework.batch.sample.domain.trade.internal.FlatFileCustomerCreditDao
 
destroy() - Method in class org.springframework.batch.test.DataSourceInitializer
 
destroy() - Method in class test.jdbc.datasource.DataSourceInitializer
 
DISCOUNT_AMOUNT_COLUMN - Static variable in class org.springframework.batch.sample.domain.order.internal.mapper.OrderItemFieldSetMapper
 
DISCOUNT_PERC_COLUMN - Static variable in class org.springframework.batch.sample.domain.order.internal.mapper.OrderItemFieldSetMapper
 
doAfterWrite(List<O>) - Method in class org.springframework.batch.core.step.item.SimpleChunkProcessor
Call the listener's after write method.
doAggregate(Object[]) - Method in class org.springframework.batch.item.file.transform.DelimitedLineAggregator
 
doAggregate(Object[]) - Method in class org.springframework.batch.item.file.transform.ExtractorLineAggregator
Aggregate provided fields into single String.
doAggregate(Object[]) - Method in class org.springframework.batch.item.file.transform.FormatterLineAggregator
 
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.
doBasicLogging(JoinPoint) - Method in class org.springframework.batch.sample.common.LogAdvice
 
doBegin(Object, TransactionDefinition) - Method in class org.springframework.batch.support.transaction.ResourcelessTransactionManager
 
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.JdbcCursorItemReader
Close the cursor and database connection.
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(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.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.
doGetResult(Object) - Method in class org.springframework.batch.sample.domain.order.internal.valang.FutureDateFunction
 
doGetResult(Object) - Method in class org.springframework.batch.sample.domain.order.internal.valang.TotalOrderItemsFunction
 
doGetResult(Object) - Method in class org.springframework.batch.sample.domain.order.internal.valang.ValidateDiscountsFunction
 
doGetResult(Object) - Method in class org.springframework.batch.sample.domain.order.internal.valang.ValidateHandlingPricesFunction
 
doGetResult(Object) - Method in class org.springframework.batch.sample.domain.order.internal.valang.ValidateIdsFunction
 
doGetResult(Object) - Method in class org.springframework.batch.sample.domain.order.internal.valang.ValidatePricesFunction
 
doGetResult(Object) - Method in class org.springframework.batch.sample.domain.order.internal.valang.ValidateQuantitiesFunction
 
doGetResult(Object) - Method in class org.springframework.batch.sample.domain.order.internal.valang.ValidateShippingPricesFunction
 
doGetResult(Object) - Method in class org.springframework.batch.sample.domain.order.internal.valang.ValidateTotalPricesFunction
 
doGetTransaction() - Method in class org.springframework.batch.support.transaction.ResourcelessTransactionManager
 
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.
doJumpToPage(int) - Method in class org.springframework.batch.item.database.AbstractPagingItemReader
 
doJumpToPage(int) - Method in class org.springframework.batch.item.database.IbatisPagingItemReader
 
doJumpToPage(int) - Method in class org.springframework.batch.item.database.JdbcPagingItemReader
 
doJumpToPage(int) - Method in class org.springframework.batch.item.database.JpaPagingItemReader
 
DONE - Static variable in class org.springframework.batch.sample.common.StagingItemWriter
 
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 HibernateCursorItemReader.setQueryString(String).
doOpen() - Method in class org.springframework.batch.item.database.JdbcCursorItemReader
Execute the JdbcCursorItemReader.setSql(String) query.
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.AbstractListenerParser
 
doParse(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.batch.core.configuration.xml.FlowParser
 
doParse(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.batch.core.configuration.xml.JobParser
Create a bean definition for a FlowJob.
doParse(Element, 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.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.AbstractPagingItemReader
 
doRead() - Method in class org.springframework.batch.item.database.HibernateCursorItemReader
 
doRead() - Method in class org.springframework.batch.item.database.JdbcCursorItemReader
Read next row and map it to item, verify cursor position if JdbcCursorItemReader.setVerifyCursorPosition(boolean) is true.
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.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
 
doStronglyTypedLogging(Object) - Method in class org.springframework.batch.sample.common.LogAdvice
 
doTokenize(String) - Method in class org.springframework.batch.item.file.transform.AbstractLineTokenizer
 
doTokenize(String) - Method in class org.springframework.batch.item.file.transform.DelimitedLineTokenizer
Yields the tokens resulting from the splitting of the supplied line.
doTokenize(String) - Method in class org.springframework.batch.item.file.transform.FixedLengthTokenizer
Yields the tokens resulting from the splitting of the supplied line.
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.
DummyItemWriter - Class in org.springframework.batch.sample.support
 
DummyItemWriter() - Constructor for class org.springframework.batch.sample.support.DummyItemWriter
 
DuplicateJobException - Exception in org.springframework.batch.core.configuration
Checked exception that indicates a name clash when registering Job instances.
DuplicateJobException(String) - Constructor for exception org.springframework.batch.core.configuration.DuplicateJobException
Create an exception with the given message.
DuplicateJobException(String, Throwable) - Constructor for exception org.springframework.batch.core.configuration.DuplicateJobException
 
DynamicMethodInvocationException - Exception in org.springframework.batch.item.adapter
Indicates an error has been encountered while trying to dynamically call 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.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.sample.domain.football.Game
 
equals(Object) - Method in class org.springframework.batch.sample.domain.football.PlayerSummary
 
equals(Object) - Method in class org.springframework.batch.sample.domain.order.Address
 
equals(Object) - Method in class org.springframework.batch.sample.domain.order.BillingInfo
 
equals(Object) - Method in class org.springframework.batch.sample.domain.order.Customer
 
equals(Object) - Method in class org.springframework.batch.sample.domain.order.LineItem
 
equals(Object) - Method in class org.springframework.batch.sample.domain.order.Order
 
equals(Object) - Method in class org.springframework.batch.sample.domain.order.ShippingInfo
 
equals(Object) - Method in class org.springframework.batch.sample.domain.person.Child
 
equals(Object) - Method in class org.springframework.batch.sample.domain.person.Person
 
equals(Object) - Method in class org.springframework.batch.sample.domain.trade.CustomerCredit
 
equals(Object) - Method in class org.springframework.batch.sample.domain.trade.CustomerDebit
 
equals(Object) - Method in class org.springframework.batch.sample.domain.trade.Trade
 
equals(Object) - Method in class org.springframework.batch.support.SimpleMethodInvoker
 
example - package example
 
ExampleItemReader - Class in example
ItemReader with hard-coded input data.
ExampleItemReader() - Constructor for class example.ExampleItemReader
 
ExampleItemWriter - Class in example
Dummy ItemWriter which only logs data it receives.
ExampleItemWriter() - Constructor for class example.ExampleItemWriter
 
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
 
ExceptionHandler - Interface in org.springframework.batch.repeat.exception
Handler to allow strategies for re-throwing exceptions.
ExceptionThrowingItemReaderProxy<T> - Class in org.springframework.batch.sample.support
Hacked ItemReader that throws exception on a given record number (useful for testing restart).
ExceptionThrowingItemReaderProxy() - Constructor for class org.springframework.batch.sample.support.ExceptionThrowingItemReaderProxy
 
execute(JobExecution) - Method in class org.springframework.batch.core.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.
executeInternal(JobExecutionContext) - Method in class org.springframework.batch.sample.quartz.JobLauncherDetails
 
executeStep(Step) - Method in interface org.springframework.batch.core.job.flow.FlowExecutor
 
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.
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
 
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.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
 
ExportedJobLoader - Interface in org.springframework.batch.sample.launch
 
ExtendedConnectionDataSourceProxy - Class in org.springframework.batch.item.database
Implementation of SmartDataSource that is capable of keeping a single JDBC Connection which is NOT closed after each use even if Connection.close() is called.
ExtendedConnectionDataSourceProxy() - Constructor for class org.springframework.batch.item.database.ExtendedConnectionDataSourceProxy
No arg constructor for use when configured using JavaBean style.
ExtendedConnectionDataSourceProxy(DataSource) - Constructor for class org.springframework.batch.item.database.ExtendedConnectionDataSourceProxy
Constructor that takes as a parameter with the {&link DataSource} to be wrapped.
extract(T) - Method in class org.springframework.batch.item.file.transform.BeanWrapperFieldExtractor
 
extract(T) - Method in interface org.springframework.batch.item.file.transform.FieldExtractor
 
extract(T) - Method in class org.springframework.batch.item.file.transform.PassThroughFieldExtractor
Get an array of fields as close as possible to the input.
extract(Order) - Method in class org.springframework.batch.sample.domain.order.internal.extractor.AddressFieldExtractor
 
extract(Order) - Method in class org.springframework.batch.sample.domain.order.internal.extractor.BillingInfoFieldExtractor
 
extract(Order) - Method in class org.springframework.batch.sample.domain.order.internal.extractor.CustomerFieldExtractor
 
extract(Order) - Method in class org.springframework.batch.sample.domain.order.internal.extractor.FooterFieldExtractor
 
extract(Order) - Method in class org.springframework.batch.sample.domain.order.internal.extractor.HeaderFieldExtractor
 
extract(LineItem) - Method in class org.springframework.batch.sample.domain.order.internal.extractor.LineItemFieldExtractor
 
ExtractorLineAggregator<T> - Class in org.springframework.batch.item.file.transform
An abstract LineAggregator implementation that utilizes a FieldExtractor to convert the incoming object to an array of its parts.
ExtractorLineAggregator() - Constructor for class org.springframework.batch.item.file.transform.ExtractorLineAggregator
 

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.
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.
FieldSetResultSetExtractor - Class in org.springframework.batch.sample.common
ResultSetExtractor implementation that returns list of FieldSets for given ResultSet.
FileUtils - Class in org.springframework.batch.item.util
Utility methods for files used in batch processing.
finalize() - Method in class test.jdbc.datasource.DataSourceInitializer
 
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
 
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
 
findRunningJobExecutions(String) - Method in class org.springframework.batch.core.explore.support.SimpleJobExplorer
 
findRunningJobExecutions(String) - Method in class org.springframework.batch.core.repository.dao.JdbcJobExecutionDao
 
findRunningJobExecutions(String) - Method in interface org.springframework.batch.core.repository.dao.JobExecutionDao
 
findRunningJobExecutions(String) - Method in class org.springframework.batch.core.repository.dao.MapJobExecutionDao
 
FIRST_NAME_COLUMN - Static variable in class org.springframework.batch.sample.domain.order.internal.mapper.CustomerFieldSetMapper
 
FIXED_AMOUNT - Static variable in class org.springframework.batch.sample.domain.trade.internal.CustomerCreditIncreaseProcessor
 
FIXED_AMOUNT - Static variable in class org.springframework.batch.sample.domain.trade.internal.CustomerCreditUpdatePreparedStatementSetter
 
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
 
FlatFileCustomerCreditDao - Class in org.springframework.batch.sample.domain.trade.internal
Writes customer's credit information in a file.
FlatFileCustomerCreditDao() - Constructor for class org.springframework.batch.sample.domain.trade.internal.FlatFileCustomerCreditDao
 
FlatFileFooterCallback - Interface in org.springframework.batch.item.file
Callback interface for writing a footer to a file.
FlatFileFormatException - Exception in org.springframework.batch.item.file.transform
Exception indicating that some type of error has occured while attempting to parse a line of input into tokens.
FlatFileFormatException(String) - 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
 
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
This class is used as a holder for a BatchStatus/ExitStatus pair.
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.
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).
FlowParser - Class in org.springframework.batch.core.configuration.xml
 
FlowParser(String, String) - Constructor for class org.springframework.batch.core.configuration.xml.FlowParser
Construct a FlowParser with the specified name and using the provided job repository ref.
flush() - Method in class org.springframework.batch.support.transaction.TransactionAwareBufferedWriter
 
FlushFailedException - Exception in org.springframework.batch.support.transaction
Unchecked exception indicating that an error has occurred while trying to flush a buffer.
FlushFailedException(String, Throwable) - Constructor for exception org.springframework.batch.support.transaction.FlushFailedException
Create a new FlushFailedException based on a message and another exception.
FlushFailedException(String) - Constructor for exception org.springframework.batch.support.transaction.FlushFailedException
Create a new FlushFailedException based on a message.
FootballExceptionHandler - Class in org.springframework.batch.sample.domain.football.internal
 
FootballExceptionHandler() - Constructor for class org.springframework.batch.sample.domain.football.internal.FootballExceptionHandler
 
FooterFieldExtractor - Class in org.springframework.batch.sample.domain.order.internal.extractor
 
FooterFieldExtractor() - Constructor for class org.springframework.batch.sample.domain.order.internal.extractor.FooterFieldExtractor
 
ForceRollbackForWriteSkipException - Exception in org.springframework.batch.core.step.item
Fatal exception to be thrown when a rollback must be forced, typically after catching an exception that otherwise would not cause a rollback.
ForceRollbackForWriteSkipException(String, Throwable) - Constructor for exception org.springframework.batch.core.step.item.ForceRollbackForWriteSkipException
 
FormatterLineAggregator<T> - Class in org.springframework.batch.item.file.transform
A LineAggregator implementation which produces a String by aggregating the provided item via the Formatter syntax.
FormatterLineAggregator() - Constructor for class org.springframework.batch.item.file.transform.FormatterLineAggregator
 
FragmentEventReader - Interface in org.springframework.batch.item.xml.stax
Interface for event readers which support treating XML fragments as standalone XML documents by wrapping the fragments with StartDocument and EndDocument events.
fromCode(char) - Static method in enum org.springframework.batch.sample.domain.trade.CustomerOperation
 
fromMetaData(DataSource) - Static method in enum org.springframework.batch.support.DatabaseType
Convenience method that pulls a database product name from the DataSource's metadata.
fromProductName(String) - Static method in enum org.springframework.batch.support.DatabaseType
Static method to obtain a DatabaseType from the provided product name.
fromPropertyName(String) - Static method in enum org.springframework.batch.core.listener.JobListenerMetaData
Return the relevant meta data for the provided property name.
fromPropertyName(String) - Static method in enum org.springframework.batch.core.listener.StepListenerMetaData
Return the relevant meta data for the provided property name.
FutureDateFunction - Class in org.springframework.batch.sample.domain.order.internal.valang
Returns Boolean.TRUE if given value is future date, else it returns Boolean.FALSE
FutureDateFunction(Function[], int, int) - Constructor for class org.springframework.batch.sample.domain.order.internal.valang.FutureDateFunction
 

G

Game - Class in org.springframework.batch.sample.domain.football
 
Game() - Constructor for class org.springframework.batch.sample.domain.football.Game
 
GameFieldSetMapper - Class in org.springframework.batch.sample.domain.football.internal
 
GameFieldSetMapper() - Constructor for class org.springframework.batch.sample.domain.football.internal.GameFieldSetMapper
 
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.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.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.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.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
generateTopJumpToQuery(AbstractSqlPagingQueryProvider, String) - Static method in class org.springframework.batch.item.database.support.SqlPagingQueryUtils
Generate SQL query string using a TOP clause
generateTopSqlQuery(AbstractSqlPagingQueryProvider, boolean, String) - Static method in class org.springframework.batch.item.database.support.SqlPagingQueryUtils
Generate SQL query string using a TOP clause
GeneratingTradeItemReader - Class in org.springframework.batch.sample.domain.trade.internal
Generates configurable number of Trade items.
GeneratingTradeItemReader() - Constructor for class org.springframework.batch.sample.domain.trade.internal.GeneratingTradeItemReader
 
GeneratingTradeResettingListener - Class in org.springframework.batch.sample.loopFlow
This listener resets the count of its GeneratingTradeItemReader after the step.
GeneratingTradeResettingListener() - Constructor for class org.springframework.batch.sample.loopFlow.GeneratingTradeResettingListener
 
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
 
getAddress() - Method in class org.springframework.batch.sample.domain.order.internal.xml.Customer
 
getAddress() - Method in class org.springframework.batch.sample.domain.person.Person
 
getAddressee() - Method in class org.springframework.batch.sample.domain.order.Address
 
getAddrLine1() - Method in class org.springframework.batch.sample.domain.order.Address
 
getAddrLine2() - Method in class org.springframework.batch.sample.domain.order.Address
 
getAdjustedOutputs(Chunk<I>, Chunk<O>) - Method in class org.springframework.batch.core.step.item.FaultTolerantChunkProcessor
 
getAdjustedOutputs(Chunk<I>, Chunk<O>) - Method in class org.springframework.batch.core.step.item.SimpleChunkProcessor
Extension point for subclasses that want to adjust the outputs based on additional saved data in the inputs.
getAge() - Method in class org.springframework.batch.sample.domain.order.internal.xml.Customer
 
getAge() - Method in class org.springframework.batch.sample.domain.person.Person
 
getAllFailureExceptions() - Method in class org.springframework.batch.core.JobExecution
Return all failure causing exceptions for this JobExecution, including step executions.
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
 
getAsText() - Method in class org.springframework.batch.item.file.transform.RangeArrayPropertyEditor
 
getAttempts() - Method in class org.springframework.batch.sample.domain.football.Game
 
getAttempts() - Method in class org.springframework.batch.sample.domain.football.PlayerSummary
 
getAttribute(String, String, ConfigurableListableBeanFactory) - Static method in class org.springframework.batch.core.configuration.xml.BeanDefinitionUtils
 
getAttribute(String) - Method in class org.springframework.batch.repeat.context.SynchronizedAttributeAccessor
 
getBeanClass() - Method in class org.springframework.batch.core.configuration.xml.AbstractListenerParser
 
getBeanClass(Element) - Method in class org.springframework.batch.core.configuration.xml.FlowParser
 
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
 
getBilling() - Method in class org.springframework.batch.sample.domain.order.Order
 
getBillingAddress() - Method in class org.springframework.batch.sample.domain.order.Order
 
getBirthYear() - Method in class org.springframework.batch.sample.domain.football.Player
 
getBufferSize() - Method in class org.springframework.batch.support.transaction.TransactionAwareBufferedWriter
Convenience method for clients to determine if there is any unflushed data.
getChildren() - Method in class org.springframework.batch.sample.domain.person.Person
 
getChunkOperations() - Method in class org.springframework.batch.core.step.item.SimpleStepFactoryBean
Protected getter for the chunk operations to make them available in subclasses.
getCity() - Method in class org.springframework.batch.sample.domain.order.Address
 
getClobTypeToUse() - Method in class org.springframework.batch.core.repository.dao.AbstractJdbcBatchMetadataDao
 
getCloseSuppressingConnectionProxy(Connection) - Method in class org.springframework.batch.item.database.ExtendedConnectionDataSourceProxy
Wrap the given Connection with a proxy that delegates every method call to it but suppresses close calls.
getCode() - Method in enum org.springframework.batch.sample.domain.trade.CustomerOperation
 
getCommitCount() - Method in class org.springframework.batch.core.StepExecution
Returns the current number of commits for this execution
getCompanyName() - Method in class org.springframework.batch.sample.domain.order.Customer
 
getCompleteCount() - Method in interface org.springframework.batch.retry.RetryStatistics
 
getCompletes() - Method in class org.springframework.batch.sample.domain.football.Game
 
getCompletes() - Method in class org.springframework.batch.sample.domain.football.PlayerSummary
 
getCompositeListener() - Method in class org.springframework.batch.core.step.AbstractStep
 
getConfigurations() - Method in class org.springframework.batch.sample.launch.DefaultJobLoader
 
getConfigurations() - Method in interface org.springframework.batch.sample.launch.ExportedJobLoader
 
getConfigurations() - Method in interface org.springframework.batch.sample.launch.JobLoader
 
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
 
getCounter() - Method in class org.springframework.batch.sample.domain.trade.internal.GeneratingTradeItemReader
 
getCounter() - Method in class org.springframework.batch.sample.support.RetrySampleItemWriter
 
getCountry() - Method in class org.springframework.batch.sample.domain.order.Address
 
getCreateTime() - Method in class org.springframework.batch.core.JobExecution
 
getCredit() - Method in class org.springframework.batch.sample.domain.trade.CustomerCredit
 
getCredit() - Method in class org.springframework.batch.sample.domain.trade.CustomerUpdate
 
getCurrentItemCount() - Method in class org.springframework.batch.item.support.AbstractItemCountingItemStreamItemReader
 
getCurrentResource() - Method in class org.springframework.batch.item.file.MultiResourceItemReader
 
getCustomer() - Method in class org.springframework.batch.sample.domain.order.internal.xml.Order
 
getCustomer() - Method in class org.springframework.batch.sample.domain.order.Order
 
getCustomer() - Method in class org.springframework.batch.sample.domain.trade.Trade
 
getCustomerByName(String) - Method in interface org.springframework.batch.sample.domain.trade.CustomerDao
 
getCustomerByName(String) - Method in class org.springframework.batch.sample.domain.trade.internal.JdbcCustomerDao
 
getCustomerName() - Method in class org.springframework.batch.sample.domain.trade.CustomerUpdate
 
getData() - Method in class org.springframework.batch.sample.domain.person.PersonService
 
getDate(String) - Method in class org.springframework.batch.core.JobParameters
Typesafe Getter for the Date represented by the provided key.
getDate(String, Date) - Method in class org.springframework.batch.core.JobParameters
Typesafe Getter for the Date represented by the provided key.
getDate() - Method in class org.springframework.batch.sample.domain.order.internal.xml.Order
 
getDebit() - Method in class org.springframework.batch.sample.domain.trade.CustomerDebit
 
getDebutYear() - Method in class org.springframework.batch.sample.domain.football.Player
 
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
 
getDescription() - Method in class org.springframework.batch.sample.domain.order.internal.xml.LineItem
 
getDiscountAmount() - Method in class org.springframework.batch.sample.domain.order.LineItem
 
getDiscountPerc() - Method in class org.springframework.batch.sample.domain.order.LineItem
 
getDouble(String) - Method in class org.springframework.batch.core.JobParameters
Typesafe Getter for the Long represented by the provided key.
getDouble(String, double) - Method in class org.springframework.batch.core.JobParameters
Typesafe Getter for the Double represented by the provided key.
getDouble(String) - Method in class org.springframework.batch.item.ExecutionContext
Typesafe Getter for the Double represented by the provided key.
getDouble(String, double) - Method in class org.springframework.batch.item.ExecutionContext
Typesafe Getter for the Double represented by the provided key with default value to return if key is not represented.
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
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
 
getErrors() - Method in class org.springframework.batch.sample.domain.trade.internal.HibernateCreditDao
Public accessor for the errors property.
getException() - Method in class org.springframework.batch.core.step.item.SkipWrapper
Public getter for the exception.
getExceptionHandler() - Method in class org.springframework.batch.core.step.item.SimpleStepFactoryBean
Protected getter for the ExceptionHandler.
getExceptionTranslator() - Method in class org.springframework.batch.item.database.JdbcCursorItemReader
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
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'.
getFieldSet(ResultSet) - Static method in class org.springframework.batch.sample.common.FieldSetResultSetExtractor
Processes single row in ResultSet and returns its FieldSet representation.
getFilterCount(Chunk<I>, Chunk<O>) - Method in class org.springframework.batch.core.step.item.FaultTolerantChunkProcessor
 
getFilterCount(Chunk<I>, Chunk<O>) - Method in class org.springframework.batch.core.step.item.SimpleChunkProcessor
Extension point for subclasses to calculate the filter count.
getFilterCount() - Method in class org.springframework.batch.core.StepContribution
Public getter for the filter counter.
getFilterCount() - Method in class org.springframework.batch.core.StepExecution
Returns the current number of items filtered out of this execution
getFirstName() - Method in class org.springframework.batch.sample.domain.football.Player
 
getFirstName() - Method in class org.springframework.batch.sample.domain.order.Customer
 
getFirstName() - Method in class org.springframework.batch.sample.domain.person.Person
 
getFooter() - Static method in class org.springframework.batch.sample.domain.multiline.AggregateItem
 
getFromClause() - Method in class org.springframework.batch.item.database.support.AbstractSqlPagingQueryProvider
 
getHandlingPrice() - Method in class org.springframework.batch.sample.domain.order.LineItem
 
getHeader() - Static method in class org.springframework.batch.sample.domain.multiline.AggregateItem
 
getId() - Method in class org.springframework.batch.core.Entity
 
getId() - Method in class org.springframework.batch.core.scope.context.StepContext
 
getId() - Method in class org.springframework.batch.sample.common.ProcessIndicatorItemWrapper
 
getId() - Method in class org.springframework.batch.sample.domain.football.Game
 
getId() - Method in class org.springframework.batch.sample.domain.football.Player
 
getId() - Method in class org.springframework.batch.sample.domain.football.PlayerSummary
 
getId() - Method in class org.springframework.batch.sample.domain.trade.CustomerCredit
 
getIncrementer(String, String) - Method in interface org.springframework.batch.item.database.support.DataFieldMaxValueIncrementerFactory
Return the DataFieldMaxValueIncrementer for the provided database type.
getIncrementer(String, String) - Method in class org.springframework.batch.item.database.support.DefaultDataFieldMaxValueIncrementerFactory
 
getInput() - Method in exception org.springframework.batch.item.file.FlatFileParseException
 
getInt(String) - Method in class org.springframework.batch.item.ExecutionContext
Typesafe Getter for the Integer represented by the provided key.
getInt(String, int) - Method in class org.springframework.batch.item.ExecutionContext
Typesafe Getter for the Integer represented by the provided key with default value to return if key is not represented.
getInterceptions() - Method in class org.springframework.batch.sample.domain.football.Game
 
getInterceptions() - Method in class org.springframework.batch.sample.domain.football.PlayerSummary
 
getIsin() - Method in class org.springframework.batch.sample.domain.trade.Trade
 
getItem() - Method in class org.springframework.batch.core.step.item.SkipWrapper
Public getter for the item.
getItem() - Method in class org.springframework.batch.sample.common.ProcessIndicatorItemWrapper
 
getItem() - Method in class org.springframework.batch.sample.domain.multiline.AggregateItem
Accessor for the wrapped item.
getItemId() - Method in class org.springframework.batch.sample.domain.order.LineItem
 
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.ClassPathXmlJobRegistry
 
getJob(String) - Method in class org.springframework.batch.core.configuration.support.MapJobRegistry
 
getJob(String) - Method in interface org.springframework.batch.sample.launch.ExportedJobLoader
 
getJob() - Method in class org.springframework.batch.test.AbstractJobTests
 
getJobConfiguration(String) - Method in class org.springframework.batch.sample.launch.DefaultJobLoader
 
getJobConfiguration(String) - Method in interface org.springframework.batch.sample.launch.JobLoader
 
getJobExecution(Long) - Method in interface org.springframework.batch.core.explore.JobExplorer
Retrieve a JobExecution by its id.
getJobExecution(Long) - Method in class org.springframework.batch.core.explore.support.SimpleJobExplorer
 
getJobExecution() - Method in interface org.springframework.batch.core.job.flow.FlowExecutor
 
getJobExecution(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
 
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
 
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
 
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
 
getJobName() - Method in interface org.springframework.batch.core.configuration.JobFactory
 
getJobName() - Method in class org.springframework.batch.core.configuration.support.ApplicationContextJobFactory
Return the bean name of the job in the application context.
getJobName() - Method in class org.springframework.batch.core.configuration.support.ReferenceJobFactory
Returns the job name as 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.ListableJobRegistry
Provides the currently registered job names.
getJobNames() - Method in class org.springframework.batch.core.configuration.support.ClassPathXmlJobRegistry
 
getJobNames() - Method in class org.springframework.batch.core.configuration.support.MapJobRegistry
 
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() - Method in class org.springframework.batch.core.StepExecution
Convenience method to get the current job parameters.
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.
getJobRepository() - Method in class org.springframework.batch.core.step.AbstractStep
 
getJobRepository() - Method in class org.springframework.batch.test.AbstractJobTests
 
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 the name of the item stream 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
 
getLast_name() - Method in class org.springframework.batch.sample.domain.person.Person
Intentionally non-standard method name for testing purposes
getLastJobExecution(JobInstance) - Method in class org.springframework.batch.core.repository.dao.JdbcJobExecutionDao
 
getLastJobExecution(JobInstance) - Method in interface org.springframework.batch.core.repository.dao.JobExecutionDao
Find the last JobExecution to have been created for a given JobInstance.
getLastJobExecution(JobInstance) - Method in class org.springframework.batch.core.repository.dao.MapJobExecutionDao
 
getLastJobExecution(String, JobParameters) - Method in interface org.springframework.batch.core.repository.JobRepository
 
getLastJobExecution(String, JobParameters) - Method in class org.springframework.batch.core.repository.support.SimpleJobRepository
 
getLastName() - Method in class org.springframework.batch.sample.domain.football.Player
 
getLastName() - Method in class org.springframework.batch.sample.domain.order.Customer
 
getLastStepExecution(JobInstance, String) - Method in interface org.springframework.batch.core.repository.JobRepository
 
getLastStepExecution(JobInstance, String) - Method in class org.springframework.batch.core.repository.support.SimpleJobRepository
 
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
 
getLimit() - Method in class org.springframework.batch.sample.domain.trade.internal.GeneratingTradeItemReader
 
getLineItems() - Method in class org.springframework.batch.sample.domain.order.internal.xml.Order
 
getLineItems() - Method in class org.springframework.batch.sample.domain.order.Order
 
getLineNumber() - Method in exception org.springframework.batch.item.file.FlatFileParseException
 
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
 
getMetaDataFromPropertyName(String) - Method in class org.springframework.batch.core.listener.AbstractListenerFactoryBean
 
getMetaDataFromPropertyName(String) - Method in class org.springframework.batch.core.listener.JobListenerFactoryBean
 
getMetaDataFromPropertyName(String) - Method in class org.springframework.batch.core.listener.StepListenerFactoryBean
 
getMetaDataValues() - Method in class org.springframework.batch.core.configuration.xml.AbstractListenerParser
 
getMetaDataValues() - Method in class org.springframework.batch.core.configuration.xml.JobExecutionListenerParser
 
getMetaDataValues() - Method in class org.springframework.batch.core.configuration.xml.StepListenerParser
 
getMetaDataValues() - Method in class org.springframework.batch.core.listener.AbstractListenerFactoryBean
 
getMetaDataValues() - Method in class org.springframework.batch.core.listener.JobListenerFactoryBean
 
getMetaDataValues() - Method in class org.springframework.batch.core.listener.StepListenerFactoryBean
 
getMethodInvokerByAnnotation(Class<? extends Annotation>, Object, Class<?>...) - Static method in class org.springframework.batch.support.MethodInvokerUtils
Create a MethodInvoker from the delegate based on the annotationType.
getMethodInvokerByAnnotation(Class<? extends Annotation>, Object) - Static method in class org.springframework.batch.support.MethodInvokerUtils
Create MethodInvoker for the method with the provided annotation on the provided object.
getMethodInvokerByName(String, Object, Class<?>...) - Method in class org.springframework.batch.core.listener.AbstractListenerFactoryBean
 
getMethodInvokerByName(Object, String, boolean, Class<?>...) - Static method in class org.springframework.batch.support.MethodInvokerUtils
Create a MethodInvoker using the provided method name to search.
getMethodInvokerForInterface(Class<?>, String, Object, Class<?>...) - Static method in class org.springframework.batch.support.MethodInvokerUtils
Create a MethodInvoker using the provided interface, and method name from that interface.
getMethodInvokerForSingleArgument(Object) - Static method in class org.springframework.batch.support.MethodInvokerUtils
Create a MethodInvoker for the delegate from a single public method.
getMethodName() - Method in enum org.springframework.batch.core.listener.JobListenerMetaData
 
getMethodName() - Method in interface org.springframework.batch.core.listener.ListenerMetaData
 
getMethodName() - Method in enum org.springframework.batch.core.listener.StepListenerMetaData
 
getMiddleName() - Method in class org.springframework.batch.sample.domain.order.Customer
 
getMin() - Method in class org.springframework.batch.item.file.transform.Range
 
getMoo() - Method in class org.springframework.batch.sample.domain.order.internal.xml.Customer
 
getName() - Method in class org.springframework.batch.core.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.
getName() - Method in class org.springframework.batch.sample.domain.order.internal.xml.Customer
 
getName() - Method in class org.springframework.batch.sample.domain.order.internal.xml.Shipper
 
getName() - Method in class org.springframework.batch.sample.domain.person.Child
 
getName() - Method in class org.springframework.batch.sample.domain.trade.CustomerCredit
 
getName() - Method in class org.springframework.batch.sample.domain.trade.CustomerDebit
 
getNames() - Method in class org.springframework.batch.item.file.transform.DefaultFieldSet
 
getNames() - Method in interface org.springframework.batch.item.file.transform.FieldSet
Accessor for the names of the fields.
getNext() - Method in class org.springframework.batch.core.job.flow.support.StateTransition
Public getter for the next State name.
getNext(JobParameters) - Method in interface org.springframework.batch.core.JobParametersIncrementer
Increment the provided parameters.
getNext(JobParameters) - Method in class org.springframework.batch.sample.common.InfiniteLoopIncrementer
Increment the run.id parameter.
getNextElements(ParserContext, BeanDefinition, Element) - Static method in class org.springframework.batch.core.configuration.xml.FlowParser
 
getNextElements(ParserContext, String, BeanDefinition, Element) - Static method in class org.springframework.batch.core.configuration.xml.FlowParser
 
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.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.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.
getObjectType() - Method in class test.jdbc.datasource.DerbyDataSourceFactoryBean
 
getOperation() - Method in class org.springframework.batch.sample.domain.trade.CustomerUpdate
 
getOpponent() - Method in class org.springframework.batch.sample.domain.football.Game
 
getOrder() - Method in class org.springframework.batch.core.scope.StepScope
 
getOrderDate() - Method in class org.springframework.batch.sample.domain.order.Order
 
getOrderId() - Method in class org.springframework.batch.sample.domain.order.Order
 
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.
getPassingTd() - Method in class org.springframework.batch.sample.domain.football.Game
 
getPassingTd() - Method in class org.springframework.batch.sample.domain.football.PlayerSummary
 
getPassingYards() - Method in class org.springframework.batch.sample.domain.football.Game
 
getPassingYards() - Method in class org.springframework.batch.sample.domain.football.PlayerSummary
 
getPaymentDesc() - Method in class org.springframework.batch.sample.domain.order.BillingInfo
 
getPaymentId() - Method in class org.springframework.batch.sample.domain.order.BillingInfo
 
getPerOunceRate() - Method in class org.springframework.batch.sample.domain.order.internal.xml.Shipper
 
getPerUnitOunces() - Method in class org.springframework.batch.sample.domain.order.internal.xml.LineItem
 
getPoo() - Method in class org.springframework.batch.sample.domain.order.internal.xml.Customer
 
getPosition() - Method in class org.springframework.batch.sample.domain.football.Player
 
getPrice() - Method in class org.springframework.batch.sample.domain.order.internal.xml.LineItem
 
getPrice() - Method in class org.springframework.batch.sample.domain.order.LineItem
 
getPrice() - Method in class org.springframework.batch.sample.domain.trade.Trade
 
getProcessSkipCount() - Method in class org.springframework.batch.core.StepContribution
Public getter for the process skip count.
getProcessSkipCount() - Method in class org.springframework.batch.core.StepExecution
 
getProductName() - Method in enum org.springframework.batch.support.DatabaseType
 
getProperties(JobParameters) - Method in class org.springframework.batch.core.converter.DefaultJobParametersConverter
Use the same suffixes to create properties (omitting the string suffix because it is the default).
getProperties(JobParameters) - Method in interface org.springframework.batch.core.converter.JobParametersConverter
The inverse operation: get a Properties instance.
getProperties(JobParameters) - Method in class org.springframework.batch.core.launch.support.ScheduledJobParametersFactory
Convert schedule date to Date, and assume all other parameters can be represented by their default string value.
getProperties() - Method in class org.springframework.batch.item.file.transform.DefaultFieldSet
 
getProperties() - Method in interface org.springframework.batch.item.file.transform.FieldSet
Construct name-value pairs from the field names and string values.
getProperty(String) - Method in class org.springframework.batch.sample.launch.DefaultJobLoader
 
getProperty(String) - Method in interface org.springframework.batch.sample.launch.ExportedJobLoader
 
getProperty(String) - Method in interface org.springframework.batch.sample.launch.JobLoader
 
getPropertyName() - Method in enum org.springframework.batch.core.listener.JobListenerMetaData
 
getPropertyName() - Method in interface org.springframework.batch.core.listener.ListenerMetaData
 
getPropertyName() - Method in enum org.springframework.batch.core.listener.StepListenerMetaData
 
getPropertyValue(String, String, ConfigurableListableBeanFactory) - Static method in class org.springframework.batch.core.configuration.xml.BeanDefinitionUtils
 
getQuantity() - Method in class org.springframework.batch.sample.domain.order.internal.xml.LineItem
 
getQuantity() - Method in class org.springframework.batch.sample.domain.order.LineItem
 
getQuantity() - Method in class org.springframework.batch.sample.domain.trade.Trade
 
getQuery(String) - Method in class org.springframework.batch.core.repository.dao.AbstractJdbcBatchMetadataDao
 
getReadCount() - Method in class org.springframework.batch.core.StepContribution
Public access to the read counter.
getReadCount() - Method in class org.springframework.batch.core.StepExecution
Returns the current number of items read for this execution
getReadSkipCount() - Method in class org.springframework.batch.core.StepContribution
 
getReadSkipCount() - Method in class org.springframework.batch.core.StepExecution
 
getReceivedCount() - Method in class org.springframework.batch.sample.domain.person.PersonService
 
getReceptions() - Method in class org.springframework.batch.sample.domain.football.Game
 
getReceptions() - Method in class org.springframework.batch.sample.domain.football.PlayerSummary
 
getReceptionYards() - Method in class org.springframework.batch.sample.domain.football.Game
 
getReceptionYards() - Method in class org.springframework.batch.sample.domain.football.PlayerSummary
 
getRegistrationId() - Method in class org.springframework.batch.sample.domain.order.Customer
 
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.
getReturnedCount() - Method in class org.springframework.batch.sample.domain.person.PersonService
 
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.
getRunningExecutions(String) - Method in interface org.springframework.batch.core.launch.JobOperator
Get the id values of all the running JobExecutions with the given job name.
getRunningExecutions(String) - Method in class org.springframework.batch.core.launch.support.SimpleJobOperator
 
getRushes() - Method in class org.springframework.batch.sample.domain.football.Game
 
getRushes() - Method in class org.springframework.batch.sample.domain.football.PlayerSummary
 
getRushYards() - Method in class org.springframework.batch.sample.domain.football.Game
 
getRushYards() - Method in class org.springframework.batch.sample.domain.football.PlayerSummary
 
getSelectClause() - Method in class org.springframework.batch.item.database.support.AbstractSqlPagingQueryProvider
 
getShipper() - Method in class org.springframework.batch.sample.domain.order.internal.xml.Order
 
getShipperId() - Method in class org.springframework.batch.sample.domain.order.ShippingInfo
 
getShipping() - Method in class org.springframework.batch.sample.domain.order.Order
 
getShippingAddress() - Method in class org.springframework.batch.sample.domain.order.Order
 
getShippingInfo() - Method in class org.springframework.batch.sample.domain.order.ShippingInfo
 
getShippingPrice() - Method in class org.springframework.batch.sample.domain.order.LineItem
 
getShippingTypeId() - Method in class org.springframework.batch.sample.domain.order.ShippingInfo
 
getSkipCount() - Method in class org.springframework.batch.core.StepContribution
 
getSkipCount() - Method in class org.springframework.batch.core.StepExecution
 
getSkipLimit() - Method in exception org.springframework.batch.core.step.skip.SkipLimitExceededException
 
getSkips() - Method in class org.springframework.batch.core.step.item.Chunk
 
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.
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.
getState() - Method in class org.springframework.batch.sample.domain.order.Address
 
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.FlowParser
 
getStatus() - Method in class org.springframework.batch.core.job.flow.FlowExecution
 
getStatus() - Method in class org.springframework.batch.core.JobExecution
 
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 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(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
 
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
 
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
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.
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
getTeam() - Method in class org.springframework.batch.sample.domain.football.Game
 
getThrowables() - Method in interface org.springframework.batch.repeat.support.RepeatInternalState
Returns a mutable collection of exceptions that have occurred in the current repeat context.
getThrowables() - Method in class org.springframework.batch.repeat.support.RepeatInternalStateSupport
 
getTitle() - Method in class org.springframework.batch.sample.domain.person.Person
 
getTotalItems() - Method in class org.springframework.batch.sample.domain.order.Order
 
getTotalLines() - Method in class org.springframework.batch.sample.domain.order.Order
 
getTotalPrice() - Method in class org.springframework.batch.sample.domain.order.LineItem
 
getTotalPrice() - Method in class org.springframework.batch.sample.domain.order.Order
 
getTotalPrice() - Method in class org.springframework.batch.sample.domain.trade.internal.TradeWriter
 
getTotalTd() - Method in class org.springframework.batch.sample.domain.football.Game
 
getTotalTd() - Method in class org.springframework.batch.sample.domain.football.PlayerSummary
 
getTransactionAttribute() - Method in class org.springframework.batch.core.step.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.
getType() - Method in class org.springframework.batch.core.JobParameter
 
getUniqueJobParameters() - Method in class org.springframework.batch.test.AbstractJobTests
 
getUserData() - Method in class org.springframework.batch.core.step.item.Chunk
 
getValue() - Method in class org.springframework.batch.core.JobParameter
 
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.
getWeek() - Method in class org.springframework.batch.sample.domain.football.Game
 
getWhereClause() - Method in class org.springframework.batch.item.database.support.AbstractSqlPagingQueryProvider
 
getWriteCount() - Method in class org.springframework.batch.core.StepContribution
Public access to the write counter.
getWriteCount() - Method in class org.springframework.batch.core.StepExecution
Returns the current number of items written for this execution
getWriteSkipCount() - Method in class org.springframework.batch.core.StepContribution
 
getWriteSkipCount() - Method in class org.springframework.batch.core.StepExecution
 
getYear() - Method in class org.springframework.batch.sample.domain.football.Game
 
getYear() - Method in class org.springframework.batch.sample.domain.football.PlayerSummary
 
getZipCode() - Method in class org.springframework.batch.sample.domain.order.Address
 

H

handle(FlowExecutor) - Method in interface org.springframework.batch.core.job.flow.State
Handle some business or processing logic and return a status that can be used to drive a flow to the next State.
handle(FlowExecutor) - Method in class org.springframework.batch.core.job.flow.support.state.AbstractState
 
handle(FlowExecutor) - Method in class org.springframework.batch.core.job.flow.support.state.DecisionState
 
handle(FlowExecutor) - Method in class org.springframework.batch.core.job.flow.support.state.EndState
Return the FlowExecutionStatus stored.
handle(FlowExecutor) - Method in class org.springframework.batch.core.job.flow.support.state.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
 
handleException(RepeatContext, Throwable) - Method in class org.springframework.batch.core.step.item.SimpleRetryExceptionHandler
Check if the exception is going to be retried, and veto the handling if it is.
handleException(RepeatContext, Throwable) - Method in class org.springframework.batch.repeat.exception.CompositeExceptionHandler
Iterate over the handlers delegating the call to each in turn.
handleException(RepeatContext, Throwable) - Method in class org.springframework.batch.repeat.exception.DefaultExceptionHandler
Re-throw the throwable.
handleException(RepeatContext, Throwable) - Method in interface org.springframework.batch.repeat.exception.ExceptionHandler
Deal with a Throwable during a batch - decide whether it should be re-thrown in the first place.
handleException(RepeatContext, Throwable) - Method in class org.springframework.batch.repeat.exception.LogOrRethrowExceptionHandler
Classify the throwables and decide whether to rethrow based on the result.
handleException(RepeatContext, Throwable) - Method in class org.springframework.batch.repeat.exception.RethrowOnThresholdExceptionHandler
Classify the throwables and decide whether to re-throw based on the result.
handleException(RepeatContext, Throwable) - Method in class org.springframework.batch.repeat.exception.SimpleLimitExceptionHandler
Rethrows only if the limit is breached for this context on the exception type specified.
handleException(RepeatContext, Throwable) - Method in class org.springframework.batch.sample.domain.football.internal.FootballExceptionHandler
 
handleExceptionElement(Element, ParserContext, MutablePropertyValues, String, String) - Static method in class org.springframework.batch.core.configuration.xml.AbstractStepParser
 
handleLine(String) - Method in interface org.springframework.batch.item.file.LineCallbackHandler
 
handleLine(String) - Method in class org.springframework.batch.sample.support.HeaderCopyCallback
 
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.
HANDLING_PRICE_COLUMN - Static variable in class org.springframework.batch.sample.domain.order.internal.mapper.OrderItemFieldSetMapper
 
hasAttribute(String) - Method in class org.springframework.batch.repeat.context.SynchronizedAttributeAccessor
 
hashCode() - Method in class org.springframework.batch.core.Entity
Use ID if it exists to establish hash code, otherwise fall back to Object.hashCode().
hashCode() - Method in class org.springframework.batch.core.ExitStatus
Compatible with the equals implementation.
hashCode() - Method in class org.springframework.batch.core.job.flow.FlowExecutionStatus
 
hashCode() - Method in class org.springframework.batch.core.JobParameter
 
hashCode() - Method in class org.springframework.batch.core.JobParameters
 
hashCode() - Method in class org.springframework.batch.core.listener.MethodInvokerMethodInterceptor
hashCode() - Method in class org.springframework.batch.core.scope.context.StepContext
Overrides the default behaviour to provide a hash code based only on the step execution.
hashCode() - Method in class org.springframework.batch.core.StepContribution
 
hashCode() - Method in class org.springframework.batch.core.StepExecution
 
hashCode() - Method in class org.springframework.batch.item.ExecutionContext
 
hashCode() - Method in class org.springframework.batch.item.file.transform.DefaultFieldSet
 
hashCode() - Method in class org.springframework.batch.repeat.context.SynchronizedAttributeAccessor
 
hashCode() - Method in class org.springframework.batch.sample.domain.football.Game
 
hashCode() - Method in class org.springframework.batch.sample.domain.football.PlayerSummary
 
hashCode() - Method in class org.springframework.batch.sample.domain.order.Address
 
hashCode() - Method in class org.springframework.batch.sample.domain.order.BillingInfo
 
hashCode() - Method in class org.springframework.batch.sample.domain.order.Customer
 
hashCode() - Method in class org.springframework.batch.sample.domain.order.LineItem
 
hashCode() - Method in class org.springframework.batch.sample.domain.order.Order
 
hashCode() - Method in class org.springframework.batch.sample.domain.order.ShippingInfo
 
hashCode() - Method in class org.springframework.batch.sample.domain.person.Child
 
hashCode() - Method in class org.springframework.batch.sample.domain.person.Person
 
hashCode() - Method in class org.springframework.batch.sample.domain.trade.CustomerCredit
 
hashCode() - Method in class org.springframework.batch.sample.domain.trade.CustomerDebit
 
hashCode() - Method in class org.springframework.batch.sample.domain.trade.Trade
 
hashCode() - Method in class org.springframework.batch.support.SimpleMethodInvoker
 
hasMaxValue() - Method in class org.springframework.batch.item.file.transform.Range
 
hasNames() - Method in class org.springframework.batch.item.file.transform.AbstractLineTokenizer
 
hasNames() - Method in class org.springframework.batch.item.file.transform.DefaultFieldSet
 
hasNames() - Method in interface org.springframework.batch.item.file.transform.FieldSet
Check if there are names defined for the fields.
hasNext() - Method in class org.springframework.batch.core.step.item.Chunk.ChunkIterator
 
hasNext() - Method in class org.springframework.batch.item.xml.stax.DefaultFragmentEventReader
 
HeaderCopyCallback - Class in org.springframework.batch.sample.support
Designed to be registered with both FlatFileItemReader and FlatFileItemWriter and copy header line from input file to output file.
HeaderCopyCallback() - Constructor for class org.springframework.batch.sample.support.HeaderCopyCallback
 
HeaderFieldExtractor - Class in org.springframework.batch.sample.domain.order.internal.extractor
 
HeaderFieldExtractor() - Constructor for class org.springframework.batch.sample.domain.order.internal.extractor.HeaderFieldExtractor
 
HeaderFieldSetMapper - Class in org.springframework.batch.sample.domain.order.internal.mapper
 
HeaderFieldSetMapper() - Constructor for class org.springframework.batch.sample.domain.order.internal.mapper.HeaderFieldSetMapper
 
HibernateAwareCustomerCreditItemWriter - Class in org.springframework.batch.sample.domain.trade.internal
Delegates writing to a custom DAO and flushes + clears hibernate session to fulfill the ItemWriter contract.
HibernateAwareCustomerCreditItemWriter() - Constructor for class org.springframework.batch.sample.domain.trade.internal.HibernateAwareCustomerCreditItemWriter
 
HibernateCreditDao - Class in org.springframework.batch.sample.domain.trade.internal
 
HibernateCreditDao() - Constructor for class org.springframework.batch.sample.domain.trade.internal.HibernateCreditDao
 
HibernateCursorItemReader<T> - Class in org.springframework.batch.item.database
ItemReader for reading database records built on top of Hibernate.
HibernateCursorItemReader() - Constructor for class org.springframework.batch.item.database.HibernateCursorItemReader
 
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
 
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
 
IbatisCustomerCreditDao - Class in org.springframework.batch.sample.domain.trade.internal
 
IbatisCustomerCreditDao() - Constructor for class org.springframework.batch.sample.domain.trade.internal.IbatisCustomerCreditDao
 
IbatisPagingItemReader<T> - Class in org.springframework.batch.item.database
ItemReader for reading database records using iBATIS in a paging fashion.
IbatisPagingItemReader() - Constructor for class org.springframework.batch.item.database.IbatisPagingItemReader
 
ID_ATTR - Static variable in class org.springframework.batch.core.configuration.xml.AbstractStepParser
 
ID_COLUMN - Static variable in class org.springframework.batch.sample.domain.trade.internal.CustomerCreditFieldSetMapper
 
ID_COLUMN - Static variable in class org.springframework.batch.sample.domain.trade.internal.CustomerCreditRowMapper
 
ID_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
 
increaseCreditBy(BigDecimal) - Method in class org.springframework.batch.sample.domain.trade.CustomerCredit
 
increment(int) - Method in class org.springframework.batch.repeat.context.RepeatContextCounter
Increment the counter.
increment() - Method in class org.springframework.batch.repeat.context.RepeatContextCounter
Increment by 1.
increment() - Method in class org.springframework.batch.repeat.context.RepeatContextSupport
Used by clients to increment the started count.
incrementCommitCount() - Method in class org.springframework.batch.core.StepExecution
Increment the number of commits
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.
InfiniteLoopIncrementer - Class in org.springframework.batch.sample.common
 
InfiniteLoopIncrementer() - Constructor for class org.springframework.batch.sample.common.InfiniteLoopIncrementer
 
InfiniteLoopReader - Class in org.springframework.batch.sample.common
ItemReader implementation that will continually return a new object.
InfiniteLoopReader() - Constructor for class org.springframework.batch.sample.common.InfiniteLoopReader
 
InfiniteLoopWriter - Class in org.springframework.batch.sample.common
Simple module implementation that will always return true to indicate that processing should continue.
InfiniteLoopWriter() - Constructor for class org.springframework.batch.sample.common.InfiniteLoopWriter
 
init() - Method in class org.springframework.batch.core.configuration.xml.CoreNamespaceHandler
 
init() - Method in class org.springframework.batch.core.repository.dao.XStreamExecutionContextStringSerializer
 
init(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.
initDao() - Method in class org.springframework.batch.sample.common.StagingItemWriter
Check mandatory properties.
initDao() - Method in class org.springframework.batch.sample.domain.football.internal.JdbcGameDao
 
initialized - Variable in class org.springframework.batch.item.database.AbstractPagingItemReader
 
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.
InlineStepParser - Class in org.springframework.batch.core.configuration.xml
Internal parser for the <step/> elements inside a job.
InlineStepParser() - Constructor for class org.springframework.batch.core.configuration.xml.InlineStepParser
 
INSERT_PLAYER - Static variable in class org.springframework.batch.sample.domain.football.internal.JdbcPlayerDao
 
insertCustomer(String, BigDecimal) - Method in interface org.springframework.batch.sample.domain.trade.CustomerDao
 
insertCustomer(String, BigDecimal) - Method in class org.springframework.batch.sample.domain.trade.internal.JdbcCustomerDao
 
IntArrayPropertyEditor - Class in org.springframework.batch.support
 
IntArrayPropertyEditor() - Constructor for class org.springframework.batch.support.IntArrayPropertyEditor
 
intValue(String) - Method in interface org.springframework.batch.core.launch.support.ExitCodeMapper
Convert the exit code from String into an integer that the calling environment as an operating system can interpret as an exit status.
intValue(String) - Method in class org.springframework.batch.core.launch.support.SimpleJvmExitCodeMapper
Get the operating system exit status that matches a certain Batch Framework Exitcode
InvalidCustomerLogger - Interface in org.springframework.batch.sample.domain.trade
Interface for logging invalid customers.
invoke(MethodInvocation) - Method in class org.springframework.batch.core.launch.support.RuntimeExceptionTranslator
 
invoke(MethodInvocation) - Method in class org.springframework.batch.core.listener.MethodInvokerMethodInterceptor
 
invoke(MethodInvocation) - Method in class org.springframework.batch.repeat.interceptor.RepeatOperationsInterceptor
Invoke the proceeding method call repeatedly, according to the properties of the injected RepeatOperations.
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.
isBusinessCustomer() - Method in class org.springframework.batch.sample.domain.order.Customer
 
isBusy() - Method in class org.springframework.batch.core.step.item.Chunk
Query the chunk to see if anyone has registered an interest in keeping a reference to it.
isCloseSuppressionActive(Connection) - Method in class org.springframework.batch.item.database.ExtendedConnectionDataSourceProxy
Return the status of close suppression being activated for a given Connection
isComplete(RepeatContext, RepeatStatus) - Method in class org.springframework.batch.core.resource.StepExecutionSimpleCompletionPolicy
 
isComplete(RepeatContext) - Method in class org.springframework.batch.core.resource.StepExecutionSimpleCompletionPolicy
 
isComplete() - Method in class org.springframework.batch.core.scope.context.ChunkContext
 
isComplete(Chunk<I>) - Method in class org.springframework.batch.core.step.item.FaultTolerantChunkProcessor
 
isComplete(Chunk<I>) - Method in class org.springframework.batch.core.step.item.SimpleChunkProcessor
Extension point for subclasses that want to store additional data in the inputs.
isComplete(RepeatContext, RepeatStatus) - Method in interface org.springframework.batch.repeat.CompletionPolicy
Determine whether a batch is complete given the latest result from the callback.
isComplete(RepeatContext) - Method in interface org.springframework.batch.repeat.CompletionPolicy
Allow policy to signal completion according to internal state, without having to wait for the callback to complete.
isComplete(RepeatContext, RepeatStatus) - Method in class org.springframework.batch.repeat.policy.CompletionPolicySupport
If exit status is not continuable return true, otherwise delegate to CompletionPolicySupport.isComplete(RepeatContext).
isComplete(RepeatContext) - Method in class org.springframework.batch.repeat.policy.CompletionPolicySupport
Always true.
isComplete(RepeatContext, RepeatStatus) - Method in class org.springframework.batch.repeat.policy.CompositeCompletionPolicy
This policy is complete if any of the composed policies is complete.
isComplete(RepeatContext) - Method in class org.springframework.batch.repeat.policy.CompositeCompletionPolicy
This policy is complete if any of the composed policies is complete.
isComplete(RepeatContext) - Method in class org.springframework.batch.repeat.policy.CountingCompletionPolicy
 
isComplete(RepeatContext, RepeatStatus) - Method in class org.springframework.batch.repeat.policy.DefaultResultCompletionPolicy
True if the result is null, or a RepeatStatus indicating completion.
isComplete(RepeatContext) - Method in class org.springframework.batch.repeat.policy.DefaultResultCompletionPolicy
Always false.
isComplete(RepeatContext, RepeatStatus) - Method in class org.springframework.batch.repeat.policy.SimpleCompletionPolicy
Terminate if the chunk size has been reached, or the result is null.
isComplete(RepeatContext) - Method in class org.springframework.batch.repeat.policy.SimpleCompletionPolicy
Terminate if the chunk size has been reached.
isComplete() - Method in class org.springframework.batch.repeat.policy.SimpleCompletionPolicy.SimpleTerminationContext
 
isComplete(RepeatContext) - Method in class org.springframework.batch.repeat.policy.TimeoutTerminationPolicy
Check the timeout and complete gracefully if it has expires.
isComplete() - Method in class org.springframework.batch.repeat.policy.TimeoutTerminationPolicy.TimeoutBatchContext
 
isComplete(RepeatContext, RepeatStatus) - Method in class org.springframework.batch.repeat.support.RepeatTemplate
Delegate to the CompletionPolicy.
isComplete(RepeatContext) - Method in class org.springframework.batch.repeat.support.RepeatTemplate
Delegate to CompletionPolicy.
isCompleteOnly() - Method in class org.springframework.batch.repeat.context.RepeatContextSupport
 
isCompleteOnly() - Method in interface org.springframework.batch.repeat.RepeatContext
Public accessor for the complete flag.
isContinuable() - Method in enum org.springframework.batch.repeat.RepeatStatus
 
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.ThrottleLimitResultQueue
 
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 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.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().
isExpecting() - Method in class org.springframework.batch.repeat.support.ThrottleLimitResultQueue
 
isFail() - Method in class org.springframework.batch.core.job.flow.FlowExecutionStatus
 
isFooter() - Method in class org.springframework.batch.sample.domain.multiline.AggregateItem
Responds true if this record is a footer in an aggregate.
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
 
isHeader() - Method in class org.springframework.batch.sample.domain.multiline.AggregateItem
Responds true if this record is a header in an aggregate.
ISIN_COLUMN - Static variable in class org.springframework.batch.sample.domain.trade.internal.TradeFieldSetMapper
 
ISIN_COLUMN - Static variable in class org.springframework.batch.sample.domain.trade.internal.TradeRowMapper
 
isJobInstanceExists(String, JobParameters) - Method in interface org.springframework.batch.core.repository.JobRepository
Check if an instance of this job already exists with the parameters provided.
isJobInstanceExists(String, JobParameters) - Method in class org.springframework.batch.core.repository.support.SimpleJobRepository
 
isLessThan(BatchStatus) - Method in enum org.springframework.batch.core.BatchStatus
 
isLessThanOrEqualTo(BatchStatus) - Method in enum org.springframework.batch.core.BatchStatus
 
isListener(Object, Class<?>, ListenerMetaData[]) - Static method in class org.springframework.batch.core.listener.AbstractListenerFactoryBean
Convenience method to check whether the given object is or can be made into a listener.
isListener(Object) - Static method in class org.springframework.batch.core.listener.JobListenerFactoryBean
Convenience method to check whether the given object is or can be made into a JobExecutionListener.
isListener(Object) - Static method in class org.springframework.batch.core.listener.StepListenerFactoryBean
Convenience method to check whether the given object is or can be made into a StepListener.
isNew(Object[]) - Method in class org.springframework.batch.item.jms.JmsNewMethodArgumentsIdentifier
If any of the arguments is a message, check the JMS re-delivered flag and return it, otherwise return false to be on the safe side.
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.
isRegistered() - Method in class org.springframework.batch.sample.domain.order.Customer
 
isRestart() - Method in interface org.springframework.batch.core.job.flow.FlowExecutor
 
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.ExitStatus
Check if this status represents a running process.
isRunning() - Method in class org.springframework.batch.core.JobExecution
Test if this JobExecution indicates that it is running.
isSingleton() - Method in class org.springframework.batch.core.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.
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.
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.
isUsingNamedParameters() - Method in interface org.springframework.batch.item.database.PagingQueryProvider
Indicate whether the generated queries use named parameter syntax.
isUsingNamedParameters() - Method in class org.springframework.batch.item.database.support.AbstractSqlPagingQueryProvider
 
isVip() - Method in class org.springframework.batch.sample.domain.order.Customer
 
isWrapperFor(Class<?>) - Method in class org.springframework.batch.item.database.ExtendedConnectionDataSourceProxy
Performs only a 'shallow' non-recursive check of self's and delegate's class to retain Java 5 compatibility.
ITEM_ID_COLUMN - Static variable in class org.springframework.batch.sample.domain.order.internal.mapper.OrderItemFieldSetMapper
 
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
 
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.

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 that opens a JDBC cursor and continually retrieves the next row in the ResultSet.
JdbcCursorItemReader() - Constructor for class org.springframework.batch.item.database.JdbcCursorItemReader
 
JdbcCustomerDao - Class in org.springframework.batch.sample.domain.trade.internal
 
JdbcCustomerDao() - Constructor for class org.springframework.batch.sample.domain.trade.internal.JdbcCustomerDao
 
JdbcCustomerDebitDao - Class in org.springframework.batch.sample.domain.trade.internal
Reduces customer's credit by the provided amount.
JdbcCustomerDebitDao() - Constructor for class org.springframework.batch.sample.domain.trade.internal.JdbcCustomerDebitDao
 
JdbcExecutionContextDao - Class in org.springframework.batch.core.repository.dao
JDBC DAO for ExecutionContext.
JdbcExecutionContextDao() - Constructor for class org.springframework.batch.core.repository.dao.JdbcExecutionContextDao
 
JdbcGameDao - Class in org.springframework.batch.sample.domain.football.internal
 
JdbcGameDao() - Constructor for class org.springframework.batch.sample.domain.football.internal.JdbcGameDao
 
JdbcJobExecutionDao - Class in org.springframework.batch.core.repository.dao
Jdbc implementation of JobExecutionDao.
JdbcJobExecutionDao() - Constructor for class org.springframework.batch.core.repository.dao.JdbcJobExecutionDao
 
JdbcJobInstanceDao - Class in org.springframework.batch.core.repository.dao
Jdbc implementation of JobInstanceDao.
JdbcJobInstanceDao() - Constructor for class org.springframework.batch.core.repository.dao.JdbcJobInstanceDao
 
JdbcPagingItemReader<T> - Class in org.springframework.batch.item.database
ItemReader for reading database records using JDBC in a paging fashion.
JdbcPagingItemReader() - Constructor for class org.springframework.batch.item.database.JdbcPagingItemReader
 
JdbcParameterUtils - Class in org.springframework.batch.item.database
Helper methods for SQL statement parameter parsing.
JdbcParameterUtils() - Constructor for class org.springframework.batch.item.database.JdbcParameterUtils
 
JdbcPlayerDao - Class in org.springframework.batch.sample.domain.football.internal
 
JdbcPlayerDao() - Constructor for class org.springframework.batch.sample.domain.football.internal.JdbcPlayerDao
 
JdbcPlayerSummaryDao - Class in org.springframework.batch.sample.domain.football.internal
 
JdbcPlayerSummaryDao() - Constructor for class org.springframework.batch.sample.domain.football.internal.JdbcPlayerSummaryDao
 
JdbcStepExecutionDao - Class in org.springframework.batch.core.repository.dao
Jdbc implementation of StepExecutionDao.
JdbcStepExecutionDao() - Constructor for class org.springframework.batch.core.repository.dao.JdbcStepExecutionDao
 
JdbcTradeDao - Class in org.springframework.batch.sample.domain.trade.internal
Writes a Trade object to a database
JdbcTradeDao() - Constructor for class org.springframework.batch.sample.domain.trade.internal.JdbcTradeDao
 
JmsItemReader<T> - Class in org.springframework.batch.item.jms
An ItemReader for JMS using a JmsTemplate.
JmsItemReader() - Constructor for class org.springframework.batch.item.jms.JmsItemReader
 
JmsItemWriter<T> - Class in org.springframework.batch.item.jms
An ItemWriter for JMS using a JmsTemplate.
JmsItemWriter() - Constructor for class org.springframework.batch.item.jms.JmsItemWriter
 
JmsMethodArgumentsKeyGenerator - Class in org.springframework.batch.item.jms
A MethodArgumentsKeyGenerator for JMS
JmsMethodArgumentsKeyGenerator() - Constructor for class org.springframework.batch.item.jms.JmsMethodArgumentsKeyGenerator
 
JmsMethodInvocationRecoverer<T> - Class in org.springframework.batch.item.jms
 
JmsMethodInvocationRecoverer() - Constructor for class org.springframework.batch.item.jms.JmsMethodInvocationRecoverer
 
JmsNewMethodArgumentsIdentifier<T> - Class in org.springframework.batch.item.jms
A NewMethodArgumentsIdentifier for JMS that looks for a message in the arguments and checks its delivery status.
JmsNewMethodArgumentsIdentifier() - Constructor for class org.springframework.batch.item.jms.JmsNewMethodArgumentsIdentifier
 
jmsTemplate - Variable in class org.springframework.batch.item.jms.JmsItemReader
 
Job - Interface in org.springframework.batch.core
Batch domain object representing a job.
JOB_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
 
JobExecutionNotificationPublisher - Class in org.springframework.batch.sample.jmx
JMX notification broadcaster
JobExecutionNotificationPublisher() - Constructor for class org.springframework.batch.sample.jmx.JobExecutionNotificationPublisher
 
JobExecutionNotRunningException - Exception in org.springframework.batch.core.launch
Execution indicating that a JobExecution that is not currently running has been requested to stop.
JobExecutionNotRunningException(String) - Constructor for exception org.springframework.batch.core.launch.JobExecutionNotRunningException
Create a JobExecutionNotRunningException with a message.
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
 
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
 
JobLauncher - Interface in org.springframework.batch.core.launch
Simple interface for controlling jobs, including possible ad-hoc executions, based on different runtime identifiers.
JobLauncherDetails - Class in org.springframework.batch.sample.quartz
 
JobLauncherDetails() - Constructor for class org.springframework.batch.sample.quartz.JobLauncherDetails
 
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.sample.launch
 
JobLocator - Interface in org.springframework.batch.core.configuration
A runtime service locator interface for retrieving job configurations by name.
JobOperator - Interface in org.springframework.batch.core.launch
Low level interface for inspecting and controlling jobs with access only to primitive and collection types.
JobParameter - Class in org.springframework.batch.core
Domain representation of a parameter to a batch job.
JobParameter(String) - 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.
JobParametersIncrementer - Interface in org.springframework.batch.core
Interface for obtaining the next JobParameters in a sequence.
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
 
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
 
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
 
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
 
jumpToItem(int) - Method in class org.springframework.batch.item.database.AbstractPagingItemReader
 
jumpToItem(int) - Method in class org.springframework.batch.item.database.JdbcCursorItemReader
Use ResultSet.absolute(int) if possible, otherwise scroll by calling ResultSet.next().
jumpToItem(int) - Method in class org.springframework.batch.item.support.AbstractItemCountingItemStreamItemReader
Move to the given item index.
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

LAST_NAME_COLUMN - Static variable in class org.springframework.batch.sample.domain.order.internal.mapper.CustomerFieldSetMapper
 
LastModifiedResourceComparator - Class in org.springframework.batch.support
Comparator to sort resources by the file last modified time.
LastModifiedResourceComparator() - Constructor for class org.springframework.batch.support.LastModifiedResourceComparator
 
launchJob() - Method in class org.springframework.batch.test.AbstractJobTests
Launch the entire job, including all steps.
launchJob(JobParameters) - Method in class org.springframework.batch.test.AbstractJobTests
Launch the entire job, including all steps
launchStep(String) - Method in class org.springframework.batch.test.AbstractJobTests
Launch just the specified step in the job.
launchStep(String, ExecutionContext) - Method in class org.springframework.batch.test.AbstractJobTests
Launch just the specified step in the job.
launchStep(String, JobParameters) - Method in class org.springframework.batch.test.AbstractJobTests
Launch just the specified step in the job.
launchStep(String, JobParameters, ExecutionContext) - Method in class org.springframework.batch.test.AbstractJobTests
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(int) - Constructor for class org.springframework.batch.core.step.skip.LimitCheckingItemSkipPolicy
Convenience constructor that assumes all exception types are skippable and none are fatal.
LimitCheckingItemSkipPolicy(int, Collection<Class<? extends Throwable>>, Collection<Class<? extends Throwable>>) - Constructor for class org.springframework.batch.core.step.skip.LimitCheckingItemSkipPolicy
 
LimitCheckingItemSkipPolicy(int, Classifier<Throwable, Boolean>, Classifier<Throwable, Boolean>) - Constructor for class org.springframework.batch.core.step.skip.LimitCheckingItemSkipPolicy
 
LimitDecider - Class in org.springframework.batch.sample.loopFlow
This decider will return "CONTINUE" until the limit it reached, at which point it will return "COMPLETE".
LimitDecider() - Constructor for class org.springframework.batch.sample.loopFlow.LimitDecider
 
LINE_ID_BILLING_ADDR - Static variable in class org.springframework.batch.sample.domain.order.Address
 
LINE_ID_BILLING_INFO - Static variable in class org.springframework.batch.sample.domain.order.BillingInfo
 
LINE_ID_BUSINESS_CUST - Static variable in class org.springframework.batch.sample.domain.order.Customer
 
LINE_ID_COLUMN - Static variable in class org.springframework.batch.sample.domain.order.internal.mapper.CustomerFieldSetMapper
 
LINE_ID_FOOTER - Static variable in class org.springframework.batch.sample.domain.order.Order
 
LINE_ID_HEADER - Static variable in class org.springframework.batch.sample.domain.order.Order
 
LINE_ID_ITEM - Static variable in class org.springframework.batch.sample.domain.order.LineItem
 
LINE_ID_NON_BUSINESS_CUST - Static variable in class org.springframework.batch.sample.domain.order.Customer
 
LINE_ID_SHIPPING_ADDR - Static variable in class org.springframework.batch.sample.domain.order.Address
 
LINE_ID_SHIPPING_INFO - Static variable in class org.springframework.batch.sample.domain.order.ShippingInfo
 
LineAggregator<T> - Interface in org.springframework.batch.item.file.transform
Interface used to create string representing object.
LineCallbackHandler - Interface in org.springframework.batch.item.file
Callback interface for handling a line from file.
LineItem - Class in org.springframework.batch.sample.domain.order.internal.xml
An XML line-item.
LineItem() - Constructor for class org.springframework.batch.sample.domain.order.internal.xml.LineItem
 
LineItem - Class in org.springframework.batch.sample.domain.order
 
LineItem() - Constructor for class org.springframework.batch.sample.domain.order.LineItem
 
LineItemFieldExtractor - Class in org.springframework.batch.sample.domain.order.internal.extractor
 
LineItemFieldExtractor() - Constructor for class org.springframework.batch.sample.domain.order.internal.extractor.LineItemFieldExtractor
 
LineMapper<T> - Interface in org.springframework.batch.item.file
Interface for mapping lines (strings) to domain objects typically used to map lines read from a file to domain objects on a per line basis.
LineTokenizer - Interface in org.springframework.batch.item.file.transform
Interface that is used by framework to split string obtained typically from a file into tokens.
ListableJobRegistry - Interface in org.springframework.batch.core.configuration
A listable extension of JobRegistry.
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
 
loadResource(String) - Method in class org.springframework.batch.sample.launch.DefaultJobLoader
 
loadResource(String) - Method in interface org.springframework.batch.sample.launch.ExportedJobLoader
 
loadResource(String) - Method in interface org.springframework.batch.sample.launch.JobLoader
 
log(CustomerUpdate) - Method in class org.springframework.batch.sample.domain.trade.internal.CommonsLoggingInvalidCustomerLogger
 
log(CustomerUpdate) - Method in interface org.springframework.batch.sample.domain.trade.InvalidCustomerLogger
 
LogAdvice - Class in org.springframework.batch.sample.common
Wraps calls for 'Processing' methods which output a single Object to write the string representation of the object to the log.
LogAdvice() - Constructor for class org.springframework.batch.sample.common.LogAdvice
 
logger - Static variable in class org.springframework.batch.core.job.AbstractJob
 
logger - 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 - Static variable in class org.springframework.batch.sample.domain.trade.internal.CommonsLoggingInvalidCustomerLogger
 
logger - Static variable in class org.springframework.batch.sample.jmx.JobExecutionNotificationPublisher
 
logger - Variable in class org.springframework.batch.test.AbstractJobTests
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

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.
main(String...) - Static method in class test.jdbc.datasource.DataSourceInitializer
Main method as convenient entry point.
MapExecutionContextDao - Class in org.springframework.batch.core.repository.dao
In-memory implementation of ExecutionContextDao backed by static maps.
MapExecutionContextDao() - Constructor for class org.springframework.batch.core.repository.dao.MapExecutionContextDao
 
mapFieldSet(FieldSet) - Method in class org.springframework.batch.item.file.mapping.BeanWrapperFieldSetMapper
Map the FieldSet to an object retrieved from the enclosing Spring context, or to a new instance of the required type if no prototype is available.
mapFieldSet(FieldSet) - Method in interface org.springframework.batch.item.file.mapping.FieldSetMapper
Method used to map data obtained from a FieldSet into an object.
mapFieldSet(FieldSet) - Method in class org.springframework.batch.item.file.mapping.PassThroughFieldSetMapper
 
mapFieldSet(FieldSet) - Method in class org.springframework.batch.sample.domain.football.internal.GameFieldSetMapper
 
mapFieldSet(FieldSet) - Method in class org.springframework.batch.sample.domain.football.internal.PlayerFieldSetMapper
 
mapFieldSet(FieldSet) - Method in class org.springframework.batch.sample.domain.multiline.AggregateItemFieldSetMapper
Build an AggregateItem based on matching the first column in the input FieldSet to check for begin and end delimiters.
mapFieldSet(FieldSet) - Method in class org.springframework.batch.sample.domain.order.internal.mapper.AddressFieldSetMapper
 
mapFieldSet(FieldSet) - Method in class org.springframework.batch.sample.domain.order.internal.mapper.BillingFieldSetMapper
 
mapFieldSet(FieldSet) - Method in class org.springframework.batch.sample.domain.order.internal.mapper.CustomerFieldSetMapper
 
mapFieldSet(FieldSet) - Method in class org.springframework.batch.sample.domain.order.internal.mapper.HeaderFieldSetMapper
 
mapFieldSet(FieldSet) - Method in class org.springframework.batch.sample.domain.order.internal.mapper.OrderItemFieldSetMapper
 
mapFieldSet(FieldSet) - Method in class org.springframework.batch.sample.domain.order.internal.mapper.ShippingFieldSetMapper
 
mapFieldSet(FieldSet) - Method in class org.springframework.batch.sample.domain.trade.CustomerUpdateFieldSetMapper
 
mapFieldSet(FieldSet) - Method in class org.springframework.batch.sample.domain.trade.internal.CustomerCreditFieldSetMapper
 
mapFieldSet(FieldSet) - Method in class org.springframework.batch.sample.domain.trade.internal.TradeFieldSetMapper
 
MapJobExecutionDao - Class in org.springframework.batch.core.repository.dao
In-memory implementation of JobExecutionDao.
MapJobExecutionDao() - Constructor for class org.springframework.batch.core.repository.dao.MapJobExecutionDao
 
MapJobExplorerFactoryBean - Class in org.springframework.batch.core.explore.support
A FactoryBean that automates the creation of a SimpleJobExplorer using in-memory DAO implementations.
MapJobExplorerFactoryBean() - Constructor for class org.springframework.batch.core.explore.support.MapJobExplorerFactoryBean
 
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 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
 
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.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
 
mapRow(ResultSet, int) - Method in class org.springframework.batch.sample.domain.football.internal.PlayerSummaryMapper
 
mapRow(ResultSet, int) - Method in class org.springframework.batch.sample.domain.football.internal.PlayerSummaryRowMapper
 
mapRow(ResultSet, int) - Method in class org.springframework.batch.sample.domain.trade.internal.CustomerCreditRowMapper
 
mapRow(ResultSet, int) - Method in class org.springframework.batch.sample.domain.trade.internal.CustomerDebitRowMapper
 
mapRow(ResultSet, int) - Method in class org.springframework.batch.sample.domain.trade.internal.TradeRowMapper
 
MapStepExecutionDao - Class in org.springframework.batch.core.repository.dao
In-memory implementation of StepExecutionDao.
MapStepExecutionDao() - Constructor for class org.springframework.batch.core.repository.dao.MapStepExecutionDao
 
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.
MIDDLE_NAME_COLUMN - Static variable in class org.springframework.batch.sample.domain.order.internal.mapper.CustomerFieldSetMapper
 
moveCursorToNextFragment(XMLEventReader) - Method in class org.springframework.batch.item.xml.StaxEventItemReader
Responsible for moving the cursor before the StartElement of the fragment root.
MulticasterBatchListener<T,S> - Class in org.springframework.batch.core.listener
 
MulticasterBatchListener() - Constructor for class org.springframework.batch.core.listener.MulticasterBatchListener
Initialise the listener instance.
MultiResourceItemReader<T> - Class in org.springframework.batch.item.file
Reads items from multiple resources sequentially - resource list is given by MultiResourceItemReader.setResources(Resource[]), the actual reading is delegated to MultiResourceItemReader.setDelegate(ResourceAwareItemReaderItemStream).
MultiResourceItemReader() - Constructor for class org.springframework.batch.item.file.MultiResourceItemReader
 
MultiResourceItemWriter<T> - Class in org.springframework.batch.item.file
Wraps a ResourceAwareItemWriterItemStream and creates a new output resource when the count of items written in current resource exceeds MultiResourceItemWriter.setItemCountLimitPerResource(int).
MultiResourceItemWriter() - Constructor for class org.springframework.batch.item.file.MultiResourceItemWriter
 
MultiResourcePartitioner - Class in org.springframework.batch.core.partition.support
Implementation of Partitioner that locates multiple resources and associates their file names with execution context keys.
MultiResourcePartitioner() - Constructor for class org.springframework.batch.core.partition.support.MultiResourcePartitioner
 
MySqlPagingQueryProvider - Class in org.springframework.batch.item.database.support
MySQL implementation of a PagingQueryProvider using database specific features.
MySqlPagingQueryProvider() - Constructor for class org.springframework.batch.item.database.support.MySqlPagingQueryProvider
 

N

NAME_COLUMN - Static variable in class org.springframework.batch.sample.domain.trade.internal.CustomerCreditFieldSetMapper
 
NAME_COLUMN - Static variable in class org.springframework.batch.sample.domain.trade.internal.CustomerCreditRowMapper
 
names - Variable in class org.springframework.batch.item.file.transform.AbstractLineTokenizer
 
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
 
NEW - Static variable in class org.springframework.batch.sample.common.StagingItemWriter
 
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
 
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.sample.jmx.JobExecutionNotificationPublisher
If the event is a SimpleMessageApplicationEvent for open and close we log the event at INFO level and send a JMX notification if we are also an MBean.
onError(RepeatContext, Throwable) - Method in class org.springframework.batch.repeat.listener.CompositeRepeatListener
 
onError(RepeatContext, Throwable) - Method in class org.springframework.batch.repeat.listener.RepeatListenerSupport
 
onError(RepeatContext, Throwable) - Method in interface org.springframework.batch.repeat.RepeatListener
Called when a repeat callback fails by throwing an exception.
onError(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.
onError(RepeatContext, Throwable) - Method in class org.springframework.batch.sample.domain.trade.internal.HibernateCreditDao
 
onError(JoinPoint, StepExecution, Throwable) - Method in class org.springframework.batch.sample.jmx.StepExecutionApplicationEventAdvice
 
onErrorInStep(StepExecution, Throwable) - Method in class org.springframework.batch.core.listener.StepListenerSupport
 
onErrorInStep(StepExecution, Throwable) - Method in class org.springframework.batch.sample.common.StagingItemReader
 
onErrorInStep(StepExecution, Throwable) - Method in class org.springframework.batch.sample.common.StagingItemWriter
 
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 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 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 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.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 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.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.
open(ExecutionContext) - Method in class org.springframework.batch.sample.domain.trade.internal.FlatFileCustomerCreditDao
 
open(RepeatContext) - Method in class org.springframework.batch.sample.domain.trade.internal.HibernateCreditDao
 
open() - Method in class org.springframework.batch.sample.domain.trade.internal.IbatisCustomerCreditDao
 
open(ExecutionContext) - Method in class org.springframework.batch.sample.domain.trade.internal.TradeWriter
 
OraclePagingQueryProvider - Class in org.springframework.batch.item.database.support
Oracle implementation of a PagingQueryProvider using database specific features.
OraclePagingQueryProvider() - Constructor for class org.springframework.batch.item.database.support.OraclePagingQueryProvider
 
Order - Class in org.springframework.batch.sample.domain.order.internal.xml
An XML order.
Order() - Constructor for class org.springframework.batch.sample.domain.order.internal.xml.Order
 
Order - Class in org.springframework.batch.sample.domain.order
 
Order() - Constructor for class org.springframework.batch.sample.domain.order.Order
 
ORDER_DATE_COLUMN - Static variable in class org.springframework.batch.sample.domain.order.internal.mapper.HeaderFieldSetMapper
 
ORDER_ID_COLUMN - Static variable in class org.springframework.batch.sample.domain.order.internal.mapper.HeaderFieldSetMapper
 
OrderDao - Interface in org.springframework.batch.sample.domain.order
Interface for writing Order objects.
OrderItemFieldSetMapper - Class in org.springframework.batch.sample.domain.order.internal.mapper
 
OrderItemFieldSetMapper() - Constructor for class org.springframework.batch.sample.domain.order.internal.mapper.OrderItemFieldSetMapper
 
OrderItemReader - Class in org.springframework.batch.sample.domain.order.internal
 
OrderItemReader() - Constructor for class org.springframework.batch.sample.domain.order.internal.OrderItemReader
 
OrderLineAggregator - Class in org.springframework.batch.sample.domain.order.internal
Converts Order object to a list of strings.
OrderLineAggregator() - Constructor for class org.springframework.batch.sample.domain.order.internal.OrderLineAggregator
 
org.springframework.batch.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.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.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.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.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.sample.common - package org.springframework.batch.sample.common
 
org.springframework.batch.sample.domain.football - package org.springframework.batch.sample.domain.football
 
org.springframework.batch.sample.domain.football.internal - package org.springframework.batch.sample.domain.football.internal
 
org.springframework.batch.sample.domain.multiline - package org.springframework.batch.sample.domain.multiline
 
org.springframework.batch.sample.domain.order - package org.springframework.batch.sample.domain.order
 
org.springframework.batch.sample.domain.order.internal - package org.springframework.batch.sample.domain.order.internal
 
org.springframework.batch.sample.domain.order.internal.extractor - package org.springframework.batch.sample.domain.order.internal.extractor
 
org.springframework.batch.sample.domain.order.internal.mapper - package org.springframework.batch.sample.domain.order.internal.mapper
 
org.springframework.batch.sample.domain.order.internal.valang - package org.springframework.batch.sample.domain.order.internal.valang
 
org.springframework.batch.sample.domain.order.internal.xml - package org.springframework.batch.sample.domain.order.internal.xml
 
org.springframework.batch.sample.domain.person - package org.springframework.batch.sample.domain.person
 
org.springframework.batch.sample.domain.person.internal - package org.springframework.batch.sample.domain.person.internal
 
org.springframework.batch.sample.domain.trade - package org.springframework.batch.sample.domain.trade
 
org.springframework.batch.sample.domain.trade.internal - package org.springframework.batch.sample.domain.trade.internal
 
org.springframework.batch.sample.jmx - package org.springframework.batch.sample.jmx
 
org.springframework.batch.sample.launch - package org.springframework.batch.sample.launch
 
org.springframework.batch.sample.loopFlow - package org.springframework.batch.sample.loopFlow
 
org.springframework.batch.sample.quartz - package org.springframework.batch.sample.quartz
 
org.springframework.batch.sample.support - package org.springframework.batch.sample.support
 
org.springframework.batch.support - package org.springframework.batch.support
Infrastructure implementations of support concerns.
org.springframework.batch.support.annotation - package org.springframework.batch.support.annotation
 
org.springframework.batch.support.transaction - package org.springframework.batch.support.transaction
Infrastructure implementations of support transaction concerns.
org.springframework.batch.test - package org.springframework.batch.test
 
OsgiBundleXmlApplicationContextFactory - Class in org.springframework.batch.core.configuration.support
 
OsgiBundleXmlApplicationContextFactory() - Constructor for class org.springframework.batch.core.configuration.support.OsgiBundleXmlApplicationContextFactory
 
OutputFileListener - Class in org.springframework.batch.sample.common
 
OutputFileListener() - Constructor for class org.springframework.batch.sample.common.OutputFileListener
 
OutputFileNameListener - Class in org.springframework.batch.sample.common
 
OutputFileNameListener() - Constructor for class org.springframework.batch.sample.common.OutputFileNameListener
 

P

page - Variable in class org.springframework.batch.item.database.AbstractPagingItemReader
 
pageSize - Variable in class org.springframework.batch.item.database.AbstractPagingItemReader
 
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, 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.
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
 
parseStep(Element, ParserContext, String) - Method in class org.springframework.batch.core.configuration.xml.AbstractStepParser
 
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.
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
 
PAYMENT_DESC_COLUMN - Static variable in class org.springframework.batch.sample.domain.order.internal.mapper.BillingFieldSetMapper
 
PAYMENT_TYPE_ID_COLUMN - Static variable in class org.springframework.batch.sample.domain.order.internal.mapper.BillingFieldSetMapper
 
peek() - Method in class org.springframework.batch.item.xml.stax.DefaultFragmentEventReader
 
Person - Class in org.springframework.batch.sample.domain.person
 
Person() - Constructor for class org.springframework.batch.sample.domain.person.Person
 
PersonService - Class in org.springframework.batch.sample.domain.person
Custom class that contains logic that would normally be be contained in ItemReader and ItemWriter.
PersonService() - Constructor for class org.springframework.batch.sample.domain.person.PersonService
 
PersonWriter - Class in org.springframework.batch.sample.domain.person.internal
 
PersonWriter() - Constructor for class org.springframework.batch.sample.domain.person.internal.PersonWriter
 
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
 
Player - Class in org.springframework.batch.sample.domain.football
 
Player() - Constructor for class org.springframework.batch.sample.domain.football.Player
 
PlayerDao - Interface in org.springframework.batch.sample.domain.football
Interface for writing Player objects to arbitrary output.
PlayerFieldSetMapper - Class in org.springframework.batch.sample.domain.football.internal
 
PlayerFieldSetMapper() - Constructor for class org.springframework.batch.sample.domain.football.internal.PlayerFieldSetMapper
 
PlayerItemWriter - Class in org.springframework.batch.sample.domain.football.internal
 
PlayerItemWriter() - Constructor for class org.springframework.batch.sample.domain.football.internal.PlayerItemWriter
 
PlayerSummary - Class in org.springframework.batch.sample.domain.football
Domain object representing the summary of a given Player's year.
PlayerSummary() - Constructor for class org.springframework.batch.sample.domain.football.PlayerSummary
 
PlayerSummaryMapper - Class in org.springframework.batch.sample.domain.football.internal
RowMapper used to map a ResultSet to a PlayerSummary
PlayerSummaryMapper() - Constructor for class org.springframework.batch.sample.domain.football.internal.PlayerSummaryMapper
 
PlayerSummaryRowMapper - Class in org.springframework.batch.sample.domain.football.internal
RowMapper used to map a ResultSet to a PlayerSummary
PlayerSummaryRowMapper() - Constructor for class org.springframework.batch.sample.domain.football.internal.PlayerSummaryRowMapper
 
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
 
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.
PRICE_COLUMN - Static variable in class org.springframework.batch.sample.domain.order.internal.mapper.OrderItemFieldSetMapper
 
PRICE_COLUMN - Static variable in class org.springframework.batch.sample.domain.trade.internal.CustomerDebitRowMapper
 
PRICE_COLUMN - Static variable in class org.springframework.batch.sample.domain.trade.internal.TradeFieldSetMapper
 
PRICE_COLUMN - Static variable in class org.springframework.batch.sample.domain.trade.internal.TradeRowMapper
 
process(StepContribution, Chunk<I>) - Method in interface org.springframework.batch.core.step.item.ChunkProcessor
 
process(StepContribution, Chunk<I>) - Method in class org.springframework.batch.core.step.item.SimpleChunkProcessor
 
process(I) - Method in class org.springframework.batch.item.adapter.ItemProcessorAdapter
Invoke the delegate method and return the result.
process(I) - Method in interface org.springframework.batch.item.ItemProcessor
Process the provided item, returning a potentially modified or new item for continued processing.
process(I) - Method in class org.springframework.batch.item.support.CompositeItemProcessor
 
process(T) - Method in class org.springframework.batch.item.support.PassThroughItemProcessor
Just returns the item back to the caller.
process(T) - Method in class org.springframework.batch.item.validator.ValidatingItemProcessor
Validate the item and return it unmodified
process(ProcessIndicatorItemWrapper<T>) - Method in class org.springframework.batch.sample.common.StagingItemProcessor
Use the technical identifier to mark the input row as processed and return unwrapped item.
process(CustomerUpdate) - Method in class org.springframework.batch.sample.domain.trade.CustomerUpdateProcessor
 
process(CustomerCredit) - Method in class org.springframework.batch.sample.domain.trade.internal.CustomerCreditIncreaseProcessor
 
process(Trade) - Method in class org.springframework.batch.sample.domain.trade.internal.TradeProcessor
 
ProcessIndicatorItemWrapper<T> - Class in org.springframework.batch.sample.common
Item wrapper useful in "process indicator" usecase, where input is marked as processed by the processor/writer.
ProcessIndicatorItemWrapper(long, T) - Constructor for class org.springframework.batch.sample.common.ProcessIndicatorItemWrapper
 
processPerson(String, String) - Method in class org.springframework.batch.sample.domain.person.PersonService
 
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(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.

Q

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

R

Range - Class in org.springframework.batch.item.file.transform
A class to represent ranges.
Range(int) - Constructor for class org.springframework.batch.item.file.transform.Range
 
Range(int, int) - Constructor for class org.springframework.batch.item.file.transform.Range
 
RangeArrayPropertyEditor - Class in org.springframework.batch.item.file.transform
Property editor implementation which parses string and creates array of ranges.
RangeArrayPropertyEditor() - Constructor for class org.springframework.batch.item.file.transform.RangeArrayPropertyEditor
 
read() - Method in class example.ExampleItemReader
Reads next record from input
read(StepContribution, Chunk<I>) - Method in class org.springframework.batch.core.step.item.FaultTolerantChunkProvider
 
read(StepContribution, Chunk<I>) - Method in class org.springframework.batch.core.step.item.SimpleChunkProvider
 
read() - Method in class org.springframework.batch.item.adapter.ItemReaderAdapter
 
read() - Method in class org.springframework.batch.item.file.MultiResourceItemReader
Reads the next item, jumping to next resource if necessary.
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.ListItemReader
 
read() - Method in class org.springframework.batch.sample.common.InfiniteLoopReader
 
read() - Method in class org.springframework.batch.sample.common.StagingItemReader
 
read() - Method in class org.springframework.batch.sample.domain.multiline.AggregateItemReader
Get the next list of records.
read() - Method in class org.springframework.batch.sample.domain.order.internal.OrderItemReader
 
read() - Method in class org.springframework.batch.sample.domain.trade.internal.GeneratingTradeItemReader
 
read() - Method in class org.springframework.batch.sample.support.ExceptionThrowingItemReaderProxy
 
readAndTrim(int) - Method in class org.springframework.batch.item.file.transform.DefaultFieldSet
Read and trim the String value at 'index'.
readBigDecimal(int) - Method in class org.springframework.batch.item.file.transform.DefaultFieldSet
 
readBigDecimal(String) - Method in class org.springframework.batch.item.file.transform.DefaultFieldSet
 
readBigDecimal(int, BigDecimal) - Method in class org.springframework.batch.item.file.transform.DefaultFieldSet
 
readBigDecimal(String, BigDecimal) - Method in class org.springframework.batch.item.file.transform.DefaultFieldSet
 
readBigDecimal(int) - Method in interface org.springframework.batch.item.file.transform.FieldSet
Read the BigDecimal value at index 'index'.
readBigDecimal(String) - Method in interface org.springframework.batch.item.file.transform.FieldSet
Read the BigDecimal value from column with given 'name.
readBigDecimal(int, BigDecimal) - Method in interface org.springframework.batch.item.file.transform.FieldSet
Read the BigDecimal value at index 'index', returning the supplied defaultValue if the trimmed string value at index 'index' is blank.
readBigDecimal(String, BigDecimal) - Method in interface org.springframework.batch.item.file.transform.FieldSet
Read the BigDecimal value from column with given 'name, returning the supplied defaultValue if the trimmed string value at index 'index' is blank.
readBoolean(int) - Method in class org.springframework.batch.item.file.transform.DefaultFieldSet
 
readBoolean(String) - Method in class org.springframework.batch.item.file.transform.DefaultFieldSet
 
readBoolean(int, String) - Method in class org.springframework.batch.item.file.transform.DefaultFieldSet
 
readBoolean(String, String) - Method in class org.springframework.batch.item.file.transform.DefaultFieldSet
 
readBoolean(int) - Method in interface org.springframework.batch.item.file.transform.FieldSet
Read the 'boolean' value at index 'index'.
readBoolean(String) - Method in interface org.springframework.batch.item.file.transform.FieldSet
Read the 'boolean' value from column with given 'name'.
readBoolean(int, String) - Method in interface org.springframework.batch.item.file.transform.FieldSet
Read the 'boolean' value at index 'index'.
readBoolean(String, String) - Method in interface org.springframework.batch.item.file.transform.FieldSet
Read the 'boolean' value from column with given 'name'.
readByte(int) - Method in class org.springframework.batch.item.file.transform.DefaultFieldSet
 
readByte(String) - Method in class org.springframework.batch.item.file.transform.DefaultFieldSet
 
readByte(int) - Method in interface org.springframework.batch.item.file.transform.FieldSet
Read the 'byte' value at index 'index'.
readByte(String) - Method in interface org.springframework.batch.item.file.transform.FieldSet
Read the 'byte' value from column with given 'name'.
readChar(int) - Method in class org.springframework.batch.item.file.transform.DefaultFieldSet
 
readChar(String) - Method in class org.springframework.batch.item.file.transform.DefaultFieldSet
 
readChar(int) - Method in interface org.springframework.batch.item.file.transform.FieldSet
Read the 'char' value at index 'index'.
readChar(String) - Method in interface org.springframework.batch.item.file.transform.FieldSet
Read the 'char' value from column with given 'name'.
readDate(int) - Method in class org.springframework.batch.item.file.transform.DefaultFieldSet
 
readDate(String) - Method in class org.springframework.batch.item.file.transform.DefaultFieldSet
 
readDate(int, String) - Method in class org.springframework.batch.item.file.transform.DefaultFieldSet
 
readDate(String, String) - Method in class org.springframework.batch.item.file.transform.DefaultFieldSet
 
readDate(int) - Method in interface org.springframework.batch.item.file.transform.FieldSet
Read the java.util.Date value in default format at designated column index.
readDate(String) - Method in interface org.springframework.batch.item.file.transform.FieldSet
Read the java.sql.Date value in given format from column with given name.
readDate(int, String) - Method in interface org.springframework.batch.item.file.transform.FieldSet
Read the java.util.Date value in default format at designated column index.
readDate(String, String) - Method in interface org.springframework.batch.item.file.transform.FieldSet
Read the java.sql.Date value in given format from column with given name.
readDouble(int) - Method in class org.springframework.batch.item.file.transform.DefaultFieldSet
 
readDouble(String) - Method in class org.springframework.batch.item.file.transform.DefaultFieldSet
 
readDouble(int) - Method in interface org.springframework.batch.item.file.transform.FieldSet
Read the 'double' value at index 'index'.
readDouble(String) - Method in interface org.springframework.batch.item.file.transform.FieldSet
Read the 'double' value from column with given 'name.
ReaderNotOpenException - Exception in org.springframework.batch.item
Exception indicating that an ItemReader needed to be opened before read.
ReaderNotOpenException(String) - Constructor for exception org.springframework.batch.item.ReaderNotOpenException
Create a new ReaderNotOpenException based on a message.
ReaderNotOpenException(String, Throwable) - Constructor for exception org.springframework.batch.item.ReaderNotOpenException
Create a new ReaderNotOpenException based on a message and another exception.
readFloat(int) - Method in class org.springframework.batch.item.file.transform.DefaultFieldSet
 
readFloat(String) - Method in class org.springframework.batch.item.file.transform.DefaultFieldSet
 
readFloat(int) - Method in interface org.springframework.batch.item.file.transform.FieldSet
Read the 'float' value at index 'index'.
readFloat(String) - Method in interface org.springframework.batch.item.file.transform.FieldSet
Read the 'float' value from column with given 'name.
readInt(int) - Method in class org.springframework.batch.item.file.transform.DefaultFieldSet
 
readInt(String) - Method in class org.springframework.batch.item.file.transform.DefaultFieldSet
 
readInt(int, int) - Method in class org.springframework.batch.item.file.transform.DefaultFieldSet
 
readInt(String, int) - Method in class org.springframework.batch.item.file.transform.DefaultFieldSet
 
readInt(int) - Method in interface org.springframework.batch.item.file.transform.FieldSet
Read the 'int' value at index 'index'.
readInt(String) - Method in interface org.springframework.batch.item.file.transform.FieldSet
Read the 'int' value from column with given 'name'.
readInt(int, int) - Method in interface org.springframework.batch.item.file.transform.FieldSet
Read the 'int' value at index 'index', using the supplied defaultValue if the field value is blank.
readInt(String, int) - Method in interface org.springframework.batch.item.file.transform.FieldSet
Read the 'int' value from column with given 'name', using the supplied defaultValue if the field value is blank.
readLong(int) - Method in class org.springframework.batch.item.file.transform.DefaultFieldSet
 
readLong(String) - Method in class org.springframework.batch.item.file.transform.DefaultFieldSet
 
readLong(int, long) - Method in class org.springframework.batch.item.file.transform.DefaultFieldSet
 
readLong(String, long) - Method in class org.springframework.batch.item.file.transform.DefaultFieldSet
 
readLong(int) - Method in interface org.springframework.batch.item.file.transform.FieldSet
Read the 'long' value at index 'index'.
readLong(String) - Method in interface org.springframework.batch.item.file.transform.FieldSet
Read the 'long' value from column with given 'name'.
readLong(int, long) - Method in interface org.springframework.batch.item.file.transform.FieldSet
Read the 'long' value at index 'index', using the supplied defaultValue if the field value is blank.
readLong(String, long) - Method in interface org.springframework.batch.item.file.transform.FieldSet
Read the 'long' value from column with given 'name', using the supplied defaultValue if the field value is blank.
readRawString(int) - Method in class org.springframework.batch.item.file.transform.DefaultFieldSet
 
readRawString(String) - Method in class org.springframework.batch.item.file.transform.DefaultFieldSet
 
readRawString(int) - Method in interface org.springframework.batch.item.file.transform.FieldSet
Read the String value at index 'index' including trailing whitespace (don't trim).
readRawString(String) - Method in interface org.springframework.batch.item.file.transform.FieldSet
Read the String value from column with given 'name' including trailing whitespace (don't trim).
readShort(int) - Method in class org.springframework.batch.item.file.transform.DefaultFieldSet
 
readShort(String) - Method in class org.springframework.batch.item.file.transform.DefaultFieldSet
 
readShort(int) - Method in interface org.springframework.batch.item.file.transform.FieldSet
Read the 'short' value at index 'index'.
readShort(String) - Method in interface org.springframework.batch.item.file.transform.FieldSet
Read the 'short' value from column with given 'name'.
readString(int) - Method in class org.springframework.batch.item.file.transform.DefaultFieldSet
 
readString(String) - Method in class org.springframework.batch.item.file.transform.DefaultFieldSet
 
readString(int) - Method in interface org.springframework.batch.item.file.transform.FieldSet
Read the String value at index 'index'.
readString(String) - Method in interface org.springframework.batch.item.file.transform.FieldSet
Read the String value from column with given 'name'.
RecordSeparatorPolicy - Interface in org.springframework.batch.item.file.separator
Policy for text file-based input sources to determine the end of a record, e.g. a record might be a single line, or it might be multiple lines terminated by a semicolon.
recover(Object[], Throwable) - Method in class org.springframework.batch.item.jms.JmsMethodInvocationRecoverer
Send one message per item in the arguments list using the default destination of the jms template.
recover(Object[], Throwable) - Method in interface org.springframework.batch.retry.interceptor.MethodInvocationRecoverer
Recover gracefully from an error.
recover(RetryContext) - Method in interface org.springframework.batch.retry.RecoveryCallback
 
RecoveryCallback<T> - Interface in org.springframework.batch.retry
Callback for stateful retry after all tries are exhausted.
RecursiveCollectionLineAggregator<T> - Class in org.springframework.batch.item.file.transform
An implementation of LineAggregator that concatenates a collection of items of a common type with the system line separator.
RecursiveCollectionLineAggregator() - Constructor for class org.springframework.batch.item.file.transform.RecursiveCollectionLineAggregator
 
ReferenceJobFactory - Class in org.springframework.batch.core.configuration.support
A JobFactory that just keeps a reference to a Job.
ReferenceJobFactory(Job) - Constructor for class org.springframework.batch.core.configuration.support.ReferenceJobFactory
 
REG_ID_COLUMN - Static variable in class org.springframework.batch.sample.domain.order.internal.mapper.CustomerFieldSetMapper
 
register(JobFactory) - Method in interface org.springframework.batch.core.configuration.JobRegistry
Registers a Job at runtime.
register(JobFactory) - Method in class org.springframework.batch.core.configuration.support.ClassPathXmlJobRegistry
 
register(JobFactory) - Method in class org.springframework.batch.core.configuration.support.MapJobRegistry
 
register(ChunkListener) - Method in class org.springframework.batch.core.listener.CompositeChunkListener
Register additional listener.
register(ItemProcessListener<? super T, ? super S>) - Method in class org.springframework.batch.core.listener.CompositeItemProcessListener
Register additional listener.
register(ItemReadListener<? super T>) - Method in class org.springframework.batch.core.listener.CompositeItemReadListener
Register additional listener.
register(ItemWriteListener<? super S>) - Method in class org.springframework.batch.core.listener.CompositeItemWriteListener
Register additional listener.
register(JobExecutionListener) - Method in class org.springframework.batch.core.listener.CompositeJobExecutionListener
Register additional listener.
register(SkipListener<? super T, ? super S>) - Method in class org.springframework.batch.core.listener.CompositeSkipListener
Register additional listener.
register(StepExecutionListener) - Method in class org.springframework.batch.core.listener.CompositeStepExecutionListener
Register additional listener.
register(StepListener) - Method in class org.springframework.batch.core.listener.MulticasterBatchListener
Register the listener for callbacks on the appropriate interfaces implemented.
register(StepExecution) - Static method in class org.springframework.batch.core.scope.context.StepSynchronizationManager
Register a context with the current thread - always put a matching StepSynchronizationManager.close() call in a finally block to ensure that the correct context is available in the enclosing block.
register(ItemStream) - Method in class org.springframework.batch.item.support.CompositeItemStream
Register a ItemStream as one of the interesting providers under the provided key.
register(RepeatListener) - Method in class org.springframework.batch.repeat.listener.CompositeRepeatListener
Register additional listener.
register(RepeatContext) - Static method in class org.springframework.batch.repeat.support.RepeatSynchronizationManager
Method for registering a context - should only be used by RepeatOperations implementations to ensure that RepeatSynchronizationManager.getContext() always returns the correct value.
register(RetryContext) - Static method in class org.springframework.batch.retry.support.RetrySynchronizationManager
Method for registering a context - should only be used by RetryOperations implementations to ensure that RetrySynchronizationManager.getContext() always returns the correct value.
registerChunkListener(ChunkListener) - Method in class org.springframework.batch.core.step.tasklet.TaskletStep
Register a chunk listener for callbacks at the appropriate stages in a step execution.
registerCustomEditors(PropertyEditorRegistry) - Method in class org.springframework.batch.support.DefaultPropertyEditorRegistrar
Register the custom editors with the given registry.
registerDestructionCallback(String, Runnable) - Method in class org.springframework.batch.core.scope.context.StepContext
Allow clients to register callbacks for clean up on close.
registerDestructionCallback(String, Runnable) - Method in class org.springframework.batch.core.scope.StepScope
 
registerDestructionCallback(String, Runnable) - Method in class org.springframework.batch.repeat.context.RepeatContextSupport
 
registerDestructionCallback(String, Runnable) - Method in interface org.springframework.batch.repeat.RepeatContext
Register a callback to be executed on close, associated with the attribute having the given name.
REGISTERED_COLUMN - Static variable in class org.springframework.batch.sample.domain.order.internal.mapper.CustomerFieldSetMapper
 
registerJobExecutionListener(JobExecutionListener) - Method in class org.springframework.batch.core.job.AbstractJob
Register a single listener for the JobExecutionListener callbacks.
registerListener(RetryListener) - Method in class org.springframework.batch.core.step.item.BatchRetryTemplate
 
registerListener(StepListener) - Method in class org.springframework.batch.core.step.item.SimpleChunkProcessor
Register a listener for callbacks at the appropriate stages in a process.
registerListener(StepListener) - Method in class org.springframework.batch.core.step.item.SimpleChunkProvider
Register a listener for callbacks at the appropriate stages in a process.
registerListener(RepeatListener) - Method in class org.springframework.batch.repeat.support.RepeatTemplate
Register an additional listener.
registerListener(RetryListener) - Method in class org.springframework.batch.retry.support.RetryTemplate
Register an additional listener.
registerStepExecutionListener(StepExecutionListener) - Method in class org.springframework.batch.core.step.AbstractStep
Register a step listener for callbacks at the appropriate stages in a step execution.
registerStream(ItemStream) - Method in class org.springframework.batch.core.step.tasklet.TaskletStep
Register a single ItemStream for callbacks to the stream interface.
registerStreams(TaskletStep, ItemStream[]) - Method in class org.springframework.batch.core.step.item.FaultTolerantStepFactoryBean
Register the streams with the step.
registerStreams(TaskletStep, ItemStream[]) - Method in class org.springframework.batch.core.step.item.SimpleStepFactoryBean
Register the streams with the step.
registerThrowable(Exception) - Method in class org.springframework.batch.retry.context.RetryContextSupport
Set the exception for the public interface RetryContext, and also increment the retry count if the throwable is non-null.
registerThrowable(RetryContext, Exception) - Method in class org.springframework.batch.retry.policy.CompositeRetryPolicy
Delegate to the policies that were in operation when the context was created.
registerThrowable(RetryContext, Exception) - Method in class org.springframework.batch.retry.policy.ExceptionClassifierRetryPolicy
Delegate to the policy currently activated in the context.
registerThrowable(RetryContext, Exception) - Method in class org.springframework.batch.retry.policy.NeverRetryPolicy
Do nothing.
registerThrowable(RetryContext, Exception) - Method in class org.springframework.batch.retry.policy.SimpleRetryPolicy
Update the status with another attempted retry and the latest exception.
registerThrowable(RetryContext, Exception) - Method in class org.springframework.batch.retry.policy.TimeoutRetryPolicy
 
registerThrowable(RetryContext, Exception) - Method in interface org.springframework.batch.retry.RetryPolicy
Called once per retry attempt, after the callback fails.
registerThrowable(RetryPolicy, RetryState, RetryContext, Exception) - Method in class org.springframework.batch.retry.support.RetryTemplate
 
release() - Static method in class org.springframework.batch.core.scope.context.StepSynchronizationManager
A convenient "deep" close operation.
remove(String) - Method in class org.springframework.batch.core.scope.StepScope
 
remove(Exception) - Method in class org.springframework.batch.core.step.item.Chunk.ChunkIterator
 
remove() - Method in class org.springframework.batch.core.step.item.Chunk.ChunkIterator
 
remove(String) - Method in class org.springframework.batch.item.ExecutionContext
Removes the mapping for a key from this context if it is present.
remove(Object) - Method in class org.springframework.batch.retry.policy.MapRetryContextCache
 
remove(Object) - Method in interface org.springframework.batch.retry.policy.RetryContextCache
 
remove(Object) - Method in class org.springframework.batch.retry.policy.SoftReferenceMapRetryContextCache
 
removeAttribute(String) - Method in class org.springframework.batch.core.scope.context.StepContext
Override base class behaviour to ensure destruction callbacks are unregistered as well as the default behaviour.
removeAttribute(String) - Method in class org.springframework.batch.repeat.context.SynchronizedAttributeAccessor
 
removeJobExecutions(Collection<JobExecution>) - Method in class org.springframework.batch.test.JobRepositoryTestUtils
Remove the JobExecution instances, and all associated JobInstance and StepExecution instances from the standard RDBMS locations used by Spring Batch.
removeJobExecutions() - Method in class org.springframework.batch.test.JobRepositoryTestUtils
Remove all the JobExecution instances, and all associated JobInstance and StepExecution instances from the standard RDBMS locations used by Spring Batch.
RepeatCallback - Interface in org.springframework.batch.repeat
Callback interface for batch operations.
RepeatContext - Interface in org.springframework.batch.repeat
Base interface for context which controls the state and completion / termination of a batch step.
RepeatContextCounter - Class in org.springframework.batch.repeat.context
Helper class for policies that need to count the number of occurrences of some event (e.g. an exception type in the context) in the scope of a batch.
RepeatContextCounter(RepeatContext, String) - Constructor for class org.springframework.batch.repeat.context.RepeatContextCounter
Convenience constructor with useParent=false.
RepeatContextCounter(RepeatContext, String, boolean) - Constructor for class org.springframework.batch.repeat.context.RepeatContextCounter
Construct a new RepeatContextCounter.
RepeatContextSupport - Class in org.springframework.batch.repeat.context
 
RepeatContextSupport(RepeatContext) - Constructor for class org.springframework.batch.repeat.context.RepeatContextSupport
Constructor for RepeatContextSupport.
RepeatException - Exception in org.springframework.batch.repeat
 
RepeatException(String) - Constructor for exception org.springframework.batch.repeat.RepeatException
 
RepeatException(String, Throwable) - Constructor for exception org.springframework.batch.repeat.RepeatException
 
RepeatInternalState - Interface in org.springframework.batch.repeat.support
Internal interface for extensions of RepeatTemplate.
RepeatInternalStateSupport - Class in org.springframework.batch.repeat.support
 
RepeatInternalStateSupport() - Constructor for class org.springframework.batch.repeat.support.RepeatInternalStateSupport
 
RepeatListener - Interface in org.springframework.batch.repeat
Interface for listeners to the batch process.
RepeatListenerSupport - Class in org.springframework.batch.repeat.listener
Empty method implementation of RepeatListener.
RepeatListenerSupport() - Constructor for class org.springframework.batch.repeat.listener.RepeatListenerSupport
 
RepeatOperations - Interface in org.springframework.batch.repeat
The main interface providing access to batch operations.
RepeatOperationsInterceptor - Class in org.springframework.batch.repeat.interceptor
A MethodInterceptor that can be used to automatically repeat calls to a method on a service.
RepeatOperationsInterceptor() - Constructor for class org.springframework.batch.repeat.interceptor.RepeatOperationsInterceptor
 
RepeatStatus - Enum in org.springframework.batch.repeat
 
RepeatSynchronizationManager - Class in org.springframework.batch.repeat.support
Global variable support for repeat clients.
RepeatTemplate - Class in org.springframework.batch.repeat.support
Simple implementation and base class for batch templates implementing RepeatOperations.
RepeatTemplate() - Constructor for class org.springframework.batch.repeat.support.RepeatTemplate
 
replaceExitCode(String) - Method in class org.springframework.batch.core.ExitStatus
Add an exit code to an existing ExitStatus.
reset() - Method in class org.springframework.batch.item.xml.stax.DefaultFragmentEventReader
 
reset() - Method in interface org.springframework.batch.item.xml.stax.FragmentEventReader
Reset the state of the fragment reader - make it forget it assumptions about current position of cursor (e.g. in case of rollback of the wrapped reader).
resetCounter() - Method in class org.springframework.batch.sample.domain.trade.internal.GeneratingTradeItemReader
 
resolveContextualObject(String) - Method in class org.springframework.batch.core.scope.StepScope
 
ResourceAwareItemReaderItemStream<T> - Interface in org.springframework.batch.item.file
Interface for ItemReaders that implement ItemStream and read input from Resource.
ResourceAwareItemWriterItemStream<T> - Interface in org.springframework.batch.item.file
Interface for ItemWriters that implement ItemStream and write output to Resource.
ResourcelessTransactionManager - Class in org.springframework.batch.support.transaction
 
ResourcelessTransactionManager() - Constructor for class org.springframework.batch.support.transaction.ResourcelessTransactionManager
 
ResourceSuffixCreator - Interface in org.springframework.batch.item.file
Strategy interface for translating resource index into unique filename suffix.
restart(long) - Method in interface org.springframework.batch.core.launch.JobOperator
Restart a failed or stopped JobExecution.
restart(long) - Method in class org.springframework.batch.core.launch.support.SimpleJobOperator
 
results - Variable in class org.springframework.batch.item.database.AbstractPagingItemReader
 
resume(String, FlowExecutor) - Method in interface org.springframework.batch.core.job.flow.Flow
 
resume(String, FlowExecutor) - Method in class org.springframework.batch.core.job.flow.support.SimpleFlow
 
RethrowOnThresholdExceptionHandler - Class in org.springframework.batch.repeat.exception
Implementation of ExceptionHandler that rethrows when exceptions of a given type reach a threshold.
RethrowOnThresholdExceptionHandler() - Constructor for class org.springframework.batch.repeat.exception.RethrowOnThresholdExceptionHandler
Set up the exception handler.
RetryCacheCapacityExceededException - Exception in org.springframework.batch.retry.policy
Exception that indicates that a cache limit was exceeded.
RetryCacheCapacityExceededException(String) - Constructor for exception org.springframework.batch.retry.policy.RetryCacheCapacityExceededException
Constructs a new instance with a message.
RetryCacheCapacityExceededException(String, Throwable) - Constructor for exception org.springframework.batch.retry.policy.RetryCacheCapacityExceededException
Constructs a new instance with a message and nested exception.
RetryCallback<T> - Interface in org.springframework.batch.retry
Callback interface for an operation that can be retried using a RetryOperations.
RetryContext - Interface in org.springframework.batch.retry
Low-level access to ongoing retry operation.
RetryContextCache - Interface in org.springframework.batch.retry.policy
Simple map-like abstraction for stateful retry policies to use when storing and retrieving RetryContext instances.
RetryContextSupport - Class in org.springframework.batch.retry.context
 
RetryContextSupport(RetryContext) - Constructor for class org.springframework.batch.retry.context.RetryContextSupport
 
RetryException - Exception in org.springframework.batch.retry
 
RetryException(String, Throwable) - Constructor for exception org.springframework.batch.retry.RetryException
 
RetryException(String) - Constructor for exception org.springframework.batch.retry.RetryException
 
RetryListener - Interface in org.springframework.batch.retry
Interface for listener that can be used to add behaviour to a retry.
RetryListenerSupport - Class in org.springframework.batch.retry.listener
Empty method implementation of RetryListener.
RetryListenerSupport() - Constructor for class org.springframework.batch.retry.listener.RetryListenerSupport
 
RetryOperations - Interface in org.springframework.batch.retry
Defines the basic set of operations implemented by RetryOperations to execute operations with configurable retry behaviour.
RetryOperationsInterceptor - Class in org.springframework.batch.retry.interceptor
A MethodInterceptor that can be used to automatically retry calls to a method on a service if it fails.
RetryOperationsInterceptor() - Constructor for class org.springframework.batch.retry.interceptor.RetryOperationsInterceptor
 
RetryPolicy - Interface in org.springframework.batch.retry
A RetryPolicy is responsible for allocating and managing resources needed by RetryOperations.
RetrySampleItemWriter<T> - Class in org.springframework.batch.sample.support
Simulates temporary output trouble - requires to retry 3 times to pass successfully.
RetrySampleItemWriter() - Constructor for class org.springframework.batch.sample.support.RetrySampleItemWriter
 
RetryState - Interface in org.springframework.batch.retry
Stateful retry is characterised by having to recognise the items that are being processed, so this interface is used primarily to provide a cache key in between failed attempts.
RetryStatistics - Interface in org.springframework.batch.retry
Interface for statistics reporting of retry attempts.
RetrySynchronizationManager - Class in org.springframework.batch.retry.support
Global variable support for retry clients.
RetryTemplate - Class in org.springframework.batch.retry.support
Template class that simplifies the execution of operations with retry semantics.
RetryTemplate() - Constructor for class org.springframework.batch.retry.support.RetryTemplate
 
RIGHT - Static variable in class org.springframework.batch.item.file.transform.Alignment
 
rollbackFor(Exception) - Method in interface org.springframework.batch.retry.RetryState
Check whether this exception requires a rollback.
rollbackFor(Exception) - Method in class org.springframework.batch.retry.support.DefaultRetryState
 
rs - Variable in class org.springframework.batch.item.database.JdbcCursorItemReader
 
run(Job, JobParameters) - Method in interface org.springframework.batch.core.launch.JobLauncher
Start a job execution for the given Job and JobParameters .
run(Job, JobParameters) - Method in class org.springframework.batch.core.launch.support.SimpleJobLauncher
Run the provided job with the given JobParameters.
RuntimeExceptionTranslator - Class in org.springframework.batch.core.launch.support
 
RuntimeExceptionTranslator() - Constructor for class org.springframework.batch.core.launch.support.RuntimeExceptionTranslator
 

S

saveExecutionContext(JobExecution) - Method in interface org.springframework.batch.core.repository.dao.ExecutionContextDao
Persist the execution context associated with the given jobExecution, persistent entry for the context should not exist yet.
saveExecutionContext(StepExecution) - Method in interface org.springframework.batch.core.repository.dao.ExecutionContextDao
Persist the execution context associated with the given stepExecution, persistent entry for the context should not exist yet.
saveExecutionContext(JobExecution) - Method in class org.springframework.batch.core.repository.dao.JdbcExecutionContextDao
 
saveExecutionContext(StepExecution) - Method in class org.springframework.batch.core.repository.dao.JdbcExecutionContextDao
 
saveExecutionContext(JobExecution) - Method in class org.springframework.batch.core.repository.dao.MapExecutionContextDao
 
saveExecutionContext(StepExecution) - Method in class org.springframework.batch.core.repository.dao.MapExecutionContextDao
 
saveJobExecution(JobExecution) - Method in class org.springframework.batch.core.repository.dao.JdbcJobExecutionDao
SQL implementation using Sequences via the Spring incrementer abstraction.
saveJobExecution(JobExecution) - Method in interface org.springframework.batch.core.repository.dao.JobExecutionDao
Save a new JobExecution.
saveJobExecution(JobExecution) - Method in class org.springframework.batch.core.repository.dao.MapJobExecutionDao
 
savePlayer(Player) - Method in class org.springframework.batch.sample.domain.football.internal.JdbcPlayerDao
 
savePlayer(Player) - Method in interface org.springframework.batch.sample.domain.football.PlayerDao
 
saveStepExecution(StepExecution) - Method in class org.springframework.batch.core.repository.dao.JdbcStepExecutionDao
Save a StepExecution.
saveStepExecution(StepExecution) - Method in class org.springframework.batch.core.repository.dao.MapStepExecutionDao
 
saveStepExecution(StepExecution) - Method in interface org.springframework.batch.core.repository.dao.StepExecutionDao
Save the given StepExecution.
SCHEDULE_DATE_KEY - Static variable in class org.springframework.batch.core.launch.support.ScheduledJobParametersFactory
 
ScheduledJobParametersFactory - Class in org.springframework.batch.core.launch.support
 
ScheduledJobParametersFactory() - Constructor for class org.springframework.batch.core.launch.support.ScheduledJobParametersFactory
 
serialize(Map<String, Object>) - Method in interface org.springframework.batch.core.repository.dao.ExecutionContextStringSerializer
Serialize the context to a string representation
serialize(Map<String, Object>) - Method in class org.springframework.batch.core.repository.dao.XStreamExecutionContextStringSerializer
 
setAddress(String) - Method in class org.springframework.batch.sample.domain.order.internal.xml.Customer
 
setAddress(Address) - Method in class org.springframework.batch.sample.domain.person.Person
 
setAddressee(String) - Method in class org.springframework.batch.sample.domain.order.Address
 
setAddressMapper(FieldSetMapper<Address>) - Method in class org.springframework.batch.sample.domain.order.internal.OrderItemReader
 
setAddrLine1(String) - Method in class org.springframework.batch.sample.domain.order.Address
 
setAddrLine2(String) - Method in class org.springframework.batch.sample.domain.order.Address
 
setAge(int) - Method in class org.springframework.batch.sample.domain.order.internal.xml.Customer
 
setAge(int) - Method in class org.springframework.batch.sample.domain.person.Person
 
setAggregators(Map<String, LineAggregator<Object>>) - Method in class org.springframework.batch.sample.domain.order.internal.OrderLineAggregator
Set aggregators for all types of lines in the output file
setAllowStartIfComplete(boolean) - Method in class org.springframework.batch.core.step.AbstractStep
Public setter for flag that determines whether the step should start again if it is already complete.
setAllowStartIfComplete(boolean) - Method in class org.springframework.batch.core.step.item.SimpleStepFactoryBean
Public setter for the flag to indicate that the step should be replayed on a restart, even if successful the first time.
setAncestorsCompleteOnly() - Static method in class org.springframework.batch.repeat.support.RepeatSynchronizationManager
Set current session and all ancestors (via parent) to complete
setApplicationContext(ApplicationContext) - Method in class org.springframework.batch.core.configuration.support.ClassPathXmlApplicationContextFactory
Setter for the parent application context.
setApplicationContext(ApplicationContext) - Method in class org.springframework.batch.core.configuration.support.ClassPathXmlJobRegistry
 
setApplicationContext(ApplicationContext) - Method in class org.springframework.batch.core.configuration.support.OsgiBundleXmlApplicationContextFactory
Setter for the parent application context.
setApplicationContext(ApplicationContext) - Method in class org.springframework.batch.core.configuration.xml.CoreNamespacePostProcessor
 
setApplicationContext(ApplicationContext) - Method in class org.springframework.batch.sample.launch.DefaultJobLoader
 
setApplicationContext(ApplicationContext) - Method in class org.springframework.batch.test.AbstractJobTests
setApplicationEventPublisher(ApplicationEventPublisher) - Method in class org.springframework.batch.sample.jmx.StepExecutionApplicationEventAdvice
 
setArguments(Object[]) - Method in class org.springframework.batch.item.adapter.AbstractMethodInvokingDelegator
 
setAscending(boolean) - Method in class org.springframework.batch.item.database.support.AbstractSqlPagingQueryProvider
Set the flag that signals that the sort key is applied ascending (default true).
setAscending(boolean) - Method in class org.springframework.batch.item.database.support.SqlPagingQueryProviderFactoryBean
 
setAssertUpdates(boolean) - Method in class org.springframework.batch.item.database.IbatisBatchItemWriter
Public setter for the flag that determines whether an assertion is made that all items cause at least one row to be updated.
setAssertUpdates(boolean) - Method in class org.springframework.batch.item.database.JdbcBatchItemWriter
Public setter for the flag that determines whether an assertion is made that all items cause at least one row to be updated.
setAsText(String) - Method in class org.springframework.batch.item.file.transform.RangeArrayPropertyEditor
 
setAsText(String) - Method in class org.springframework.batch.support.IntArrayPropertyEditor
 
setAttempts(int) - Method in class org.springframework.batch.sample.domain.football.Game
 
setAttempts(int) - Method in class org.springframework.batch.sample.domain.football.PlayerSummary
 
setAttribute(String, Object) - Method in class org.springframework.batch.repeat.context.SynchronizedAttributeAccessor
 
setAttributeIfAbsent(String, Object) - Method in class org.springframework.batch.repeat.context.SynchronizedAttributeAccessor
Additional support for atomic put if absent.
setBackOffPeriod(long) - Method in class org.springframework.batch.retry.backoff.FixedBackOffPolicy
Set the back off period in milliseconds.
setBackOffPolicy(BackOffPolicy) - Method in class org.springframework.batch.core.step.item.BatchRetryTemplate
 
setBackOffPolicy(BackOffPolicy) - Method in class org.springframework.batch.core.step.item.FaultTolerantStepFactoryBean
Public setter for the BackOffPolicy.
setBackOffPolicy(BackOffPolicy) - Method in class org.springframework.batch.retry.support.RetryTemplate
Setter for BackOffPolicy.
setBeanFactory(BeanFactory) - Method in class org.springframework.batch.core.scope.util.PlaceholderProxyFactoryBean
 
setBeanFactory(BeanFactory) - Method in class org.springframework.batch.item.file.mapping.BeanWrapperFieldSetMapper
 
setBeanName(String) - Method in class org.springframework.batch.core.job.AbstractJob
Set the name property if it is not already set.
setBeanName(String) - Method in class org.springframework.batch.core.step.AbstractStep
Set the name property if it is not already set.
setBeanName(String) - Method in class org.springframework.batch.core.step.item.SimpleStepFactoryBean
Set the bean name property, which will become the name of the Step when it is created.
setBegin(String) - Method in class org.springframework.batch.sample.domain.multiline.AggregateItemFieldSetMapper
Public setter for the begin value.
setBilling(BillingInfo) - Method in class org.springframework.batch.sample.domain.order.Order
 
setBillingAddress(Address) - Method in class org.springframework.batch.sample.domain.order.Order
 
setBillingMapper(FieldSetMapper<BillingInfo>) - Method in class org.springframework.batch.sample.domain.order.internal.OrderItemReader
 
setBirthYear(int) - Method in class org.springframework.batch.sample.domain.football.Player
 
setBuffering(boolean) - Method in class org.springframework.batch.core.step.item.ChunkOrientedTasklet
Flag to indicate that items should be buffered once read.
setBuffering(boolean) - Method in class org.springframework.batch.core.step.item.FaultTolerantChunkProcessor
A flag to indicate that items have been buffered and therefore will always come back as a chunk after a rollback.
setBundleContext(BundleContext) - Method in class org.springframework.batch.core.configuration.support.OsgiBundleXmlApplicationContextFactory
Stash the BundleContext for creating a job application context later.
setBusinessCustomer(boolean) - Method in class org.springframework.batch.sample.domain.order.Customer
 
setBusy(boolean) - Method in class org.springframework.batch.core.step.item.Chunk
Register an interest in the chunk to prevent it from being cleaned up before the flag is reset to false.
setCacheCapacity(int) - Method in class org.springframework.batch.core.step.item.FaultTolerantStepFactoryBean
Public setter for the capacity of the cache in the retry policy.
setCallable(Callable<RepeatStatus>) - Method in class org.springframework.batch.core.step.tasklet.CallableTaskletAdapter
Public setter for the Callable.
setCapacity(int) - Method in class org.springframework.batch.retry.policy.MapRetryContextCache
Public setter for the capacity.
setCapacity(int) - Method in class org.springframework.batch.retry.policy.SoftReferenceMapRetryContextCache
Public setter for the capacity.
setChildren(List<Child>) - Method in class org.springframework.batch.sample.domain.person.Person
 
setChunkCompletionPolicy(CompletionPolicy) - Method in class org.springframework.batch.core.step.item.SimpleStepFactoryBean
Public setter for the CompletionPolicy applying to the chunk level.
setChunkListeners(ChunkListener[]) - Method in class org.springframework.batch.core.step.tasklet.TaskletStep
Register each of the objects as listeners.
setChunkMonitor(ChunkMonitor) - Method in class org.springframework.batch.core.step.item.FaultTolerantChunkProcessor
 
setChunkOperations(RepeatOperations) - Method in class org.springframework.batch.core.step.item.SimpleStepFactoryBean
Public setter for the chunkOperations.
setChunkSize(int) - Method in class org.springframework.batch.repeat.policy.SimpleCompletionPolicy
 
setCity(String) - Method in class org.springframework.batch.sample.domain.order.Address
 
setClassifier(Classifier<T, ItemWriter<? super T>>) - Method in class org.springframework.batch.item.support.ClassifierCompositeItemWriter
 
setClobTypeToUse(int) - Method in class org.springframework.batch.core.repository.dao.AbstractJdbcBatchMetadataDao
 
setColumns(Range[]) - Method in class org.springframework.batch.item.file.transform.FixedLengthTokenizer
Set the column ranges.
setCommand(String) - Method in class org.springframework.batch.core.step.tasklet.SystemCommandTasklet
 
setComments(String[]) - Method in class org.springframework.batch.item.file.FlatFileItemReader
Setter for comment prefixes.
setCommitCount(int) - Method in class org.springframework.batch.core.StepExecution
Sets the current number of commits for this execution
setCommitInterval(int) - Method in class org.springframework.batch.core.step.item.SimpleStepFactoryBean
Set the commit interval.
setCompanyName(String) - Method in class org.springframework.batch.sample.domain.order.Customer
 
setComparator(Comparator<Resource>) - Method in class org.springframework.batch.item.file.MultiResourceItemReader
 
setComplete() - Method in class org.springframework.batch.core.scope.context.ChunkContext
Setter for the flag to signal complete processing of a chunk.
setCompleteOnly() - Method in class org.springframework.batch.repeat.context.RepeatContextSupport
 
setCompleteOnly() - Method in interface org.springframework.batch.repeat.RepeatContext
Signal to the framework that the current batch should complete normally, independent of the current CompletionPolicy.
setCompleteOnly() - Static method in class org.springframework.batch.repeat.support.RepeatSynchronizationManager
Convenience method to set the current repeat operation to complete if it exists.
setCompletes(int) - Method in class org.springframework.batch.sample.domain.football.Game
 
setCompletes(int) - Method in class org.springframework.batch.sample.domain.football.PlayerSummary
 
setCompletionPolicy(CompletionPolicy) - Method in class org.springframework.batch.repeat.support.RepeatTemplate
Setter for policy to decide when the batch is complete.
setContextFactory(ContextFactory) - Method in class org.springframework.batch.core.scope.util.PlaceholderTargetSource
Public setter for the context factory.
setContinuation(String) - Method in class org.springframework.batch.item.file.separator.DefaultRecordSeparatorPolicy
Public setter for the continuation.
setCountry(String) - Method in class org.springframework.batch.sample.domain.order.Address
 
setCreateTime(Date) - Method in class org.springframework.batch.core.JobExecution
 
setCredit(BigDecimal) - Method in class org.springframework.batch.sample.domain.trade.CustomerCredit
 
setCreditFilter(double) - Method in class org.springframework.batch.sample.domain.trade.internal.CustomerCreditUpdateWriter
 
setCurrentItemCount(int) - Method in class org.springframework.batch.item.support.AbstractItemCountingItemStreamItemReader
The index of the item to start reading from.
setCustomEditors(Map<? extends Object, ? extends PropertyEditor>) - Method in class org.springframework.batch.support.DefaultPropertyEditorRegistrar
Specify the custom editors to register.
setCustomer(Customer) - Method in class org.springframework.batch.sample.domain.order.internal.xml.Order
 
setCustomer(Customer) - Method in class org.springframework.batch.sample.domain.order.Order
 
setCustomer(String) - Method in class org.springframework.batch.sample.domain.trade.Trade
 
setCustomerCreditDao(CustomerCreditDao) - Method in class org.springframework.batch.sample.domain.trade.internal.CustomerCreditItemWriter
Public setter for the CustomerCreditDao.
setCustomerDao(CustomerDao) - Method in class org.springframework.batch.sample.domain.trade.CustomerUpdateProcessor
 
setCustomerDao(CustomerDao) - Method in class org.springframework.batch.sample.domain.trade.CustomerUpdateWriter
 
setCustomerMapper(FieldSetMapper<Customer>) - Method in class org.springframework.batch.sample.domain.order.internal.OrderItemReader
 
setCustomerTokenizer(LineTokenizer) - Method in class org.springframework.batch.sample.domain.trade.CompositeCustomerUpdateLineTokenizer
Set the LineTokenizer that will be used to tokenize any lines that begin with A, U, or D, and are thus a customer operation.
setDao(CustomerCreditDao) - Method in class org.springframework.batch.sample.domain.trade.internal.CustomerCreditUpdateWriter
 
setDao(CustomerDebitDao) - Method in class org.springframework.batch.sample.domain.trade.internal.CustomerUpdateWriter
 
setDao(CustomerCreditDao) - Method in class org.springframework.batch.sample.domain.trade.internal.HibernateAwareCustomerCreditItemWriter
 
setDao(TradeDao) - Method in class org.springframework.batch.sample.domain.trade.internal.TradeWriter
 
setDatabaseType(String) - Method in class org.springframework.batch.core.repository.support.JobRepositoryFactoryBean
Sets the database type.
setDatabaseType(String) - Method in class org.springframework.batch.item.database.support.SqlPagingQueryProviderFactoryBean
 
setDataDirectory(String) - Method in class test.jdbc.datasource.DerbyDataSourceFactoryBean
 
setDataSource(DataSource) - Method in class org.springframework.batch.core.explore.support.JobExplorerFactoryBean
Public setter for the DataSource.
setDataSource(DataSource) - Method in class org.springframework.batch.core.repository.support.JobRepositoryFactoryBean
Public setter for the DataSource.
setDataSource(DataSource) - Method in class org.springframework.batch.item.database.ExtendedConnectionDataSourceProxy
Setter for the {&link DataSource} that is to be wrapped.
setDataSource(DataSource) - Method in class org.springframework.batch.item.database.JdbcBatchItemWriter
Public setter for the data source for injection purposes.
setDataSource(DataSource) - Method in class org.springframework.batch.item.database.JdbcCursorItemReader
Public setter for the data source for injection purposes.
setDataSource(DataSource) - Method in class org.springframework.batch.item.database.JdbcPagingItemReader
 
setDataSource(DataSource) - Method in class org.springframework.batch.item.database.support.SqlPagingQueryProviderFactoryBean
 
setDataSource(DataSource) - Method in class org.springframework.batch.sample.common.StagingItemListener
 
setDataSource(DataSource) - Method in class org.springframework.batch.sample.common.StagingItemProcessor
 
setDataSource(DataSource) - Method in class org.springframework.batch.sample.common.StagingItemReader
 
setDataSource(DataSource) - Method in class org.springframework.batch.sample.domain.trade.internal.JdbcCustomerDebitDao
 
setDataSource(DataSource) - Method in class org.springframework.batch.sample.domain.trade.internal.JdbcTradeDao
 
setDataSource(DataSource) - Method in class org.springframework.batch.test.DataSourceInitializer
 
setDataSource(DataSource) - Method in class org.springframework.batch.test.JobRepositoryTestUtils
 
setDataSource(DataSource) - Method in class test.jdbc.datasource.DataSourceInitializer
 
setDate(Date) - Method in class org.springframework.batch.sample.domain.order.internal.xml.Order
 
setDateFormat(DateFormat) - Method in class org.springframework.batch.core.converter.DefaultJobParametersConverter
Public setter for injecting a date format.
setDateFormat(DateFormat) - Method in class org.springframework.batch.core.launch.support.ScheduledJobParametersFactory
Public setter for injecting a date format.
setDateFormat(DateFormat) - Method in class org.springframework.batch.item.file.transform.DefaultFieldSet
The DateFormat to use for parsing numbers.
setDateFormat(DateFormat) - Method in class org.springframework.batch.item.file.transform.DefaultFieldSetFactory
The DateFormat to use for parsing numbers.
setDebit(BigDecimal) - Method in class org.springframework.batch.sample.domain.trade.CustomerDebit
 
setDebutYear(int) - Method in class org.springframework.batch.sample.domain.football.Player
 
setDefaultValue(C) - Method in class org.springframework.batch.classify.SubclassClassifier
Public setter for the default value for mapping keys that are not found in the map (or their subclasses).
setDefaultValue(String) - Method in class org.springframework.batch.support.SystemPropertyInitializer
Mandatory property specifying the default value of the System property.
setDelegate(Classifier<C, T>) - Method in class org.springframework.batch.classify.ClassifierAdapter
 
setDelegate(Object) - Method in class org.springframework.batch.classify.ClassifierAdapter
Search for the Classifier annotation on a method in the supplied delegate and use that to create a Classifier from the parameter type to the return type.
setDelegate(Object) - Method in class org.springframework.batch.core.listener.AbstractListenerFactoryBean
 
setDelegate(ResourceAwareItemReaderItemStream<? extends T>) - Method in class org.springframework.batch.item.file.MultiResourceItemReader
 
setDelegate(ResourceAwareItemWriterItemStream<? super T>) - Method in class org.springframework.batch.item.file.MultiResourceItemWriter
Delegate used for actual writing of the output.
setDelegate(LineAggregator<T>) - Method in class org.springframework.batch.item.file.transform.RecursiveCollectionLineAggregator
Public setter for the LineAggregator to use on single items, that are not Strings.
setDelegate(FieldSetMapper<T>) - Method in class org.springframework.batch.sample.domain.multiline.AggregateItemFieldSetMapper
Public setter for the delegate.
setDelegate(ItemReader<T>) - Method in class org.springframework.batch.sample.support.ExceptionThrowingItemReaderProxy
 
setDelegates(ItemWriter<? super T>[]) - Method in class org.springframework.batch.item.support.CompositeItemWriter
 
setDelimiter(String) - Method in class org.springframework.batch.item.file.transform.DelimitedLineAggregator
Public setter for the delimiter.
setDelimiter(char) - Method in class org.springframework.batch.item.file.transform.DelimitedLineTokenizer
Setter for the delimiter character.
setDescription(String) - Method in class org.springframework.batch.sample.domain.order.internal.xml.LineItem
 
setDestroyScripts(Resource[]) - Method in class org.springframework.batch.test.DataSourceInitializer
 
setDestroyScripts(Resource[]) - Method in class test.jdbc.datasource.DataSourceInitializer
 
setDiscountAmount(BigDecimal) - Method in class org.springframework.batch.sample.domain.order.LineItem
 
setDiscountPerc(BigDecimal) - Method in class org.springframework.batch.sample.domain.order.LineItem
 
setDisplayName(String) - Method in class org.springframework.batch.core.configuration.support.OsgiBundleXmlApplicationContextFactory
 
setDriverSupportsAbsolute(boolean) - Method in class org.springframework.batch.item.database.JdbcCursorItemReader
Indicate whether the JDBC driver supports setting the absolute row on a ResultSet.
setEncoding(String) - Method in class org.springframework.batch.item.file.FlatFileItemReader
Setter for the encoding for this input source.
setEncoding(String) - Method in class org.springframework.batch.item.file.FlatFileItemWriter
Sets encoding for output template.
setEncoding(String) - Method in class org.springframework.batch.item.xml.StaxEventItemWriter
Set encoding to be used for output file.
setEnd() - Method in class org.springframework.batch.core.step.item.Chunk
Set the flag to say that this chunk represents an end of stream (there is no more data to process).
setEnd(String) - Method in class org.springframework.batch.sample.domain.multiline.AggregateItemFieldSetMapper
Public setter for the end field value.
setEndTime(Date) - Method in class org.springframework.batch.core.JobExecution
 
setEndTime(Date) - Method in class org.springframework.batch.core.StepExecution
Sets the time that this execution ended
setEntityManagerFactory(EntityManagerFactory) - Method in class org.springframework.batch.item.database.JpaItemWriter
Set the EntityManager to be used internally.
setEntityManagerFactory(EntityManagerFactory) - Method in class org.springframework.batch.item.database.JpaPagingItemReader
 
setEnvironmentParams(String[]) - Method in class org.springframework.batch.core.step.tasklet.SystemCommandTasklet
 
setExceptionClasses(Collection<Class<? extends Throwable>>) - Method in class org.springframework.batch.repeat.exception.SimpleLimitExceptionHandler
Setter for the exception classes that this handler counts.
setExceptionClassifier(Classifier<Throwable, LogOrRethrowExceptionHandler.Level>) - Method in class org.springframework.batch.repeat.exception.LogOrRethrowExceptionHandler
Setter for the Classifier used by this handler.
setExceptionClassifier(Classifier<Throwable, RetryPolicy>) - Method in class org.springframework.batch.retry.policy.ExceptionClassifierRetryPolicy
Setter for an exception classifier.
setExceptionHandler(ExceptionHandler) - Method in class org.springframework.batch.core.step.item.SimpleStepFactoryBean
Public setter for the ExceptionHandler.
setExceptionHandler(ExceptionHandler) - Method in class org.springframework.batch.repeat.support.RepeatTemplate
Setter for exception handler strategy.
setExecutionContext(ExecutionContext) - Method in class org.springframework.batch.core.JobExecution
Sets the ExecutionContext for this execution
setExecutionContext(ExecutionContext) - Method in class org.springframework.batch.core.StepExecution
Sets the ExecutionContext for this execution
setExhaustedOnly() - Method in class org.springframework.batch.retry.context.RetryContextSupport
 
setExhaustedOnly() - Method in interface org.springframework.batch.retry.RetryContext
Signal to the framework that no more attempts should be made to try or retry the current RetryCallback.
setExitCodeMapper(ExitCodeMapper) - Method in class org.springframework.batch.core.launch.support.CommandLineJobRunner
Injection setter for the ExitCodeMapper.
setExitMessageLength(int) - Method in class org.springframework.batch.core.repository.dao.JdbcJobExecutionDao
Public setter for the exit message length in database.
setExitMessageLength(int) - Method in class org.springframework.batch.core.repository.dao.JdbcStepExecutionDao
Public setter for the exit message length in database.
setExitMessageLength(int) - Method in class org.springframework.batch.core.repository.support.JobRepositoryFactoryBean
Public setter for the exit message length in database.
setExitStatus(ExitStatus) - Method in class org.springframework.batch.core.JobExecution
 
setExitStatus(ExitStatus) - Method in class org.springframework.batch.core.StepContribution
Set the ExitStatus for this contribution.
setExitStatus(ExitStatus) - Method in class org.springframework.batch.core.StepExecution
 
setFailingCustomers(List<String>) - Method in class org.springframework.batch.sample.domain.trade.internal.TradeWriter
Public setter for the the customers on which failure should occur.
setFailOnFlush(int) - Method in class org.springframework.batch.sample.domain.trade.internal.HibernateCreditDao
Public setter for the failOnFlush property.
setFatalExceptionClasses(Collection<Class<? extends Throwable>>) - Method in class org.springframework.batch.core.step.item.FaultTolerantStepFactoryBean
Exception classes that are not skippable (but may be retryable).
setFatalExceptionClasses(Collection<Class<? extends Throwable>>) - Method in class org.springframework.batch.repeat.exception.SimpleLimitExceptionHandler
Setter for the exception classes that shouldn't be counted, but rethrown immediately.
setFatalExceptionClasses(Collection<Class<? extends Throwable>>) - Method in class org.springframework.batch.retry.policy.SimpleRetryPolicy
Set the fatal exceptions.
setFetchSize(int) - Method in class org.springframework.batch.item.database.HibernateCursorItemReader
Gives the JDBC driver a hint as to the number of rows that should be fetched from the database when more rows are needed for this ResultSet object.
setFetchSize(int) - Method in class org.springframework.batch.item.database.JdbcCursorItemReader
Gives the JDBC driver a hint as to the number of rows that should be fetched from the database when more rows are needed for this ResultSet object.
setFetchSize(int) - Method in class org.springframework.batch.item.database.JdbcPagingItemReader
Gives the JDBC driver a hint as to the number of rows that should be fetched from the database when more rows are needed for this ResultSet object.
setFieldExtractor(FieldExtractor<T>) - Method in class org.springframework.batch.item.file.transform.ExtractorLineAggregator
Public setter for the field extractor responsible for splitting an input object up into an array of objects.
setFieldSetFactory(FieldSetFactory) - Method in class org.springframework.batch.item.file.transform.AbstractLineTokenizer
Factory for FieldSet instances.
setFieldSetMapper(FieldSetMapper<T>) - Method in class org.springframework.batch.item.file.mapping.DefaultLineMapper
 
setFieldSetMappers(Map<String, FieldSetMapper<T>>) - Method in class org.springframework.batch.item.file.mapping.PatternMatchingCompositeLineMapper
 
setFieldSetReader(ItemReader<FieldSet>) - Method in class org.springframework.batch.sample.domain.order.internal.OrderItemReader
 
setFieldsUsedAsTargetMethodArguments(String[]) - Method in class org.springframework.batch.item.adapter.PropertyExtractingDelegatingItemWriter
 
setFilter(boolean) - Method in class org.springframework.batch.item.validator.ValidatingItemProcessor
Should the processor filter invalid records instead of skipping them?
setFilterCount(int) - Method in class org.springframework.batch.core.StepExecution
Public setter for the number of items filtered out of this execution.
setFirstName(String) - Method in class org.springframework.batch.sample.domain.football.Player
 
setFirstName(String) - Method in class org.springframework.batch.sample.domain.order.Customer
 
setFirstName(String) - Method in class org.springframework.batch.sample.domain.person.Person
 
setFlow(Flow) - Method in class org.springframework.batch.core.job.flow.FlowJob
Public setter for the flow.
setFooterCallback(FlatFileFooterCallback) - Method in class org.springframework.batch.item.file.FlatFileItemWriter
footerCallback will be called after writing the last item to file, but before the file is closed.
setFooterCallback(StaxWriterCallback) - Method in class org.springframework.batch.item.xml.StaxEventItemWriter
footerCallback is called after writing all items but before closing the file
setFooterTokenizer(LineTokenizer) - Method in class org.springframework.batch.sample.domain.trade.CompositeCustomerUpdateLineTokenizer
Set the LineTokenizer that will be used to tokenize any lines that being with F and is thus a footer record.
setForceDisjointRanges(boolean) - Method in class org.springframework.batch.item.file.transform.RangeArrayPropertyEditor
Set force disjoint ranges.
setFormat(String) - Method in class org.springframework.batch.item.file.transform.FormatterLineAggregator
Set the format string used to aggregate items.
setFragmentRootElementName(String) - Method in class org.springframework.batch.item.xml.StaxEventItemReader
 
setFromClause(String) - Method in class org.springframework.batch.item.database.support.AbstractSqlPagingQueryProvider
 
setFromClause(String) - Method in class org.springframework.batch.item.database.support.SqlPagingQueryProviderFactoryBean
 
setGridSize(int) - Method in class org.springframework.batch.core.partition.support.TaskExecutorPartitionHandler
Passed to the StepExecutionSplitter in the TaskExecutorPartitionHandler.handle(StepExecutionSplitter, StepExecution) method, instructing it how many StepExecution instances are required, ideally.
setHandlers(ExceptionHandler[]) - Method in class org.springframework.batch.repeat.exception.CompositeExceptionHandler
 
setHandlingPrice(BigDecimal) - Method in class org.springframework.batch.sample.domain.order.LineItem
 
setHeaderCallback(FlatFileHeaderCallback) - Method in class org.springframework.batch.item.file.FlatFileItemWriter
headerCallback will be called before writing the first item to file.
setHeaderCallback(StaxWriterCallback) - Method in class org.springframework.batch.item.xml.StaxEventItemWriter
headerCallback is called before writing any items.
setHeaderMapper(FieldSetMapper<Order>) - Method in class org.springframework.batch.sample.domain.order.internal.OrderItemReader
 
setHibernateTemplate(HibernateOperations) - Method in class org.springframework.batch.item.database.HibernateItemWriter
Public setter for the HibernateOperations property.
setHierarchicalStreamDriver(HierarchicalStreamDriver) - Method in class org.springframework.batch.core.repository.dao.XStreamExecutionContextStringSerializer
 
setId(Long) - Method in class org.springframework.batch.core.Entity
 
setId(String) - Method in class org.springframework.batch.sample.domain.football.Game
 
setId(String) - Method in class org.springframework.batch.sample.domain.football.Player
 
setId(String) - Method in class org.springframework.batch.sample.domain.football.PlayerSummary
 
setId(int) - Method in class org.springframework.batch.sample.domain.trade.CustomerCredit
 
setIgnoreFailedDrop(boolean) - Method in class org.springframework.batch.test.DataSourceInitializer
 
setIgnoreFailedDrop(boolean) - Method in class test.jdbc.datasource.DataSourceInitializer
 
setIgnoreWarnings(boolean) - Method in class org.springframework.batch.item.database.JdbcCursorItemReader
Set whether SQLWarnings should be ignored (only logged) or exception should be thrown.
setIgnoreWhitespace(boolean) - Method in class org.springframework.batch.item.file.separator.SuffixRecordSeparatorPolicy
Flag to indicate that the decision to terminate a record should ignore whitespace at the end of the line.
setIncrementer(DataFieldMaxValueIncrementer) - Method in class org.springframework.batch.sample.common.StagingItemWriter
Setter for the key generator for the staging table.
setIncrementer(DataFieldMaxValueIncrementer) - Method in class org.springframework.batch.sample.domain.trade.internal.JdbcTradeDao
 
setIncrementerColumnName(String) - Method in class org.springframework.batch.item.database.support.DefaultDataFieldMaxValueIncrementerFactory
Public setter for the column name (defaults to "ID") in the incrementer.
setIncrementerFactory(DataFieldMaxValueIncrementerFactory) - Method in class org.springframework.batch.core.repository.support.JobRepositoryFactoryBean
 
setInitialInterval(long) - Method in class org.springframework.batch.retry.backoff.ExponentialBackOffPolicy
Set the initial sleep interval value.
setInitScripts(Resource[]) - Method in class org.springframework.batch.test.DataSourceInitializer
 
setInitScripts(Resource[]) - Method in class test.jdbc.datasource.DataSourceInitializer
 
setInputKeyName(String) - Method in class org.springframework.batch.sample.common.OutputFileListener
 
setInterceptions(int) - Method in class org.springframework.batch.sample.domain.football.Game
 
setInterceptions(int) - Method in class org.springframework.batch.sample.domain.football.PlayerSummary
 
setInterruptionPolicy(StepInterruptionPolicy) - Method in class org.springframework.batch.core.step.tasklet.TaskletStep
Setter for the StepInterruptionPolicy.
setInterruptOnCancel(boolean) - Method in class org.springframework.batch.core.step.tasklet.SystemCommandTasklet
If true tasklet will attempt to interrupt the thread executing the system command if SystemCommandTasklet.setTimeout(long) has been exceeded or user interrupts the job.
setInvalidCustomerLogger(InvalidCustomerLogger) - Method in class org.springframework.batch.sample.domain.trade.CustomerUpdateProcessor
 
setIsin(String) - Method in class org.springframework.batch.sample.domain.trade.Trade
 
setIsolation(Isolation) - Method in class org.springframework.batch.core.step.item.SimpleStepFactoryBean
 
setIsolationLevelForCreate(String) - Method in class org.springframework.batch.core.repository.support.AbstractJobRepositoryFactoryBean
public setter for the isolation level to be used for the transaction when job execution entities are initially created.
setIsReaderTransactionalQueue(boolean) - Method in class org.springframework.batch.core.step.item.SimpleStepFactoryBean
Flag to signal that the reader is transactional (usually a JMS consumer) so that items are re-presented after a rollback.
setItemCountLimitPerResource(int) - Method in class org.springframework.batch.item.file.MultiResourceItemWriter
After this limit is exceeded the next chunk will be written into newly created resource.
setItemId(long) - Method in class org.springframework.batch.sample.domain.order.LineItem
 
setItemMapper(FieldSetMapper<LineItem>) - Method in class org.springframework.batch.sample.domain.order.internal.OrderItemReader
 
setItemPreparedStatementSetter(ItemPreparedStatementSetter<T>) - Method in class org.springframework.batch.item.database.JdbcBatchItemWriter
Public setter for the ItemPreparedStatementSetter.
setItemProcessor(ItemProcessor<? super I, ? extends O>) - Method in class org.springframework.batch.core.step.item.SimpleChunkProcessor
 
setItemProcessor(ItemProcessor<? super T, ? extends S>) - Method in class org.springframework.batch.core.step.item.SimpleStepFactoryBean
 
setItemProcessors(List<ItemProcessor>) - Method in class org.springframework.batch.item.support.CompositeItemProcessor
 
setItemReader(ItemReader<? extends T>) - Method in class org.springframework.batch.core.step.item.SimpleStepFactoryBean
 
setItemReader(ItemReader<AggregateItem<T>>) - Method in class org.springframework.batch.sample.domain.multiline.AggregateItemReader
 
setItemSqlParameterSourceProvider(ItemSqlParameterSourceProvider<T>) - Method in class org.springframework.batch.item.database.JdbcBatchItemWriter
Public setter for the ItemSqlParameterSourceProvider.
setItemType(Class<? extends T>) - Method in class org.springframework.batch.item.jms.JmsItemReader
Set the expected type of incoming message payloads.
setItemWriter(ItemWriter<? super O>) - Method in class org.springframework.batch.core.step.item.SimpleChunkProcessor
 
setItemWriter(ItemWriter<? super S>) - Method in class org.springframework.batch.core.step.item.SimpleStepFactoryBean
 
setItemWriter(ItemWriter<String>) - Method in class org.springframework.batch.sample.domain.trade.internal.FlatFileCustomerCreditDao
 
setJdbcTemplate(SimpleJdbcOperations) - Method in class org.springframework.batch.core.repository.dao.AbstractJdbcBatchMetadataDao
 
setJdbcTemplate(SimpleJdbcOperations) - Method in class org.springframework.batch.sample.common.StagingItemProcessor
 
setJmsTemplate(JmsOperations) - Method in class org.springframework.batch.item.jms.JmsItemReader
Setter for jms template.
setJmsTemplate(JmsOperations) - Method in class org.springframework.batch.item.jms.JmsItemWriter
Setter for JMS template.
setJmsTemplate(JmsOperations) - Method in class org.springframework.batch.item.jms.JmsMethodInvocationRecoverer
Setter for jms template.
setJobExecutionIncrementer(DataFieldMaxValueIncrementer) - Method in class org.springframework.batch.core.repository.dao.JdbcJobExecutionDao
Setter for DataFieldMaxValueIncrementer to be used when generating primary keys for JobExecution instances.
setJobExecutionListeners(JobExecutionListener[]) - Method in class org.springframework.batch.core.job.AbstractJob
Public setter for injecting JobExecutionListeners.
setJobExplorer(JobExplorer) - Method in class org.springframework.batch.core.launch.support.CommandLineJobRunner
Injection setter for JobExplorer.
setJobExplorer(JobExplorer) - Method in class org.springframework.batch.core.launch.support.SimpleJobOperator
Public setter for the JobExplorer.
setJobIncrementer(DataFieldMaxValueIncrementer) - Method in class org.springframework.batch.core.repository.dao.JdbcJobInstanceDao
Setter for DataFieldMaxValueIncrementer to be used when generating primary keys for JobInstance instances.
setJobInstance(JobInstance) - Method in class org.springframework.batch.core.JobExecution
 
setJobLauncher(JobLauncher) - Method in class org.springframework.batch.core.launch.support.SimpleJobOperator
Public setter for the JobLauncher.
setJobLauncher(JobLauncher) - Method in class org.springframework.batch.sample.quartz.JobLauncherDetails
Public setter for the JobLauncher.
setJobLocator(JobLocator) - Method in class org.springframework.batch.core.launch.support.CommandLineJobRunner
JobLocator to find a job to run.
setJobLocator(JobLocator) - Method in class org.springframework.batch.sample.quartz.JobLauncherDetails
Public setter for the JobLocator.
setJobParametersConverter(JobParametersConverter) - Method in class org.springframework.batch.core.launch.support.CommandLineJobRunner
Injection setter for JobParametersConverter.
setJobParametersConverter(JobParametersConverter) - Method in class org.springframework.batch.core.launch.support.SimpleJobOperator
Public setter for the JobParametersConverter.
setJobParametersIncrementer(JobParametersIncrementer) - Method in class org.springframework.batch.core.job.AbstractJob
Public setter for the JobParametersIncrementer.
setJobParametersIncrementer(JobParametersIncrementer) - Method in class org.springframework.batch.test.JobRepositoryTestUtils
 
setJobPaths(Resource[]) - Method in class org.springframework.batch.core.configuration.support.ClassPathXmlJobRegistry
 
setJobRegistry(JobRegistry) - Method in class org.springframework.batch.core.configuration.support.JobFactoryRegistrationListener
Public setter for a JobRegistry to use for all the bind and unbind events.
setJobRegistry(JobRegistry) - Method in class org.springframework.batch.core.configuration.support.JobRegistryBeanPostProcessor
Injection setter for JobRegistry.
setJobRegistry(ListableJobRegistry) - Method in class org.springframework.batch.core.launch.support.SimpleJobOperator
Public setter for the ListableJobRegistry.
setJobRepository(JobRepository) - Method in class org.springframework.batch.core.job.AbstractJob
Public setter for the JobRepository that is needed to manage the state of the batch meta domain (jobs, steps, executions) during the life of a job.
setJobRepository(JobRepository) - Method in class org.springframework.batch.core.launch.support.SimpleJobLauncher
Set the JobRepsitory.
setJobRepository(JobRepository) - Method in class org.springframework.batch.core.launch.support.SimpleJobOperator
 
setJobRepository(JobRepository) - Method in class org.springframework.batch.core.step.AbstractStep
Public setter for JobRepository.
setJobRepository(JobRepository) - Method in class org.springframework.batch.core.step.item.SimpleStepFactoryBean
Public setter for JobRepository.
setJobRepository(JobRepository) - Method in class org.springframework.batch.test.JobRepositoryTestUtils
 
setKeyGenerator(KeyGenerator) - Method in class org.springframework.batch.core.step.item.FaultTolerantChunkProcessor
The KeyGenerator to use to identify failed items across rollback.
setKeyGenerator(KeyGenerator) - Method in class org.springframework.batch.core.step.item.FaultTolerantStepFactoryBean
The KeyGenerator to use to identify failed items across rollback.
setKeyGenerator(MethodArgumentsKeyGenerator) - Method in class org.springframework.batch.retry.interceptor.StatefulRetryOperationsInterceptor
 
setKeyName(String) - Method in class org.springframework.batch.core.partition.support.MultiResourcePartitioner
The name of the key for the file name in each ExecutionContext.
setKeyName(String) - Method in class org.springframework.batch.core.resource.StepExecutionSimpleCompletionPolicy
Public setter for the key name of a Long value in the JobParameters that will contain a commit interval.
setKeyName(String) - Method in class org.springframework.batch.support.SystemPropertyInitializer
Set the key name for the System property that is created.
setKeys(String[]) - Method in class org.springframework.batch.core.listener.ExecutionContextPromotionListener
 
setKeys(String[]) - Method in class org.springframework.batch.core.listener.JobParameterExecutionContextCopyListener
 
setLast_name(String) - Method in class org.springframework.batch.sample.domain.person.Person
Intentionally non-standard method name for testing purposes
setLastName(String) - Method in class org.springframework.batch.sample.domain.football.Player
 
setLastName(String) - Method in class org.springframework.batch.sample.domain.order.Customer
 
setLastUpdated(Date) - Method in class org.springframework.batch.core.JobExecution
Set the last time this JobExecution was updated.
setLastUpdated(Date) - Method in class org.springframework.batch.core.StepExecution
Set the time when the StepExecution was last updated before persisting
setLauncher(JobLauncher) - Method in class org.springframework.batch.core.launch.support.CommandLineJobRunner
Injection setter for the JobLauncher.
setLimit(int) - Method in class org.springframework.batch.repeat.exception.SimpleLimitExceptionHandler
The limit on the given exception type within a single context before it is rethrown.
setLimit(int) - Method in class org.springframework.batch.sample.domain.trade.internal.GeneratingTradeItemReader
 
setLimit(int) - Method in class org.springframework.batch.sample.loopFlow.LimitDecider
 
setLineAggregator(LineAggregator<T>) - Method in class org.springframework.batch.item.file.FlatFileItemWriter
Public setter for the LineAggregator.
setLineItems(List<LineItem>) - Method in class org.springframework.batch.sample.domain.order.internal.xml.Order
 
setLineItems(List<LineItem>) - Method in class org.springframework.batch.sample.domain.order.Order
 
setLineMapper(LineMapper<T>) - Method in class org.springframework.batch.item.file.FlatFileItemReader
Setter for line mapper.
setLineSeparator(String) - Method in class org.springframework.batch.item.file.FlatFileItemWriter
Public setter for the line separator.
setLinesToSkip(int) - Method in class org.springframework.batch.item.file.FlatFileItemReader
Public setter for the number of lines to skip at the start of a file.
setLineTokenizer(LineTokenizer) - Method in class org.springframework.batch.item.file.mapping.DefaultLineMapper
 
setListeners(List<? extends ChunkListener>) - Method in class org.springframework.batch.core.listener.CompositeChunkListener
Public setter for the listeners.
setListeners(List<? extends ItemProcessListener<? super T, ? super S>>) - Method in class org.springframework.batch.core.listener.CompositeItemProcessListener
Public setter for the listeners.
setListeners(List<? extends ItemReadListener<? super T>>) - Method in class org.springframework.batch.core.listener.CompositeItemReadListener
Public setter for the listeners.
setListeners(List<? extends ItemWriteListener<? super S>>) - Method in class org.springframework.batch.core.listener.CompositeItemWriteListener
Public setter for the listeners.
setListeners(List<? extends JobExecutionListener>) - Method in class org.springframework.batch.core.listener.CompositeJobExecutionListener
Public setter for the listeners.
setListeners(List<? extends SkipListener<? super T, ? super S>>) - Method in class org.springframework.batch.core.listener.CompositeSkipListener
Public setter for the listeners.
setListeners(StepExecutionListener[]) - Method in class org.springframework.batch.core.listener.CompositeStepExecutionListener
Public setter for the listeners.
setListeners(List<? extends StepListener>) - Method in class org.springframework.batch.core.listener.MulticasterBatchListener
Register each of the objects as listeners.
setListeners(RetryListener[]) - Method in class org.springframework.batch.core.step.item.BatchRetryTemplate
 
setListeners(List<? extends StepListener>) - Method in class org.springframework.batch.core.step.item.SimpleChunkProcessor
Register some StepListeners with the handler.
setListeners(List<? extends StepListener>) - Method in class org.springframework.batch.core.step.item.SimpleChunkProvider
Register some StepListeners with the handler.
setListeners(StepListener[]) - Method in class org.springframework.batch.core.step.item.SimpleStepFactoryBean
The listeners to inject into the Step.
setListeners(RepeatListener[]) - Method in class org.springframework.batch.repeat.listener.CompositeRepeatListener
Public setter for the listeners.
setListeners(RepeatListener[]) - Method in class org.springframework.batch.repeat.support.RepeatTemplate
Set the listeners for this template, registering them for callbacks at appropriate times in the iteration.
setListeners(RetryListener[]) - Method in class org.springframework.batch.retry.support.RetryTemplate
Setter for listeners.
setLobHandler(LobHandler) - Method in class org.springframework.batch.core.explore.support.JobExplorerFactoryBean
The lob handler to use when saving ExecutionContext instances.
setLobHandler(LobHandler) - Method in class org.springframework.batch.core.repository.dao.JdbcExecutionContextDao
 
setLocale(Locale) - Method in class org.springframework.batch.item.file.transform.FormatterLineAggregator
Public setter for the locale.
setLoginTimeout(int) - Method in class org.springframework.batch.item.database.ExtendedConnectionDataSourceProxy
 
setLogWriter(PrintWriter) - Method in class org.springframework.batch.item.database.ExtendedConnectionDataSourceProxy
 
setMapping(Map<String, Integer>) - Method in class org.springframework.batch.core.launch.support.SimpleJvmExitCodeMapper
Supply the ExitCodeMappings
setMappings(Map<Object, ExitStatus>) - Method in class org.springframework.batch.core.step.tasklet.ConfigurableSystemProcessExitCodeMapper
 
setMarshaller(Marshaller) - Method in class org.springframework.batch.item.xml.StaxEventItemWriter
Set Object to XML marshaller.
setMatcherMap(Map<String, T>) - Method in class org.springframework.batch.classify.BackToBackPatternClassifier
A convenience method for creating a pattern matching classifier for the matcher component.
setMaxAttempts(int) - Method in class org.springframework.batch.retry.policy.SimpleRetryPolicy
Setter for retry attempts.
setMaxCount(int) - Method in class org.springframework.batch.repeat.policy.CountingCompletionPolicy
Setter for maximum value of count before termination.
setMaximumLength(int) - Method in class org.springframework.batch.item.file.transform.FormatterLineAggregator
Public setter for the maximum length of the formatted string.
setMaxInterval(long) - Method in class org.springframework.batch.retry.backoff.ExponentialBackOffPolicy
Setter for maximum back off period.
setMaxItemCount(int) - Method in class org.springframework.batch.item.support.AbstractItemCountingItemStreamItemReader
The maximum index of the items to be read.
setMaxRows(int) - Method in class org.springframework.batch.item.database.JdbcCursorItemReader
Sets the limit for the maximum number of rows that any ResultSet object can contain to the given number.
setMetaDataMap(Map<String, String>) - Method in class org.springframework.batch.core.listener.AbstractListenerFactoryBean
 
setMiddleName(String) - Method in class org.springframework.batch.sample.domain.order.Customer
 
setMinimumLength(int) - Method in class org.springframework.batch.item.file.transform.FormatterLineAggregator
Public setter for the minimum length of the formatted string.
setMoo(int) - Method in class org.springframework.batch.sample.domain.order.internal.xml.Customer
 
setMultiplier(double) - Method in class org.springframework.batch.retry.backoff.ExponentialBackOffPolicy
Set the multiplier value.
setName(String) - Method in class org.springframework.batch.core.job.AbstractJob
Set the name property.
setName(String) - Method in class org.springframework.batch.core.scope.StepScope
Public setter for the name property.
setName(String) - Method in class org.springframework.batch.core.step.AbstractStep
Set the name property.
setName(String) - Method in class org.springframework.batch.item.support.AbstractItemCountingItemStreamItemReader
The name of the component which will be used as a stem for keys in the ExecutionContext.
setName(String) - Method in class org.springframework.batch.item.util.ExecutionContextUserSupport
 
setName(String) - Method in class org.springframework.batch.sample.domain.order.internal.xml.Customer
 
setName(String) - Method in class org.springframework.batch.sample.domain.order.internal.xml.Shipper
 
setName(String) - Method in class org.springframework.batch.sample.domain.person.Child
 
setName(String) - Method in class org.springframework.batch.sample.domain.trade.CustomerCredit
 
setName(String) - Method in class org.springframework.batch.sample.domain.trade.CustomerDebit
 
setNames(String[]) - Method in class org.springframework.batch.item.file.transform.AbstractLineTokenizer
Setter for column names.
setNames(String[]) - Method in class org.springframework.batch.item.file.transform.BeanWrapperFieldExtractor
 
setNewItemIdentifier(NewMethodArgumentsIdentifier) - Method in class org.springframework.batch.retry.interceptor.StatefulRetryOperationsInterceptor
Public setter for the NewMethodArgumentsIdentifier.
setNoRollbackExceptionClasses(Collection<Class<? extends Throwable>>) - Method in class org.springframework.batch.core.step.item.FaultTolerantStepFactoryBean
Exception classes that are candidates for no rollback.
setNotificationPublisher(NotificationPublisher) - Method in class org.springframework.batch.sample.jmx.JobExecutionNotificationPublisher
Injection setter.
setNumberFormat(NumberFormat) - Method in class org.springframework.batch.core.converter.DefaultJobParametersConverter
Public setter for the NumberFormat.
setNumberFormat(NumberFormat) - Method in class org.springframework.batch.item.file.transform.DefaultFieldSet
The NumberFormat to use for parsing numbers.
setNumberFormat(NumberFormat) - Method in class org.springframework.batch.item.file.transform.DefaultFieldSetFactory
The NumberFormat to use for parsing numbers.
setOpponent(String) - Method in class org.springframework.batch.sample.domain.football.Game
 
setOrder(int) - Method in class org.springframework.batch.core.scope.StepScope
 
setOrderDate(Date) - Method in class org.springframework.batch.sample.domain.order.Order
 
setOrderId(long) - Method in class org.springframework.batch.sample.domain.order.Order
 
setOutputKeyName(String) - Method in class org.springframework.batch.sample.common.OutputFileListener
 
setOverwriteOutput(boolean) - Method in class org.springframework.batch.item.xml.StaxEventItemWriter
Set "overwrite" flag for the output file.
setPageSize(int) - Method in class org.springframework.batch.item.database.AbstractPagingItemReader
The number of rows to retreive at a time.
setParameters(List<?>) - Method in class org.springframework.batch.core.resource.ListPreparedStatementSetter
The parameter values that will be set on the PreparedStatement.
setParameterValues(Map<String, Object>) - Method in class org.springframework.batch.item.database.IbatisPagingItemReader
The parameter values to be used for the query execution.
setParameterValues(Map<String, Object>) - Method in class org.springframework.batch.item.database.JdbcPagingItemReader
The parameter values to be used for the query execution.
setParameterValues(Map<String, Object>) - Method in class org.springframework.batch.item.database.JpaPagingItemReader
The parameter values to be used for the query execution.
setPartitionHandler(PartitionHandler) - Method in class org.springframework.batch.core.partition.support.PartitionStep
Public setter for mandatory property PartitionHandler.
setPassingTd(int) - Method in class org.springframework.batch.sample.domain.football.Game
 
setPassingTd(int) - Method in class org.springframework.batch.sample.domain.football.PlayerSummary
 
setPassingYards(int) - Method in class org.springframework.batch.sample.domain.football.Game
 
setPassingYards(int) - Method in class org.springframework.batch.sample.domain.football.PlayerSummary
 
setPath(Resource) - Method in class org.springframework.batch.core.configuration.support.ClassPathXmlApplicationContextFactory
Setter for the path to the xml to load to create an ApplicationContext.
setPath(String) - Method in class org.springframework.batch.core.configuration.support.OsgiBundleXmlApplicationContextFactory
 
setPatternMap(Map<String, T>) - Method in class org.springframework.batch.classify.PatternMatchingClassifier
A map from pattern to value
setPaymentDesc(String) - Method in class org.springframework.batch.sample.domain.order.BillingInfo
 
setPaymentId(String) - Method in class org.springframework.batch.sample.domain.order.BillingInfo
 
setPerOunceRate(double) - Method in class org.springframework.batch.sample.domain.order.internal.xml.Shipper
 
setPerUnitOunces(double) - Method in class org.springframework.batch.sample.domain.order.internal.xml.LineItem
 
setPlayerDao(PlayerDao) - Method in class org.springframework.batch.sample.domain.football.internal.PlayerItemWriter
 
setPolicies(CompletionPolicy[]) - Method in class org.springframework.batch.repeat.policy.CompositeCompletionPolicy
Setter for the policies.
setPolicies(RetryPolicy[]) - Method in class org.springframework.batch.retry.policy.CompositeRetryPolicy
Setter for policies.
setPolicyMap(Map<Class<? extends Throwable>, RetryPolicy>) - Method in class org.springframework.batch.retry.policy.ExceptionClassifierRetryPolicy
Setter for policy map.
setPoo(int) - Method in class org.springframework.batch.sample.domain.order.internal.xml.Customer
 
setPosition(String) - Method in class org.springframework.batch.sample.domain.football.Player
 
setPreparedStatementSetter(PreparedStatementSetter) - Method in class org.springframework.batch.item.database.JdbcCursorItemReader
Set the PreparedStatementSetter to use if any parameter values that need to be set in the supplied query.
setPrice(double) - Method in class org.springframework.batch.sample.domain.order.internal.xml.LineItem
 
setPrice(BigDecimal) - Method in class org.springframework.batch.sample.domain.order.LineItem
 
setPrice(BigDecimal) - Method in class org.springframework.batch.sample.domain.trade.Trade
 
setProcessSkipCount(int) - Method in class org.springframework.batch.core.StepExecution
Set the number of records skipped during processing.
setProcessSkipPolicy(SkipPolicy) - Method in class org.springframework.batch.core.step.item.FaultTolerantChunkProcessor
 
setPropagation(Propagation) - Method in class org.springframework.batch.core.step.item.SimpleStepFactoryBean
 
setProperty(String, String) - Method in class org.springframework.batch.sample.launch.DefaultJobLoader
 
setProperty(String, String) - Method in interface org.springframework.batch.sample.launch.ExportedJobLoader
 
setProperty(String, String) - Method in interface org.springframework.batch.sample.launch.JobLoader
 
setPrototypeBeanName(String) - Method in class org.springframework.batch.item.file.mapping.BeanWrapperFieldSetMapper
The bean name (id) for an object that can be populated from the field set that will be passed into BeanWrapperFieldSetMapper.mapFieldSet(FieldSet).
setProxyTargetClass(boolean) - Method in class org.springframework.batch.core.scope.StepScope
Flag to indicate that proxies should use dynamic subclassing.
setQuantity(int) - Method in class org.springframework.batch.sample.domain.order.internal.xml.LineItem
 
setQuantity(int) - Method in class org.springframework.batch.sample.domain.order.LineItem
 
setQuantity(long) - Method in class org.springframework.batch.sample.domain.trade.Trade
 
setQueryId(String) - Method in class org.springframework.batch.item.database.IbatisPagingItemReader
 
setQueryName(String) - Method in class org.springframework.batch.item.database.HibernateCursorItemReader
 
setQueryProvider(PagingQueryProvider) - Method in class org.springframework.batch.item.database.JdbcPagingItemReader
 
setQueryString(String) - Method in class org.springframework.batch.item.database.HibernateCursorItemReader
 
setQueryString(String) - Method in class org.springframework.batch.item.database.JpaPagingItemReader
 
setQueryTimeout(int) - Method in class org.springframework.batch.item.database.JdbcCursorItemReader
Sets the number of seconds the driver will wait for a Statement object to execute to the given number of seconds.
setQuoteCharacter(String) - Method in class org.springframework.batch.item.file.separator.DefaultRecordSeparatorPolicy
Public setter for the quoteCharacter.
setQuoteCharacter(char) - Method in class org.springframework.batch.item.file.transform.DelimitedLineTokenizer
Public setter for the quoteCharacter.
setReadCount(int) - Method in class org.springframework.batch.core.StepExecution
Sets the current number of read items for this execution
setReader(GeneratingTradeItemReader) - Method in class org.springframework.batch.sample.loopFlow.GeneratingTradeResettingListener
 
setReadSkipCount(int) - Method in class org.springframework.batch.core.StepExecution
Set the number of records skipped on read
setReceptions(int) - Method in class org.springframework.batch.sample.domain.football.Game
 
setReceptions(int) - Method in class org.springframework.batch.sample.domain.football.PlayerSummary
 
setReceptionYards(int) - Method in class org.springframework.batch.sample.domain.football.Game
 
setReceptionYards(int) - Method in class org.springframework.batch.sample.domain.football.PlayerSummary
 
setRecordSeparatorPolicy(RecordSeparatorPolicy) - Method in class org.springframework.batch.item.file.FlatFileItemReader
Public setter for the recordSeparatorPolicy.
setRecoverer(MethodInvocationRecoverer<? extends Object>) - Method in class org.springframework.batch.retry.interceptor.StatefulRetryOperationsInterceptor
Public setter for the MethodInvocationRecoverer to use if the retry is exhausted.
setReflectionProvider(ReflectionProvider) - Method in class org.springframework.batch.core.repository.dao.XStreamExecutionContextStringSerializer
 
setRegistered(boolean) - Method in class org.springframework.batch.sample.domain.order.Customer
 
setRegistrationId(long) - Method in class org.springframework.batch.sample.domain.order.Customer
 
setRegistry(JobRegistry) - Method in class org.springframework.batch.core.launch.support.JobRegistryBackgroundJobRunner
Public setter for the JobRegistry.
setRegistry(ListableJobRegistry) - Method in class org.springframework.batch.sample.launch.DefaultJobLoader
 
setRepeatOperations(RepeatOperations) - Method in class org.springframework.batch.repeat.interceptor.RepeatOperationsInterceptor
Setter for the RepeatOperations.
setResource(Resource) - Method in class org.springframework.batch.item.file.FlatFileItemReader
Public setter for the input resource.
setResource(Resource) - Method in class org.springframework.batch.item.file.FlatFileItemWriter
Setter for resource.
setResource(Resource) - Method in class org.springframework.batch.item.file.MultiResourceItemWriter
Prototype for output resources.
setResource(Resource) - Method in interface org.springframework.batch.item.file.ResourceAwareItemReaderItemStream
 
setResource(Resource) - Method in interface org.springframework.batch.item.file.ResourceAwareItemWriterItemStream
 
setResource(Resource) - Method in class org.springframework.batch.item.xml.StaxEventItemReader
 
setResource(Resource) - Method in class org.springframework.batch.item.xml.StaxEventItemWriter
Set output file.
setResources(Resource[]) - Method in class org.springframework.batch.core.partition.support.MultiResourcePartitioner
The resources to assign to each partition.
setResources(Resource[]) - Method in class org.springframework.batch.item.file.MultiResourceItemReader
 
setResourceSuffixCreator(ResourceSuffixCreator) - Method in class org.springframework.batch.item.file.MultiResourceItemWriter
Allows customization of the suffix of the created resources based on the index.
setRestartable(boolean) - Method in class org.springframework.batch.core.job.AbstractJob
Boolean flag to prevent categorically a job from restarting, even if it has failed previously.
setRetryableExceptionClasses(Collection<Class<? extends Throwable>>) - Method in class org.springframework.batch.core.step.item.FaultTolerantStepFactoryBean
Public setter for the Class[].
setRetryableExceptionClasses(Collection<Class<? extends Throwable>>) - Method in class org.springframework.batch.retry.policy.SimpleRetryPolicy
Set the retryable exceptions.
setRetryContextCache(RetryContextCache) - Method in class org.springframework.batch.core.step.item.BatchRetryTemplate
 
setRetryContextCache(RetryContextCache) - Method in class org.springframework.batch.core.step.item.FaultTolerantStepFactoryBean
Override the default retry context cache for retry of chunk processing.
setRetryContextCache(RetryContextCache) - Method in class org.springframework.batch.retry.support.RetryTemplate
Public setter for the RetryContextCache.
setRetryLimit(int) - Method in class org.springframework.batch.core.step.item.FaultTolerantStepFactoryBean
Public setter for the retry limit.
setRetryListeners(RetryListener...) - Method in class org.springframework.batch.core.step.item.FaultTolerantStepFactoryBean
Public setter for the RetryListeners.
setRetryOperations(RetryOperations) - Method in class org.springframework.batch.retry.interceptor.RetryOperationsInterceptor
 
setRetryOperations(RetryOperations) - Method in class org.springframework.batch.retry.interceptor.StatefulRetryOperationsInterceptor
 
setRetryPolicy(RetryPolicy) - Method in class org.springframework.batch.core.step.item.BatchRetryTemplate
 
setRetryPolicy(RetryPolicy) - Method in class org.springframework.batch.core.step.item.FaultTolerantStepFactoryBean
Setter for the retry policy.
setRetryPolicy(RetryPolicy) - Method in class org.springframework.batch.retry.support.RetryTemplate
Setter for RetryPolicy.
setRollbackClassifier(Classifier<Throwable, Boolean>) - Method in class org.springframework.batch.core.step.item.FaultTolerantChunkProcessor
A classifier that can distinguish between exceptions that cause rollback (return true) or not (return false).
setRollbackClassifier(Classifier<Throwable, Boolean>) - Method in class org.springframework.batch.core.step.item.FaultTolerantChunkProvider
Classifier to determine whether exceptions have been marked as no-rollback (as opposed to skippable).
setRollbackCount(int) - Method in class org.springframework.batch.core.StepExecution
Setter for number of rollbacks for this execution
setRootElementAttributes(Map<String, String>) - Method in class org.springframework.batch.item.xml.StaxEventItemWriter
Set the root element attributes to be written.
setRootTagName(String) - Method in class org.springframework.batch.item.xml.StaxEventItemWriter
Set the tag name of the root element.
setRouterDelegate(Object) - Method in class org.springframework.batch.classify.BackToBackPatternClassifier
A convenience method of creating a router classifier based on a plain old Java Object.
setRowMapper(RowMapper) - Method in class org.springframework.batch.item.database.JdbcCursorItemReader
Set the RowMapper to be used for all calls to read().
setRowMapper(RowMapper) - Method in class org.springframework.batch.item.database.JdbcPagingItemReader
The row mapper implementation to be used by this reader
setRushes(int) - Method in class org.springframework.batch.sample.domain.football.Game
 
setRushes(int) - Method in class org.springframework.batch.sample.domain.football.PlayerSummary
 
setRushYards(int) - Method in class org.springframework.batch.sample.domain.football.Game
 
setRushYards(int) - Method in class org.springframework.batch.sample.domain.football.PlayerSummary
 
setSaveState(boolean) - Method in class org.springframework.batch.item.file.FlatFileItemWriter
Set the flag indicating whether or not state should be saved in the provided ExecutionContext during the ItemStream call to update.
setSaveState(boolean) - Method in class org.springframework.batch.item.file.MultiResourceItemReader
Set the boolean indicating whether or not state should be saved in the provided ExecutionContext during the ItemStream call to update.
setSaveState(boolean) - Method in class org.springframework.batch.item.file.MultiResourceItemWriter
 
setSaveState(boolean) - Method in class org.springframework.batch.item.support.AbstractItemCountingItemStreamItemReader
Set the flag that determines whether to save internal data for ExecutionContext.
setSaveState(boolean) - Method in class org.springframework.batch.item.xml.StaxEventItemWriter
 
setSelectClause(String) - Method in class org.springframework.batch.item.database.support.AbstractSqlPagingQueryProvider
 
setSelectClause(String) - Method in class org.springframework.batch.item.database.support.SqlPagingQueryProviderFactoryBean
 
setSeparator(String) - Method in class org.springframework.batch.sample.domain.trade.internal.FlatFileCustomerCreditDao
 
setSessionFactory(SessionFactory) - Method in class org.springframework.batch.item.database.HibernateCursorItemReader
 
setSessionFactory(SessionFactory) - Method in class org.springframework.batch.item.database.HibernateItemWriter
Set the Hibernate SessionFactory to be used internally.
setSessionFactory(SessionFactory) - Method in class org.springframework.batch.sample.domain.trade.internal.HibernateAwareCustomerCreditItemWriter
 
setShipper(Shipper) - Method in class org.springframework.batch.sample.domain.order.internal.xml.Order
 
setShipperId(String) - Method in class org.springframework.batch.sample.domain.order.ShippingInfo
 
setShipping(ShippingInfo) - Method in class org.springframework.batch.sample.domain.order.Order
 
setShippingAddress(Address) - Method in class org.springframework.batch.sample.domain.order.Order
 
setShippingInfo(String) - Method in class org.springframework.batch.sample.domain.order.ShippingInfo
 
setShippingMapper(FieldSetMapper<ShippingInfo>) - Method in class org.springframework.batch.sample.domain.order.internal.OrderItemReader
 
setShippingPrice(BigDecimal) - Method in class org.springframework.batch.sample.domain.order.LineItem
 
setShippingTypeId(String) - Method in class org.springframework.batch.sample.domain.order.ShippingInfo
 
setShouldDeleteIfEmpty(boolean) - Method in class org.springframework.batch.item.file.FlatFileItemWriter
Flag to indicate that the target file should be deleted if no lines have been written (other than header and footer) on close.
setShouldDeleteIfExists(boolean) - Method in class org.springframework.batch.item.file.FlatFileItemWriter
Flag to indicate that the target file should be deleted if it already exists, otherwise it will be appended.
setSimpleJdbcTemplate(SimpleJdbcOperations) - Method in class org.springframework.batch.item.database.JdbcBatchItemWriter
Public setter for the JdbcOperations.
setSingleton(boolean) - Method in class org.springframework.batch.core.step.item.SimpleStepFactoryBean
Public setter for the singleton flag.
setSkipLimit(int) - Method in class org.springframework.batch.core.step.item.FaultTolerantStepFactoryBean
A limit that determines skip policy.
setSkippableExceptionClasses(Collection<Class<? extends Throwable>>) - Method in class org.springframework.batch.core.step.item.FaultTolerantStepFactoryBean
Exception classes that when raised won't crash the job but will result in the item which handling caused the exception being skipped.
setSkippedLinesCallback(LineCallbackHandler) - Method in class org.springframework.batch.item.file.FlatFileItemReader
 
setSkipPolicy(SkipPolicy) - Method in class org.springframework.batch.core.step.item.FaultTolerantChunkProvider
The policy that determines whether exceptions can be skipped on read.
setSleeper(Sleeper) - Method in class org.springframework.batch.retry.backoff.ExponentialBackOffPolicy
Public setter for the Sleeper strategy.
setSleeper(Sleeper) - Method in class org.springframework.batch.retry.backoff.FixedBackOffPolicy
Public setter for the Sleeper strategy.
setSortKey(String) - Method in class org.springframework.batch.item.database.support.AbstractSqlPagingQueryProvider
 
setSortKey(String) - Method in class org.springframework.batch.item.database.support.SqlPagingQueryProviderFactoryBean
 
setSql(String) - Method in class org.springframework.batch.item.database.JdbcBatchItemWriter
Public setter for the query string to execute on write.
setSql(String) - Method in class org.springframework.batch.item.database.JdbcCursorItemReader
Set the SQL statement to be used when creating the cursor.
setSqlMapClient(SqlMapClient) - Method in class org.springframework.batch.item.database.IbatisBatchItemWriter
Public setter for SqlMapClient for injection purposes.
setSqlMapClient(SqlMapClient) - Method in class org.springframework.batch.item.database.IbatisPagingItemReader
 
setSqlMapClientTemplate(SqlMapClientTemplate) - Method in class org.springframework.batch.item.database.IbatisBatchItemWriter
Public setter for the SqlMapClientTemplate.
setStartLimit(int) - Method in class org.springframework.batch.core.step.AbstractStep
Public setter for the startLimit.
setStartLimit(int) - Method in class org.springframework.batch.core.step.item.SimpleStepFactoryBean
Public setter for the start limit for the step.
setStartTime(Date) - Method in class org.springframework.batch.core.JobExecution
 
setStartTime(Date) - Method in class org.springframework.batch.core.StepExecution
Sets the time this execution started
setState(String) - Method in class org.springframework.batch.sample.domain.order.Address
 
setStatementId(String) - Method in class org.springframework.batch.item.database.IbatisBatchItemWriter
Public setter for the statement id identifying the statement in the SqlMap configuration file.
setStatementId(String) - Method in class org.springframework.batch.sample.domain.trade.internal.IbatisCustomerCreditDao
 
setStateTransitions(List<StateTransition>) - Method in class org.springframework.batch.core.job.flow.support.SimpleFlow
Public setter for the stateTransitions.
setStatus(BatchStatus) - Method in class org.springframework.batch.core.JobExecution
Set the value of the status field.
setStatus(BatchStatus) - Method in class org.springframework.batch.core.StepExecution
Sets the current status of this step
setStatuses(String[]) - Method in class org.springframework.batch.core.listener.ExecutionContextPromotionListener
 
setStep(Step) - Method in class org.springframework.batch.core.partition.support.TaskExecutorPartitionHandler
Setter for the Step that will be used to execute the partitioned StepExecution.
setStepExecutionIncrementer(DataFieldMaxValueIncrementer) - Method in class org.springframework.batch.core.repository.dao.JdbcStepExecutionDao
 
setStepExecutionListeners(StepExecutionListener[]) - Method in class org.springframework.batch.core.step.AbstractStep
Register each of the objects as listeners.
setStepExecutionSplitter(StepExecutionSplitter) - Method in class org.springframework.batch.core.partition.support.PartitionStep
Public setter for mandatory property StepExecutionSplitter.
setStepOperations(RepeatOperations) - Method in class org.springframework.batch.core.step.item.SimpleStepFactoryBean
Public setter for the stepOperations.
setStepOperations(RepeatOperations) - Method in class org.springframework.batch.core.step.tasklet.TaskletStep
The RepeatOperations to use for the outer loop of the batch processing.
setSteps(List<Step>) - Method in class org.springframework.batch.core.job.SimpleJob
Public setter for the steps in this job.
setStreams(ItemStream[]) - Method in class org.springframework.batch.core.step.item.SimpleStepFactoryBean
The streams to inject into the Step.
setStreams(ItemStream[]) - Method in class org.springframework.batch.core.step.tasklet.TaskletStep
Register each of the streams for callbacks at the appropriate time in the step.
setStreams(ItemStream[]) - Method in class org.springframework.batch.item.support.CompositeItemStream
Public setter for the listeners.
setStrict(boolean) - Method in class org.springframework.batch.core.listener.ExecutionContextPromotionListener
If set to TRUE, the listener will throw an exception if any 'key' is not found in the Step ExecutionContext.
setStrict(boolean) - Method in class org.springframework.batch.item.file.FlatFileItemReader
In strict mode the reader will throw an exception on AbstractItemCountingItemStreamItemReader.open(org.springframework.batch.item.ExecutionContext) if the input resource does not exist.
setStrict(boolean) - Method in class org.springframework.batch.item.file.mapping.BeanWrapperFieldSetMapper
Public setter for the 'strict' property.
setStrict(boolean) - Method in class org.springframework.batch.item.file.transform.FixedLengthTokenizer
Public setter for the strict flag.
setStrict(boolean) - Method in class org.springframework.batch.item.xml.StaxEventItemReader
In strict mode the reader will throw an exception on AbstractItemCountingItemStreamItemReader.open(org.springframework.batch.item.ExecutionContext) if the input resource does not exist.
setSuffix(String) - Method in class org.springframework.batch.item.file.separator.SuffixRecordSeparatorPolicy
Lines ending in this terminator String signal the end of a record.
setSystemExiter(SystemExiter) - Method in class org.springframework.batch.core.launch.support.CommandLineJobRunner
Injection setter for the SystemExiter.
setSystemProcessExitCodeMapper(SystemProcessExitCodeMapper) - Method in class org.springframework.batch.core.step.tasklet.SystemCommandTasklet
 
setTablePrefix(String) - Method in class org.springframework.batch.core.explore.support.JobExplorerFactoryBean
Sets the table prefix for all the batch meta-data tables.
setTablePrefix(String) - Method in class org.springframework.batch.core.repository.dao.AbstractJdbcBatchMetadataDao
Public setter for the table prefix property.
setTablePrefix(String) - Method in class org.springframework.batch.core.repository.support.JobRepositoryFactoryBean
Sets the table prefix for all the batch meta-data tables.
setTargetBeanName(String) - Method in class org.springframework.batch.core.scope.util.PlaceholderProxyFactoryBean
Set the name of the bean that is to be scoped.
setTargetMethod(String) - Method in class org.springframework.batch.item.adapter.AbstractMethodInvokingDelegator
 
setTargetObject(Object) - Method in class org.springframework.batch.item.adapter.AbstractMethodInvokingDelegator
 
setTargetType(Class<? extends T>) - Method in class org.springframework.batch.item.file.mapping.BeanWrapperFieldSetMapper
Public setter for the type of bean to create instead of using a prototype bean.
setTaskExecutor(TaskExecutor) - Method in class org.springframework.batch.core.job.flow.support.state.SplitState
Public setter for the taskExecutor.
setTaskExecutor(TaskExecutor) - Method in class org.springframework.batch.core.launch.support.SimpleJobLauncher
Set the TaskExecutor.
setTaskExecutor(TaskExecutor) - Method in class org.springframework.batch.core.partition.support.TaskExecutorPartitionHandler
Setter for the TaskExecutor that is used to farm out step executions to multiple threads.
setTaskExecutor(TaskExecutor) - Method in class org.springframework.batch.core.step.item.SimpleStepFactoryBean
Public setter for the TaskExecutor.
setTaskExecutor(TaskExecutor) - Method in class org.springframework.batch.core.step.tasklet.SystemCommandTasklet
Sets the task executor that will be used to execute the system command NB!
setTaskExecutor(TaskExecutor) - Method in class org.springframework.batch.repeat.support.TaskExecutorRepeatTemplate
Setter for task executor to be used to run the individual item callbacks.
setTasklet(Tasklet) - Method in class org.springframework.batch.core.step.tasklet.TaskletStep
Public setter for the Tasklet.
setTeam(String) - Method in class org.springframework.batch.sample.domain.football.Game
 
setTerminateOnly() - Method in class org.springframework.batch.core.StepExecution
Set a flag that will signal to an execution environment that this execution (and its surrounding job) wishes to exit.
setTerminateOnly() - Method in class org.springframework.batch.repeat.context.RepeatContextSupport
 
setTerminateOnly() - Method in interface org.springframework.batch.repeat.RepeatContext
Signal to the framework that the current batch should complete abnormally, independent of the current CompletionPolicy.
setTerminationCheckInterval(long) - Method in class org.springframework.batch.core.step.tasklet.SystemCommandTasklet
The time interval how often the tasklet will check for termination status.
setThresholds(Map<Class<? extends Throwable>, Integer>) - Method in class org.springframework.batch.repeat.exception.RethrowOnThresholdExceptionHandler
A map from exception classes to a threshold value of type Integer.
setThrottleLimit(int) - Method in class org.springframework.batch.core.step.item.SimpleStepFactoryBean
Public setter for the throttle limit.
setThrottleLimit(int) - Method in class org.springframework.batch.repeat.support.TaskExecutorRepeatTemplate
Public setter for the throttle limit.
setThrowExceptionOnRecordNumber(int) - Method in class org.springframework.batch.sample.support.ExceptionThrowingItemReaderProxy
 
setTimeout(long) - Method in class org.springframework.batch.core.step.tasklet.SystemCommandTasklet
Timeout in milliseconds.
setTimeout(long) - Method in class org.springframework.batch.retry.policy.TimeoutRetryPolicy
Setter for timeout.
setTitle(String) - Method in class org.springframework.batch.sample.domain.person.Person
 
setTokenizers(Map<String, LineTokenizer>) - Method in class org.springframework.batch.item.file.mapping.PatternMatchingCompositeLineMapper
 
setTokenizers(Map<String, LineTokenizer>) - Method in class org.springframework.batch.item.file.transform.PatternMatchingCompositeLineTokenizer
 
setTotalItems(int) - Method in class org.springframework.batch.sample.domain.order.Order
 
setTotalLines(int) - Method in class org.springframework.batch.sample.domain.order.Order
 
setTotalPrice(BigDecimal) - Method in class org.springframework.batch.sample.domain.order.LineItem
 
setTotalPrice(BigDecimal) - Method in class org.springframework.batch.sample.domain.order.Order
 
setTotalTd(int) - Method in class org.springframework.batch.sample.domain.football.Game
 
setTotalTd(int) - Method in class org.springframework.batch.sample.domain.football.PlayerSummary
 
setTransactionAttribute(TransactionAttribute) - Method in class org.springframework.batch.core.step.tasklet.TaskletStep
Public setter for the TransactionAttribute.
setTransactionManager(PlatformTransactionManager) - Method in class org.springframework.batch.core.repository.support.AbstractJobRepositoryFactoryBean
Public setter for the PlatformTransactionManager.
setTransactionManager(PlatformTransactionManager) - Method in class org.springframework.batch.core.step.item.SimpleStepFactoryBean
Public setter for the PlatformTransactionManager.
setTransactionManager(PlatformTransactionManager) - Method in class org.springframework.batch.core.step.tasklet.TaskletStep
Public setter for the PlatformTransactionManager.
setTransactionTimeout(int) - Method in class org.springframework.batch.core.step.item.SimpleStepFactoryBean
The timeout for an individual transaction in the step.
setTypeMap(Map<Class<? extends T>, C>) - Method in class org.springframework.batch.classify.SubclassClassifier
Set the classifications up as a map.
setTypes(Collection<Class<? extends Throwable>>) - Method in class org.springframework.batch.classify.BinaryExceptionClassifier
Set of Throwable class types to keys for the classifier.
setUnmarshaller(Unmarshaller) - Method in class org.springframework.batch.item.xml.StaxEventItemReader
 
setUpOutputFile(File, boolean, boolean) - Static method in class org.springframework.batch.item.util.FileUtils
Set up output file for batch processing.
setUseParent(boolean) - Method in class org.springframework.batch.repeat.exception.RethrowOnThresholdExceptionHandler
Flag to indicate the the exception counters should be shared between sibling contexts in a nested batch.
setUseParent(boolean) - Method in class org.springframework.batch.repeat.exception.SimpleLimitExceptionHandler
Flag to indicate the the exception counters should be shared between sibling contexts in a nested batch (i.e. inner loop).
setUseParent(boolean) - Method in class org.springframework.batch.repeat.policy.CountingCompletionPolicy
Flag to indicate whether the count is at the level of the parent context, or just local to the context.
setUserData(Object) - Method in class org.springframework.batch.core.step.item.Chunk
 
setUseSharedExtendedConnection(boolean) - Method in class org.springframework.batch.item.database.JdbcCursorItemReader
Indicate whether the connection used for the cursor should be used by all other processing thus sharing the same transaction.
setUseStatelessSession(boolean) - Method in class org.springframework.batch.item.database.HibernateCursorItemReader
Can be set only in uninitialized state.
setValidationFailure(int) - Method in class org.springframework.batch.sample.domain.trade.internal.TradeProcessor
Public setter for the the index on which failure should occur.
setValidator(Validator) - Method in class org.springframework.batch.item.validator.SpringValidator
 
setValidator(Validator<? super T>) - Method in class org.springframework.batch.item.validator.ValidatingItemProcessor
Set the validator used to validate each item.
setValues(PreparedStatement) - Method in class org.springframework.batch.core.resource.ListPreparedStatementSetter
 
setValues(T, PreparedStatement) - Method in interface org.springframework.batch.item.database.ItemPreparedStatementSetter
Set parameter values on the given PreparedStatement as determined from the provided item.
setValues(Map<String, Object>, PreparedStatement) - Method in class org.springframework.batch.item.database.support.ColumnMapItemPreparedStatementSetter
 
setValues(CustomerCredit, PreparedStatement) - Method in class org.springframework.batch.sample.domain.trade.internal.CustomerCreditUpdatePreparedStatementSetter
 
setVerifyCursorPosition(boolean) - Method in class org.springframework.batch.item.database.JdbcCursorItemReader
Allow verification of cursor position after current row is processed by RowMapper or RowCallbackHandler.
setVersion(Integer) - Method in class org.springframework.batch.core.Entity
Public setter for the version needed only by repository methods.
setVersion(String) - Method in class org.springframework.batch.item.xml.StaxEventItemWriter
Set XML version to be used for output XML.
setVip(boolean) - Method in class org.springframework.batch.sample.domain.order.Customer
 
setWeek(int) - Method in class org.springframework.batch.sample.domain.football.Game
 
setWhereClause(String) - Method in class org.springframework.batch.item.database.support.AbstractSqlPagingQueryProvider
 
setWhereClause(String) - Method in class org.springframework.batch.item.database.support.SqlPagingQueryProviderFactoryBean
 
setWorkingDirectory(String) - Method in class org.springframework.batch.core.step.tasklet.SystemCommandTasklet
 
setWriteCount(int) - Method in class org.springframework.batch.core.StepExecution
Sets the current number of written items for this execution
setWriteSkipCount(int) - Method in class org.springframework.batch.core.StepExecution
Set the number of records skipped on write
setWriteSkipPolicy(SkipPolicy) - Method in class org.springframework.batch.core.step.item.FaultTolerantChunkProcessor
 
setYear(int) - Method in class org.springframework.batch.sample.domain.football.Game
 
setYear(int) - Method in class org.springframework.batch.sample.domain.football.PlayerSummary
 
setZipCode(String) - Method in class org.springframework.batch.sample.domain.order.Address
 
Shipper - Class in org.springframework.batch.sample.domain.order.internal.xml
An XML shipper.
Shipper() - Constructor for class org.springframework.batch.sample.domain.order.internal.xml.Shipper
 
SHIPPER_ID_COLUMN - Static variable in class org.springframework.batch.sample.domain.order.internal.mapper.ShippingFieldSetMapper
 
SHIPPING_PRICE_COLUMN - Static variable in class org.springframework.batch.sample.domain.order.internal.mapper.OrderItemFieldSetMapper
 
SHIPPING_TYPE_ID_COLUMN - Static variable in class org.springframework.batch.sample.domain.order.internal.mapper.ShippingFieldSetMapper
 
ShippingFieldSetMapper - Class in org.springframework.batch.sample.domain.order.internal.mapper
 
ShippingFieldSetMapper() - Constructor for class org.springframework.batch.sample.domain.order.internal.mapper.ShippingFieldSetMapper
 
ShippingInfo - Class in org.springframework.batch.sample.domain.order
 
ShippingInfo() - Constructor for class org.springframework.batch.sample.domain.order.ShippingInfo
 
shouldClose(Connection) - Method in class org.springframework.batch.item.database.ExtendedConnectionDataSourceProxy
 
shouldRethrow(RetryPolicy, RetryContext, RetryState) - Method in class org.springframework.batch.retry.support.RetryTemplate
Extension point for subclasses to decide on behaviour after catching an exception in a RetryCallback.
shouldSkip(Throwable, int) - Method in class org.springframework.batch.core.step.skip.AlwaysSkipItemSkipPolicy
 
shouldSkip(Throwable, int) - Method in class org.springframework.batch.core.step.skip.LimitCheckingItemSkipPolicy
Given the provided exception and skip count, determine whether or not processing should continue for the given exception.
shouldSkip(Throwable, int) - Method in class org.springframework.batch.core.step.skip.NeverSkipItemSkipPolicy
 
shouldSkip(Throwable, int) - Method in interface org.springframework.batch.core.step.skip.SkipPolicy
Returns true or false, indicating whether or not processing should continue with the given throwable.
SimpleChunkProcessor<I,O> - Class in org.springframework.batch.core.step.item
Simple implementation of the ChunkProcessor interface that handles basic item writing and processing.
SimpleChunkProcessor(ItemProcessor<? super I, ? extends O>, ItemWriter<? super O>) - Constructor for class org.springframework.batch.core.step.item.SimpleChunkProcessor
 
SimpleChunkProvider<I> - Class in org.springframework.batch.core.step.item
Simple implementation of the ChunkProvider interface that does basic chunk providing from an ItemReader.
SimpleChunkProvider(ItemReader<? extends I>, RepeatOperations) - Constructor for class org.springframework.batch.core.step.item.SimpleChunkProvider
 
SimpleCompletionPolicy - Class in org.springframework.batch.repeat.policy
Policy for terminating a batch after a fixed number of operations.
SimpleCompletionPolicy() - Constructor for class org.springframework.batch.repeat.policy.SimpleCompletionPolicy
 
SimpleCompletionPolicy(int) - Constructor for class org.springframework.batch.repeat.policy.SimpleCompletionPolicy
 
SimpleCompletionPolicy.SimpleTerminationContext - Class in org.springframework.batch.repeat.policy
 
SimpleCompletionPolicy.SimpleTerminationContext(RepeatContext) - Constructor for class org.springframework.batch.repeat.policy.SimpleCompletionPolicy.SimpleTerminationContext
 
SimpleFlow - Class in org.springframework.batch.core.job.flow.support
A Flow that branches conditionally depending on the exit status of the last State.
SimpleFlow(String) - Constructor for class org.springframework.batch.core.job.flow.support.SimpleFlow
Create a flow with the given name.
SimpleJob - Class in org.springframework.batch.core.job
Simple implementation of Job interface providing the ability to run a JobExecution.
SimpleJob() - Constructor for class org.springframework.batch.core.job.SimpleJob
Default constructor for job with null name
SimpleJob(String) - Constructor for class org.springframework.batch.core.job.SimpleJob
 
SimpleJobExplorer - Class in org.springframework.batch.core.explore.support
Implementation of JobExplorer using the injected DAOs.
SimpleJobExplorer(JobInstanceDao, JobExecutionDao, StepExecutionDao, ExecutionContextDao) - Constructor for class org.springframework.batch.core.explore.support.SimpleJobExplorer
 
SimpleJobLauncher - Class in org.springframework.batch.core.launch.support
Simple implementation of the JobLauncher interface.
SimpleJobLauncher() - Constructor for class org.springframework.batch.core.launch.support.SimpleJobLauncher
 
SimpleJobOperator - Class in org.springframework.batch.core.launch.support
Simple implementation of the JobOperator interface.
SimpleJobOperator() - Constructor for class org.springframework.batch.core.launch.support.SimpleJobOperator
 
SimpleJobRepository - Class in org.springframework.batch.core.repository.support
Implementation of JobRepository that stores JobInstances, JobExecutions, and StepExecutions using the injected DAOs.
SimpleJobRepository(JobInstanceDao, JobExecutionDao, StepExecutionDao, ExecutionContextDao) - Constructor for class org.springframework.batch.core.repository.support.SimpleJobRepository
 
SimpleJvmExitCodeMapper - Class in org.springframework.batch.core.launch.support
An implementation of ExitCodeMapper that can be configured through a map from batch exit codes (String) to integer results.
SimpleJvmExitCodeMapper() - Constructor for class org.springframework.batch.core.launch.support.SimpleJvmExitCodeMapper
 
SimpleLimitExceptionHandler - Class in org.springframework.batch.repeat.exception
Simple implementation of exception handler which looks for given exception types.
SimpleLimitExceptionHandler(int) - Constructor for class org.springframework.batch.repeat.exception.SimpleLimitExceptionHandler
Convenience constructor for the SimpleLimitExceptionHandler to set the limit.
SimpleLimitExceptionHandler() - Constructor for class org.springframework.batch.repeat.exception.SimpleLimitExceptionHandler
Default constructor for the SimpleLimitExceptionHandler.
SimpleMessageApplicationEvent - Class in org.springframework.batch.sample.jmx
 
SimpleMessageApplicationEvent(Object, String) - Constructor for class org.springframework.batch.sample.jmx.SimpleMessageApplicationEvent
 
SimpleMethodInvoker - Class in org.springframework.batch.support
Simple implementation of the MethodInvoker interface that invokes a method on an object.
SimpleMethodInvoker(Object, Method) - Constructor for class org.springframework.batch.support.SimpleMethodInvoker
 
SimpleMethodInvoker(Object, String, Class<?>...) - Constructor for class org.springframework.batch.support.SimpleMethodInvoker
 
SimplePartitioner - Class in org.springframework.batch.core.partition.support
Simplest possible implementation of Partitioner.
SimplePartitioner() - Constructor for class org.springframework.batch.core.partition.support.SimplePartitioner
 
SimpleRecordSeparatorPolicy - Class in org.springframework.batch.item.file.separator
Simplest possible RecordSeparatorPolicy - treats all lines as record endings.
SimpleRecordSeparatorPolicy() - Constructor for class org.springframework.batch.item.file.separator.SimpleRecordSeparatorPolicy
 
SimpleResourceSuffixCreator - Class in org.springframework.batch.item.file
Trivial implementation of ResourceSuffixCreator that uses the index itself as suffix, separated by dot.
SimpleResourceSuffixCreator() - Constructor for class org.springframework.batch.item.file.SimpleResourceSuffixCreator
 
SimpleRetryExceptionHandler - Class in org.springframework.batch.core.step.item
An ExceptionHandler that is aware of the retry context so that it can distinguish between a fatal exception and one that can be retried.
SimpleRetryExceptionHandler(RetryPolicy, ExceptionHandler, Collection<Class<? extends Throwable>>) - Constructor for class org.springframework.batch.core.step.item.SimpleRetryExceptionHandler
Create an exception handler from its mandatory properties.
SimpleRetryPolicy - Class in org.springframework.batch.retry.policy
Simple retry policy that retries a fixed number of times for a set of named exceptions (and subclasses).
SimpleRetryPolicy() - Constructor for class org.springframework.batch.retry.policy.SimpleRetryPolicy
Create a SimpleRetryPolicy with the default number of retry attempts.
SimpleRetryPolicy(int) - Constructor for class org.springframework.batch.retry.policy.SimpleRetryPolicy
Create a SimpleRetryPolicy with the specified number of retry attempts, and default exceptions to retry.
SimpleStepExecutionSplitter - Class in org.springframework.batch.core.partition.support
Generic implementation of StepExecutionSplitter that delegates to a Partitioner to generate ExecutionContext instances.
SimpleStepExecutionSplitter(JobRepository, Step) - Constructor for class org.springframework.batch.core.partition.support.SimpleStepExecutionSplitter
 
SimpleStepExecutionSplitter(JobRepository, Step, Partitioner) - Constructor for class org.springframework.batch.core.partition.support.SimpleStepExecutionSplitter
Construct a SimpleStepExecutionSplitter from its mandatory properties.
SimpleStepFactoryBean<T,S> - Class in org.springframework.batch.core.step.item
Most common configuration options for simple steps should be found here.
SimpleStepFactoryBean() - Constructor for class org.springframework.batch.core.step.item.SimpleStepFactoryBean
Default constructor for SimpleStepFactoryBean.
SimpleSystemProcessExitCodeMapper - Class in org.springframework.batch.core.step.tasklet
Simple SystemProcessExitCodeMapper implementation that performs following mapping: 0 -> ExitStatus.FINISHED else -> ExitStatus.FAILED
SimpleSystemProcessExitCodeMapper() - Constructor for class org.springframework.batch.core.step.tasklet.SimpleSystemProcessExitCodeMapper
 
size() - Method in class org.springframework.batch.core.step.item.Chunk
 
size() - Method in class org.springframework.batch.item.ExecutionContext
Returns number of entries in the context
skip(Exception) - Method in class org.springframework.batch.core.step.item.Chunk
Register an anonymous skip.
SkipException - Exception in org.springframework.batch.core.step.skip
Base exception indicating that the skip has failed or caused a failure.
SkipException(String, Throwable) - Constructor for exception org.springframework.batch.core.step.skip.SkipException
 
SkipException(String) - Constructor for exception org.springframework.batch.core.step.skip.SkipException
 
SkipLimitExceededException - Exception in org.springframework.batch.core.step.skip
Exception indicating that the skip limit for a particular has been exceeded.
SkipLimitExceededException(int, Throwable) - Constructor for exception org.springframework.batch.core.step.skip.SkipLimitExceededException
 
SkipListener<T,S> - Interface in org.springframework.batch.core
Interface for listener to skipped items.
SkipListenerFailedException - Exception in org.springframework.batch.core.step.skip
Special exception to indicate a failure in a skip listener.
SkipListenerFailedException(String, RuntimeException, Throwable) - Constructor for exception org.springframework.batch.core.step.skip.SkipListenerFailedException
 
SkipListenerSupport<T,S> - Class in org.springframework.batch.core.listener
Basic no-op implementations of all SkipListener implementations.
SkipListenerSupport() - Constructor for class org.springframework.batch.core.listener.SkipListenerSupport
 
SkipPolicy - Interface in org.springframework.batch.core.step.skip
Policy for determining whether or not some processing should be skipped.
SkipWrapper<T> - Class in org.springframework.batch.core.step.item
Wrapper for an item and its exception if it failed processing.
SkipWrapper(T) - Constructor for class org.springframework.batch.core.step.item.SkipWrapper
 
SkipWrapper(Exception) - Constructor for class org.springframework.batch.core.step.item.SkipWrapper
 
SkipWrapper(T, Exception) - Constructor for class org.springframework.batch.core.step.item.SkipWrapper
 
sleep(long) - Method in class org.springframework.batch.retry.backoff.ObjectWaitSleeper
 
sleep(long) - Method in interface org.springframework.batch.retry.backoff.Sleeper
Pause for the specified period using whatever means available.
Sleeper - Interface in org.springframework.batch.retry.backoff
Strategy interface for backoff policies to delegate the pausing of execution.
SoftReferenceMapRetryContextCache - Class in org.springframework.batch.retry.policy
Map-based implementation of RetryContextCache.
SoftReferenceMapRetryContextCache() - Constructor for class org.springframework.batch.retry.policy.SoftReferenceMapRetryContextCache
Create a SoftReferenceMapRetryContextCache with default capacity.
SoftReferenceMapRetryContextCache(int) - Constructor for class org.springframework.batch.retry.policy.SoftReferenceMapRetryContextCache
 
split(StepExecution, int) - Method in interface org.springframework.batch.core.partition.StepExecutionSplitter
Partition the provided StepExecution into a set of parallel executable instances with the same parent JobExecution.
split(StepExecution, int) - Method in class org.springframework.batch.core.partition.support.SimpleStepExecutionSplitter
 
SplitParser - Class in org.springframework.batch.core.configuration.xml
Internal parser for the <split/> elements inside a job.
SplitParser(String) - Constructor for class org.springframework.batch.core.configuration.xml.SplitParser
Construct a FlowParser using the provided job repository ref.
SplitState - Class in org.springframework.batch.core.job.flow.support.state
A State implementation that splits a Flow into multiple parallel subflows.
SplitState(Collection<Flow>, String) - Constructor for class org.springframework.batch.core.job.flow.support.state.SplitState
 
SpringValidator<T> - Class in org.springframework.batch.item.validator
Adapts the Validator interface to Validator.
SpringValidator() - Constructor for class org.springframework.batch.item.validator.SpringValidator
 
SqlPagingQueryProviderFactoryBean - Class in org.springframework.batch.item.database.support
Factory bean for PagingQueryProvider interface.
SqlPagingQueryProviderFactoryBean() - Constructor for class org.springframework.batch.item.database.support.SqlPagingQueryProviderFactoryBean
 
SqlPagingQueryUtils - Class in org.springframework.batch.item.database.support
Utility class that generates the actual SQL statements used by query providers.
SqlPagingQueryUtils() - Constructor for class org.springframework.batch.item.database.support.SqlPagingQueryUtils
 
SqlServerPagingQueryProvider - Class in org.springframework.batch.item.database.support
Sql Server implementation of a PagingQueryProvider using database specific features.
SqlServerPagingQueryProvider() - Constructor for class org.springframework.batch.item.database.support.SqlServerPagingQueryProvider
 
SqlWindowingPagingQueryProvider - Class in org.springframework.batch.item.database.support
Generic Paging Query Provider using standard SQL:2003 windowing functions.
SqlWindowingPagingQueryProvider() - Constructor for class org.springframework.batch.item.database.support.SqlWindowingPagingQueryProvider
 
StagingItemListener - Class in org.springframework.batch.sample.common
Thread-safe database ItemReader implementing the process indicator pattern.
StagingItemListener() - Constructor for class org.springframework.batch.sample.common.StagingItemListener
 
StagingItemProcessor<T> - Class in org.springframework.batch.sample.common
Marks the input row as 'processed'.
StagingItemProcessor() - Constructor for class org.springframework.batch.sample.common.StagingItemProcessor
 
StagingItemReader<T> - Class in org.springframework.batch.sample.common
Thread-safe database ItemReader implementing the process indicator pattern.
StagingItemReader() - Constructor for class org.springframework.batch.sample.common.StagingItemReader
 
StagingItemWriter<T> - Class in org.springframework.batch.sample.common
Database ItemWriter implementing the process indicator pattern.
StagingItemWriter() - Constructor for class org.springframework.batch.sample.common.StagingItemWriter
 
StandaloneStepParser - Class in org.springframework.batch.core.configuration.xml
Internal parser for the <step/> elements for a job.
StandaloneStepParser() - Constructor for class org.springframework.batch.core.configuration.xml.StandaloneStepParser
 
start(FlowExecutor) - Method in interface org.springframework.batch.core.job.flow.Flow
 
start(FlowExecutor) - Method in class org.springframework.batch.core.job.flow.support.SimpleFlow
 
start(String, String) - Method in interface org.springframework.batch.core.launch.JobOperator
Start a new instance of a job with the parameters specified.
start(String, String) - Method in class org.springframework.batch.core.launch.support.SimpleJobOperator
 
start(RepeatContext) - Method in class org.springframework.batch.core.resource.StepExecutionSimpleCompletionPolicy
 
start(RepeatContext) - Method in interface org.springframework.batch.repeat.CompletionPolicy
Create a new context for the execution of a batch.
start(RepeatContext) - Method in class org.springframework.batch.repeat.policy.CompletionPolicySupport
Build a new RepeatContextSupport and return it.
start(RepeatContext) - Method in class org.springframework.batch.repeat.policy.CompositeCompletionPolicy
Create a new composite context from all the available policies.
start(RepeatContext) - Method in class org.springframework.batch.repeat.policy.CountingCompletionPolicy
 
start(RepeatContext) - Method in class org.springframework.batch.repeat.policy.SimpleCompletionPolicy
Reset the counter.
start(RepeatContext) - Method in class org.springframework.batch.repeat.policy.TimeoutTerminationPolicy
Start the clock on the timeout.
start() - Method in class org.springframework.batch.repeat.support.RepeatTemplate
Delegate to the CompletionPolicy.
start(RetryContext) - Method in interface org.springframework.batch.retry.backoff.BackOffPolicy
Start a new block of back off operations.
start(RetryContext) - Method in class org.springframework.batch.retry.backoff.ExponentialBackOffPolicy
Returns a new instance of BackOffContext configured with the 'expSeed' and 'increment' values.
start(RetryContext) - Method in class org.springframework.batch.retry.backoff.StatelessBackOffPolicy
Returns 'null'.
startCloseSuppression(Connection) - Method in class org.springframework.batch.item.database.ExtendedConnectionDataSourceProxy
 
startDocument(XMLEventWriter) - Method in class org.springframework.batch.item.xml.StaxEventItemWriter
Writes simple XML header containing: xml declaration - defines encoding and XML version opening tag of the root element and its attributes If this is not sufficient for you, simply override this method.
StartLimitExceededException - Exception in org.springframework.batch.core
Indicates the step's start limit has been exceeded.
StartLimitExceededException(String) - Constructor for exception org.springframework.batch.core.StartLimitExceededException
 
startNextInstance(String) - Method in interface org.springframework.batch.core.launch.JobOperator
Launch the next in a sequence of JobInstance determined by the JobParametersIncrementer attached to the specified job.
startNextInstance(String) - Method in class org.springframework.batch.core.launch.support.SimpleJobOperator
 
State - Interface in org.springframework.batch.core.job.flow
 
STATE_COLUMN - Static variable in class org.springframework.batch.sample.domain.order.internal.mapper.AddressFieldSetMapper
 
StatefulRetryOperationsInterceptor - Class in org.springframework.batch.retry.interceptor
A MethodInterceptor that can be used to automatically retry calls to a method on a service if it fails.
StatefulRetryOperationsInterceptor() - Constructor for class org.springframework.batch.retry.interceptor.StatefulRetryOperationsInterceptor
 
StatelessBackOffPolicy - Class in org.springframework.batch.retry.backoff
Simple base class for BackOffPolicy implementations that maintain no state across invocations.
StatelessBackOffPolicy() - Constructor for class org.springframework.batch.retry.backoff.StatelessBackOffPolicy
 
StateTransition - Class in org.springframework.batch.core.job.flow.support
Value object representing a potential transition from one State to another.
StaxEventItemReader<T> - Class in org.springframework.batch.item.xml
Item reader for reading XML input based on StAX.
StaxEventItemReader() - Constructor for class org.springframework.batch.item.xml.StaxEventItemReader
 
StaxEventItemWriter<T> - Class in org.springframework.batch.item.xml
An implementation of ItemWriter which uses StAX and Marshaller for serializing object to XML.
StaxEventItemWriter() - Constructor for class org.springframework.batch.item.xml.StaxEventItemWriter
 
StaxWriterCallback - Interface in org.springframework.batch.item.xml
Callback interface for writing to an XML file - useful e.g. for handling headers and footers.
Step - Interface in org.springframework.batch.core
Batch domain interface representing the configuration of a step.
StepContext - Class in org.springframework.batch.core.scope.context
Simple implementation of StepContext.
StepContext(StepExecution) - Constructor for class org.springframework.batch.core.scope.context.StepContext
Create a new instance of StepContext for this StepExecution.
StepContextFactory - Class in org.springframework.batch.core.scope.util
Implementation of ContextFactory that provides the current StepContext as a context object.
StepContextFactory() - Constructor for class org.springframework.batch.core.scope.util.StepContextFactory
 
StepContextRepeatCallback - Class in org.springframework.batch.core.scope.context
Convenient base class for clients who need to do something in a repeat callback inside a Step.
StepContextRepeatCallback(StepExecution) - Constructor for class org.springframework.batch.core.scope.context.StepContextRepeatCallback
 
StepContribution - Class in org.springframework.batch.core
Represents a contribution to a StepExecution, buffering changes until they can be applied at a chunk boundary.
StepContribution(StepExecution) - Constructor for class org.springframework.batch.core.StepContribution
 
StepExecution - Class in org.springframework.batch.core
Batch domain object representation the execution of a step.
StepExecution(String, JobExecution, Long) - Constructor for class org.springframework.batch.core.StepExecution
Constructor with mandatory properties.
StepExecution(String, JobExecution) - Constructor for class org.springframework.batch.core.StepExecution
Constructor that substitutes in null for the execution id
StepExecutionAggregator - Class in org.springframework.batch.core.partition.support
Convenience class for aggregating a set of StepExecution instances into a single result.
StepExecutionAggregator() - Constructor for class org.springframework.batch.core.partition.support.StepExecutionAggregator
 
StepExecutionApplicationEventAdvice - Class in org.springframework.batch.sample.jmx
Wraps calls for methods taking StepExecution as an argument and publishes notifications in the form of ApplicationEvent.
StepExecutionApplicationEventAdvice() - Constructor for class org.springframework.batch.sample.jmx.StepExecutionApplicationEventAdvice
 
StepExecutionDao - Interface in org.springframework.batch.core.repository.dao
 
StepExecutionListener - Interface in org.springframework.batch.core
Listener interface for the lifecycle of a Step.
StepExecutionListenerSupport - Class in org.springframework.batch.core.listener
 
StepExecutionListenerSupport() - Constructor for class org.springframework.batch.core.listener.StepExecutionListenerSupport
 
StepExecutionSimpleCompletionPolicy - Class in org.springframework.batch.core.resource
A CompletionPolicy that picks up a commit interval from JobParameters by listening to the start of a step.
StepExecutionSimpleCompletionPolicy() - Constructor for class org.springframework.batch.core.resource.StepExecutionSimpleCompletionPolicy
 
StepExecutionSplitter - Interface in org.springframework.batch.core.partition
Strategy interface for generating input contexts for a partitioned step execution independent from the fabric they are going to run on.
StepHolder - Interface in org.springframework.batch.core.step
Interface for holders of a Step as a convenience for callers who need access to the underlying instance.
StepInterruptionPolicy - Interface in org.springframework.batch.core.step
Strategy interface for an interruption policy.
StepListener - Interface in org.springframework.batch.core
Marker interface that acts as a parent to all step domain listeners, such as: StepExecutionListener, ChunkListener, ItemReadListener and ItemWriteListener
StepListenerFactoryBean - Class in org.springframework.batch.core.listener
This AbstractListenerFactoryBean implementation is used to create a StepListener.
StepListenerFactoryBean() - Constructor for class org.springframework.batch.core.listener.StepListenerFactoryBean
 
StepListenerFailedException - Exception in org.springframework.batch.core.listener
Exception to indicate a problem in a step listener.
StepListenerFailedException(String, Throwable) - Constructor for exception org.springframework.batch.core.listener.StepListenerFailedException
 
StepListenerFailedException(String, Throwable, RuntimeException) - Constructor for exception org.springframework.batch.core.listener.StepListenerFailedException
 
StepListenerMetaData - Enum in org.springframework.batch.core.listener
Enumeration for StepListener meta data, which ties together the names of methods, their interfaces, annotation, and expected arguments.
StepListenerParser - Class in org.springframework.batch.core.configuration.xml
Parser for a step listener element.
StepListenerParser() - Constructor for class org.springframework.batch.core.configuration.xml.StepListenerParser
 
StepListenerSupport<T,S> - Class in org.springframework.batch.core.listener
Basic no-op implementations of all StepListener implementations.
StepListenerSupport() - Constructor for class org.springframework.batch.core.listener.StepListenerSupport
 
StepLocator - Interface in org.springframework.batch.core.step
Interface for locating a Step instance by name.
StepRunner - Class in org.springframework.batch.test
Utility class for executing steps outside of a Job.
StepRunner(JobLauncher, JobRepository) - Constructor for class org.springframework.batch.test.StepRunner
 
StepScope - Class in org.springframework.batch.core.scope
Scope for step context.
StepScope() - Constructor for class org.springframework.batch.core.scope.StepScope
 
StepScopeManager - Class in org.springframework.batch.core.scope.context
Convenient aspect to wrap a single threaded step execution, where the implementation of the Step is not step scope aware (i.e. not the ones provided by the framework).
StepScopeManager() - Constructor for class org.springframework.batch.core.scope.context.StepScopeManager
 
StepState - Class in org.springframework.batch.core.job.flow.support.state
State implementation that delegates to a FlowExecutor to execute the specified Step.
StepState(Step) - Constructor for class org.springframework.batch.core.job.flow.support.state.StepState
 
StepState(String, Step) - Constructor for class org.springframework.batch.core.job.flow.support.state.StepState
 
StepSynchronizationManager - Class in org.springframework.batch.core.scope.context
Central convenience class for framework use in managing the step scope context.
StepSynchronizationManager() - Constructor for class org.springframework.batch.core.scope.context.StepSynchronizationManager
 
stop() - Method in class org.springframework.batch.core.JobExecution
Signal the JobExecution to stop.
stop(long) - Method in interface org.springframework.batch.core.launch.JobOperator
Send a stop signal to the JobExecution with the supplied id.
stop() - Static method in class org.springframework.batch.core.launch.support.JobRegistryBackgroundJobRunner
If embedded in a JVM, call this method to terminate the main method.
stop(long) - Method in class org.springframework.batch.core.launch.support.SimpleJobOperator
 
stopCloseSuppression(Connection) - Method in class org.springframework.batch.item.database.ExtendedConnectionDataSourceProxy
 
STOPPED - Static variable in class org.springframework.batch.core.ExitStatus
Convenient constant value representing finished processing with interrupted status.
STOPPED - Static variable in class org.springframework.batch.core.job.flow.FlowExecutionStatus
Special well-known status value.
STRING_TYPE - Static variable in class org.springframework.batch.core.converter.DefaultJobParametersConverter
 
stringToProperties(String) - Static method in class org.springframework.batch.support.PropertiesConverter
Parse a String to a Properties object.
SubclassClassifier<T,C> - Class in org.springframework.batch.classify
A Classifier for a parameterised object type based on a map.
SubclassClassifier() - Constructor for class org.springframework.batch.classify.SubclassClassifier
Create a SubclassClassifier with null default value.
SubclassClassifier(C) - Constructor for class org.springframework.batch.classify.SubclassClassifier
Create a SubclassClassifier with supplied default value.
SubclassClassifier(Map<Class<? extends T>, C>, C) - Constructor for class org.springframework.batch.classify.SubclassClassifier
Create a SubclassClassifier with supplied default value.
SuffixRecordSeparatorPolicy - Class in org.springframework.batch.item.file.separator
A RecordSeparatorPolicy that looks for an exact match for a String at the end of a line (e.g. a semicolon).
SuffixRecordSeparatorPolicy() - Constructor for class org.springframework.batch.item.file.separator.SuffixRecordSeparatorPolicy
 
SummaryFooterCallback - Class in org.springframework.batch.sample.support
Writes summary info in the footer of a file.
SummaryFooterCallback() - Constructor for class org.springframework.batch.sample.support.SummaryFooterCallback
 
SybasePagingQueryProvider - Class in org.springframework.batch.item.database.support
Sybase implementation of a PagingQueryProvider using database specific features.
SybasePagingQueryProvider() - Constructor for class org.springframework.batch.item.database.support.SybasePagingQueryProvider
 
SynchronizedAttributeAccessor - Class in org.springframework.batch.repeat.context
An AttributeAccessor that synchronizes on a mutex (not this) before modifying or accessing the underlying attributes.
SynchronizedAttributeAccessor() - Constructor for class org.springframework.batch.repeat.context.SynchronizedAttributeAccessor
 
synchronizeStatus(JobExecution) - Method in class org.springframework.batch.core.repository.dao.JdbcJobExecutionDao
 
synchronizeStatus(JobExecution) - Method in interface org.springframework.batch.core.repository.dao.JobExecutionDao
Because it may be possible that the status of a JobExecution is updated while running, the following method will synchronize only the status and version fields.
synchronizeStatus(JobExecution) - Method in class org.springframework.batch.core.repository.dao.MapJobExecutionDao
 
SystemCommandException - Exception in org.springframework.batch.core.step.tasklet
Exception indicating failed execution of system command.
SystemCommandException(String) - Constructor for exception org.springframework.batch.core.step.tasklet.SystemCommandException
 
SystemCommandException(String, Throwable) - Constructor for exception org.springframework.batch.core.step.tasklet.SystemCommandException
 
SystemCommandTasklet - Class in org.springframework.batch.core.step.tasklet
Tasklet that executes a system command.
SystemCommandTasklet() - Constructor for class org.springframework.batch.core.step.tasklet.SystemCommandTasklet
 
SystemExiter - Interface in org.springframework.batch.core.launch.support
Interface for exiting the JVM.
SystemProcessExitCodeMapper - Interface in org.springframework.batch.core.step.tasklet
Maps the exit code of a system process to ExitStatus value returned by a system command.
SystemPropertyInitializer - Class in org.springframework.batch.support
Helper class that sets up a System property with a default value.
SystemPropertyInitializer() - Constructor for class org.springframework.batch.support.SystemPropertyInitializer
 

T

take() - Method in class org.springframework.batch.repeat.support.ThrottleLimitResultQueue
 
TaskExecutorPartitionHandler - Class in org.springframework.batch.core.partition.support
A PartitionHandler that uses a TaskExecutor to execute the partitioned Step locally in multiple threads.
TaskExecutorPartitionHandler() - Constructor for class org.springframework.batch.core.partition.support.TaskExecutorPartitionHandler
 
TaskExecutorRepeatTemplate - Class in org.springframework.batch.repeat.support
Provides RepeatOperations support including interceptors that can be used to modify or monitor the behaviour at run time.
TaskExecutorRepeatTemplate() - Constructor for class org.springframework.batch.repeat.support.TaskExecutorRepeatTemplate
 
Tasklet - Interface in org.springframework.batch.core.step.tasklet
Strategy for processing in a step.
TaskletStep - Class in org.springframework.batch.core.step.tasklet
Simple implementation of executing the step as a call to a Tasklet, possibly repeated, and each call surrounded by a transaction.
TaskletStep() - Constructor for class org.springframework.batch.core.step.tasklet.TaskletStep
Default constructor.
TaskletStep(String) - Constructor for class org.springframework.batch.core.step.tasklet.TaskletStep
 
TerminatedRetryException - Exception in org.springframework.batch.retry
 
TerminatedRetryException(String, Throwable) - Constructor for exception org.springframework.batch.retry.TerminatedRetryException
 
TerminatedRetryException(String) - Constructor for exception org.springframework.batch.retry.TerminatedRetryException
 
test.jdbc.datasource - package test.jdbc.datasource
 
testing - Static variable in class org.springframework.batch.core.launch.support.JobRegistryBackgroundJobRunner
 
ThreadStepInterruptionPolicy - Class in org.springframework.batch.core.step
Policy that checks the current thread to see if it has been interrupted.
ThreadStepInterruptionPolicy() - Constructor for class org.springframework.batch.core.step.ThreadStepInterruptionPolicy
 
ThrottleLimitResultQueue<T> - Class in org.springframework.batch.repeat.support
An implementation of the ResultQueue that throttles the number of expected results, limiting it to a maximum at any given time.
ThrottleLimitResultQueue(int) - Constructor for class org.springframework.batch.repeat.support.ThrottleLimitResultQueue
 
TimeoutRetryPolicy - Class in org.springframework.batch.retry.policy
A RetryPolicy that allows a retry only if it hasn't timed out.
TimeoutRetryPolicy() - Constructor for class org.springframework.batch.retry.policy.TimeoutRetryPolicy
 
TimeoutTerminationPolicy - Class in org.springframework.batch.repeat.policy
Termination policy that times out after a fixed period.
TimeoutTerminationPolicy() - Constructor for class org.springframework.batch.repeat.policy.TimeoutTerminationPolicy
Default constructor.
TimeoutTerminationPolicy(long) - Constructor for class org.springframework.batch.repeat.policy.TimeoutTerminationPolicy
Construct a TimeoutTerminationPolicy with the specified timeout value (in milliseconds).
TimeoutTerminationPolicy.TimeoutBatchContext - Class in org.springframework.batch.repeat.policy
 
TimeoutTerminationPolicy.TimeoutBatchContext(RepeatContext) - Constructor for class org.springframework.batch.repeat.policy.TimeoutTerminationPolicy.TimeoutBatchContext
 
toJobParameters() - Method in class org.springframework.batch.core.JobParametersBuilder
Conversion method that takes the current state of this builder and returns it as a JobruntimeParameters object.
tokenize(String) - Method in class org.springframework.batch.item.file.transform.AbstractLineTokenizer
Yields the tokens resulting from the splitting of the supplied line.
tokenize(String) - Method in interface org.springframework.batch.item.file.transform.LineTokenizer
Yields the tokens resulting from the splitting of the supplied line.
tokenize(String) - Method in class org.springframework.batch.item.file.transform.PatternMatchingCompositeLineTokenizer
 
tokenize(String) - Method in class org.springframework.batch.sample.domain.trade.CompositeCustomerUpdateLineTokenizer
 
TopLevelJobListenerParser - Class in org.springframework.batch.core.configuration.xml
Parse <job-listener/> elements in the batch namespace.
TopLevelJobListenerParser() - Constructor for class org.springframework.batch.core.configuration.xml.TopLevelJobListenerParser
 
TopLevelStepListenerParser - Class in org.springframework.batch.core.configuration.xml
Parse <step-listener/> elements in the batch namespace.
TopLevelStepListenerParser() - Constructor for class org.springframework.batch.core.configuration.xml.TopLevelStepListenerParser
 
TopLevelStepParser - Class in org.springframework.batch.core.configuration.xml
Parser for the lt;step/gt; top level element in the Batch namespace.
TopLevelStepParser() - Constructor for class org.springframework.batch.core.configuration.xml.TopLevelStepParser
 
toString() - Method in class org.springframework.batch.core.Entity
 
toString() - Method in class org.springframework.batch.core.ExitStatus
 
toString() - Method in class org.springframework.batch.core.job.AbstractJob
 
toString() - Method in class org.springframework.batch.core.job.flow.FlowExecution
 
toString() - Method in class org.springframework.batch.core.job.flow.FlowExecutionStatus
 
toString() - Method in class org.springframework.batch.core.job.flow.support.state.AbstractState
 
toString() - Method in class org.springframework.batch.core.job.flow.support.state.EndState
 
toString() - Method in class org.springframework.batch.core.job.flow.support.StateTransition
 
toString() - Method in class org.springframework.batch.core.JobExecution
 
toString() - Method in class org.springframework.batch.core.JobInstance
 
toString() - Method in class org.springframework.batch.core.JobParameter
 
toString() - Method in class org.springframework.batch.core.JobParameters
 
toString() - Method in class org.springframework.batch.core.resource.StepExecutionSimpleCompletionPolicy
Delegates to the wrapped CompletionPolicy if set, otherwise returns the value of StepExecutionSimpleCompletionPolicy.setKeyName(String).
toString() - Method in class org.springframework.batch.core.scope.context.ChunkContext
 
toString() - Method in class org.springframework.batch.core.scope.context.StepContext
 
toString() - Method in class org.springframework.batch.core.step.AbstractStep
 
toString() - Method in class org.springframework.batch.core.step.item.Chunk
 
toString() - Method in class org.springframework.batch.core.step.item.SkipWrapper
 
toString() - Method in class org.springframework.batch.core.StepContribution
 
toString() - Method in class org.springframework.batch.core.StepExecution
 
toString() - Method in class org.springframework.batch.item.ExecutionContext
 
toString() - Method in class org.springframework.batch.item.file.transform.DefaultFieldSet
 
toString() - Method in class org.springframework.batch.item.file.transform.Range
 
toString() - Method in class org.springframework.batch.repeat.context.SynchronizedAttributeAccessor
 
toString() - Method in class org.springframework.batch.repeat.policy.SimpleCompletionPolicy
 
toString() - Method in class org.springframework.batch.retry.backoff.ExponentialBackOffPolicy
 
toString() - Method in class org.springframework.batch.retry.context.RetryContextSupport
 
toString() - Method in class org.springframework.batch.retry.support.DefaultRetryState
 
toString() - Method in class org.springframework.batch.sample.domain.football.Game
 
toString() - Method in class org.springframework.batch.sample.domain.football.Player
 
toString() - Method in class org.springframework.batch.sample.domain.football.PlayerSummary
 
toString() - Method in class org.springframework.batch.sample.domain.order.Address
 
toString() - Method in class org.springframework.batch.sample.domain.order.BillingInfo
 
toString() - Method in class org.springframework.batch.sample.domain.order.Customer
 
toString() - Method in class org.springframework.batch.sample.domain.order.internal.xml.Customer
 
toString() - Method in class org.springframework.batch.sample.domain.order.internal.xml.Order
 
toString() - Method in class org.springframework.batch.sample.domain.order.LineItem
 
toString() - Method in class org.springframework.batch.sample.domain.order.Order
 
toString() - Method in class org.springframework.batch.sample.domain.person.Child
 
toString() - Method in class org.springframework.batch.sample.domain.person.Person
 
toString() - Method in class org.springframework.batch.sample.domain.trade.CustomerCredit
 
toString() - Method in class org.springframework.batch.sample.domain.trade.CustomerDebit
 
toString() - Method in class org.springframework.batch.sample.domain.trade.CustomerUpdate
 
toString() - Method in class org.springframework.batch.sample.domain.trade.Trade
 
toString() - Method in class org.springframework.batch.sample.jmx.SimpleMessageApplicationEvent
 
TOTAL_PRICE_COLUMN - Static variable in class org.springframework.batch.sample.domain.order.internal.mapper.OrderItemFieldSetMapper
 
TotalOrderItemsFunction - Class in org.springframework.batch.sample.domain.order.internal.valang
Validates total items count in Order.
TotalOrderItemsFunction(Function[], int, int) - Constructor for class org.springframework.batch.sample.domain.order.internal.valang.TotalOrderItemsFunction
 
Trade - Class in org.springframework.batch.sample.domain.trade
 
Trade() - Constructor for class org.springframework.batch.sample.domain.trade.Trade
 
Trade(String, long, BigDecimal, String) - Constructor for class org.springframework.batch.sample.domain.trade.Trade
 
TradeDao - Interface in org.springframework.batch.sample.domain.trade
Interface for writing a Trade object to an arbitrary output.
TradeFieldSetMapper - Class in org.springframework.batch.sample.domain.trade.internal
 
TradeFieldSetMapper() - Constructor for class org.springframework.batch.sample.domain.trade.internal.TradeFieldSetMapper
 
TradeProcessor - Class in org.springframework.batch.sample.domain.trade.internal
Processes the Trade - throwing validation errors if necessary.
TradeProcessor() - Constructor for class org.springframework.batch.sample.domain.trade.internal.TradeProcessor
 
TradeRowMapper - Class in org.springframework.batch.sample.domain.trade.internal
 
TradeRowMapper() - Constructor for class org.springframework.batch.sample.domain.trade.internal.TradeRowMapper
 
TradeWriter - Class in org.springframework.batch.sample.domain.trade.internal
Delegates the actual writing to custom DAO delegate.
TradeWriter() - Constructor for class org.springframework.batch.sample.domain.trade.internal.TradeWriter
 
TransactionAwareBufferedWriter - Class in org.springframework.batch.support.transaction
Wrapper for a Writer that delays actually writing to the buffer if a transaction is active.
TransactionAwareBufferedWriter(Writer, String) - Constructor for class org.springframework.batch.support.transaction.TransactionAwareBufferedWriter
 
TransactionAwareProxyFactory<T> - Class in org.springframework.batch.support.transaction
Factory for transaction aware objects (like lists, sets, maps).
transform(StepContribution, Chunk<I>) - Method in class org.springframework.batch.core.step.item.FaultTolerantChunkProcessor
 
transform(StepContribution, Chunk<I>) - Method in class org.springframework.batch.core.step.item.SimpleChunkProcessor
 
TRUE_SYMBOL - Static variable in class org.springframework.batch.sample.domain.order.internal.mapper.CustomerFieldSetMapper
 

U

unbind(JobFactory, Map<String, ?>) - Method in class org.springframework.batch.core.configuration.support.JobFactoryRegistrationListener
Take the JobFactory provided and unregister it with the JobRegistry.
UnexpectedInputException - Exception in org.springframework.batch.item
Used to signal an unexpected end of an input or message stream.
UnexpectedInputException(String) - Constructor for exception org.springframework.batch.item.UnexpectedInputException
Create a new UnexpectedInputException based on a message.
UnexpectedInputException(String, Throwable) - Constructor for exception org.springframework.batch.item.UnexpectedInputException
Create a new UnexpectedInputException based on a message and another exception.
UnexpectedJobExecutionException - Exception in org.springframework.batch.core
Indicates to the framework that a critical error has occurred and processing should immediately stop.
UnexpectedJobExecutionException(String) - Constructor for exception org.springframework.batch.core.UnexpectedJobExecutionException
Constructs a new instance with a message.
UnexpectedJobExecutionException(String, Throwable) - Constructor for exception org.springframework.batch.core.UnexpectedJobExecutionException
Constructs a new instance with a message.
UNKNOWN - Static variable in class org.springframework.batch.core.ExitStatus
Convenient constant value representing unknown state - assumed not continuable.
UNKNOWN - Static variable in class org.springframework.batch.core.job.flow.FlowExecutionStatus
Special well-known status value.
unregister(String) - Method in interface org.springframework.batch.core.configuration.JobRegistry
Unregisters a previously registered Job.
unregister(String) - Method in class org.springframework.batch.core.configuration.support.ClassPathXmlJobRegistry
 
unregister(String) - Method in class org.springframework.batch.core.configuration.support.MapJobRegistry
 
unwrap(Class<T>) - Method in class org.springframework.batch.item.database.ExtendedConnectionDataSourceProxy
Returns either self or delegate (in this order) if one of them can be cast to supplied parameter class.
update(JobExecution) - Method in interface org.springframework.batch.core.repository.JobRepository
Update the JobExecution (but not its ExecutionContext).
update(StepExecution) - Method in interface org.springframework.batch.core.repository.JobRepository
Update the StepExecution (but not its ExecutionContext).
update(JobExecution) - Method in class org.springframework.batch.core.repository.support.SimpleJobRepository
 
update(StepExecution) - Method in class org.springframework.batch.core.repository.support.SimpleJobRepository
 
update(RepeatContext) - Method in class org.springframework.batch.core.resource.StepExecutionSimpleCompletionPolicy
 
update(ExecutionContext) - Method in class org.springframework.batch.item.database.HibernateCursorItemReader
Clears the session if not stateful and delegates to super class.
update(ExecutionContext) - Method in class org.springframework.batch.item.file.FlatFileItemWriter
 
update(ExecutionContext) - Method in class org.springframework.batch.item.file.MultiResourceItemReader
Store the current resource index and position in the resource.
update(ExecutionContext) - Method in class org.springframework.batch.item.file.MultiResourceItemWriter
 
update(ExecutionContext) - Method in interface org.springframework.batch.item.ItemStream
Indicates that the execution context provided during open is about to be saved.
update(ExecutionContext) - Method in class org.springframework.batch.item.ItemStreamSupport
Return empty ExecutionContext.
update(ExecutionContext) - Method in class org.springframework.batch.item.support.AbstractItemCountingItemStreamItemReader
 
update(ExecutionContext) - Method in class org.springframework.batch.item.support.CompositeItemStream
Simple aggregate ExecutionContext provider for the contributions registered under the given key.
update(ExecutionContext) - Method in class org.springframework.batch.item.xml.StaxEventItemWriter
Get the restart data.
update(RepeatContext) - Method in interface org.springframework.batch.repeat.CompletionPolicy
Give implementations the opportunity to update the state of the current batch.
update(RepeatContext) - Method in class org.springframework.batch.repeat.policy.CompletionPolicySupport
Increment the context so the counter is up to date.
update(RepeatContext) - Method in class org.springframework.batch.repeat.policy.CompositeCompletionPolicy
Update all the composed contexts, and also increment the parent context.
update(RepeatContext) - Method in class org.springframework.batch.repeat.policy.CountingCompletionPolicy
 
update() - Method in class org.springframework.batch.repeat.policy.SimpleCompletionPolicy.SimpleTerminationContext
 
update(RepeatContext) - Method in class org.springframework.batch.repeat.policy.SimpleCompletionPolicy
Increment the counter in the context.
update(RepeatContext) - Method in class org.springframework.batch.repeat.support.RepeatTemplate
Delegate to the CompletionPolicy.
update(ExecutionContext) - Method in class org.springframework.batch.sample.domain.trade.internal.TradeWriter
 
updateCustomer(String, BigDecimal) - Method in interface org.springframework.batch.sample.domain.trade.CustomerDao
 
updateCustomer(String, BigDecimal) - Method in class org.springframework.batch.sample.domain.trade.internal.JdbcCustomerDao
 
updateExecutionContext(JobExecution) - Method in interface org.springframework.batch.core.repository.dao.ExecutionContextDao
Persist the updates of execution context associated with the given jobExecution.
updateExecutionContext(StepExecution) - Method in interface org.springframework.batch.core.repository.dao.ExecutionContextDao
Persist the updates of execution context associated with the given stepExecution.
updateExecutionContext(JobExecution) - Method in class org.springframework.batch.core.repository.dao.JdbcExecutionContextDao
 
updateExecutionContext(StepExecution) - Method in class org.springframework.batch.core.repository.dao.JdbcExecutionContextDao
 
updateExecutionContext(StepExecution) - Method in class org.springframework.batch.core.repository.dao.MapExecutionContextDao
 
updateExecutionContext(JobExecution) - Method in class org.springframework.batch.core.repository.dao.MapExecutionContextDao
 
updateExecutionContext(StepExecution) - Method in interface org.springframework.batch.core.repository.JobRepository
Persist the updated ExecutionContexts of the given StepExecution.
updateExecutionContext(JobExecution) - Method in interface org.springframework.batch.core.repository.JobRepository
Persist the updated ExecutionContext of the given JobExecution.
updateExecutionContext(StepExecution) - Method in class org.springframework.batch.core.repository.support.SimpleJobRepository
 
updateExecutionContext(JobExecution) - Method in class org.springframework.batch.core.repository.support.SimpleJobRepository
 
updateJobExecution(JobExecution) - Method in class org.springframework.batch.core.repository.dao.JdbcJobExecutionDao
Update given JobExecution using a SQL UPDATE statement.
updateJobExecution(JobExecution) - Method in interface org.springframework.batch.core.repository.dao.JobExecutionDao
Update and existing JobExecution.
updateJobExecution(JobExecution) - Method in class org.springframework.batch.core.repository.dao.MapJobExecutionDao
 
updateJobExecutionStatus(FlowExecutionStatus) - Method in interface org.springframework.batch.core.job.flow.FlowExecutor
Handle any status changes that might be needed in the JobExecution.
updateStepExecution(StepExecution) - Method in class org.springframework.batch.core.job.AbstractJob
Convenience method for subclasses so they can change the state of a StepExecution if necessary.
updateStepExecution(StepExecution) - Method in class org.springframework.batch.core.repository.dao.JdbcStepExecutionDao
 
updateStepExecution(StepExecution) - Method in class org.springframework.batch.core.repository.dao.MapStepExecutionDao
 
updateStepExecution(StepExecution) - Method in interface org.springframework.batch.core.repository.dao.StepExecutionDao
Update the given StepExecution Preconditions: Id must not be null.
updateTotalPrice(List<Trade>) - Method in class org.springframework.batch.sample.domain.trade.internal.TradeWriter
 
upgradeStatus(BatchStatus) - Method in class org.springframework.batch.core.JobExecution
Upgrade the status field if the provided value is greater than the existing one.
upgradeStatus(BatchStatus) - Method in class org.springframework.batch.core.StepExecution
Upgrade the status field if the provided value is greater than the existing one.
upgradeTo(BatchStatus) - Method in enum org.springframework.batch.core.BatchStatus
Method used to move status values through their logical progression, and override less severe failures with more severe ones.
UPPER_BORDER_NOT_DEFINED - Static variable in class org.springframework.batch.item.file.transform.Range
 

V

validate(T) - Method in class org.springframework.batch.item.validator.SpringValidator
 
validate(T) - Method in interface org.springframework.batch.item.validator.Validator
Method used to validate if the value is valid.
ValidateDiscountsFunction - Class in org.springframework.batch.sample.domain.order.internal.valang
 
ValidateDiscountsFunction(Function[], int, int) - Constructor for class org.springframework.batch.sample.domain.order.internal.valang.ValidateDiscountsFunction
 
ValidateHandlingPricesFunction - Class in org.springframework.batch.sample.domain.order.internal.valang
 
ValidateHandlingPricesFunction(Function[], int, int) - Constructor for class org.springframework.batch.sample.domain.order.internal.valang.ValidateHandlingPricesFunction
 
ValidateIdsFunction - Class in org.springframework.batch.sample.domain.order.internal.valang
 
ValidateIdsFunction(Function[], int, int) - Constructor for class org.springframework.batch.sample.domain.order.internal.valang.ValidateIdsFunction
 
ValidatePricesFunction - Class in org.springframework.batch.sample.domain.order.internal.valang
 
ValidatePricesFunction(Function[], int, int) - Constructor for class org.springframework.batch.sample.domain.order.internal.valang.ValidatePricesFunction
 
ValidateQuantitiesFunction - Class in org.springframework.batch.sample.domain.order.internal.valang
 
ValidateQuantitiesFunction(Function[], int, int) - Constructor for class org.springframework.batch.sample.domain.order.internal.valang.ValidateQuantitiesFunction
 
ValidateShippingPricesFunction - Class in org.springframework.batch.sample.domain.order.internal.valang
 
ValidateShippingPricesFunction(Function[], int, int) - Constructor for class org.springframework.batch.sample.domain.order.internal.valang.ValidateShippingPricesFunction
 
ValidateTotalPricesFunction - Class in org.springframework.batch.sample.domain.order.internal.valang
 
ValidateTotalPricesFunction(Function[], int, int) - Constructor for class org.springframework.batch.sample.domain.order.internal.valang.ValidateTotalPricesFunction
 
ValidatingItemProcessor<T> - Class in org.springframework.batch.item.validator
Simple implementation of ItemProcessor that validates input and returns it without modifications.
ValidatingItemProcessor() - Constructor for class org.springframework.batch.item.validator.ValidatingItemProcessor
Default constructor
ValidatingItemProcessor(Validator<? super T>) - Constructor for class org.springframework.batch.item.validator.ValidatingItemProcessor
Creates a ValidatingItemProcessor based on the given Validator.
ValidationException - Exception in org.springframework.batch.item.validator
This exception should be thrown when there are validation errors.
ValidationException(String, Throwable) - Constructor for exception org.springframework.batch.item.validator.ValidationException
Create a new ValidationException based on a message and another exception.
ValidationException(String) - Constructor for exception org.springframework.batch.item.validator.ValidationException
Create a new ValidationException based on a message.
Validator<T> - Interface in org.springframework.batch.item.validator
Interface used to validate objects.
VALUE_NOT_SET - Static variable in class org.springframework.batch.item.database.JdbcCursorItemReader
 
VALUE_NOT_SET - Static variable in class org.springframework.batch.item.database.JdbcPagingItemReader
 
valueOf(String) - Static method in enum org.springframework.batch.core.BatchStatus
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.springframework.batch.core.JobParameter.ParameterType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.springframework.batch.core.listener.JobListenerMetaData
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.springframework.batch.core.listener.StepListenerMetaData
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.springframework.batch.repeat.exception.LogOrRethrowExceptionHandler.Level
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.springframework.batch.repeat.RepeatStatus
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.springframework.batch.sample.domain.trade.CustomerOperation
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.springframework.batch.support.DatabaseType
Returns the enum constant of this type with the specified name.
values() - Static method in enum org.springframework.batch.core.BatchStatus
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.springframework.batch.core.JobParameter.ParameterType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.springframework.batch.core.listener.JobListenerMetaData
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.springframework.batch.core.listener.StepListenerMetaData
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.springframework.batch.repeat.exception.LogOrRethrowExceptionHandler.Level
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.springframework.batch.repeat.RepeatStatus
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.springframework.batch.sample.domain.trade.CustomerOperation
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.springframework.batch.support.DatabaseType
Returns an array containing the constants of this enum type, in the order they are declared.
VIP_COLUMN - Static variable in class org.springframework.batch.sample.domain.order.internal.mapper.CustomerFieldSetMapper
 

W

waitForResults(RepeatInternalState) - Method in class org.springframework.batch.repeat.support.RepeatTemplate
If necessary, wait for results to come back from remote or concurrent processes.
waitForResults(RepeatInternalState) - Method in class org.springframework.batch.repeat.support.TaskExecutorRepeatTemplate
Wait for all the results to appear on the queue and execute the after interceptors for each one.
WORKING - Static variable in class org.springframework.batch.sample.common.StagingItemWriter
 
write(List<? extends Object>) - Method in class example.ExampleItemWriter
 
write(StepContribution, Chunk<I>, Chunk<O>) - Method in class org.springframework.batch.core.step.item.FaultTolerantChunkProcessor
 
write(StepContribution, Chunk<I>, Chunk<O>) - Method in class org.springframework.batch.core.step.item.SimpleChunkProcessor
Simple implementation delegates to the SimpleChunkProcessor.doWrite(List) method and increments the write count in the contribution.
write(List<? extends T>) - Method in class org.springframework.batch.item.adapter.ItemWriterAdapter
 
write(List<? extends T>) - Method in class org.springframework.batch.item.adapter.PropertyExtractingDelegatingItemWriter
Extracts values from item's fields named in fieldsUsedAsTargetMethodArguments and passes them as arguments to the delegate method.
write(List<? extends T>) - Method in class org.springframework.batch.item.database.HibernateItemWriter
Save or update any entities not in the current hibernate session and then flush and clear the hibernate session.
write(List<? extends T>) - Method in class org.springframework.batch.item.database.IbatisBatchItemWriter
 
write(List<? extends T>) - Method in class org.springframework.batch.item.database.JdbcBatchItemWriter
 
write(List<? extends T>) - Method in class org.springframework.batch.item.database.JpaItemWriter
Merge all provided items that aren't already in the persistence context and then flush and clear the entity manager.
write(List<? extends T>) - Method in class org.springframework.batch.item.file.FlatFileItemWriter
Writes out a string followed by a "new line", where the format of the new line separator is determined by the underlying operating system.
write(List<? extends T>) - Method in class org.springframework.batch.item.file.MultiResourceItemWriter
 
write(List<? extends T>) - Method in interface org.springframework.batch.item.ItemWriter
Process the supplied data element.
write(List<? extends T>) - Method in class org.springframework.batch.item.jms.JmsItemWriter
Send the items one-by-one to the default destination of the jms template.
write(List<? extends T>) - Method in class org.springframework.batch.item.support.ClassifierCompositeItemWriter
Delegates to injected ItemWriter instances according to their classification by the Classifier.
write(List<? extends T>) - Method in class org.springframework.batch.item.support.CompositeItemWriter
Calls injected ItemProcessors in order.
write(List<? extends T>) - Method in class org.springframework.batch.item.xml.StaxEventItemWriter
Write the value objects and flush them to the file.
write(XMLEventWriter) - Method in interface org.springframework.batch.item.xml.StaxWriterCallback
Write contents using the supplied XMLEventWriter.
write(List<? extends Object>) - Method in class org.springframework.batch.sample.common.InfiniteLoopWriter
 
write(List<? extends T>) - Method in class org.springframework.batch.sample.common.StagingItemWriter
Serialize the item to the staging table, and add a NEW processed flag.
write(List<? extends Game>) - Method in class org.springframework.batch.sample.domain.football.internal.JdbcGameDao
 
write(List<? extends PlayerSummary>) - Method in class org.springframework.batch.sample.domain.football.internal.JdbcPlayerSummaryDao
 
write(List<? extends Player>) - Method in class org.springframework.batch.sample.domain.football.internal.PlayerItemWriter
 
write(Order) - Method in interface org.springframework.batch.sample.domain.order.OrderDao
 
write(List<? extends Person>) - Method in class org.springframework.batch.sample.domain.person.internal.PersonWriter
 
write(CustomerDebit) - Method in interface org.springframework.batch.sample.domain.trade.CustomerDebitDao
 
write(List<? extends CustomerUpdate>) - Method in class org.springframework.batch.sample.domain.trade.CustomerUpdateWriter
 
write(List<? extends CustomerCredit>) - Method in class org.springframework.batch.sample.domain.trade.internal.CustomerCreditItemWriter
 
write(List<? extends CustomerCredit>) - Method in class org.springframework.batch.sample.domain.trade.internal.CustomerCreditUpdateWriter
 
write(List<? extends Trade>) - Method in class org.springframework.batch.sample.domain.trade.internal.CustomerUpdateWriter
 
write(List<? extends CustomerCredit>) - Method in class org.springframework.batch.sample.domain.trade.internal.HibernateAwareCustomerCreditItemWriter
 
write(Object) - Method in class org.springframework.batch.sample.domain.trade.internal.HibernateCreditDao
 
write(CustomerDebit) - Method in class org.springframework.batch.sample.domain.trade.internal.JdbcCustomerDebitDao
 
write(List<? extends Trade>) - Method in class org.springframework.batch.sample.domain.trade.internal.TradeWriter
 
write(List<? extends Object>) - Method in class org.springframework.batch.sample.support.DummyItemWriter
 
write(List<? extends T>) - Method in class org.springframework.batch.sample.support.RetrySampleItemWriter
 
write(char[], int, int) - Method in class org.springframework.batch.support.transaction.TransactionAwareBufferedWriter
 
writeCredit(CustomerCredit) - Method in interface org.springframework.batch.sample.domain.trade.CustomerCreditDao
 
writeCredit(CustomerCredit) - Method in class org.springframework.batch.sample.domain.trade.internal.FlatFileCustomerCreditDao
 
writeCredit(CustomerCredit) - Method in class org.springframework.batch.sample.domain.trade.internal.HibernateCreditDao
 
writeCredit(CustomerCredit) - Method in class org.springframework.batch.sample.domain.trade.internal.IbatisCustomerCreditDao
 
WriteFailedException - Exception in org.springframework.batch.item
Unchecked exception indicating that an error has occurred while trying to clear a buffer on a rollback.
WriteFailedException(String, Throwable) - Constructor for exception org.springframework.batch.item.WriteFailedException
Create a new WriteFailedException based on a message and another exception.
WriteFailedException(String) - Constructor for exception org.springframework.batch.item.WriteFailedException
Create a new WriteFailedException based on a message.
writeFooter(Writer) - Method in interface org.springframework.batch.item.file.FlatFileFooterCallback
Write contents to a file using the supplied Writer.
writeFooter(Writer) - Method in class org.springframework.batch.sample.support.SummaryFooterCallback
 
writeHeader(Writer) - Method in interface org.springframework.batch.item.file.FlatFileHeaderCallback
Write contents to a file using the supplied Writer.
writeHeader(Writer) - Method in class org.springframework.batch.sample.support.HeaderCopyCallback
 
writeItems(List<O>) - Method in class org.springframework.batch.core.step.item.SimpleChunkProcessor
 
WriterNotOpenException - Exception in org.springframework.batch.item
Exception indicating that an ItemWriter needed to be opened before being written to..
WriterNotOpenException(String) - Constructor for exception org.springframework.batch.item.WriterNotOpenException
Create a new WriterNotOpenException based on a message.
WriterNotOpenException(String, Throwable) - Constructor for exception org.springframework.batch.item.WriterNotOpenException
Create a new WriterNotOpenException based on a message and another exception.
writeTrade(Trade) - Method in class org.springframework.batch.sample.domain.trade.internal.JdbcTradeDao
 
writeTrade(Trade) - Method in interface org.springframework.batch.sample.domain.trade.TradeDao
 

X

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

Z

ZERO - Static variable in class org.springframework.batch.repeat.exception.RethrowOnThresholdExceptionHandler
 
ZIP_CODE_COLUMN - Static variable in class org.springframework.batch.sample.domain.order.internal.mapper.AddressFieldSetMapper
 

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

Copyright © 2009 SpringSource. All Rights Reserved.