Index
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form
A
- abandon(long) - Method in interface org.springframework.batch.core.launch.JobOperator
-
Mark the
JobExecution
as ABANDONED. - abandon(long) - Method in class org.springframework.batch.core.launch.support.SimpleJobOperator
- ABANDONED - Enum constant in enum class org.springframework.batch.core.BatchStatus
-
Status of a batch job that did not stop properly and can not be restarted.
- abandonStepExecution() - Method in interface org.springframework.batch.core.job.flow.FlowExecutor
-
Handle any status changes that might be needed at the start of a state.
- abandonStepExecution() - Method in class org.springframework.batch.core.job.flow.JobFlowExecutor
- AbstractApplicationContextFactory - Class in org.springframework.batch.core.configuration.support
-
ApplicationContextFactory
implementation that takes a parent context and a path to the context to create. - AbstractApplicationContextFactory(Object...) - Constructor for class org.springframework.batch.core.configuration.support.AbstractApplicationContextFactory
-
Create a factory instance with the resource specified.
- AbstractCursorItemReader<T> - Class in org.springframework.batch.item.database
-
Abstract base class for any simple item reader that opens a database cursor and continually retrieves the next row in the ResultSet.
- AbstractCursorItemReader() - Constructor for class org.springframework.batch.item.database.AbstractCursorItemReader
- AbstractFileItemWriter<T> - Class in org.springframework.batch.item.support
-
Base class for item writers that write data to a file or stream.
- AbstractFileItemWriter() - Constructor for class org.springframework.batch.item.support.AbstractFileItemWriter
- AbstractFileItemWriter.OutputState - Class in org.springframework.batch.item.support
-
Encapsulates the runtime state of the writer.
- AbstractFlowParser - Class in org.springframework.batch.core.configuration.xml
- AbstractFlowParser() - Constructor for class org.springframework.batch.core.configuration.xml.AbstractFlowParser
- AbstractItemCountingItemStreamItemReader<T> - Class in org.springframework.batch.item.support
-
Abstract superclass for
ItemReader
s that supports restart by storing item count in theExecutionContext
(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 aSimpleJobExplorer
. - 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 aSimpleJobRepository
. - AbstractJobRepositoryFactoryBean() - Constructor for class org.springframework.batch.core.repository.support.AbstractJobRepositoryFactoryBean
- AbstractJpaQueryProvider - Class in org.springframework.batch.item.database.orm
-
Abstract JPA Query Provider to serve as a base class for all JPA
Query
providers. - AbstractJpaQueryProvider() - Constructor for class org.springframework.batch.item.database.orm.AbstractJpaQueryProvider
- AbstractLineTokenizer - Class in org.springframework.batch.item.file.transform
-
Abstract class handling common concerns of various
LineTokenizer
implementations such as dealing with names and actual construction ofFieldSet
- AbstractLineTokenizer() - Constructor for class org.springframework.batch.item.file.transform.AbstractLineTokenizer
- AbstractListenerFactoryBean<T> - Class in org.springframework.batch.core.listener
-
FactoryBean
implementation that builds a listener based on the various lifecycle methods or annotations that are provided. - AbstractListenerFactoryBean() - Constructor for class org.springframework.batch.core.listener.AbstractListenerFactoryBean
- AbstractListenerParser - Class in org.springframework.batch.core.configuration.xml
- AbstractListenerParser() - Constructor for class org.springframework.batch.core.configuration.xml.AbstractListenerParser
- AbstractMethodInvokingDelegator<T> - Class in org.springframework.batch.item.adapter
-
Superclass for delegating classes which dynamically call a custom method of injected object.
- AbstractMethodInvokingDelegator() - Constructor for class org.springframework.batch.item.adapter.AbstractMethodInvokingDelegator
- AbstractMethodInvokingDelegator.InvocationTargetThrowableWrapper - Exception in org.springframework.batch.item.adapter
- AbstractPaginatedDataItemReader<T> - Class in org.springframework.batch.item.data
-
A base class that handles basic reading logic based on the paginated semantics of Spring Data's paginated facilities.
- AbstractPaginatedDataItemReader() - Constructor for class org.springframework.batch.item.data.AbstractPaginatedDataItemReader
- AbstractPagingItemReader<T> - Class in org.springframework.batch.item.database
-
Abstract
ItemStreamReader
for to extend when reading database records in a paging fashion. - AbstractPagingItemReader() - Constructor for class org.springframework.batch.item.database.AbstractPagingItemReader
- AbstractPartitionHandler - Class in org.springframework.batch.core.partition.support
-
Base
PartitionHandler
implementation providing common base features. - AbstractPartitionHandler() - Constructor for class org.springframework.batch.core.partition.support.AbstractPartitionHandler
- AbstractSqlPagingQueryProvider - Class in org.springframework.batch.item.database.support
-
Abstract SQL Paging Query Provider to serve as a base class for all provided SQL paging query providers.
- AbstractSqlPagingQueryProvider() - Constructor for class org.springframework.batch.item.database.support.AbstractSqlPagingQueryProvider
- AbstractState - Class in org.springframework.batch.core.job.flow.support.state
- AbstractState(String) - Constructor for class org.springframework.batch.core.job.flow.support.state.AbstractState
- AbstractStep - Class in org.springframework.batch.core.step
-
A
Step
implementation that provides common behavior to subclasses, including registering and calling listeners. - AbstractStep() - Constructor for class org.springframework.batch.core.step.AbstractStep
-
Default constructor.
- AbstractStep(String) - Constructor for class org.springframework.batch.core.step.AbstractStep
-
Convenient constructor for setting only the name property.
- AbstractStepParser - Class in org.springframework.batch.core.configuration.xml
-
Internal parser for the <step/> elements inside a job.
- AbstractStepParser() - Constructor for class org.springframework.batch.core.configuration.xml.AbstractStepParser
- AbstractTaskletStepBuilder<B extends AbstractTaskletStepBuilder<B>> - Class in org.springframework.batch.core.step.builder
-
Base class for step builders that want to build a
TaskletStep
. - AbstractTaskletStepBuilder(AbstractTaskletStepBuilder<?>) - Constructor for class org.springframework.batch.core.step.builder.AbstractTaskletStepBuilder
-
Create a new builder initialized with any properties in the parent.
- AbstractTaskletStepBuilder(StepBuilderHelper<?>) - Constructor for class org.springframework.batch.core.step.builder.AbstractTaskletStepBuilder
- add(XMLEvent) - Method in class org.springframework.batch.item.xml.stax.NoStartEndDocumentStreamWriter
- add(XMLEvent) - Method in class org.springframework.batch.item.xml.stax.UnclosedElementCollectingEventWriter
- add(XMLEvent) - Method in class org.springframework.batch.item.xml.stax.UnopenedElementClosingEventWriter
- add(XMLEventReader) - Method in class org.springframework.batch.item.xml.stax.NoStartEndDocumentStreamWriter
- add(Flow...) - Method in class org.springframework.batch.core.job.builder.FlowBuilder.SplitBuilder
-
Add flows to the split, in addition to the current state already present in the parent builder.
- add(StepExecution) - Method in interface org.springframework.batch.core.repository.JobRepository
-
Save the
StepExecution
and itsExecutionContext
. - add(StepExecution) - Method in class org.springframework.batch.core.repository.support.SimpleJobRepository
- add(W) - Method in class org.springframework.batch.item.Chunk
-
Add the item to the chunk.
- addAll(Collection<StepExecution>) - Method in interface org.springframework.batch.core.repository.JobRepository
-
Save a collection of
StepExecution
s and eachExecutionContext
. - addAll(Collection<StepExecution>) - Method in class org.springframework.batch.core.repository.support.SimpleJobRepository
- addAll(List<W>) - Method in class org.springframework.batch.item.Chunk
-
Add all items to the chunk.
- addApplicationContextFactory(ApplicationContextFactory) - Method in class org.springframework.batch.core.configuration.support.AutomaticJobRegistrar
-
Add a single
ApplicationContextFactory
to the set that is used to load contexts and jobs. - addColumns(Range) - Method in class org.springframework.batch.item.file.builder.FlatFileItemReaderBuilder.FixedLengthBuilder
-
Add a column range to the existing list
- addColumns(Range, int) - Method in class org.springframework.batch.item.file.builder.FlatFileItemReaderBuilder.FixedLengthBuilder
-
Insert a column range to the existing list
- addComment(String) - Method in class org.springframework.batch.item.file.builder.FlatFileItemReaderBuilder
-
Add a string to the list of Strings that indicate commented lines.
- addDate(String, Date) - Method in class org.springframework.batch.core.JobParametersBuilder
-
Add a new identifying
Date
parameter for the given key. - addDate(String, Date, boolean) - Method in class org.springframework.batch.core.JobParametersBuilder
-
Add a new
Date
parameter for the given key. - addDouble(String, Double) - Method in class org.springframework.batch.core.JobParametersBuilder
-
Add a new identifying
Double
parameter for the given key. - addDouble(String, Double, boolean) - Method in class org.springframework.batch.core.JobParametersBuilder
-
Add a new
Double
parameter for the given key. - addExitDescription(String) - Method in class org.springframework.batch.core.ExitStatus
-
Add an exit description to an existing
ExitStatus
. - addExitDescription(Throwable) - Method in class org.springframework.batch.core.ExitStatus
-
Extract the stack trace from the throwable provided and append it to the existing description.
- addExitStatus(String) - Method in interface org.springframework.batch.core.job.flow.FlowExecutor
- addExitStatus(String) - Method in class org.springframework.batch.core.job.flow.JobFlowExecutor
- addFailureException(Throwable) - Method in class org.springframework.batch.core.JobExecution
-
Add the provided throwable to the failure exception list.
- addFailureException(Throwable) - Method in class org.springframework.batch.core.StepExecution
-
Add a
Throwable
to failure exceptions. - addFragmentRootElements(String...) - Method in class org.springframework.batch.item.xml.builder.StaxEventItemReaderBuilder
-
Adds the list of fragments to be used as the root of each chunk to the configuration.
- addFragmentRootElements(List<String>) - Method in class org.springframework.batch.item.xml.builder.StaxEventItemReaderBuilder
-
Adds the list of fragments to be used as the root of each chunk to the configuration.
- addIncludedField(int) - Method in class org.springframework.batch.item.file.builder.FlatFileItemReaderBuilder.DelimitedBuilder
-
Add an index to the list of fields to be included from the file
- addJobExecutionListener(JobExecutionListener) - Method in class org.springframework.batch.core.job.builder.JobBuilderHelper.CommonJobProperties
- addJobParameter(String, JobParameter<?>) - Method in class org.springframework.batch.core.JobParametersBuilder
-
Add a new
JobParameter
for the given key. - addJobParameter(String, T, Class<T>) - Method in class org.springframework.batch.core.JobParametersBuilder
-
Add an identifying job parameter.
- addJobParameter(String, T, Class<T>, boolean) - Method in class org.springframework.batch.core.JobParametersBuilder
-
Add a job parameter.
- addJobParameters(JobParameters) - Method in class org.springframework.batch.core.JobParametersBuilder
-
Copy job parameters into the current state.
- addLocalDate(String, LocalDate) - Method in class org.springframework.batch.core.JobParametersBuilder
-
Add a new identifying
LocalDate
parameter for the given key. - addLocalDate(String, LocalDate, boolean) - Method in class org.springframework.batch.core.JobParametersBuilder
-
Add a new
LocalDate
parameter for the given key. - addLocalDateTime(String, LocalDateTime) - Method in class org.springframework.batch.core.JobParametersBuilder
-
Add a new identifying
LocalDateTime
parameter for the given key. - addLocalDateTime(String, LocalDateTime, boolean) - Method in class org.springframework.batch.core.JobParametersBuilder
-
Add a new
LocalDateTime
parameter for the given key. - addLocalTime(String, LocalTime) - Method in class org.springframework.batch.core.JobParametersBuilder
-
Add a new identifying
LocalTime
parameter for the given key. - addLocalTime(String, LocalTime, boolean) - Method in class org.springframework.batch.core.JobParametersBuilder
-
Add a new
LocalTime
parameter for the given key. - addLong(String, Long) - Method in class org.springframework.batch.core.JobParametersBuilder
-
Add a new identifying
Long
parameter for the given key. - addLong(String, Long, boolean) - Method in class org.springframework.batch.core.JobParametersBuilder
-
Add a new
Long
parameter for the given key. - addStep(Step) - Method in class org.springframework.batch.core.job.SimpleJob
-
Convenience method for adding a single step to the job.
- addStepExecutionListener(StepExecutionListener) - Method in class org.springframework.batch.core.step.builder.StepBuilderHelper.CommonStepProperties
- addStepExecutionListeners(List<JobExecutionListener>) - Method in class org.springframework.batch.core.job.builder.JobBuilderHelper.CommonJobProperties
- addStepExecutionListeners(List<StepExecutionListener>) - Method in class org.springframework.batch.core.step.builder.StepBuilderHelper.CommonStepProperties
- addStepExecutions(List<StepExecution>) - Method in class org.springframework.batch.core.JobExecution
-
Add some step executions.
- addStepExecutions(JobExecution) - Method in class org.springframework.batch.core.repository.dao.JdbcStepExecutionDao
- addStepExecutions(JobExecution) - Method in interface org.springframework.batch.core.repository.dao.StepExecutionDao
-
Retrieve all the
StepExecution
for the parentJobExecution
. - addString(String, String) - Method in class org.springframework.batch.core.JobParametersBuilder
-
Add a new identifying String parameter for the given key.
- addString(String, String, boolean) - Method in class org.springframework.batch.core.JobParametersBuilder
-
Add a new String parameter for the given key.
- after(RepeatContext, RepeatStatus) - Method in class org.springframework.batch.repeat.listener.CompositeRepeatListener
- after(RepeatContext, RepeatStatus) - Method in class org.springframework.batch.repeat.listener.RepeatListenerSupport
-
Deprecated.
- 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_CHUNK - Enum constant in enum class org.springframework.batch.core.listener.StepListenerMetaData
- AFTER_CHUNK_ERROR - Enum constant in enum class org.springframework.batch.core.listener.StepListenerMetaData
- AFTER_JOB - Enum constant in enum class org.springframework.batch.core.listener.JobListenerMetaData
- AFTER_PROCESS - Enum constant in enum class org.springframework.batch.core.listener.StepListenerMetaData
- AFTER_READ - Enum constant in enum class org.springframework.batch.core.listener.StepListenerMetaData
- AFTER_STEP - Enum constant in enum class org.springframework.batch.core.listener.StepListenerMetaData
- AFTER_WRITE - Enum constant in enum class org.springframework.batch.core.listener.StepListenerMetaData
- afterChunk(ChunkContext) - Method in interface org.springframework.batch.core.ChunkListener
-
Callback after the chunk is executed, outside the transaction.
- afterChunk(ChunkContext) - Method in class org.springframework.batch.core.listener.ChunkListenerSupport
-
Deprecated.
- afterChunk(ChunkContext) - Method in class org.springframework.batch.core.listener.CompositeChunkListener
-
Call the registered listeners in reverse order.
- afterChunk(ChunkContext) - Method in class org.springframework.batch.core.listener.MulticasterBatchListener
- AfterChunk - Annotation Interface in org.springframework.batch.core.annotation
-
Marks a method to be called after a chunk is executed.
Expected signature: void afterChunk(ChunkContext context) - afterChunkError(ChunkContext) - Method in interface org.springframework.batch.core.ChunkListener
-
Callback after a chunk has been marked for rollback.
- afterChunkError(ChunkContext) - Method in class org.springframework.batch.core.listener.ChunkListenerSupport
-
Deprecated.
- afterChunkError(ChunkContext) - Method in class org.springframework.batch.core.listener.CompositeChunkListener
-
Call the registered listeners in reverse order.
- afterChunkError(ChunkContext) - Method in class org.springframework.batch.core.listener.MulticasterBatchListener
- AfterChunkError - Annotation Interface in org.springframework.batch.core.annotation
-
Marks a method to be called after a chunk has failed and been marked for rollback.
Expected signature: void afterFailedChunk(ChunkContext context) - afterJob(JobExecution) - Method in interface org.springframework.batch.core.JobExecutionListener
-
Callback after completion of a job.
- afterJob(JobExecution) - Method in class org.springframework.batch.core.listener.CompositeJobExecutionListener
-
Call the registered listeners in reverse order, respecting and prioritising those that implement
Ordered
. - afterJob(JobExecution) - Method in class org.springframework.batch.core.listener.JobExecutionListenerSupport
-
Deprecated.
- AfterJob - Annotation Interface in org.springframework.batch.core.annotation
-
Marks a method to be called after a
Job
has completed. - afterProcess(T, S) - Method in interface org.springframework.batch.core.ItemProcessListener
-
Called after
ItemProcessor.process(Object)
returns. - afterProcess(T, S) - Method in class org.springframework.batch.core.listener.CompositeItemProcessListener
-
Call the registered listeners in reverse order, respecting and prioritising those that implement
Ordered
. - afterProcess(T, S) - Method in class org.springframework.batch.core.listener.MulticasterBatchListener
- AfterProcess - Annotation Interface in org.springframework.batch.core.annotation
-
Marks a method to be called after an item is passed to an
ItemProcessor
. - afterPropertiesSet() - Method in class org.springframework.batch.core.configuration.support.AutomaticJobRegistrar
- afterPropertiesSet() - Method in class org.springframework.batch.core.configuration.support.DefaultJobLoader
- afterPropertiesSet() - Method in class org.springframework.batch.core.configuration.support.JobRegistryBeanPostProcessor
-
Deprecated.Make sure the registry is set before use.
- afterPropertiesSet() - Method in class org.springframework.batch.core.configuration.support.JobRegistrySmartInitializingSingleton
-
Make sure the registry is set before use.
- afterPropertiesSet() - Method in class org.springframework.batch.core.configuration.xml.SimpleFlowFactoryBean
-
Check mandatory properties (name).
- afterPropertiesSet() - Method in class org.springframework.batch.core.explore.support.AbstractJobExplorerFactoryBean
- afterPropertiesSet() - Method in class org.springframework.batch.core.explore.support.JobExplorerFactoryBean
- afterPropertiesSet() - Method in class org.springframework.batch.core.job.AbstractJob
-
Assert mandatory properties:
JobRepository
. - afterPropertiesSet() - Method in class org.springframework.batch.core.job.CompositeJobParametersValidator
- afterPropertiesSet() - Method in class org.springframework.batch.core.job.DefaultJobParametersValidator
-
Check that there are no overlaps between required and optional keys.
- afterPropertiesSet() - Method in class org.springframework.batch.core.job.flow.FlowStep
-
Ensure that the flow is set.
- afterPropertiesSet() - Method in class org.springframework.batch.core.job.flow.support.SimpleFlow
-
Locate start state and pre-populate data structures needed for execution.
- afterPropertiesSet() - Method in class org.springframework.batch.core.job.SimpleStepHandler
-
Check mandatory properties (jobRepository).
- afterPropertiesSet() - Method in class org.springframework.batch.core.launch.support.JobOperatorFactoryBean
- afterPropertiesSet() - Method in class org.springframework.batch.core.launch.support.SimpleJobOperator
-
Check mandatory properties.
- afterPropertiesSet() - Method in class org.springframework.batch.core.launch.support.TaskExecutorJobLauncher
-
Ensure the required dependencies of a
JobRepository
have been set. - afterPropertiesSet() - Method in class org.springframework.batch.core.listener.AbstractListenerFactoryBean
- afterPropertiesSet() - Method in class org.springframework.batch.core.listener.ExecutionContextPromotionListener
- afterPropertiesSet() - Method in class org.springframework.batch.core.partition.support.PartitionStep
-
Assert that mandatory properties are set (stepExecutionSplitter, partitionHandler) and delegate top superclass.
- afterPropertiesSet() - Method in class org.springframework.batch.core.partition.support.RemoteStepExecutionAggregator
- afterPropertiesSet() - Method in class org.springframework.batch.core.partition.support.SimpleStepExecutionSplitter
-
Check mandatory properties (step name, job repository and partitioner).
- afterPropertiesSet() - Method in class org.springframework.batch.core.partition.support.TaskExecutorPartitionHandler
- afterPropertiesSet() - Method in class org.springframework.batch.core.repository.dao.AbstractJdbcBatchMetadataDao
- afterPropertiesSet() - Method in class org.springframework.batch.core.repository.dao.JdbcExecutionContextDao
- afterPropertiesSet() - Method in class org.springframework.batch.core.repository.dao.JdbcJobExecutionDao
- afterPropertiesSet() - Method in class org.springframework.batch.core.repository.dao.JdbcJobInstanceDao
- afterPropertiesSet() - Method in class org.springframework.batch.core.repository.dao.JdbcStepExecutionDao
- afterPropertiesSet() - Method in class org.springframework.batch.core.repository.support.AbstractJobRepositoryFactoryBean
- afterPropertiesSet() - Method in class org.springframework.batch.core.repository.support.JobRepositoryFactoryBean
- afterPropertiesSet() - Method in class org.springframework.batch.core.step.AbstractStep
- afterPropertiesSet() - Method in class org.springframework.batch.core.step.item.SimpleChunkProcessor
-
Check mandatory properties.
- afterPropertiesSet() - Method in class org.springframework.batch.core.step.job.JobStep
- afterPropertiesSet() - Method in class org.springframework.batch.core.step.tasklet.CallableTaskletAdapter
-
Assert that the callable is set.
- afterPropertiesSet() - Method in class org.springframework.batch.core.step.tasklet.SystemCommandTasklet
- afterPropertiesSet() - Method in class org.springframework.batch.core.step.tasklet.TaskletStep
- afterPropertiesSet() - Method in class org.springframework.batch.integration.async.AsyncItemProcessor
-
Check mandatory properties (the
AsyncItemProcessor.setDelegate(ItemProcessor)
). - afterPropertiesSet() - Method in class org.springframework.batch.integration.async.AsyncItemWriter
- afterPropertiesSet() - Method in class org.springframework.batch.integration.chunk.ChunkProcessorChunkHandler
- afterPropertiesSet() - Method in class org.springframework.batch.integration.chunk.MessageSourcePollerInterceptor
-
Asserts that mandatory properties are set.
- afterPropertiesSet() - Method in class org.springframework.batch.integration.config.annotation.BatchIntegrationConfiguration
- afterPropertiesSet() - Method in class org.springframework.batch.integration.partition.MessageChannelPartitionHandler
- afterPropertiesSet() - Method in class org.springframework.batch.item.adapter.AbstractMethodInvokingDelegator
- afterPropertiesSet() - Method in class org.springframework.batch.item.adapter.PropertyExtractingDelegatingItemWriter
- afterPropertiesSet() - Method in class org.springframework.batch.item.data.MongoCursorItemReader
-
Checks mandatory properties
- afterPropertiesSet() - Method in class org.springframework.batch.item.data.MongoItemReader
-
Deprecated.Checks mandatory properties
- afterPropertiesSet() - Method in class org.springframework.batch.item.data.MongoItemWriter
- afterPropertiesSet() - Method in class org.springframework.batch.item.data.MongoPagingItemReader
- afterPropertiesSet() - Method in class org.springframework.batch.item.data.Neo4jItemReader
-
Deprecated.Checks mandatory properties
- afterPropertiesSet() - Method in class org.springframework.batch.item.data.Neo4jItemWriter
-
Deprecated.Checks mandatory properties
- afterPropertiesSet() - Method in class org.springframework.batch.item.data.RepositoryItemReader
- afterPropertiesSet() - Method in class org.springframework.batch.item.data.RepositoryItemWriter
-
Check mandatory properties - there must be a repository.
- afterPropertiesSet() - Method in class org.springframework.batch.item.database.AbstractCursorItemReader
-
Assert that mandatory properties are set.
- afterPropertiesSet() - Method in class org.springframework.batch.item.database.AbstractPagingItemReader
-
Check mandatory properties.
- afterPropertiesSet() - Method in class org.springframework.batch.item.database.ExtendedConnectionDataSourceProxy
- afterPropertiesSet() - Method in class org.springframework.batch.item.database.JdbcBatchItemWriter
-
Check mandatory properties - there must be a NamedParameterJdbcOperations and an SQL statement plus a parameter source.
- afterPropertiesSet() - Method in class org.springframework.batch.item.database.JdbcCursorItemReader
-
Assert that mandatory properties are set.
- afterPropertiesSet() - Method in class org.springframework.batch.item.database.JdbcPagingItemReader
-
Check mandatory properties.
- afterPropertiesSet() - Method in class org.springframework.batch.item.database.JpaCursorItemReader
- afterPropertiesSet() - Method in class org.springframework.batch.item.database.JpaItemWriter
-
Check mandatory properties - there must be an entityManagerFactory.
- afterPropertiesSet() - Method in class org.springframework.batch.item.database.JpaPagingItemReader
- afterPropertiesSet() - Method in class org.springframework.batch.item.database.orm.JpaNamedQueryProvider
- afterPropertiesSet() - Method in class org.springframework.batch.item.database.orm.JpaNativeQueryProvider
- afterPropertiesSet() - Method in class org.springframework.batch.item.database.StoredProcedureItemReader
-
Assert that mandatory properties are set.
- afterPropertiesSet() - Method in class org.springframework.batch.item.file.FlatFileItemReader
- afterPropertiesSet() - Method in class org.springframework.batch.item.file.FlatFileItemWriter
-
Assert that mandatory properties (lineAggregator) are set.
- afterPropertiesSet() - Method in class org.springframework.batch.item.file.mapping.BeanWrapperFieldSetMapper
-
Check that precisely one of type or prototype bean name is specified.
- afterPropertiesSet() - Method in class org.springframework.batch.item.file.mapping.DefaultLineMapper
- afterPropertiesSet() - Method in class org.springframework.batch.item.file.mapping.PatternMatchingCompositeLineMapper
- afterPropertiesSet() - Method in class org.springframework.batch.item.file.transform.BeanWrapperFieldExtractor
- afterPropertiesSet() - Method in class org.springframework.batch.item.file.transform.DelimitedLineTokenizer
- afterPropertiesSet() - Method in class org.springframework.batch.item.file.transform.PatternMatchingCompositeLineTokenizer
- afterPropertiesSet() - Method in class org.springframework.batch.item.jms.JmsItemReader
- afterPropertiesSet() - Method in class org.springframework.batch.item.json.JsonFileItemWriter
-
Assert that mandatory properties (jsonObjectMarshaller) are set.
- afterPropertiesSet() - Method in class org.springframework.batch.item.KeyValueItemWriter
- afterPropertiesSet() - Method in class org.springframework.batch.item.ldif.LdifReader
- afterPropertiesSet() - Method in class org.springframework.batch.item.ldif.MappingLdifReader
- afterPropertiesSet() - Method in class org.springframework.batch.item.mail.javamail.MimeMessageItemWriter
-
Check mandatory properties (mailSender).
- afterPropertiesSet() - Method in class org.springframework.batch.item.mail.SimpleMailMessageItemWriter
-
Check mandatory properties (mailSender).
- afterPropertiesSet() - Method in class org.springframework.batch.item.support.CompositeItemProcessor
- afterPropertiesSet() - Method in class org.springframework.batch.item.support.CompositeItemWriter
- afterPropertiesSet() - Method in class org.springframework.batch.item.support.ScriptItemProcessor
- afterPropertiesSet() - Method in class org.springframework.batch.item.support.SynchronizedItemStreamReader
- afterPropertiesSet() - Method in class org.springframework.batch.item.support.SynchronizedItemStreamWriter
- afterPropertiesSet() - Method in class org.springframework.batch.item.validator.BeanValidatingItemProcessor
- afterPropertiesSet() - Method in class org.springframework.batch.item.validator.SpringValidator
- afterPropertiesSet() - Method in class org.springframework.batch.item.validator.ValidatingItemProcessor
- afterPropertiesSet() - Method in class org.springframework.batch.item.xml.StaxEventItemReader
-
Ensure that all required dependencies for the ItemReader to run are provided after all properties have been set.
- afterPropertiesSet() - Method in class org.springframework.batch.item.xml.StaxEventItemWriter
- afterPropertiesSet() - Method in class org.springframework.batch.repeat.exception.SimpleLimitExceptionHandler
-
Apply the provided properties to create a delegate handler.
- afterPropertiesSet() - Method in class org.springframework.batch.support.SystemPropertyInitializer
-
Sets the System property with the provided name and default value.
- afterRead(T) - Method in interface org.springframework.batch.core.ItemReadListener
-
Called after
ItemReader.read()
. - afterRead(T) - Method in class org.springframework.batch.core.listener.CompositeItemReadListener
-
Call the registered listeners in reverse order, respecting and prioritising those that implement
Ordered
. - afterRead(T) - Method in class org.springframework.batch.core.listener.MulticasterBatchListener
- AfterRead - Annotation Interface in org.springframework.batch.core.annotation
-
Marks a method to be called after an item is read from an
ItemReader
Expected signature: void afterRead(T item) - afterSingletonsInstantiated() - Method in class org.springframework.batch.core.configuration.support.JobRegistrySmartInitializingSingleton
- afterStep(StepExecution) - Method in class org.springframework.batch.core.listener.CompositeStepExecutionListener
-
Call the registered listeners in reverse order, respecting and prioritizing those that implement
Ordered
. - afterStep(StepExecution) - Method in class org.springframework.batch.core.listener.ExecutionContextPromotionListener
- afterStep(StepExecution) - Method in class org.springframework.batch.core.listener.MulticasterBatchListener
- afterStep(StepExecution) - Method in class org.springframework.batch.core.listener.StepExecutionListenerSupport
-
Deprecated.
- afterStep(StepExecution) - Method in class org.springframework.batch.core.step.NoWorkFoundStepExecutionListener
- afterStep(StepExecution) - Method in interface org.springframework.batch.core.StepExecutionListener
-
Give a listener a chance to modify the exit status from a step.
- afterStep(StepExecution) - Method in class org.springframework.batch.integration.chunk.ChunkMessageChannelItemWriter
- AfterStep - Annotation Interface in org.springframework.batch.core.annotation
-
Marks a method to be called after a
Step
has completed. - afterTestMethod(TestContext) - Method in class org.springframework.batch.test.JobScopeTestExecutionListener
- afterTestMethod(TestContext) - Method in class org.springframework.batch.test.StepScopeTestExecutionListener
- afterWrite(Chunk<? extends S>) - Method in interface org.springframework.batch.core.ItemWriteListener
-
Called after
ItemWriter.write(Chunk)
. - afterWrite(Chunk<? extends S>) - Method in class org.springframework.batch.core.listener.CompositeItemWriteListener
-
Call the registered listeners in reverse order, respecting and prioritising those that implement
Ordered
. - afterWrite(Chunk<? extends S>) - Method in class org.springframework.batch.core.listener.MulticasterBatchListener
- AfterWrite - Annotation Interface in org.springframework.batch.core.annotation
-
Marks a method to be called after an item is passed to an
ItemWriter
. - aggregate(Collection<FlowExecution>) - Method in interface org.springframework.batch.core.job.flow.support.state.FlowExecutionAggregator
- aggregate(Collection<FlowExecution>) - Method in class org.springframework.batch.core.job.flow.support.state.MaxValueFlowExecutionAggregator
-
Aggregate all of the
FlowExecutionStatus
es of theFlowExecution
s into one status. - aggregate(Collection<T>) - Method in class org.springframework.batch.item.file.transform.RecursiveCollectionLineAggregator
- aggregate(List<?>) - Method in class org.springframework.batch.integration.partition.MessageChannelPartitionHandler
- aggregate(StepExecution, Collection<StepExecution>) - Method in class org.springframework.batch.core.partition.support.DefaultStepExecutionAggregator
-
Aggregates the input executions into the result
StepExecution
. - aggregate(StepExecution, Collection<StepExecution>) - Method in class org.springframework.batch.core.partition.support.RemoteStepExecutionAggregator
-
Aggregates the input executions into the result
StepExecution
delegating to the delegate aggregator once the input has been refreshed from theJobExplorer
. - aggregate(StepExecution, Collection<StepExecution>) - Method in interface org.springframework.batch.core.partition.support.StepExecutionAggregator
-
Take the inputs and aggregate, putting the aggregates into the result.
- aggregate(T) - Method in class org.springframework.batch.item.file.transform.ExtractorLineAggregator
-
Extract fields from the given item using the
FieldExtractor
and then aggregate them. - aggregate(T) - Method in interface org.springframework.batch.item.file.transform.LineAggregator
-
Create a string from the value provided.
- aggregate(T) - Method in class org.springframework.batch.item.file.transform.PassThroughLineAggregator
-
Simply convert to a String with toString().
- aggregator(StepExecutionAggregator) - Method in class org.springframework.batch.core.step.builder.PartitionStepBuilder
-
Provide a step execution aggregator for aggregating partitioned step executions into a single result for the
PartitionStep
itself. - aggregator(StepExecutionAggregator) - Method in class org.springframework.batch.integration.partition.RemotePartitioningManagerStepBuilder
- allowStartIfComplete(boolean) - Method in class org.springframework.batch.core.step.builder.StepBuilderHelper
- allowStartIfComplete(boolean) - Method in class org.springframework.batch.integration.chunk.RemoteChunkingManagerStepBuilder
- allowStartIfComplete(boolean) - Method in class org.springframework.batch.integration.partition.RemotePartitioningManagerStepBuilder
- allowStartIfComplete(boolean) - Method in class org.springframework.batch.integration.partition.RemotePartitioningWorkerStepBuilder
- AlwaysSkipItemSkipPolicy - Class in org.springframework.batch.core.step.skip
-
Implementation of the
SkipPolicy
interface that will always return that an item should be skipped. - AlwaysSkipItemSkipPolicy() - Constructor for class org.springframework.batch.core.step.skip.AlwaysSkipItemSkipPolicy
- AmqpItemReader<T> - Class in org.springframework.batch.item.amqp
-
AMQP
ItemReader
implementation using anAmqpTemplate
to receive and/or convert messages. - AmqpItemReader(AmqpTemplate) - Constructor for class org.springframework.batch.item.amqp.AmqpItemReader
-
Initialize the AmqpItemReader.
- AmqpItemReaderBuilder<T> - Class in org.springframework.batch.item.amqp.builder
-
A builder implementation for the
AmqpItemReader
- AmqpItemReaderBuilder() - Constructor for class org.springframework.batch.item.amqp.builder.AmqpItemReaderBuilder
- AmqpItemWriter<T> - Class in org.springframework.batch.item.amqp
-
AMQP
ItemWriter
implementation using anAmqpTemplate
to send messages. - AmqpItemWriter(AmqpTemplate) - Constructor for class org.springframework.batch.item.amqp.AmqpItemWriter
- AmqpItemWriterBuilder<T> - Class in org.springframework.batch.item.amqp.builder
-
A builder implementation for the
AmqpItemWriter
- AmqpItemWriterBuilder() - Constructor for class org.springframework.batch.item.amqp.builder.AmqpItemWriterBuilder
- amqpTemplate(AmqpTemplate) - Method in class org.springframework.batch.item.amqp.builder.AmqpItemReaderBuilder
-
Establish the amqpTemplate to be used by the AmqpItemReader.
- amqpTemplate(AmqpTemplate) - Method in class org.springframework.batch.item.amqp.builder.AmqpItemWriterBuilder
-
Establish the amqpTemplate to be used by the AmqpItemWriter.
- and(boolean) - Method in enum class org.springframework.batch.repeat.RepeatStatus
- 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. - AnnotationMethodResolver - Class in org.springframework.batch.support
-
MethodResolver
implementation that finds a single Method on the given Class that contains the specified annotation type. - AnnotationMethodResolver(Class<? extends Annotation>) - Constructor for class org.springframework.batch.support.AnnotationMethodResolver
-
Create a
MethodResolver
for the specified Method-level annotation type. - append - Variable in class org.springframework.batch.item.support.AbstractFileItemWriter
- append(boolean) - Method in class org.springframework.batch.item.file.builder.FlatFileItemWriterBuilder
-
If set to true and the file exists, the output will be appended to the existing file.
- append(boolean) - Method in class org.springframework.batch.item.json.builder.JsonFileItemWriterBuilder
-
If set to true and the file exists, the output will be appended to the existing file.
- applicationContext - Variable in class org.springframework.batch.core.configuration.support.DefaultBatchConfiguration
- ApplicationContextFactory - Interface in org.springframework.batch.core.configuration.support
-
Factory for the creation of
ApplicationContext
instances. - ApplicationContextJobFactory - Class in org.springframework.batch.core.configuration.support
-
A
JobFactory
that creates its ownApplicationContext
and pulls a bean out when asked to create aJob
. - ApplicationContextJobFactory(String, ApplicationContextFactory) - Constructor for class org.springframework.batch.core.configuration.support.ApplicationContextJobFactory
- apply(StepContribution) - Method in class org.springframework.batch.core.StepExecution
-
This method should be called on successful execution just before a chunk commit.
- applyConfiguration(SimpleStepBuilder<T, S>) - Method in class org.springframework.batch.core.step.factory.FaultTolerantStepFactoryBean
- applyConfiguration(SimpleStepBuilder<T, S>) - Method in class org.springframework.batch.core.step.factory.SimpleStepFactoryBean
- applyStatementSettings(PreparedStatement) - Method in class org.springframework.batch.item.database.AbstractCursorItemReader
-
Prepare the given JDBC Statement (or PreparedStatement or CallableStatement), applying statement settings such as fetch size, max rows, and query timeout.
- arguments(Object...) - Method in class org.springframework.batch.item.data.builder.RepositoryItemReaderBuilder
-
Arguments to be passed to the data providing method.
- arguments(List<?>) - Method in class org.springframework.batch.item.data.builder.RepositoryItemReaderBuilder
-
Arguments to be passed to the data providing method.
- ArrayFieldSetMapper - Class in org.springframework.batch.item.file.mapping
-
A basic array mapper, returning the values backing a fieldset.
- ArrayFieldSetMapper() - Constructor for class org.springframework.batch.item.file.mapping.ArrayFieldSetMapper
- ASCENDING - Enum constant in enum class org.springframework.batch.item.database.Order
- assertUpdates - Variable in class org.springframework.batch.item.database.JdbcBatchItemWriter
- assertUpdates(boolean) - Method in class org.springframework.batch.item.database.builder.JdbcBatchItemWriterBuilder
-
If set to true, confirms that every insert results in the update of at least one row in the database.
- AsynchronousFailureException - Exception in org.springframework.batch.integration.chunk
-
Exception indicating that a failure or early completion condition was detected in a remote worker.
- AsynchronousFailureException(String) - Constructor for exception org.springframework.batch.integration.chunk.AsynchronousFailureException
-
Create a new
AsynchronousFailureException
based on a message. - AsynchronousFailureException(String, Throwable) - Constructor for exception org.springframework.batch.integration.chunk.AsynchronousFailureException
-
Create a new
AsynchronousFailureException
based on a message and another exception. - AsyncItemProcessor<I,
O> - Class in org.springframework.batch.integration.async -
An
ItemProcessor
that delegates to a nested processor and in the background. - AsyncItemProcessor() - Constructor for class org.springframework.batch.integration.async.AsyncItemProcessor
- AsyncItemWriter<T> - Class in org.springframework.batch.integration.async
- AsyncItemWriter() - Constructor for class org.springframework.batch.integration.async.AsyncItemWriter
- attributeNames() - Method in class org.springframework.batch.repeat.context.SynchronizedAttributeAccessor
- AutomaticJobRegistrar - Class in org.springframework.batch.core.configuration.support
-
Loads and unloads
Jobs
when the application context is created and destroyed. - AutomaticJobRegistrar() - Constructor for class org.springframework.batch.core.configuration.support.AutomaticJobRegistrar
- autoregisterBeansForNamespace(ParserContext, Object) - Static method in class org.springframework.batch.core.configuration.xml.CoreNamespaceUtils
-
Create the beans based on the content of the source.
- AvroItemReader<T> - Class in org.springframework.batch.item.avro
-
An
ItemReader
that deserializes data from aResource
containing serialized Avro objects. - AvroItemReader(Resource, Class<T>) - Constructor for class org.springframework.batch.item.avro.AvroItemReader
- AvroItemReader(Resource, Resource) - Constructor for class org.springframework.batch.item.avro.AvroItemReader
- AvroItemReaderBuilder<T> - Class in org.springframework.batch.item.avro.builder
-
A builder implementation for the
AvroItemReader
. - AvroItemReaderBuilder() - Constructor for class org.springframework.batch.item.avro.builder.AvroItemReaderBuilder
- AvroItemWriter<T> - Class in org.springframework.batch.item.avro
-
An
ItemWriter
that serializes data to anWritableResource
using Avro. - AvroItemWriter(WritableResource, Class<T>) - Constructor for class org.springframework.batch.item.avro.AvroItemWriter
-
This constructor will create an ItemWriter that does not embedded Avro schema.
- AvroItemWriter(WritableResource, Resource, Class<T>) - Constructor for class org.springframework.batch.item.avro.AvroItemWriter
- AvroItemWriterBuilder<T> - Class in org.springframework.batch.item.avro.builder
-
A builder implementation for the
AvroItemWriter
. - AvroItemWriterBuilder() - Constructor for class org.springframework.batch.item.avro.builder.AvroItemWriterBuilder
B
- backOffPolicy(BackOffPolicy) - Method in class org.springframework.batch.core.step.builder.FaultTolerantStepBuilder
-
Provide a backoff policy to prevent items being retried immediately (e.g. in case the failure was caused by a remote resource failure that might take some time to be resolved).
- backOffPolicy(BackOffPolicy) - Method in class org.springframework.batch.integration.chunk.RemoteChunkingManagerStepBuilder
- BATCH_JOB_OBSERVATION - Enum constant in enum class org.springframework.batch.core.observability.BatchJobObservation
- BATCH_STEP_OBSERVATION - Enum constant in enum class org.springframework.batch.core.observability.BatchStepObservation
- BATCH_VERSION_KEY - Static variable in class org.springframework.batch.core.SpringBatchVersion
-
The key to use in the execution context for batch version.
- BatchConfigurationException - Exception in org.springframework.batch.core.configuration
-
Represents that an error has occurred in the configuration of the base batch infrastructure (the creation of a
JobRepository
, for example). - BatchConfigurationException(String) - Constructor for exception org.springframework.batch.core.configuration.BatchConfigurationException
-
Create an exception with the given message.
- BatchConfigurationException(String, Throwable) - Constructor for exception org.springframework.batch.core.configuration.BatchConfigurationException
-
Create an exception with the given message and
Throwable
. - BatchConfigurationException(Throwable) - Constructor for exception org.springframework.batch.core.configuration.BatchConfigurationException
-
Create an exception with the given
Throwable
. - BatchIntegrationConfiguration<I,
O> - Class in org.springframework.batch.integration.config.annotation -
Base configuration class for Spring Batch Integration factory beans.
- BatchIntegrationConfiguration(JobRepository, JobExplorer, PlatformTransactionManager) - Constructor for class org.springframework.batch.integration.config.annotation.BatchIntegrationConfiguration
- BatchIntegrationNamespaceHandler - Class in org.springframework.batch.integration.config.xml
-
The namespace handler for the Spring Batch Integration namespace.
- BatchIntegrationNamespaceHandler() - Constructor for class org.springframework.batch.integration.config.xml.BatchIntegrationNamespaceHandler
- BatchJobContext - Class in org.springframework.batch.core.observability
-
Observation context for batch jobs.
- BatchJobContext(JobExecution) - Constructor for class org.springframework.batch.core.observability.BatchJobContext
- BatchJobObservation - Enum Class in org.springframework.batch.core.observability
-
Observation created around a Job execution.
- BatchJobObservationConvention - Interface in org.springframework.batch.core.observability
-
ObservationConvention
forBatchJobContext
. - BatchMetrics - Class in org.springframework.batch.core.observability
-
Central class for batch metrics.
- BatchObservabilityBeanPostProcessor - Class in org.springframework.batch.core.configuration.annotation
-
Bean post processor that configures observable batch artifacts (jobs and steps) with Micrometer's observation registry.
- BatchObservabilityBeanPostProcessor() - Constructor for class org.springframework.batch.core.configuration.annotation.BatchObservabilityBeanPostProcessor
- BatchRetryTemplate - Class in org.springframework.batch.core.step.item
-
A special purpose retry template that deals specifically with multi-valued stateful retry.
- BatchRetryTemplate() - Constructor for class org.springframework.batch.core.step.item.BatchRetryTemplate
- BatchScopeSupport - Class in org.springframework.batch.core.scope
-
ScopeSupport.
- BatchScopeSupport() - Constructor for class org.springframework.batch.core.scope.BatchScopeSupport
- BatchScopeSupport.Scopifier - Class in org.springframework.batch.core.scope
-
Helper class to scan a bean definition hierarchy and force the use of auto-proxy for step scoped beans.
- batchSize(int) - Method in class org.springframework.batch.item.data.builder.MongoCursorItemReaderBuilder
-
The size of batches to use when iterating over results.
- BatchStatus - Enum Class in org.springframework.batch.core
-
Enumeration representing the status of an execution.
- BatchStepContext - Class in org.springframework.batch.core.observability
-
Observation context for batch steps.
- BatchStepContext(StepExecution) - Constructor for class org.springframework.batch.core.observability.BatchStepContext
- BatchStepObservation - Enum Class in org.springframework.batch.core.observability
-
Observation created around a step execution.
- BatchStepObservationConvention - Interface in org.springframework.batch.core.observability
-
ObservationConvention
forBatchStepContext
. - BatchTestContextBeanPostProcessor - Class in org.springframework.batch.test.context
-
BeanPostProcessor
implementation that injects a job bean intoJobLauncherTestUtils
if there is a unique job bean. - BatchTestContextBeanPostProcessor() - Constructor for class org.springframework.batch.test.context.BatchTestContextBeanPostProcessor
- BatchTestContextCustomizer - Class in org.springframework.batch.test.context
-
ContextCustomizer
implementation that adds batch test utility classes (JobLauncherTestUtils
andJobRepositoryTestUtils
) as beans in the test context. - BatchTestContextCustomizer() - Constructor for class org.springframework.batch.test.context.BatchTestContextCustomizer
- BatchTestContextCustomizerFactory - Class in org.springframework.batch.test.context
-
Factory for
BatchTestContextCustomizer
. - BatchTestContextCustomizerFactory() - Constructor for class org.springframework.batch.test.context.BatchTestContextCustomizerFactory
- BeanDefinitionUtils - Class in org.springframework.batch.core.configuration.xml
- beanFactory(BeanFactory) - Method in class org.springframework.batch.integration.partition.RemotePartitioningManagerStepBuilder
-
Set the bean factory.
- beanFactory(BeanFactory) - Method in class org.springframework.batch.integration.partition.RemotePartitioningWorkerStepBuilder
-
Set the bean factory.
- beanFactory(BeanFactory) - Method in class org.springframework.batch.item.file.builder.FlatFileItemReaderBuilder
-
Configures the
BeanFactory
used to create the beans that are returned as items. - BeanFactoryStepLocator - Class in org.springframework.batch.integration.partition
-
A
StepLocator
implementation that just looks in its enclosing bean factory for components of typeStep
. - BeanFactoryStepLocator() - Constructor for class org.springframework.batch.integration.partition.BeanFactoryStepLocator
- beanMapped() - Method in class org.springframework.batch.item.database.builder.JdbcBatchItemWriterBuilder
-
Creates a
BeanPropertyItemSqlParameterSourceProvider
to be used as yourItemSqlParameterSourceProvider
. - beanMapperStrict(boolean) - Method in class org.springframework.batch.item.file.builder.FlatFileItemReaderBuilder
-
If set to true, mapping will fail if the
FieldSet
contains fields that cannot be mapped to the bean. - BeanPropertyItemSqlParameterSourceProvider<T> - Class in org.springframework.batch.item.database
-
A convenient implementation for providing BeanPropertySqlParameterSource when the item has JavaBean properties that correspond to names used for parameters in the SQL statement.
- BeanPropertyItemSqlParameterSourceProvider() - Constructor for class org.springframework.batch.item.database.BeanPropertyItemSqlParameterSourceProvider
- beanRowMapper(Class<T>) - Method in class org.springframework.batch.item.database.builder.JdbcCursorItemReaderBuilder
-
Creates a
BeanPropertyRowMapper
to be used as yourRowMapper
. - beanRowMapper(Class<T>) - Method in class org.springframework.batch.item.database.builder.JdbcPagingItemReaderBuilder
-
Creates a
BeanPropertyRowMapper
to be used as yourRowMapper
. - BeanValidatingItemProcessor<T> - Class in org.springframework.batch.item.validator
-
A
ValidatingItemProcessor
that uses the Bean Validation API (JSR-303) to validate items. - BeanValidatingItemProcessor() - Constructor for class org.springframework.batch.item.validator.BeanValidatingItemProcessor
-
Create a new instance of
BeanValidatingItemProcessor
with the default configuration. - BeanValidatingItemProcessor(LocalValidatorFactoryBean) - Constructor for class org.springframework.batch.item.validator.BeanValidatingItemProcessor
-
Create a new instance of
BeanValidatingItemProcessor
. - BeanWrapperFieldExtractor<T> - Class in org.springframework.batch.item.file.transform
-
This is a field extractor for a java bean.
- BeanWrapperFieldExtractor() - Constructor for class org.springframework.batch.item.file.transform.BeanWrapperFieldExtractor
- BeanWrapperFieldSetMapper<T> - Class in org.springframework.batch.item.file.mapping
-
FieldSetMapper
implementation based on bean property paths. - BeanWrapperFieldSetMapper() - Constructor for class org.springframework.batch.item.file.mapping.BeanWrapperFieldSetMapper
- before(RepeatContext) - Method in class org.springframework.batch.repeat.listener.CompositeRepeatListener
- before(RepeatContext) - Method in class org.springframework.batch.repeat.listener.RepeatListenerSupport
-
Deprecated.
- before(RepeatContext) - Method in interface org.springframework.batch.repeat.RepeatListener
-
Called by the framework before each batch item.
- BEFORE_CHUNK - Enum constant in enum class org.springframework.batch.core.listener.StepListenerMetaData
- BEFORE_JOB - Enum constant in enum class org.springframework.batch.core.listener.JobListenerMetaData
- BEFORE_PROCESS - Enum constant in enum class org.springframework.batch.core.listener.StepListenerMetaData
- BEFORE_READ - Enum constant in enum class org.springframework.batch.core.listener.StepListenerMetaData
- BEFORE_STEP - Enum constant in enum class org.springframework.batch.core.listener.StepListenerMetaData
- BEFORE_WRITE - Enum constant in enum class org.springframework.batch.core.listener.StepListenerMetaData
- beforeChunk(ChunkContext) - Method in interface org.springframework.batch.core.ChunkListener
-
Callback before the chunk is executed, but inside the transaction.
- beforeChunk(ChunkContext) - Method in class org.springframework.batch.core.listener.ChunkListenerSupport
-
Deprecated.
- beforeChunk(ChunkContext) - Method in class org.springframework.batch.core.listener.CompositeChunkListener
-
Call the registered listeners in order, respecting and prioritizing those that implement
Ordered
. - beforeChunk(ChunkContext) - Method in class org.springframework.batch.core.listener.MulticasterBatchListener
- BeforeChunk - Annotation Interface in org.springframework.batch.core.annotation
-
Marks a method to be called before a chunk is executed.
- beforeJob(JobExecution) - Method in interface org.springframework.batch.core.JobExecutionListener
-
Callback before a job executes.
- beforeJob(JobExecution) - Method in class org.springframework.batch.core.listener.CompositeJobExecutionListener
-
Call the registered listeners in order, respecting and prioritising those that implement
Ordered
. - beforeJob(JobExecution) - Method in class org.springframework.batch.core.listener.JobExecutionListenerSupport
-
Deprecated.
- BeforeJob - Annotation Interface in org.springframework.batch.core.annotation
-
Marks a method to be called before a
Job
is executed, which comes after aJobExecution
is created and persisted but before the firstStep
is executed. - 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(T) - Method in class org.springframework.batch.core.listener.MulticasterBatchListener
- BeforeProcess - Annotation Interface in org.springframework.batch.core.annotation
-
Marks a method to be called before an item is passed to an
ItemProcessor
Expected signature: void beforeProcess(T item) - beforeRead() - Method in interface org.springframework.batch.core.ItemReadListener
-
Called before
ItemReader.read()
- beforeRead() - Method in class org.springframework.batch.core.listener.CompositeItemReadListener
-
Call the registered listeners in order, respecting and prioritising those that implement
Ordered
. - beforeRead() - Method in class org.springframework.batch.core.listener.MulticasterBatchListener
- BeforeRead - Annotation Interface in org.springframework.batch.core.annotation
-
Marks a method to be called before an item is read from an
ItemReader
Expected signature: void beforeRead() - beforeStep(StepExecution) - Method in class org.springframework.batch.core.listener.CompositeStepExecutionListener
-
Call the registered listeners in order, respecting and prioritizing those that implement
Ordered
. - beforeStep(StepExecution) - Method in class org.springframework.batch.core.listener.JobParameterExecutionContextCopyListener
- beforeStep(StepExecution) - Method in class org.springframework.batch.core.listener.MulticasterBatchListener
- beforeStep(StepExecution) - Method in class org.springframework.batch.core.listener.StepExecutionListenerSupport
-
Deprecated.
- beforeStep(StepExecution) - Method in class org.springframework.batch.core.resource.StepExecutionSimpleCompletionPolicy
-
Set up a
SimpleCompletionPolicy
with a commit interval taken from theJobParameters
. - beforeStep(StepExecution) - Method in class org.springframework.batch.core.step.tasklet.SystemCommandTasklet
-
Get a reference to
StepExecution
for interrupt checks during system command execution. - beforeStep(StepExecution) - Method in interface org.springframework.batch.core.StepExecutionListener
-
Initialize the state of the listener with the
StepExecution
from the current scope. - beforeStep(StepExecution) - Method in class org.springframework.batch.integration.chunk.ChunkMessageChannelItemWriter
- BeforeStep - Annotation Interface in org.springframework.batch.core.annotation
-
Marks a method to be called before a
Step
is executed, which comes after aStepExecution
is created and persisted but before the first item is read. - beforeTestMethod(TestContext) - Method in class org.springframework.batch.test.JobScopeTestExecutionListener
- beforeTestMethod(TestContext) - Method in class org.springframework.batch.test.StepScopeTestExecutionListener
- beforeWrite(Chunk<? extends S>) - Method in interface org.springframework.batch.core.ItemWriteListener
-
Called before
ItemWriter.write(Chunk)
- beforeWrite(Chunk<? extends S>) - Method in class org.springframework.batch.core.listener.CompositeItemWriteListener
-
Call the registered listeners in order, respecting and prioritising those that implement
Ordered
. - beforeWrite(Chunk<? extends S>) - Method in class org.springframework.batch.core.listener.MulticasterBatchListener
- BeforeWrite - Annotation Interface in org.springframework.batch.core.annotation
-
Marks a method to be called before a chunk is passed to an
ItemWriter
. - begin(T) - Method in class org.springframework.batch.support.transaction.TransactionAwareProxyFactory
-
Make a copy of the target that can be used inside a transaction to isolate changes from the original.
- bind(JobFactory, Map<String, ?>) - Method in class org.springframework.batch.core.configuration.support.JobFactoryRegistrationListener
-
Take the
JobFactory
provided and register it with theJobRegistry
. - bufferedReaderFactory(BufferedReaderFactory) - Method in class org.springframework.batch.item.file.builder.FlatFileItemReaderBuilder
-
Configure a custom
BufferedReaderFactory
for the reader. - BufferedReaderFactory - Interface in org.springframework.batch.item.file
-
A factory strategy for custom extensions of
BufferedReader
allowing customisation of the standard behaviour of thejava.io
variety. - build() - Method in class org.springframework.batch.core.job.builder.FlowBuilder
-
Validate the current state of the builder and build a flow.
- build() - Method in class org.springframework.batch.core.job.builder.FlowJobBuilder
-
Build a job that executes the flow provided, normally composed of other steps.
- build() - Method in class org.springframework.batch.core.job.builder.JobFlowBuilder
-
Build a flow and inject it into the parent builder.
- build() - Method in class org.springframework.batch.core.job.builder.SimpleJobBuilder
- build() - Method in class org.springframework.batch.core.step.builder.AbstractTaskletStepBuilder
-
Build the step from the components collected by the fluent setters.
- build() - Method in class org.springframework.batch.core.step.builder.FaultTolerantStepBuilder
- build() - Method in class org.springframework.batch.core.step.builder.FlowStepBuilder
-
Build a step that executes the flow provided, normally composed of other steps.
- build() - Method in class org.springframework.batch.core.step.builder.JobStepBuilder
-
Build a step from the job provided.
- build() - Method in class org.springframework.batch.core.step.builder.PartitionStepBuilder
- build() - Method in class org.springframework.batch.core.step.builder.SimpleStepBuilder
-
Build a step with the reader, writer, processor as provided.
- build() - Method in class org.springframework.batch.integration.chunk.RemoteChunkingManagerStepBuilder
-
Build a manager
TaskletStep
. - build() - Method in class org.springframework.batch.integration.chunk.RemoteChunkingWorkerBuilder
-
Create an
IntegrationFlow
with aChunkProcessorChunkHandler
configured as a service activator listening to the input channel and replying on the output channel. - build() - Method in class org.springframework.batch.integration.partition.RemotePartitioningManagerStepBuilder
- build() - Method in class org.springframework.batch.item.amqp.builder.AmqpItemReaderBuilder
-
Validates and builds a
AmqpItemReader
. - build() - Method in class org.springframework.batch.item.amqp.builder.AmqpItemWriterBuilder
-
Validates and builds a
AmqpItemWriter
. - build() - Method in class org.springframework.batch.item.avro.builder.AvroItemReaderBuilder
-
Build an instance of
AvroItemReader
. - build() - Method in class org.springframework.batch.item.avro.builder.AvroItemWriterBuilder
-
Build an instance of
AvroItemWriter
. - build() - Method in class org.springframework.batch.item.data.builder.MongoCursorItemReaderBuilder
- build() - Method in class org.springframework.batch.item.data.builder.MongoItemReaderBuilder
-
Deprecated.Validates and builds a
MongoItemReader
. - build() - Method in class org.springframework.batch.item.data.builder.MongoItemWriterBuilder
-
Validates and builds a
MongoItemWriter
. - build() - Method in class org.springframework.batch.item.data.builder.MongoPagingItemReaderBuilder
- build() - Method in class org.springframework.batch.item.data.builder.Neo4jItemReaderBuilder
-
Deprecated.Returns a fully constructed
Neo4jItemReader
. - build() - Method in class org.springframework.batch.item.data.builder.Neo4jItemWriterBuilder
-
Deprecated.Validates and builds a
Neo4jItemWriter
. - build() - Method in class org.springframework.batch.item.data.builder.RepositoryItemReaderBuilder
-
Builds the
RepositoryItemReader
. - build() - Method in class org.springframework.batch.item.data.builder.RepositoryItemWriterBuilder
-
Builds the
RepositoryItemWriter
. - build() - Method in class org.springframework.batch.item.database.builder.JdbcBatchItemWriterBuilder
-
Validates configuration and builds the
JdbcBatchItemWriter
. - build() - Method in class org.springframework.batch.item.database.builder.JdbcCursorItemReaderBuilder
-
Validates configuration and builds a new reader instance.
- build() - Method in class org.springframework.batch.item.database.builder.JdbcPagingItemReaderBuilder
-
Provides a completely built instance of the
JdbcPagingItemReader
- build() - Method in class org.springframework.batch.item.database.builder.JpaCursorItemReaderBuilder
-
Returns a fully constructed
JpaCursorItemReader
. - build() - Method in class org.springframework.batch.item.database.builder.JpaItemWriterBuilder
-
Returns a fully built
JpaItemWriter
. - build() - Method in class org.springframework.batch.item.database.builder.JpaPagingItemReaderBuilder
-
Returns a fully constructed
JpaPagingItemReader
. - build() - Method in class org.springframework.batch.item.database.builder.StoredProcedureItemReaderBuilder
-
Validates configuration and builds a new reader instance
- build() - Method in class org.springframework.batch.item.file.builder.FlatFileItemReaderBuilder
-
Builds the
FlatFileItemReader
. - build() - Method in class org.springframework.batch.item.file.builder.FlatFileItemReaderBuilder.DelimitedBuilder
-
Returns a
DelimitedLineTokenizer
- build() - Method in class org.springframework.batch.item.file.builder.FlatFileItemReaderBuilder.FixedLengthBuilder
-
Returns a
FixedLengthTokenizer
- build() - Method in class org.springframework.batch.item.file.builder.FlatFileItemWriterBuilder
-
Validates and builds a
FlatFileItemWriter
. - build() - Method in class org.springframework.batch.item.file.builder.FlatFileItemWriterBuilder.DelimitedBuilder
- build() - Method in class org.springframework.batch.item.file.builder.FlatFileItemWriterBuilder.FormattedBuilder
- build() - Method in class org.springframework.batch.item.file.builder.MultiResourceItemReaderBuilder
-
Builds the
MultiResourceItemReader
. - build() - Method in class org.springframework.batch.item.file.builder.MultiResourceItemWriterBuilder
-
Builds the
MultiResourceItemWriter
. - build() - Method in class org.springframework.batch.item.jms.builder.JmsItemReaderBuilder
-
Returns a fully constructed
JmsItemReader
. - build() - Method in class org.springframework.batch.item.jms.builder.JmsItemWriterBuilder
-
Returns a fully constructed
JmsItemWriter
. - build() - Method in class org.springframework.batch.item.json.builder.JsonFileItemWriterBuilder
-
Validate the configuration and build a new
JsonFileItemWriter
. - build() - Method in class org.springframework.batch.item.json.builder.JsonItemReaderBuilder
-
Validate the configuration and build a new
JsonItemReader
. - build() - Method in class org.springframework.batch.item.kafka.builder.KafkaItemReaderBuilder
- build() - Method in class org.springframework.batch.item.kafka.builder.KafkaItemWriterBuilder
-
Validates and builds a
KafkaItemWriter
. - build() - Method in class org.springframework.batch.item.ldif.builder.LdifReaderBuilder
-
Returns a fully constructed
LdifReader
. - build() - Method in class org.springframework.batch.item.ldif.builder.MappingLdifReaderBuilder
-
Returns a fully constructed
MappingLdifReader
. - build() - Method in class org.springframework.batch.item.mail.builder.SimpleMailMessageItemWriterBuilder
-
Returns a fully constructed
SimpleMailMessageItemWriter
. - build() - Method in class org.springframework.batch.item.redis.builder.RedisItemReaderBuilder
-
Build a new
RedisItemReader
. - build() - Method in class org.springframework.batch.item.redis.builder.RedisItemWriterBuilder
-
Validates and builds a
RedisItemWriter
. - build() - Method in class org.springframework.batch.item.support.builder.ClassifierCompositeItemProcessorBuilder
-
Returns a fully constructed
ClassifierCompositeItemProcessor
. - build() - Method in class org.springframework.batch.item.support.builder.ClassifierCompositeItemWriterBuilder
-
Returns a fully constructed
ClassifierCompositeItemWriter
. - build() - Method in class org.springframework.batch.item.support.builder.CompositeItemProcessorBuilder
-
Returns a fully constructed
CompositeItemProcessor
. - build() - Method in class org.springframework.batch.item.support.builder.CompositeItemWriterBuilder
-
Returns a fully constructed
CompositeItemWriter
. - build() - Method in class org.springframework.batch.item.support.builder.ScriptItemProcessorBuilder
-
Returns a fully constructed
ScriptItemProcessor
. - build() - Method in class org.springframework.batch.item.support.builder.SingleItemPeekableItemReaderBuilder
-
Returns a fully constructed
SingleItemPeekableItemReader
. - build() - Method in class org.springframework.batch.item.support.builder.SynchronizedItemReaderBuilder
-
Returns a new
SynchronizedItemReader
. - build() - Method in class org.springframework.batch.item.support.builder.SynchronizedItemStreamReaderBuilder
-
Returns a fully constructed
SynchronizedItemStreamReader
. - build() - Method in class org.springframework.batch.item.support.builder.SynchronizedItemStreamWriterBuilder
-
Returns a fully constructed
SynchronizedItemStreamWriter
. - build() - Method in class org.springframework.batch.item.support.builder.SynchronizedItemWriterBuilder
-
Returns a new
SynchronizedItemWriter
. - build() - Method in class org.springframework.batch.item.xml.builder.StaxEventItemReaderBuilder
-
Validates the configuration and builds a new
StaxEventItemReader
- build() - Method in class org.springframework.batch.item.xml.builder.StaxEventItemWriterBuilder
-
Returns a configured
StaxEventItemWriter
- buildSortClause(Map<String, Order>) - Static method in class org.springframework.batch.item.database.support.SqlPagingQueryUtils
-
Generates ORDER BY attributes based on the sort keys.
- buildSortClause(AbstractSqlPagingQueryProvider) - Static method in class org.springframework.batch.item.database.support.SqlPagingQueryUtils
-
Generates ORDER BY attributes based on the sort keys.
- buildSortConditions(AbstractSqlPagingQueryProvider, StringBuilder) - Static method in class org.springframework.batch.item.database.support.SqlPagingQueryUtils
-
Appends the where conditions required to query for the subsequent pages.
C
- calculateDuration(LocalDateTime, LocalDateTime) - Static method in class org.springframework.batch.core.observability.BatchMetrics
-
Calculate the duration between two dates.
- CallableTaskletAdapter - Class in org.springframework.batch.core.step.tasklet
- CallableTaskletAdapter() - Constructor for class org.springframework.batch.core.step.tasklet.CallableTaskletAdapter
-
Create a new
CallableTaskletAdapter
instance. - CallableTaskletAdapter(Callable<RepeatStatus>) - Constructor for class org.springframework.batch.core.step.tasklet.CallableTaskletAdapter
-
Create a new
CallableTaskletAdapter
instance. - canContinue(RepeatStatus) - Method in class org.springframework.batch.repeat.support.RepeatTemplate
-
Check return value from batch operation.
- canRetry(RetryContext) - Method in class org.springframework.batch.core.step.item.BatchRetryTemplate
- charset() - Element in annotation interface org.springframework.batch.core.configuration.annotation.EnableBatchProcessing
-
The charset to use in the job repository and job explorer
- checkInterrupted(StepExecution) - Method in interface org.springframework.batch.core.step.StepInterruptionPolicy
-
Has the job been interrupted?
- checkInterrupted(StepExecution) - Method in class org.springframework.batch.core.step.ThreadStepInterruptionPolicy
-
Returns if the current job lifecycle has been interrupted by checking if the current thread is interrupted.
- chunk(int) - Method in class org.springframework.batch.core.step.builder.SimpleStepBuilder
-
Sets the chunk size or commit interval for this step.
- chunk(int) - Method in class org.springframework.batch.core.step.builder.StepBuilder
-
Deprecated, for removal: This API element is subject to removal in a future version.
- chunk(int) - Method in class org.springframework.batch.integration.chunk.RemoteChunkingManagerStepBuilder
- chunk(int) - Method in class org.springframework.batch.integration.partition.RemotePartitioningWorkerStepBuilder
-
Deprecated, for removal: This API element is subject to removal in a future version.
- chunk(int, PlatformTransactionManager) - Method in class org.springframework.batch.core.step.builder.StepBuilder
-
Build a step that processes items in chunks with the size provided.
- chunk(int, PlatformTransactionManager) - Method in class org.springframework.batch.integration.partition.RemotePartitioningWorkerStepBuilder
- chunk(CompletionPolicy) - Method in class org.springframework.batch.core.step.builder.SimpleStepBuilder
-
Sets a completion policy for the chunk processing.
- chunk(CompletionPolicy) - Method in class org.springframework.batch.core.step.builder.StepBuilder
-
Deprecated, for removal: This API element is subject to removal in a future version.
- chunk(CompletionPolicy) - Method in class org.springframework.batch.integration.chunk.RemoteChunkingManagerStepBuilder
- chunk(CompletionPolicy) - Method in class org.springframework.batch.integration.partition.RemotePartitioningWorkerStepBuilder
-
Deprecated, for removal: This API element is subject to removal in a future version.
- chunk(CompletionPolicy, PlatformTransactionManager) - Method in class org.springframework.batch.core.step.builder.StepBuilder
-
Build a step that processes items in chunks with the completion policy provided.
- chunk(CompletionPolicy, PlatformTransactionManager) - Method in class org.springframework.batch.integration.partition.RemotePartitioningWorkerStepBuilder
- Chunk<W> - Class in org.springframework.batch.item
-
Encapsulation of a list of items to be processed and possibly a list of failed items to be skipped.
- Chunk(List<? extends W>) - Constructor for class org.springframework.batch.item.Chunk
- Chunk(List<? extends W>, List<SkipWrapper<W>>) - Constructor for class org.springframework.batch.item.Chunk
- Chunk(W...) - Constructor for class org.springframework.batch.item.Chunk
- Chunk.ChunkIterator - Class in org.springframework.batch.item
-
Special iterator for a chunk providing the
Chunk.ChunkIterator.remove(Throwable)
method for dynamically removing an item and adding it to the skips. - ChunkContext - Class in org.springframework.batch.core.scope.context
-
Context object for weakly typed data stored for the duration of a chunk (usually a group of items processed together in a transaction).
- ChunkContext(StepContext) - Constructor for class org.springframework.batch.core.scope.context.ChunkContext
- ChunkElementParser - Class in org.springframework.batch.core.configuration.xml
-
Internal parser for the <chunk/> element inside a step.
- ChunkElementParser() - Constructor for class org.springframework.batch.core.configuration.xml.ChunkElementParser
- ChunkHandler<T> - Interface in org.springframework.batch.integration.chunk
-
Interface for a remote worker in the Remote Chunking pattern.
- ChunkIterator(List<W>) - Constructor for class org.springframework.batch.item.Chunk.ChunkIterator
- ChunkListener - Interface in org.springframework.batch.core
-
Listener interface for the lifecycle of a chunk.
- chunkListeners - Variable in class org.springframework.batch.core.step.builder.AbstractTaskletStepBuilder
- ChunkListenerSupport - Class in org.springframework.batch.core.listener
-
Deprecated.as of 5.0, in favor of the default methods on the
ChunkListener
- ChunkListenerSupport() - Constructor for class org.springframework.batch.core.listener.ChunkListenerSupport
-
Deprecated.
- ChunkMessageChannelItemWriter<T> - Class in org.springframework.batch.integration.chunk
- ChunkMessageChannelItemWriter() - Constructor for class org.springframework.batch.integration.chunk.ChunkMessageChannelItemWriter
- ChunkMessageChannelItemWriter.LocalState - Class in org.springframework.batch.integration.chunk
- ChunkMonitor - Class in org.springframework.batch.core.step.item
-
Manage the offset data between the last successful commit and updates made to an input chunk.
- ChunkMonitor() - Constructor for class org.springframework.batch.core.step.item.ChunkMonitor
- ChunkMonitor.ChunkMonitorData - Class in org.springframework.batch.core.step.item
- ChunkMonitorData(int, int) - Constructor for class org.springframework.batch.core.step.item.ChunkMonitor.ChunkMonitorData
- chunkOperations(RepeatOperations) - Method in class org.springframework.batch.core.step.builder.SimpleStepBuilder
-
Instead of a
chunk size
orcompletion policy
you can provide a complete repeat operations instance that handles the iteration over the item reader. - chunkOperations(RepeatOperations) - Method in class org.springframework.batch.integration.chunk.RemoteChunkingManagerStepBuilder
- 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
Chunk
s. - ChunkProcessorChunkHandler<S> - Class in org.springframework.batch.integration.chunk
-
A
ChunkHandler
based on aChunkProcessor
. - ChunkProcessorChunkHandler() - Constructor for class org.springframework.batch.integration.chunk.ChunkProcessorChunkHandler
- ChunkProvider<T> - Interface in org.springframework.batch.core.step.item
-
Interface for providing
Chunk
s to be processed, used by theChunkOrientedTasklet
- ChunkRequest<T> - Class in org.springframework.batch.integration.chunk
-
Encapsulation of a chunk of items to be processed remotely as part of a step execution.
- ChunkRequest(int, Chunk<? extends T>, long, StepContribution) - Constructor for class org.springframework.batch.integration.chunk.ChunkRequest
- ChunkResponse - Class in org.springframework.batch.integration.chunk
-
Encapsulates a response to processing a chunk of items, summarising the result as a
StepContribution
. - ChunkResponse(boolean, int, Long, StepContribution) - Constructor for class org.springframework.batch.integration.chunk.ChunkResponse
- ChunkResponse(boolean, int, Long, StepContribution, String) - Constructor for class org.springframework.batch.integration.chunk.ChunkResponse
- ChunkResponse(boolean, int, Long, StepContribution, String, boolean) - Constructor for class org.springframework.batch.integration.chunk.ChunkResponse
- ChunkResponse(int, Long, StepContribution) - Constructor for class org.springframework.batch.integration.chunk.ChunkResponse
- ChunkResponse(ChunkResponse, boolean) - Constructor for class org.springframework.batch.integration.chunk.ChunkResponse
- chunkSize - Variable in class org.springframework.batch.core.step.item.ChunkMonitor.ChunkMonitorData
- classifier(Classifier<? super I, ItemProcessor<?, ? extends O>>) - Method in class org.springframework.batch.item.support.builder.ClassifierCompositeItemProcessorBuilder
-
Establishes the classifier that will determine which
ItemProcessor
to use. - classifier(Classifier<T, ItemWriter<? super T>>) - Method in class org.springframework.batch.item.support.builder.ClassifierCompositeItemWriterBuilder
-
Establish the classifier to be used for the selection of which
ItemWriter
to use. - ClassifierCompositeItemProcessor<I,
O> - Class in org.springframework.batch.item.support -
Calls one of a collection of ItemProcessors, based on a router pattern implemented through the provided
Classifier
. - ClassifierCompositeItemProcessor() - Constructor for class org.springframework.batch.item.support.ClassifierCompositeItemProcessor
- ClassifierCompositeItemProcessorBuilder<I,
O> - Class in org.springframework.batch.item.support.builder -
Creates a fully qualified
ClassifierCompositeItemProcessor
. - ClassifierCompositeItemProcessorBuilder() - Constructor for class org.springframework.batch.item.support.builder.ClassifierCompositeItemProcessorBuilder
- ClassifierCompositeItemWriter<T> - Class in org.springframework.batch.item.support
-
Calls one of a collection of ItemWriters for each item, based on a router pattern implemented through the provided
Classifier
. - ClassifierCompositeItemWriter() - Constructor for class org.springframework.batch.item.support.ClassifierCompositeItemWriter
- ClassifierCompositeItemWriterBuilder<T> - Class in org.springframework.batch.item.support.builder
-
Creates a fully qualified ClassifierCompositeItemWriter.
- ClassifierCompositeItemWriterBuilder() - Constructor for class org.springframework.batch.item.support.builder.ClassifierCompositeItemWriterBuilder
- ClasspathXmlApplicationContextsFactoryBean - Class in org.springframework.batch.core.configuration.support
-
A convenient factory for creating a set of
ApplicationContextFactory
components from a set ofresources
. - ClasspathXmlApplicationContextsFactoryBean() - Constructor for class org.springframework.batch.core.configuration.support.ClasspathXmlApplicationContextsFactoryBean
- cleanupOnClose(Connection) - Method in class org.springframework.batch.item.database.AbstractCursorItemReader
-
Clean up resources.
- cleanupOnClose(Connection) - Method in class org.springframework.batch.item.database.JdbcCursorItemReader
-
Close the cursor and database connection.
- cleanupOnClose(Connection) - Method in class org.springframework.batch.item.database.StoredProcedureItemReader
-
Close the cursor and database connection.
- clear() - Method in class org.springframework.batch.core.configuration.support.DefaultJobLoader
-
Unregister all the jobs and close all the contexts created by this loader.
- clear() - Method in interface org.springframework.batch.core.configuration.support.JobLoader
-
Unregister all the jobs and close all the contexts created by this loader.
- clear() - Method in class org.springframework.batch.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. - clearDirtyFlag() - Method in class org.springframework.batch.item.ExecutionContext
-
Clears the dirty flag.
- clearPersistenceContext(boolean) - Method in class org.springframework.batch.item.database.builder.JpaItemWriterBuilder
-
If set to false, the
EntityManager
will not be cleared at the end of the chunk. defaults to true - clearSkips() - Method in class org.springframework.batch.item.Chunk
-
Clear only the skips list.
- clobType() - Element in annotation interface org.springframework.batch.core.configuration.annotation.EnableBatchProcessing
-
The type of large objects.
- close() - Method in class org.springframework.batch.core.scope.context.JobContext
-
Clean up the context at the end of a step execution.
- close() - Static method in class org.springframework.batch.core.scope.context.JobSynchronizationManager
-
Method for unregistering the current context - should always and only be used by in conjunction with a matching
JobSynchronizationManager.register(JobExecution)
to ensure thatJobSynchronizationManager.getContext()
always returns the correct value. - close() - Method in class org.springframework.batch.core.scope.context.StepContext
-
Clean up the context at the end of a step execution.
- close() - Static method in class org.springframework.batch.core.scope.context.StepSynchronizationManager
-
Method for unregistering the current context - should always and only be used by in conjunction with a matching
StepSynchronizationManager.register(StepExecution)
to ensure thatStepSynchronizationManager.getContext()
always returns the correct value. - close() - Method in class org.springframework.batch.core.scope.context.SynchronizationManagerSupport
-
Method for unregistering the current context - should always and only be used by in conjunction with a matching
SynchronizationManagerSupport.register(Object)
to ensure thatSynchronizationManagerSupport.getContext()
always returns the correct value. - close() - Method in class org.springframework.batch.core.step.item.ChunkMonitor
- close() - Method in class org.springframework.batch.integration.async.AsyncItemWriter
- close() - Method in class org.springframework.batch.integration.chunk.ChunkMessageChannelItemWriter
- close() - Method in class org.springframework.batch.item.avro.AvroItemWriter
- close() - Method in class org.springframework.batch.item.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.json.GsonJsonObjectReader
- close() - Method in class org.springframework.batch.item.json.JacksonJsonObjectReader
- close() - Method in interface org.springframework.batch.item.json.JsonObjectReader
-
Close the input resource.
- close() - Method in class org.springframework.batch.item.kafka.KafkaItemReader
- close() - Method in class org.springframework.batch.item.redis.RedisItemReader
- close() - Method in class org.springframework.batch.item.support.AbstractFileItemWriter
- close() - Method in class org.springframework.batch.item.support.AbstractFileItemWriter.OutputState
-
Close the open resource and reset counters.
- close() - Method in class org.springframework.batch.item.support.AbstractItemCountingItemStreamItemReader
- close() - Method in class org.springframework.batch.item.support.CompositeItemStream
-
Broadcast the call to close.
- close() - Method in class org.springframework.batch.item.support.CompositeItemWriter
- close() - Method in class org.springframework.batch.item.support.SingleItemPeekableItemReader
-
If the delegate is an
ItemStream
, just pass the call on, otherwise reset the peek cache. - close() - Method in class org.springframework.batch.item.support.SynchronizedItemStreamReader
- close() - Method in class org.springframework.batch.item.support.SynchronizedItemStreamWriter
- close() - Method in class org.springframework.batch.item.xml.stax.DefaultFragmentEventReader
- close() - Method in class org.springframework.batch.item.xml.stax.UnopenedElementClosingEventWriter
- close() - Method in class org.springframework.batch.item.xml.stax.NoStartEndDocumentStreamWriter
- close() - Method in class org.springframework.batch.item.xml.StaxEventItemWriter
-
Flush and close the output source.
- close() - Method in class org.springframework.batch.repeat.context.RepeatContextSupport
- close() - Method in interface org.springframework.batch.repeat.RepeatContext
-
Allow resources to be cleared, especially in destruction callbacks.
- close() - Method in class org.springframework.batch.support.transaction.TransactionAwareBufferedWriter
- close(C) - Method in class org.springframework.batch.core.scope.context.SynchronizationManagerSupport
- close(FlowExecution) - Method in interface org.springframework.batch.core.job.flow.FlowExecutor
-
Chance to clean up resources at the end of a flow (whether it completed successfully or not).
- close(FlowExecution) - Method in class org.springframework.batch.core.job.flow.JobFlowExecutor
- close(ExecutionContext) - Method in class org.springframework.batch.core.step.AbstractStep
-
Extension point for subclasses to provide callbacks to their collaborators at the end of a step (right at the end of the finally block), to close or release resources.
- close(ExecutionContext) - Method in class org.springframework.batch.core.step.tasklet.TaskletStep
- close(RepeatContext) - Method in class org.springframework.batch.repeat.listener.CompositeRepeatListener
- close(RepeatContext) - Method in class org.springframework.batch.repeat.listener.RepeatListenerSupport
-
Deprecated.
- 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, E>, Throwable) - Method in class org.springframework.batch.core.step.item.SimpleRetryExceptionHandler
-
If retry is exhausted set up some state in the context that can be used to signal that the exception should be handled.
- collection - Variable in class org.springframework.batch.item.data.builder.MongoItemReaderBuilder
-
Deprecated.
- collection - Variable in class org.springframework.batch.item.data.MongoItemReader
-
Deprecated.
- collection(String) - Method in class org.springframework.batch.item.data.builder.MongoCursorItemReaderBuilder
-
Establish an optional collection that can be queried.
- collection(String) - Method in class org.springframework.batch.item.data.builder.MongoItemReaderBuilder
-
Deprecated.Establish an optional collection that can be queried.
- collection(String) - Method in class org.springframework.batch.item.data.builder.MongoItemWriterBuilder
-
Set the name of the Mongo collection to be written to.
- collection(String) - Method in class org.springframework.batch.item.data.builder.MongoPagingItemReaderBuilder
-
Establish an optional collection that can be queried.
- ColumnMapItemPreparedStatementSetter - Class in org.springframework.batch.item.database.support
-
Implementation of the
ItemPreparedStatementSetter
interface that assumes all keys are contained within aMap
with the column name as the key. - ColumnMapItemPreparedStatementSetter() - Constructor for class org.springframework.batch.item.database.support.ColumnMapItemPreparedStatementSetter
- columnMapped() - Method in class org.springframework.batch.item.database.builder.JdbcBatchItemWriterBuilder
-
Creates a
ColumnMapItemPreparedStatementSetter
to be used as yourItemPreparedStatementSetter
. - columns(Range...) - Method in class org.springframework.batch.item.file.builder.FlatFileItemReaderBuilder.FixedLengthBuilder
-
The column ranges for each field
- CommandLineJobRunner - Class in org.springframework.batch.core.launch.support
-
Basic launcher for starting jobs from the command line.
- CommandLineJobRunner() - Constructor for class org.springframework.batch.core.launch.support.CommandLineJobRunner
- CommandRunner - Interface in org.springframework.batch.core.step.tasklet
-
Strategy interface for executing commands.
- comments - Variable in class org.springframework.batch.item.file.FlatFileItemReader
- comments(String...) - Method in class org.springframework.batch.item.file.builder.FlatFileItemReaderBuilder
-
Set an array of Strings that indicate lines that are comments (and therefore skipped by the reader).
- commit(T, T) - Method in class org.springframework.batch.support.transaction.TransactionAwareProxyFactory
-
Take the working copy state and commit it back to the original target.
- CommonJobProperties() - Constructor for class org.springframework.batch.core.job.builder.JobBuilderHelper.CommonJobProperties
- CommonJobProperties(JobBuilderHelper.CommonJobProperties) - Constructor for class org.springframework.batch.core.job.builder.JobBuilderHelper.CommonJobProperties
- CommonStepProperties() - Constructor for class org.springframework.batch.core.step.builder.StepBuilderHelper.CommonStepProperties
- CommonStepProperties(StepBuilderHelper.CommonStepProperties) - Constructor for class org.springframework.batch.core.step.builder.StepBuilderHelper.CommonStepProperties
- comparator(Comparator<Resource>) - Method in class org.springframework.batch.item.file.builder.MultiResourceItemReaderBuilder
-
Used to order the injected resources, by default compares
Resource.getFilename()
values. - compare(StateTransition, StateTransition) - Method in class org.springframework.batch.core.job.flow.support.DefaultStateTransitionComparator
- compare(Resource, Resource) - Method in class org.springframework.batch.support.LastModifiedResourceComparator
-
Compare the two resources by last modified time, so that a sorted list of resources will have oldest first.
- compareTo(ExitStatus) - Method in class org.springframework.batch.core.ExitStatus
- compareTo(FlowExecution) - Method in class org.springframework.batch.core.job.flow.FlowExecution
-
Create an ordering on
FlowExecution
instances by comparing their statuses. - compareTo(FlowExecutionStatus) - Method in class org.springframework.batch.core.job.flow.FlowExecutionStatus
-
Create an ordering on
FlowExecutionStatus
instances by comparing their statuses. - completableFutures - Variable in class org.springframework.batch.item.kafka.KafkaItemWriter
- COMPLETED - Enum constant in enum class org.springframework.batch.core.BatchStatus
-
The batch job has successfully completed its execution.
- COMPLETED - Static variable in class org.springframework.batch.core.ExitStatus
-
Convenient constant value representing finished processing.
- COMPLETED - Static variable in class org.springframework.batch.core.job.flow.FlowExecutionStatus
-
Special well-known status value.
- CompletionPolicy - Interface in org.springframework.batch.repeat
-
Interface for batch completion policies, to enable batch operations to strategise normal completion conditions.
- CompletionPolicySupport - Class in org.springframework.batch.repeat.policy
-
Very simple base class for
CompletionPolicy
implementations. - CompletionPolicySupport() - Constructor for class org.springframework.batch.repeat.policy.CompletionPolicySupport
- CompositeBatchContext(RepeatContext, List<RepeatContext>) - Constructor for class org.springframework.batch.repeat.policy.CompositeCompletionPolicy.CompositeBatchContext
- CompositeChunkListener - Class in org.springframework.batch.core.listener
- CompositeChunkListener() - Constructor for class org.springframework.batch.core.listener.CompositeChunkListener
-
Default constructor
- CompositeChunkListener(List<? extends ChunkListener>) - Constructor for class org.springframework.batch.core.listener.CompositeChunkListener
-
Convenience constructor for setting the
ChunkListener
s. - CompositeChunkListener(ChunkListener...) - Constructor for class org.springframework.batch.core.listener.CompositeChunkListener
-
Convenience constructor for setting the
ChunkListener
s. - CompositeCompletionPolicy - Class in org.springframework.batch.repeat.policy
-
Composite policy that loops through a list of delegate policies and answers calls by a consensus.
- CompositeCompletionPolicy() - Constructor for class org.springframework.batch.repeat.policy.CompositeCompletionPolicy
- CompositeCompletionPolicy.CompositeBatchContext - Class in org.springframework.batch.repeat.policy
-
Composite context that knows about the policies and contexts is was created with.
- CompositeExceptionHandler - Class in org.springframework.batch.repeat.exception
-
Composite
ExceptionHandler
that loops though a list of delegates. - CompositeExceptionHandler() - Constructor for class org.springframework.batch.repeat.exception.CompositeExceptionHandler
- CompositeItemProcessListener<T,
S> - Class in org.springframework.batch.core.listener - CompositeItemProcessListener() - Constructor for class org.springframework.batch.core.listener.CompositeItemProcessListener
- CompositeItemProcessor<I,
O> - Class in org.springframework.batch.item.support -
Composite
ItemProcessor
that passes the item through a sequence of injectedItemTransformer
s (return value of previous transformation is the entry value of the next).
Note the user is responsible for injecting a chain ofItemProcessor
s that conforms to declared input and output types. - CompositeItemProcessor() - Constructor for class org.springframework.batch.item.support.CompositeItemProcessor
-
Default constructor
- CompositeItemProcessor(List<? extends ItemProcessor<?, ?>>) - Constructor for class org.springframework.batch.item.support.CompositeItemProcessor
-
Convenience constructor for setting the delegates.
- CompositeItemProcessor(ItemProcessor<?, ?>...) - Constructor for class org.springframework.batch.item.support.CompositeItemProcessor
-
Convenience constructor for setting the delegates.
- CompositeItemProcessorBuilder<I,
O> - Class in org.springframework.batch.item.support.builder -
Creates a fully qualified
CompositeItemProcessorBuilder
. - CompositeItemProcessorBuilder() - Constructor for class org.springframework.batch.item.support.builder.CompositeItemProcessorBuilder
- CompositeItemReadListener<T> - Class in org.springframework.batch.core.listener
- CompositeItemReadListener() - Constructor for class org.springframework.batch.core.listener.CompositeItemReadListener
- CompositeItemStream - Class in org.springframework.batch.item.support
-
Simple
ItemStream
that delegates to a list of other streams. - CompositeItemStream() - Constructor for class org.springframework.batch.item.support.CompositeItemStream
-
Default constructor
- CompositeItemStream(List<ItemStream>) - Constructor for class org.springframework.batch.item.support.CompositeItemStream
-
Convenience constructor for setting the
ItemStream
s. - CompositeItemStream(ItemStream...) - Constructor for class org.springframework.batch.item.support.CompositeItemStream
-
Convenience constructor for setting the
ItemStream
s. - 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
ItemWriter
s in fixed-order sequence.
The implementation is thread-safe if all delegates are thread-safe. - CompositeItemWriter() - Constructor for class org.springframework.batch.item.support.CompositeItemWriter
-
Default constructor
- CompositeItemWriter(List<ItemWriter<? super T>>) - Constructor for class org.springframework.batch.item.support.CompositeItemWriter
-
Convenience constructor for setting the delegates.
- CompositeItemWriter(ItemWriter<? super T>...) - Constructor for class org.springframework.batch.item.support.CompositeItemWriter
-
Convenience constructor for setting the delegates.
- CompositeItemWriterBuilder<T> - Class in org.springframework.batch.item.support.builder
-
Creates a fully qualified CompositeItemWriter.
- CompositeItemWriterBuilder() - Constructor for class org.springframework.batch.item.support.builder.CompositeItemWriterBuilder
- CompositeJobExecutionListener - Class in org.springframework.batch.core.listener
- CompositeJobExecutionListener() - Constructor for class org.springframework.batch.core.listener.CompositeJobExecutionListener
- CompositeJobParametersValidator - Class in org.springframework.batch.core.job
-
Composite
JobParametersValidator
that passes the job parameters through a sequence of injectedJobParametersValidator
s - CompositeJobParametersValidator() - Constructor for class org.springframework.batch.core.job.CompositeJobParametersValidator
- CompositeRepeatListener - Class in org.springframework.batch.repeat.listener
-
Allows a user to register one or more RepeatListeners to be notified on batch events.
- CompositeRepeatListener() - Constructor for class org.springframework.batch.repeat.listener.CompositeRepeatListener
-
Default constructor
- CompositeRepeatListener(List<RepeatListener>) - Constructor for class org.springframework.batch.repeat.listener.CompositeRepeatListener
-
Convenience constructor for setting the
RepeatListener
s. - CompositeRepeatListener(RepeatListener...) - Constructor for class org.springframework.batch.repeat.listener.CompositeRepeatListener
-
Convenience constructor for setting the
RepeatListener
s. - CompositeSkipListener<T,
S> - Class in org.springframework.batch.core.listener - CompositeSkipListener() - Constructor for class org.springframework.batch.core.listener.CompositeSkipListener
- CompositeSkipPolicy - Class in org.springframework.batch.core.step.skip
- CompositeSkipPolicy() - Constructor for class org.springframework.batch.core.step.skip.CompositeSkipPolicy
- CompositeSkipPolicy(SkipPolicy[]) - Constructor for class org.springframework.batch.core.step.skip.CompositeSkipPolicy
- CompositeStepExecutionListener - Class in org.springframework.batch.core.listener
- CompositeStepExecutionListener() - Constructor for class org.springframework.batch.core.listener.CompositeStepExecutionListener
- concurrent() - Method in class org.springframework.batch.core.step.builder.AbstractTaskletStepBuilder
-
Convenience method for subclasses to determine if the step is concurrent.
- ConfigurableSystemProcessExitCodeMapper - Class in org.springframework.batch.core.step.tasklet
-
Maps exit codes to
ExitStatus
according to injected map. - ConfigurableSystemProcessExitCodeMapper() - Constructor for class org.springframework.batch.core.step.tasklet.ConfigurableSystemProcessExitCodeMapper
- connectionAutoCommit(boolean) - Method in class org.springframework.batch.item.database.builder.JdbcCursorItemReaderBuilder
-
Set whether "autoCommit" should be overridden for the connection used by the cursor.
- consumerProperties(Properties) - Method in class org.springframework.batch.item.kafka.builder.KafkaItemReaderBuilder
-
Configure the underlying consumer properties.
- containsKey(String) - Method in class org.springframework.batch.item.ExecutionContext
-
Indicates whether or not a key is represented in this context.
- containsValue(Object) - Method in class org.springframework.batch.item.ExecutionContext
-
Indicates whether or not a value is represented in this context.
- CONTINUABLE - Enum constant in enum class org.springframework.batch.repeat.RepeatStatus
-
Indicates that processing can continue.
- continueIf(boolean) - Static method in enum class 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
- conversionService - Variable in class org.springframework.batch.core.converter.DefaultJobParametersConverter
- conversionServiceRef() - Element in annotation interface org.springframework.batch.core.configuration.annotation.EnableBatchProcessing
-
Set the conversion service to use in the job repository and job explorer.
- convert(String) - Method in class org.springframework.batch.core.converter.StringToDateConverter
- convert(String) - Method in class org.springframework.batch.core.converter.StringToLocalDateConverter
- convert(String) - Method in class org.springframework.batch.core.converter.StringToLocalDateTimeConverter
- convert(String) - Method in class org.springframework.batch.core.converter.StringToLocalTimeConverter
- convert(LocalDate) - Method in class org.springframework.batch.core.converter.LocalDateToStringConverter
- convert(LocalDateTime) - Method in class org.springframework.batch.core.converter.LocalDateTimeToStringConverter
- convert(LocalTime) - Method in class org.springframework.batch.core.converter.LocalTimeToStringConverter
- convert(Date) - Method in class org.springframework.batch.core.converter.DateToStringConverter
- convert(V) - Method in class org.springframework.batch.item.SpELItemKeyMapper
- convertToSort(Map<String, Sort.Direction>) - Method in class org.springframework.batch.item.data.MongoItemReader
-
Deprecated.
- convertToSort(Map<String, Sort.Direction>) - Method in class org.springframework.batch.item.data.MongoPagingItemReader
- 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.
- CoreRuntimeHints - Class in org.springframework.batch.core.aot
-
RuntimeHintsRegistrar
for Spring Batch core module. - CoreRuntimeHints() - Constructor for class org.springframework.batch.core.aot.CoreRuntimeHints
- COUNT - Static variable in class org.springframework.batch.repeat.policy.CountingCompletionPolicy
-
Session key for global counter.
- CountingBatchContext(RepeatContext) - Constructor for class org.springframework.batch.repeat.policy.CountingCompletionPolicy.CountingBatchContext
- CountingCompletionPolicy - Class in org.springframework.batch.repeat.policy
-
Abstract base class for policies that need to count the number of occurrences of some event (e.g. 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
- countParameterPlaceholders(String, List<String>) - Static method in class org.springframework.batch.item.database.JdbcParameterUtils
-
Count the occurrences of the character placeholder in an SQL string
sql
. - countStepExecutions(JobInstance, String) - Method in class org.springframework.batch.core.repository.dao.JdbcStepExecutionDao
- countStepExecutions(JobInstance, String) - Method in interface org.springframework.batch.core.repository.dao.StepExecutionDao
-
Counts all the
StepExecution
for a given step name. - create(String[]) - Method in class org.springframework.batch.item.file.transform.DefaultFieldSetFactory
-
Create a FieldSet with anonymous tokens.
- create(String[]) - Method in interface org.springframework.batch.item.file.transform.FieldSetFactory
-
Create a FieldSet with anonymous tokens.
- create(String[], String[]) - Method in class org.springframework.batch.item.file.transform.DefaultFieldSetFactory
-
Create a FieldSet with named tokens.
- create(String[], String[]) - Method in interface org.springframework.batch.item.file.transform.FieldSetFactory
-
Create a FieldSet with named tokens.
- create(Resource, String) - Method in interface org.springframework.batch.item.file.BufferedReaderFactory
-
Create a
BufferedReader
for reading String items from the provided resource. - create(Resource, String) - Method in class org.springframework.batch.item.file.DefaultBufferedReaderFactory
- create(Resource, String) - Method in class org.springframework.batch.item.file.SimpleBinaryBufferedReaderFactory
- createAppendOnlyTransactionalList() - Static method in class org.springframework.batch.support.transaction.TransactionAwareProxyFactory
- createAppendOnlyTransactionalMap() - Static method in class org.springframework.batch.support.transaction.TransactionAwareProxyFactory
- createAppendOnlyTransactionalSet() - Static method in class org.springframework.batch.support.transaction.TransactionAwareProxyFactory
- createApplicationContext() - Method in class org.springframework.batch.core.configuration.support.AbstractApplicationContextFactory
-
Creates an
ApplicationContext
from the provided path. - createApplicationContext() - Method in interface org.springframework.batch.core.configuration.support.ApplicationContextFactory
- createApplicationContext(ConfigurableApplicationContext, Object...) - Method in class org.springframework.batch.core.configuration.support.AbstractApplicationContextFactory
- createApplicationContext(ConfigurableApplicationContext, Object...) - Method in class org.springframework.batch.core.configuration.support.GenericApplicationContextFactory
- createBinder(Object) - Method in class org.springframework.batch.item.file.mapping.BeanWrapperFieldSetMapper
-
Create a binder for the target object.
- createBuilder(String) - Method in class org.springframework.batch.core.step.factory.FaultTolerantStepFactoryBean
- createBuilder(String) - Method in class org.springframework.batch.core.step.factory.SimpleStepFactoryBean
- createChunkOperations() - Method in class org.springframework.batch.core.step.builder.SimpleStepBuilder
- createChunkProcessor() - Method in class org.springframework.batch.core.step.builder.FaultTolerantStepBuilder
- createChunkProvider() - Method in class org.springframework.batch.core.step.builder.FaultTolerantStepBuilder
- createContextCustomizer(Class<?>, List<ContextConfigurationAttributes>) - Method in class org.springframework.batch.test.context.BatchTestContextCustomizerFactory
- createCounter(MeterRegistry, String, String, Tag...) - Static method in class org.springframework.batch.core.observability.BatchMetrics
-
Create a
Counter
. - createEndStateTransition(State) - Static method in class org.springframework.batch.core.job.flow.support.StateTransition
-
Create a new end state
StateTransition
specification. - createEndStateTransition(State, String) - Static method in class org.springframework.batch.core.job.flow.support.StateTransition
-
Create a new end state
StateTransition
specification. - createExecutionContextDao() - Method in class org.springframework.batch.core.explore.support.AbstractJobExplorerFactoryBean
-
Creates an execution context instance data access object (DAO).
- createExecutionContextDao() - Method in class org.springframework.batch.core.explore.support.JobExplorerFactoryBean
- createExecutionContextDao() - Method in class org.springframework.batch.core.repository.support.AbstractJobRepositoryFactoryBean
- createExecutionContextDao() - Method in class org.springframework.batch.core.repository.support.JobRepositoryFactoryBean
- createFaultTolerantStep() - Method in class org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
-
Creates a fault tolerant
Step
. - createFlowStep() - Method in class org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
-
Create a new
FlowStep
. - 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
-
Create a new instance of
Job
. - createJob() - Method in class org.springframework.batch.core.configuration.support.ApplicationContextJobFactory
-
Create an
ApplicationContext
from the factory provided and pull out a bean with the name given during initialization. - createJob() - Method in class org.springframework.batch.core.configuration.support.ReferenceJobFactory
-
Return the instance that was passed in on initialization.
- createJobExecution() - 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, JobParameters) - Static method in class org.springframework.batch.test.MetaDataInstanceFactory
-
Create a
JobExecution
with the parameters provided. - createJobExecution(String, JobParameters) - Method in interface org.springframework.batch.core.repository.JobRepository
- createJobExecution(String, JobParameters) - Method in class org.springframework.batch.core.repository.support.SimpleJobRepository
- createJobExecutionDao() - Method in class org.springframework.batch.core.explore.support.AbstractJobExplorerFactoryBean
-
Creates a job execution data access object (DAO).
- createJobExecutionDao() - Method in class org.springframework.batch.core.explore.support.JobExplorerFactoryBean
- createJobExecutionDao() - Method in class org.springframework.batch.core.repository.support.AbstractJobRepositoryFactoryBean
- createJobExecutionDao() - Method in class org.springframework.batch.core.repository.support.JobRepositoryFactoryBean
- createJobExecutions(int) - Method in class org.springframework.batch.test.JobRepositoryTestUtils
-
Use the
JobRepository
to create someJobExecution
instances each with a single step execution. - createJobExecutions(String, String[], int) - Method in class org.springframework.batch.test.JobRepositoryTestUtils
-
Use the
JobRepository
to create someJobExecution
instances each with the given job name and each having step executions with the given step names. - 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() - Static method in class org.springframework.batch.test.MetaDataInstanceFactory
-
Create a
JobInstance
with default parameters. - createJobInstance(String, Long) - Static method in class org.springframework.batch.test.MetaDataInstanceFactory
-
Create a
JobInstance
with the parameters provided. - createJobInstance(String, JobParameters) - Method in class org.springframework.batch.core.repository.dao.JdbcJobInstanceDao
-
In this JDBC implementation a job instance id is obtained by asking the jobInstanceIncrementer (which is likely a sequence) for the next long value, and then passing the Id and parameter values into an INSERT statement.
- createJobInstance(String, JobParameters) - Method in interface org.springframework.batch.core.repository.dao.JobInstanceDao
-
Create a JobInstance with given name and parameters.
- createJobInstance(String, JobParameters) - Method in interface org.springframework.batch.core.repository.JobRepository
-
Create a new
JobInstance
with the name and job parameters provided. - createJobInstance(String, JobParameters) - Method in class org.springframework.batch.core.repository.support.SimpleJobRepository
- createJobInstanceDao() - Method in class org.springframework.batch.core.explore.support.AbstractJobExplorerFactoryBean
-
Creates a job instance data access object (DAO).
- createJobInstanceDao() - Method in class org.springframework.batch.core.explore.support.JobExplorerFactoryBean
- createJobInstanceDao() - Method in class org.springframework.batch.core.repository.support.AbstractJobRepositoryFactoryBean
- createJobInstanceDao() - Method in class org.springframework.batch.core.repository.support.JobRepositoryFactoryBean
- createLongTaskTimer(MeterRegistry, String, String, Tag...) - Static method in class org.springframework.batch.core.observability.BatchMetrics
-
Create a new
LongTaskTimer
. - createNewContext(E) - Method in class org.springframework.batch.core.scope.context.SynchronizationManagerSupport
- createNewFile(File) - Static method in class org.springframework.batch.item.util.FileUtils
-
Create a new file if it doesn't already exist.
- createNewStepState(State, String, String) - Method in class org.springframework.batch.core.configuration.xml.SimpleFlowFactoryBean
-
Provides an extension point to provide alternative
StepState
implementations within aSimpleFlow
. - createObservation(String, BatchJobContext, ObservationRegistry) - Static method in class org.springframework.batch.core.observability.BatchMetrics
-
Create a new
Observation
. - createObservation(String, BatchStepContext, ObservationRegistry) - Static method in class org.springframework.batch.core.observability.BatchMetrics
-
Create a new
Observation
. - createPartitionStep() - Method in class org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
-
Create a partition
Step
. - createQuery() - Method in class org.springframework.batch.item.database.orm.JpaNamedQueryProvider
- createQuery() - Method in class org.springframework.batch.item.database.orm.JpaNativeQueryProvider
- createQuery() - Method in interface org.springframework.batch.item.database.orm.JpaQueryProvider
-
Create the query object.
- createRetryOperations() - Method in class org.springframework.batch.core.step.builder.FaultTolerantStepBuilder
- createScopedProxy(String, BeanDefinition, BeanDefinitionRegistry, boolean) - Static method in class org.springframework.batch.core.scope.BatchScopeSupport
-
Wrap a target bean definition in a proxy that defers initialization until after the
StepContext
is available. - createSemaphore() - Method in class org.springframework.batch.core.step.tasklet.TaskletStep
-
Extension point mainly for test purposes so that the behaviour of the lock can be manipulated to simulate various pathologies.
- createSimpleStep() - Method in class org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
-
Creates a new
TaskletStep
. - createSkipPolicy() - Method in class org.springframework.batch.core.step.builder.FaultTolerantStepBuilder
- createSqlParameterSource(T) - Method in class org.springframework.batch.item.database.BeanPropertyItemSqlParameterSourceProvider
-
Provide parameter values in an
BeanPropertySqlParameterSource
based on values from the provided item. - createSqlParameterSource(T) - Method in interface org.springframework.batch.item.database.ItemSqlParameterSourceProvider
-
Provide parameter values in an
SqlParameterSource
based on values from the provided item. - createState(List<?>) - Static method in class org.springframework.batch.core.step.item.BatchRetryTemplate
- createState(List<?>, Classifier<? super Throwable, Boolean>) - Static method in class org.springframework.batch.core.step.item.BatchRetryTemplate
- createStateTransition(State, String) - Static method in class org.springframework.batch.core.job.flow.support.StateTransition
-
Create a new state
StateTransition
specification with a wildcard pattern that matches all outcomes. - createStateTransition(State, String, String) - Static method in class org.springframework.batch.core.job.flow.support.StateTransition
-
Create a new
StateTransition
specification from oneState
to another (by name). - createStaxResult() - Method in class org.springframework.batch.item.xml.StaxEventItemWriter
-
Subclasses can override to customize the STAX result.
- createStepContribution() - Method in class org.springframework.batch.core.StepExecution
-
Factory method for
StepContribution
. - createStepContribution() - Method in class org.springframework.batch.integration.chunk.ChunkMessageChannelItemWriter.LocalState
- createStepExecution() - Static method in class org.springframework.batch.test.MetaDataInstanceFactory
-
Create a
StepExecution
with default parameters. - createStepExecution(String) - Method in class org.springframework.batch.core.JobExecution
-
Register a step execution with the current job execution.
- createStepExecution(String, Long) - Static method in class org.springframework.batch.test.MetaDataInstanceFactory
-
Create a
StepExecution
with the parameters provided. - createStepExecution(JobExecution, String, Long) - Static method in class org.springframework.batch.test.MetaDataInstanceFactory
-
Create a
StepExecution
with the parameters provided. - createStepExecution(JobParameters) - Static method in class org.springframework.batch.test.MetaDataInstanceFactory
-
Create a
StepExecution
and all its parent entities with default values, but using theJobParameters
provided. - createStepExecution(JobParameters, ExecutionContext) - Static method in class org.springframework.batch.test.MetaDataInstanceFactory
-
Create a
StepExecution
and all its parent entities with default values, but using theExecutionContext
andJobParameters
provided. - createStepExecution(ExecutionContext) - Static method in class org.springframework.batch.test.MetaDataInstanceFactory
-
Create a
StepExecution
and all its parent entities with default values, but using theExecutionContext
provided. - createStepExecutionDao() - Method in class org.springframework.batch.core.explore.support.AbstractJobExplorerFactoryBean
-
Creates a step execution data access object (DAO).
- createStepExecutionDao() - Method in class org.springframework.batch.core.explore.support.JobExplorerFactoryBean
- createStepExecutionDao() - Method in class org.springframework.batch.core.repository.support.AbstractJobRepositoryFactoryBean
- createStepExecutionDao() - Method in class org.springframework.batch.core.repository.support.JobRepositoryFactoryBean
- createTask(Step, StepExecution) - Method in class org.springframework.batch.core.partition.support.TaskExecutorPartitionHandler
-
Creates the task executing the given step in the context of the given execution.
- createTasklet() - Method in class org.springframework.batch.core.step.builder.AbstractTaskletStepBuilder
- createTasklet() - Method in class org.springframework.batch.core.step.builder.FaultTolerantStepBuilder
-
Create a new chunk oriented tasklet with reader, writer and processor as provided.
- createTasklet() - Method in class org.springframework.batch.core.step.builder.SimpleStepBuilder
- createTasklet() - Method in class org.springframework.batch.core.step.builder.TaskletStepBuilder
- createTaskletStep() - Method in class org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
-
Create a new
TaskletStep
. - createTimer(MeterRegistry, String, String, Tag...) - Static method in class org.springframework.batch.core.observability.BatchMetrics
-
Create a
Timer
. - createTimerSample(MeterRegistry) - Static method in class org.springframework.batch.core.observability.BatchMetrics
-
Create a new
Timer.Sample
. - createTransactionalList() - Static method in class org.springframework.batch.support.transaction.TransactionAwareProxyFactory
- createTransactionalList(List<T>) - Static method in class org.springframework.batch.support.transaction.TransactionAwareProxyFactory
- createTransactionalMap() - Static method in class org.springframework.batch.support.transaction.TransactionAwareProxyFactory
- createTransactionalMap(Map<K, V>) - Static method in class org.springframework.batch.support.transaction.TransactionAwareProxyFactory
- createTransactionalSet() - Static method in class org.springframework.batch.support.transaction.TransactionAwareProxyFactory
- createTransactionalSet(Set<T>) - Static method in class org.springframework.batch.support.transaction.TransactionAwareProxyFactory
- createTransition(FlowExecutionStatus, String, String, String, BeanDefinition, ParserContext, boolean) - Static method in class org.springframework.batch.core.configuration.xml.AbstractFlowParser
- createXmlEventFactory() - Method in class org.springframework.batch.item.xml.StaxEventItemWriter
-
Subclasses can override to customize the event factory.
- createXmlEventWriter(XMLOutputFactory, Writer) - Method in class org.springframework.batch.item.xml.StaxEventItemWriter
-
Subclasses can override to customize the writer.
- createXmlOutputFactory() - Method in class org.springframework.batch.item.xml.StaxEventItemWriter
-
Subclasses can override to customize the factory.
- currentItemCount - Variable in class org.springframework.batch.item.data.builder.MongoItemReaderBuilder
-
Deprecated.
- currentItemCount(int) - Method in class org.springframework.batch.item.avro.builder.AvroItemReaderBuilder
-
Index for the current item.
- currentItemCount(int) - Method in class org.springframework.batch.item.data.builder.MongoCursorItemReaderBuilder
-
Index for the current item.
- currentItemCount(int) - Method in class org.springframework.batch.item.data.builder.MongoItemReaderBuilder
-
Deprecated.Index for the current item.
- currentItemCount(int) - Method in class org.springframework.batch.item.data.builder.MongoPagingItemReaderBuilder
-
Index for the current item.
- currentItemCount(int) - Method in class org.springframework.batch.item.data.builder.Neo4jItemReaderBuilder
-
Deprecated.Index for the current item.
- currentItemCount(int) - Method in class org.springframework.batch.item.data.builder.RepositoryItemReaderBuilder
-
Index for the current item.
- currentItemCount(int) - Method in class org.springframework.batch.item.database.builder.JdbcCursorItemReaderBuilder
-
Index for the current item.
- currentItemCount(int) - Method in class org.springframework.batch.item.database.builder.JdbcPagingItemReaderBuilder
-
Index for the current item.
- currentItemCount(int) - Method in class org.springframework.batch.item.database.builder.JpaCursorItemReaderBuilder
-
Index for the current item.
- currentItemCount(int) - Method in class org.springframework.batch.item.database.builder.JpaPagingItemReaderBuilder
-
Index for the current item.
- currentItemCount(int) - Method in class org.springframework.batch.item.database.builder.StoredProcedureItemReaderBuilder
-
Index for the current item.
- currentItemCount(int) - Method in class org.springframework.batch.item.file.builder.FlatFileItemReaderBuilder
-
Index for the current item.
- currentItemCount(int) - Method in class org.springframework.batch.item.json.builder.JsonItemReaderBuilder
-
Index for the current item.
- currentItemCount(int) - Method in class org.springframework.batch.item.ldif.builder.LdifReaderBuilder
-
Index for the current item.
- currentItemCount(int) - Method in class org.springframework.batch.item.ldif.builder.MappingLdifReaderBuilder
-
Index for the current item.
- currentItemCount(int) - Method in class org.springframework.batch.item.xml.builder.StaxEventItemReaderBuilder
-
Index for the current item.
- customEditors(Map<Class<?>, PropertyEditor>) - Method in class org.springframework.batch.item.file.builder.FlatFileItemReaderBuilder
-
Register custom type converters for beans being mapped.
- customizeContext(ConfigurableApplicationContext, MergedContextConfiguration) - Method in class org.springframework.batch.test.context.BatchTestContextCustomizer
D
- databaseType() - Element in annotation interface org.springframework.batch.core.configuration.annotation.EnableBatchProcessing
-
Set the type of the data source to use in the job repository.
- DatabaseType - Enum Class in org.springframework.batch.support
-
Enum representing a database type, such as DB2 or oracle.
- DataFieldMaxValueIncrementerFactory - Interface in org.springframework.batch.item.database.support
-
Factory for creating
DataFieldMaxValueIncrementer
implementations based upon a provided string. - DataFieldMaxValueJobParametersIncrementer - Class in org.springframework.batch.core.launch.support
-
This incrementer uses a
DataFieldMaxValueIncrementer
to generate the sequence of values to use as job instance discriminator. - DataFieldMaxValueJobParametersIncrementer(DataFieldMaxValueIncrementer) - Constructor for class org.springframework.batch.core.launch.support.DataFieldMaxValueJobParametersIncrementer
-
Create a new
DataFieldMaxValueJobParametersIncrementer
. - dataRowMapper(Class<T>) - Method in class org.springframework.batch.item.database.builder.JdbcCursorItemReaderBuilder
-
Creates a
DataClassRowMapper
to be used as yourRowMapper
. - dataRowMapper(Class<T>) - Method in class org.springframework.batch.item.database.builder.JdbcPagingItemReaderBuilder
-
Creates a
DataClassRowMapper
to be used as yourRowMapper
. - dataSource - Variable in class org.springframework.batch.item.database.builder.JdbcPagingItemReaderBuilder
- dataSource(DataSource) - Method in class org.springframework.batch.item.database.builder.JdbcBatchItemWriterBuilder
-
Configure the
DataSource
to be used. - dataSource(DataSource) - Method in class org.springframework.batch.item.database.builder.JdbcCursorItemReaderBuilder
-
The
DataSource
to read from - dataSource(DataSource) - Method in class org.springframework.batch.item.database.builder.JdbcPagingItemReaderBuilder
-
The
DataSource
to query against. - dataSource(DataSource) - Method in class org.springframework.batch.item.database.builder.StoredProcedureItemReaderBuilder
-
The
DataSource
to read from - dataSourceRef() - Element in annotation interface org.springframework.batch.core.configuration.annotation.EnableBatchProcessing
-
Set the data source to use in the job repository and job explorer.
- DateToStringConverter - Class in org.springframework.batch.core.converter
- DateToStringConverter() - Constructor for class org.springframework.batch.core.converter.DateToStringConverter
- DB2 - Enum constant in enum class org.springframework.batch.support.DatabaseType
- DB2AS400 - Enum constant in enum class org.springframework.batch.support.DatabaseType
- 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
- DB2VSE - Enum constant in enum class org.springframework.batch.support.DatabaseType
- DB2ZOS - Enum constant in enum class org.springframework.batch.support.DatabaseType
- DEBUG - Enum constant in enum class org.springframework.batch.repeat.exception.LogOrRethrowExceptionHandler.Level
-
Key for
Classifier
signalling that the throwable should be logged at debug level. - decide(JobExecution, StepExecution) - Method in interface org.springframework.batch.core.job.flow.JobExecutionDecider
-
Strategy for branching an execution based on the state of an ongoing
JobExecution
. - DECISION_ELE - Static variable in class org.springframework.batch.core.configuration.xml.AbstractFlowParser
-
Establishes a Decision element.
- DecisionParser - Class in org.springframework.batch.core.configuration.xml
-
Internal parser for the <decision/> elements inside a job.
- DecisionParser() - Constructor for class org.springframework.batch.core.configuration.xml.DecisionParser
- DecisionState - Class in org.springframework.batch.core.job.flow.support.state
-
State that requires a decider to make the status decision.
- DecisionState(JobExecutionDecider, String) - Constructor for class org.springframework.batch.core.job.flow.support.state.DecisionState
- decode(String) - Method in class org.springframework.batch.core.converter.DefaultJobParametersConverter
-
Decode a job parameter from a string.
- decode(String) - Method in class org.springframework.batch.core.converter.JsonJobParametersConverter
- DEFAULT_CHARSET - Static variable in class org.springframework.batch.item.file.FlatFileItemReader
- DEFAULT_CHARSET - Static variable in class org.springframework.batch.item.support.AbstractFileItemWriter
- DEFAULT_CHUNK_SIZE - Static variable in class org.springframework.batch.repeat.policy.SimpleCompletionPolicy
- DEFAULT_COMMENT_PREFIXES - Static variable in class org.springframework.batch.item.file.FlatFileItemReader
- DEFAULT_ENCODING - Static variable in class org.springframework.batch.item.xml.StaxEventItemReader
- DEFAULT_ENCODING - Static variable in class org.springframework.batch.item.xml.StaxEventItemWriter
- DEFAULT_EXIT_MESSAGE_LENGTH - Static variable in class org.springframework.batch.core.repository.dao.AbstractJdbcBatchMetadataDao
- DEFAULT_JOB_EXECUTION_ID - Static variable in class org.springframework.batch.test.MetaDataInstanceFactory
-
The default id for a job execution (123L)
- DEFAULT_JOB_INSTANCE_ID - Static variable in class org.springframework.batch.test.MetaDataInstanceFactory
-
The default id for a job instance (12L)
- DEFAULT_JOB_NAME - Static variable in class org.springframework.batch.test.MetaDataInstanceFactory
-
The default name for a job ("job")
- DEFAULT_KEY - Static variable in class org.springframework.batch.core.launch.support.DataFieldMaxValueJobParametersIncrementer
-
Default key used as a job parameter.
- DEFAULT_LINE_SEPARATOR - Static variable in class org.springframework.batch.item.support.AbstractFileItemWriter
- DEFAULT_MAX_SKIPS_ON_READ - Static variable in class org.springframework.batch.core.step.item.FaultTolerantChunkProvider
-
Hard limit for number of read skips in the same chunk.
- DEFAULT_MAX_WAIT_TIMEOUTS - Variable in class org.springframework.batch.integration.chunk.ChunkMessageChannelItemWriter
- DEFAULT_QUOTE_CHARACTER - Static variable in class org.springframework.batch.item.file.transform.DelimitedLineTokenizer
-
Convenient constant for the common case of a " character used to escape delimiters or line endings.
- DEFAULT_ROOT_TAG_NAME - Static variable in class org.springframework.batch.item.xml.StaxEventItemWriter
- DEFAULT_SHORT_CONTEXT_LENGTH - Static variable in class org.springframework.batch.core.repository.dao.AbstractJdbcBatchMetadataDao
- DEFAULT_STANDALONE_DOCUMENT - Static variable in class org.springframework.batch.item.xml.StaxEventItemWriter
- DEFAULT_STEP_EXECUTION_ID - Static variable in class org.springframework.batch.test.MetaDataInstanceFactory
-
The default id for a step execution (1234L)
- DEFAULT_STEP_NAME - Static variable in class org.springframework.batch.test.MetaDataInstanceFactory
-
The default name for a step ("step")
- DEFAULT_SUFFIX - Static variable in class org.springframework.batch.item.file.separator.SuffixRecordSeparatorPolicy
-
Default value for record terminator suffix.
- DEFAULT_TABLE_PREFIX - Static variable in class org.springframework.batch.core.repository.dao.AbstractJdbcBatchMetadataDao
-
Default value for the table prefix property.
- DEFAULT_THROTTLE_LIMIT - Static variable in class org.springframework.batch.integration.chunk.ChunkMessageChannelItemWriter
- DEFAULT_THROTTLE_LIMIT - Static variable in class org.springframework.batch.repeat.support.TaskExecutorRepeatTemplate
-
Default limit for maximum number of concurrent unfinished results allowed by the template.
- DEFAULT_TIMEOUT - Static variable in class org.springframework.batch.repeat.policy.TimeoutTerminationPolicy
-
Default timeout value in milliseconds (the value equivalent to 30 seconds).
- DEFAULT_TRANSACTIONAL - Static variable in class org.springframework.batch.item.support.AbstractFileItemWriter
- DEFAULT_XML_VERSION - Static variable in class org.springframework.batch.item.xml.StaxEventItemWriter
- DefaultBatchConfiguration - Class in org.springframework.batch.core.configuration.support
-
Base
Configuration
class that provides common JDBC-based infrastructure beans for enabling and using Spring Batch. - DefaultBatchConfiguration() - Constructor for class org.springframework.batch.core.configuration.support.DefaultBatchConfiguration
- DefaultBatchJobObservationConvention - Class in org.springframework.batch.core.observability
-
Default
BatchJobObservationConvention
implementation. - DefaultBatchJobObservationConvention() - Constructor for class org.springframework.batch.core.observability.DefaultBatchJobObservationConvention
- DefaultBatchStepObservationConvention - Class in org.springframework.batch.core.observability
-
Default
BatchStepObservationConvention
implementation. - DefaultBatchStepObservationConvention() - Constructor for class org.springframework.batch.core.observability.DefaultBatchStepObservationConvention
- DefaultBufferedReaderFactory - Class in org.springframework.batch.item.file
- DefaultBufferedReaderFactory() - Constructor for class org.springframework.batch.item.file.DefaultBufferedReaderFactory
- DefaultDataFieldMaxValueIncrementerFactory - Class in org.springframework.batch.item.database.support
-
Default implementation of the
DataFieldMaxValueIncrementerFactory
interface. - DefaultDataFieldMaxValueIncrementerFactory(DataSource) - Constructor for class org.springframework.batch.item.database.support.DefaultDataFieldMaxValueIncrementerFactory
- DefaultExceptionHandler - Class in org.springframework.batch.repeat.exception
-
Default implementation of
ExceptionHandler
- just re-throws the exception it encounters. - DefaultExceptionHandler() - Constructor for class org.springframework.batch.repeat.exception.DefaultExceptionHandler
- DefaultExecutionContextSerializer - Class in org.springframework.batch.core.repository.dao
-
An implementation of the
ExecutionContextSerializer
that produces/consumes Base64 content. - DefaultExecutionContextSerializer() - Constructor for class org.springframework.batch.core.repository.dao.DefaultExecutionContextSerializer
- DefaultFieldSet - Class in org.springframework.batch.item.file.transform
-
Default implementation of
FieldSet
using Java primitive and standard types and utilities. - DefaultFieldSet(String[]) - Constructor for class org.springframework.batch.item.file.transform.DefaultFieldSet
-
Create a FieldSet with anonymous tokens.
- DefaultFieldSet(String[], String[]) - Constructor for class org.springframework.batch.item.file.transform.DefaultFieldSet
-
Create a FieldSet with named tokens.
- DefaultFieldSet(String[], String[], DateFormat, NumberFormat) - Constructor for class org.springframework.batch.item.file.transform.DefaultFieldSet
-
Create a FieldSet with named tokens.
- DefaultFieldSet(String[], DateFormat, NumberFormat) - Constructor for class org.springframework.batch.item.file.transform.DefaultFieldSet
-
Create a FieldSet with anonymous tokens.
- DefaultFieldSetFactory - Class in org.springframework.batch.item.file.transform
-
Default implementation of
FieldSetFactory
with no special knowledge of theFieldSet
required. - DefaultFieldSetFactory() - Constructor for class org.springframework.batch.item.file.transform.DefaultFieldSetFactory
-
Default constructor.
- DefaultFieldSetFactory(DateFormat, NumberFormat) - Constructor for class org.springframework.batch.item.file.transform.DefaultFieldSetFactory
-
Convenience constructor
- DefaultFragmentEventReader - Class in org.springframework.batch.item.xml.stax
-
Default implementation of
FragmentEventReader
- DefaultFragmentEventReader(XMLEventReader) - Constructor for class org.springframework.batch.item.xml.stax.DefaultFragmentEventReader
-
Caches the StartDocument event for later use.
- DefaultItemFailureHandler - Class in org.springframework.batch.core.step.item
-
Default implementation of the
ItemListenerSupport
class that writes all exceptions via commons logging. - DefaultItemFailureHandler() - Constructor for class org.springframework.batch.core.step.item.DefaultItemFailureHandler
- DefaultJobKeyGenerator - Class in org.springframework.batch.core
-
Default implementation of the
JobKeyGenerator
interface. - DefaultJobKeyGenerator() - Constructor for class org.springframework.batch.core.DefaultJobKeyGenerator
- DefaultJobLoader - Class in org.springframework.batch.core.configuration.support
-
Default implementation of
JobLoader
. - DefaultJobLoader() - Constructor for class org.springframework.batch.core.configuration.support.DefaultJobLoader
-
Default constructor.
- DefaultJobLoader(JobRegistry) - Constructor for class org.springframework.batch.core.configuration.support.DefaultJobLoader
-
Creates a job loader with the job registry provided.
- DefaultJobLoader(JobRegistry, StepRegistry) - Constructor for class org.springframework.batch.core.configuration.support.DefaultJobLoader
-
Creates a job loader with the job and step registries provided.
- DefaultJobParametersConverter - Class in org.springframework.batch.core.converter
-
Converter for
JobParameters
instances that uses a simple naming convention for converting job parameters. - DefaultJobParametersConverter() - Constructor for class org.springframework.batch.core.converter.DefaultJobParametersConverter
- DefaultJobParametersExtractor - Class in org.springframework.batch.core.step.job
-
Simple implementation of
JobParametersExtractor
which pulls parameters with named keys out of the step execution context and the job parameters of the surrounding job. - DefaultJobParametersExtractor() - Constructor for class org.springframework.batch.core.step.job.DefaultJobParametersExtractor
- DefaultJobParametersValidator - Class in org.springframework.batch.core.job
-
Default implementation of
JobParametersValidator
. - DefaultJobParametersValidator() - Constructor for class org.springframework.batch.core.job.DefaultJobParametersValidator
-
Convenient default constructor for unconstrained validation.
- DefaultJobParametersValidator(String[], String[]) - Constructor for class org.springframework.batch.core.job.DefaultJobParametersValidator
-
Create a new validator with the required and optional job parameter keys provided.
- DefaultLineMapper<T> - Class in org.springframework.batch.item.file.mapping
-
Two-phase
LineMapper
implementation consisting of tokenization of the line intoFieldSet
followed by mapping to item. - DefaultLineMapper() - Constructor for class org.springframework.batch.item.file.mapping.DefaultLineMapper
- DefaultMailErrorHandler - Class in org.springframework.batch.item.mail
-
This
MailErrorHandler
implementation simply rethrows the exception it receives. - DefaultMailErrorHandler() - Constructor for class org.springframework.batch.item.mail.DefaultMailErrorHandler
- DefaultPropertyEditorRegistrar - Class in org.springframework.batch.support
-
A re-usable
PropertyEditorRegistrar
that can be used wherever one needs to register customPropertyEditor
instances with aPropertyEditorRegistry
(like a bean wrapper, or a type converter). - DefaultPropertyEditorRegistrar() - Constructor for class org.springframework.batch.support.DefaultPropertyEditorRegistrar
- DefaultRecordSeparatorPolicy - Class in org.springframework.batch.item.file.separator
-
A
RecordSeparatorPolicy
that treats all lines as record endings, as long as they do not have unterminated quotes, and do not end in a continuation marker. - DefaultRecordSeparatorPolicy() - Constructor for class org.springframework.batch.item.file.separator.DefaultRecordSeparatorPolicy
-
Default constructor.
- DefaultRecordSeparatorPolicy(String) - Constructor for class org.springframework.batch.item.file.separator.DefaultRecordSeparatorPolicy
-
Convenient constructor with quote character as parameter.
- DefaultRecordSeparatorPolicy(String, String) - Constructor for class org.springframework.batch.item.file.separator.DefaultRecordSeparatorPolicy
-
Convenient constructor with quote character and continuation marker as parameters.
- DefaultResultCompletionPolicy - Class in org.springframework.batch.repeat.policy
-
Very simple
CompletionPolicy
that bases its decision on the result of a batch operation. - DefaultResultCompletionPolicy() - Constructor for class org.springframework.batch.repeat.policy.DefaultResultCompletionPolicy
- DefaultStateTransitionComparator - Class in org.springframework.batch.core.job.flow.support
-
Sorts by descending specificity of pattern, based on counting wildcards (with ?
- DefaultStateTransitionComparator() - Constructor for class org.springframework.batch.core.job.flow.support.DefaultStateTransitionComparator
- DefaultStepExecutionAggregator - Class in org.springframework.batch.core.partition.support
-
Convenience class for aggregating a set of
StepExecution
instances into a single result. - DefaultStepExecutionAggregator() - Constructor for class org.springframework.batch.core.partition.support.DefaultStepExecutionAggregator
- delegate(ResourceAwareItemReaderItemStream<? extends T>) - Method in class org.springframework.batch.item.file.builder.MultiResourceItemReaderBuilder
-
Establishes the delegate to use for reading the resources provided.
- delegate(ResourceAwareItemWriterItemStream<? super T>) - Method in class org.springframework.batch.item.file.builder.MultiResourceItemWriterBuilder
-
Delegate used for actual writing of the output.
- delegate(ItemReader<T>) - Method in class org.springframework.batch.item.support.builder.SingleItemPeekableItemReaderBuilder
-
The item reader to use as a delegate.
- delegate(ItemReader<T>) - Method in class org.springframework.batch.item.support.builder.SynchronizedItemReaderBuilder
-
The item reader to use as a delegate.
- delegate(ItemStreamReader<T>) - Method in class org.springframework.batch.item.support.builder.SynchronizedItemStreamReaderBuilder
-
The item stream reader to use as a delegate.
- delegate(ItemStreamWriter<T>) - Method in class org.springframework.batch.item.support.builder.SynchronizedItemStreamWriterBuilder
-
Set the delegate
ItemStreamWriter
. - delegate(ItemWriter<T>) - Method in class org.springframework.batch.item.support.builder.SynchronizedItemWriterBuilder
-
The item writer to use as a delegate.
- delegates(List<? extends ItemProcessor<?, ?>>) - Method in class org.springframework.batch.item.support.builder.CompositeItemProcessorBuilder
-
Establishes the
ItemProcessor
delegates that will work on the item to be processed. - delegates(List<ItemWriter<? super T>>) - Method in class org.springframework.batch.item.support.builder.CompositeItemWriterBuilder
-
The list of item writers to use as delegates.
- delegates(ItemProcessor<?, ?>...) - Method in class org.springframework.batch.item.support.builder.CompositeItemProcessorBuilder
-
Establishes the
ItemProcessor
delegates that will work on the item to be processed. - delegates(ItemWriter<? super T>...) - Method in class org.springframework.batch.item.support.builder.CompositeItemWriterBuilder
-
The item writers to use as delegates.
- delete - Variable in class org.springframework.batch.item.KeyValueItemWriter
- delete(boolean) - Method in class org.springframework.batch.item.data.builder.MongoItemWriterBuilder
-
Deprecated, for removal: This API element is subject to removal in a future version.Use
MongoItemWriterBuilder.mode(Mode)
instead. Scheduled for removal in v5.3 or later. - delete(boolean) - Method in class org.springframework.batch.item.data.builder.Neo4jItemWriterBuilder
-
Deprecated.Boolean flag indicating whether the writer should save or delete the item at write time.
- delete(boolean) - Method in class org.springframework.batch.item.kafka.builder.KafkaItemWriterBuilder
-
Indicate if the items being passed to the writer are all to be sent as delete events to the topic.
- delete(boolean) - Method in class org.springframework.batch.item.redis.builder.RedisItemWriterBuilder
-
Indicate if the items being passed to the writer should be deleted.
- deleteExecutionContext(JobExecution) - Method in interface org.springframework.batch.core.repository.dao.ExecutionContextDao
-
Delete the execution context of the given
JobExecution
. - deleteExecutionContext(JobExecution) - Method in class org.springframework.batch.core.repository.dao.JdbcExecutionContextDao
-
Delete the execution context of the given
JobExecution
. - deleteExecutionContext(StepExecution) - Method in interface org.springframework.batch.core.repository.dao.ExecutionContextDao
-
Delete the execution context of the given
StepExecution
. - deleteExecutionContext(StepExecution) - Method in class org.springframework.batch.core.repository.dao.JdbcExecutionContextDao
-
Delete the execution context of the given
StepExecution
. - deleteJobExecution(JobExecution) - Method in class org.springframework.batch.core.repository.dao.JdbcJobExecutionDao
-
Delete the given job execution.
- deleteJobExecution(JobExecution) - Method in interface org.springframework.batch.core.repository.dao.JobExecutionDao
-
Delete the given job execution.
- deleteJobExecution(JobExecution) - Method in interface org.springframework.batch.core.repository.JobRepository
-
Delete the job execution object graph (ie the job execution with its execution context, all related step executions and their executions contexts, as well as associated job parameters)
- deleteJobExecution(JobExecution) - Method in class org.springframework.batch.core.repository.support.SimpleJobRepository
- deleteJobExecutionParameters(JobExecution) - Method in class org.springframework.batch.core.repository.dao.JdbcJobExecutionDao
-
Delete the parameters associated with the given job execution.
- deleteJobExecutionParameters(JobExecution) - Method in interface org.springframework.batch.core.repository.dao.JobExecutionDao
-
Delete the parameters associated with the given job execution.
- deleteJobInstance(JobInstance) - Method in class org.springframework.batch.core.repository.dao.JdbcJobInstanceDao
-
Delete the job instance.
- deleteJobInstance(JobInstance) - Method in interface org.springframework.batch.core.repository.dao.JobInstanceDao
-
Delete the job instance.
- deleteJobInstance(JobInstance) - Method in interface org.springframework.batch.core.repository.JobRepository
-
Delete the job instance object graph (ie the job instance with all associated job executions along with their respective object graphs as specified in
JobRepository.deleteJobExecution(JobExecution)
). - deleteJobInstance(JobInstance) - Method in class org.springframework.batch.core.repository.support.SimpleJobRepository
- deleteStepExecution(StepExecution) - Method in class org.springframework.batch.core.repository.dao.JdbcStepExecutionDao
-
Delete the given step execution.
- deleteStepExecution(StepExecution) - Method in interface org.springframework.batch.core.repository.dao.StepExecutionDao
-
Delete the given step execution.
- deleteStepExecution(StepExecution) - Method in interface org.springframework.batch.core.repository.JobRepository
-
Delete the step execution along with its execution context.
- deleteStepExecution(StepExecution) - Method in class org.springframework.batch.core.repository.support.SimpleJobRepository
- delimited() - Method in class org.springframework.batch.item.file.builder.FlatFileItemReaderBuilder
-
Returns an instance of a
FlatFileItemReaderBuilder.DelimitedBuilder
for building aDelimitedLineTokenizer
. - delimited() - Method in class org.springframework.batch.item.file.builder.FlatFileItemWriterBuilder
-
Returns an instance of a
FlatFileItemWriterBuilder.DelimitedBuilder
for building aDelimitedLineAggregator
. - DelimitedBuilder(FlatFileItemReaderBuilder<T>) - Constructor for class org.springframework.batch.item.file.builder.FlatFileItemReaderBuilder.DelimitedBuilder
- DelimitedBuilder(FlatFileItemWriterBuilder<T>) - Constructor for class org.springframework.batch.item.file.builder.FlatFileItemWriterBuilder.DelimitedBuilder
- DelimitedLineAggregator<T> - Class in org.springframework.batch.item.file.transform
-
A
LineAggregator
implementation that converts an object into a delimited list of strings. - DelimitedLineAggregator() - Constructor for class org.springframework.batch.item.file.transform.DelimitedLineAggregator
- DelimitedLineTokenizer - Class in org.springframework.batch.item.file.transform
-
A
LineTokenizer
implementation that splits the input String on a configurable delimiter. - DelimitedLineTokenizer() - Constructor for class org.springframework.batch.item.file.transform.DelimitedLineTokenizer
-
Create a new instance of the
DelimitedLineTokenizer
class for the common case where the delimiter is acomma
. - DelimitedLineTokenizer(String) - Constructor for class org.springframework.batch.item.file.transform.DelimitedLineTokenizer
-
Create a new instance of the
DelimitedLineTokenizer
class. - delimiter(String) - Method in class org.springframework.batch.item.file.builder.FlatFileItemReaderBuilder.DelimitedBuilder
-
Define the delimiter for the file.
- delimiter(String) - Method in class org.springframework.batch.item.file.builder.FlatFileItemWriterBuilder.DelimitedBuilder
-
Define the delimiter for the file.
- DELIMITER_COMMA - Static variable in class org.springframework.batch.item.file.transform.DelimitedLineTokenizer
-
Convenient constant for the common case of a comma delimiter.
- DELIMITER_TAB - Static variable in class org.springframework.batch.item.file.transform.DelimitedLineTokenizer
-
Convenient constant for the common case of a tab delimiter.
- DERBY - Enum constant in enum class org.springframework.batch.support.DatabaseType
- 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
- DESCENDING - Enum constant in enum class org.springframework.batch.item.database.Order
- deserialize(InputStream) - Method in class org.springframework.batch.core.repository.dao.DefaultExecutionContextSerializer
-
Deserializes an execution context from the provided
InputStream
. - deserialize(InputStream) - Method in class org.springframework.batch.core.repository.dao.Jackson2ExecutionContextStringSerializer
- destroy() - Method in class org.springframework.batch.core.configuration.support.JobRegistryBeanPostProcessor
-
Deprecated.Unregister all the
Job
instances that were registered by this post processor. - destroy() - Method in class org.springframework.batch.core.configuration.support.JobRegistrySmartInitializingSingleton
-
Unregister all the
Job
instances that were registered by this smart initializing singleton. - detectStreamInReader() - Method in class org.springframework.batch.core.step.builder.FaultTolerantStepBuilder
- determineQueryProvider(DataSource) - Method in class org.springframework.batch.item.database.builder.JdbcPagingItemReaderBuilder
- DirectPoller<S> - Class in org.springframework.batch.poller
-
A
Poller
that uses the callers thread to poll for a result as soon as it is asked for. - DirectPoller(long) - Constructor for class org.springframework.batch.poller.DirectPoller
- distanceLimit(int) - Method in class org.springframework.batch.item.file.builder.FlatFileItemReaderBuilder
-
Configures the maximum tolerance between the actual spelling of a field's name and the property's name.
- doAfterWrite(Chunk<O>) - Method in class org.springframework.batch.core.step.item.SimpleChunkProcessor
-
Call the listener's after write method.
- doAggregate(Object[]) - Method in class org.springframework.batch.item.file.transform.DelimitedLineAggregator
- doAggregate(Object[]) - Method in class org.springframework.batch.item.file.transform.ExtractorLineAggregator
-
Aggregate provided fields into single String.
- doAggregate(Object[]) - Method in class org.springframework.batch.item.file.transform.FormatterLineAggregator
- doAggregation(Collection<FlowExecution>, FlowExecutor) - Method in class org.springframework.batch.core.job.flow.support.state.SplitState
- doBegin(Object, TransactionDefinition) - Method in class org.springframework.batch.support.transaction.ResourcelessTransactionManager
- doCleanupAfterCompletion(Object) - Method in class org.springframework.batch.support.transaction.ResourcelessTransactionManager
- doClose() - Method in class org.springframework.batch.item.avro.AvroItemReader
- doClose() - Method in class org.springframework.batch.item.data.AbstractPaginatedDataItemReader
- doClose() - Method in class org.springframework.batch.item.data.MongoCursorItemReader
- doClose() - Method in class org.springframework.batch.item.data.RepositoryItemReader
- doClose() - Method in class org.springframework.batch.item.database.AbstractCursorItemReader
-
Close the cursor and database connection.
- doClose() - Method in class org.springframework.batch.item.database.AbstractPagingItemReader
- doClose() - Method in class org.springframework.batch.item.database.JpaCursorItemReader
- doClose() - Method in class org.springframework.batch.item.database.JpaPagingItemReader
- doClose() - Method in class org.springframework.batch.item.file.FlatFileItemReader
- doClose() - Method in class org.springframework.batch.item.json.JsonItemReader
- doClose() - Method in class org.springframework.batch.item.ldif.LdifReader
- doClose() - Method in class org.springframework.batch.item.ldif.MappingLdifReader
- doClose() - Method in class org.springframework.batch.item.support.AbstractItemCountingItemStreamItemReader
-
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.job.flow.FlowStep
-
Delegate to the flow provided for the execution of the step.
- doExecute(StepExecution) - Method in class org.springframework.batch.core.partition.support.PartitionStep
-
Delegate execution to the
PartitionHandler
provided. - doExecute(StepExecution) - Method in class org.springframework.batch.core.step.AbstractStep
-
Extension point for subclasses to execute business logic.
- doExecute(StepExecution) - Method in class org.springframework.batch.core.step.job.JobStep
-
Execute the job provided by delegating to the
JobLauncher
to prevent duplicate executions. - doExecute(StepExecution) - Method in class org.springframework.batch.core.step.tasklet.TaskletStep
-
Process the step and update its context so that progress can be monitored by the caller.
- doExecutionRegistration(StepExecution) - Method in class org.springframework.batch.core.step.AbstractStep
-
Registers the
StepExecution
for property resolution viaStepScope
- doExecutionRelease() - Method in class org.springframework.batch.core.step.AbstractStep
-
Releases the most recent
StepExecution
- doGetTransaction() - Method in class org.springframework.batch.support.transaction.ResourcelessTransactionManager
- doHandle(StepExecution, Set<StepExecution>) - Method in class org.springframework.batch.core.partition.support.AbstractPartitionHandler
-
Executes the specified
StepExecution
instances and returns an updated view of them. - doHandle(StepExecution, Set<StepExecution>) - Method in class org.springframework.batch.core.partition.support.TaskExecutorPartitionHandler
- doHandle(StepExecution, Set<StepExecution>) - Method in class org.springframework.batch.integration.partition.MessageChannelPartitionHandler
-
Sends
StepExecutionRequest
objects to the request channel of theMessagingTemplate
, and then receives the result back as a list ofStepExecution
on a reply channel. - 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.
- doInJobScope(JobExecution, Callable<T>) - Static method in class org.springframework.batch.test.JobScopeTestUtils
- doInStepScope(StepExecution, Callable<T>) - Static method in class org.springframework.batch.test.StepScopeTestUtils
- doOnWriteError(Exception, Chunk<O>) - Method in class org.springframework.batch.core.step.item.SimpleChunkProcessor
-
Call listener's writerError method.
- doOpen() - Method in class org.springframework.batch.item.avro.AvroItemReader
- doOpen() - Method in class org.springframework.batch.item.data.AbstractPaginatedDataItemReader
- doOpen() - Method in class org.springframework.batch.item.data.MongoCursorItemReader
- doOpen() - Method in class org.springframework.batch.item.data.RepositoryItemReader
- doOpen() - Method in class org.springframework.batch.item.database.AbstractCursorItemReader
-
Execute the statement to open the cursor.
- doOpen() - Method in class org.springframework.batch.item.database.AbstractPagingItemReader
- doOpen() - Method in class org.springframework.batch.item.database.JpaCursorItemReader
- doOpen() - Method in class org.springframework.batch.item.database.JpaPagingItemReader
- doOpen() - Method in class org.springframework.batch.item.file.FlatFileItemReader
- doOpen() - Method in class org.springframework.batch.item.json.JsonItemReader
- doOpen() - Method in class org.springframework.batch.item.ldif.LdifReader
- doOpen() - Method in class org.springframework.batch.item.ldif.MappingLdifReader
- doOpen() - Method in class org.springframework.batch.item.support.AbstractItemCountingItemStreamItemReader
-
Open resources necessary to start reading input.
- doOpen() - Method in class org.springframework.batch.item.xml.StaxEventItemReader
- doPageRead() - Method in class org.springframework.batch.item.data.AbstractPaginatedDataItemReader
-
Method this
ItemStreamReader
delegates to for the actual work of reading a page. - doPageRead() - Method in class org.springframework.batch.item.data.MongoItemReader
-
Deprecated.
- doPageRead() - Method in class org.springframework.batch.item.data.MongoPagingItemReader
- doPageRead() - Method in class org.springframework.batch.item.data.Neo4jItemReader
-
Deprecated.
- doPageRead() - Method in class org.springframework.batch.item.data.RepositoryItemReader
-
Performs the actual reading of a page via the repository.
- doParse(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.batch.core.configuration.xml.AbstractFlowParser
-
Performs the parsing for a flow definition.
- doParse(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.batch.core.configuration.xml.AbstractListenerParser
- doParse(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.batch.core.configuration.xml.InlineFlowParser
-
Does the parsing.
- doParse(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.batch.core.configuration.xml.JobParser
-
Create a bean definition for a
FlowJob
. - doParse(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.batch.core.configuration.xml.JobRepositoryParser
-
Parse and create a bean definition for a
JobRepositoryFactoryBean
. - doParse(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.batch.core.configuration.xml.TopLevelFlowParser
-
Parse the flow.
- doParse(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.batch.core.configuration.xml.TopLevelJobListenerParser
- doParse(Element, ParserContext, BeanDefinitionBuilder) - Method in class org.springframework.batch.core.configuration.xml.TopLevelStepListenerParser
- doProcess(I) - Method in class org.springframework.batch.core.step.item.SimpleChunkProcessor
- doRead() - Method in class org.springframework.batch.core.step.item.SimpleChunkProvider
-
Surrounds the read call with listener callbacks.
- doRead() - Method in class org.springframework.batch.item.avro.AvroItemReader
- doRead() - Method in class org.springframework.batch.item.data.AbstractPaginatedDataItemReader
- doRead() - Method in class org.springframework.batch.item.data.MongoCursorItemReader
- doRead() - Method in class org.springframework.batch.item.data.RepositoryItemReader
- doRead() - Method in class org.springframework.batch.item.database.AbstractCursorItemReader
-
Read next row and map it to item, verify cursor position if
AbstractCursorItemReader.setVerifyCursorPosition(boolean)
is true. - doRead() - Method in class org.springframework.batch.item.database.AbstractPagingItemReader
- doRead() - Method in class org.springframework.batch.item.database.JpaCursorItemReader
- doRead() - Method in class org.springframework.batch.item.file.FlatFileItemReader
- doRead() - Method in class org.springframework.batch.item.json.JsonItemReader
- doRead() - Method in class org.springframework.batch.item.ldif.LdifReader
- doRead() - Method in class org.springframework.batch.item.ldif.MappingLdifReader
- doRead() - Method in class org.springframework.batch.item.support.AbstractItemCountingItemStreamItemReader
-
Read next item from input.
- doRead() - Method in class org.springframework.batch.item.xml.StaxEventItemReader
-
Move to next fragment and map it to item.
- doReadPage() - Method in class org.springframework.batch.item.database.AbstractPagingItemReader
- doReadPage() - Method in class org.springframework.batch.item.database.JdbcPagingItemReader
- doReadPage() - Method in class org.springframework.batch.item.database.JpaPagingItemReader
- doRollback(DefaultTransactionStatus) - Method in class org.springframework.batch.support.transaction.ResourcelessTransactionManager
- doSetRollbackOnly(DefaultTransactionStatus) - Method in class org.springframework.batch.support.transaction.ResourcelessTransactionManager
- doTokenize(String) - Method in class org.springframework.batch.item.file.transform.AbstractLineTokenizer
- doTokenize(String) - Method in class org.springframework.batch.item.file.transform.DelimitedLineTokenizer
-
Yields the tokens resulting from the splitting of the supplied
line
. - doTokenize(String) - Method in class org.springframework.batch.item.file.transform.FixedLengthTokenizer
-
Yields the tokens resulting from the splitting of the supplied
line
. - doTokenize(String) - Method in class org.springframework.batch.item.file.transform.RegexLineTokenizer
- doUpdate(RepeatContext) - Method in class org.springframework.batch.repeat.policy.CountingCompletionPolicy
-
Extension point for subclasses.
- doWrite(EntityManager, Chunk<? extends T>) - Method in class org.springframework.batch.item.database.JpaItemWriter
-
Do perform the actual write operation.
- doWrite(Chunk<? extends T>) - Method in class org.springframework.batch.item.data.MongoItemWriter
-
Performs the actual write to the store via the template.
- doWrite(Chunk<? extends T>) - Method in class org.springframework.batch.item.data.Neo4jItemWriter
-
Deprecated.Performs the actual write using the template.
- doWrite(Chunk<? extends T>) - Method in class org.springframework.batch.item.data.RepositoryItemWriter
-
Performs the actual write to the repository.
- doWrite(Chunk<? extends T>) - Method in class org.springframework.batch.item.file.FlatFileItemWriter
- doWrite(Chunk<? extends T>) - Method in class org.springframework.batch.item.json.JsonFileItemWriter
- doWrite(Chunk<? extends T>) - Method in class org.springframework.batch.item.support.AbstractFileItemWriter
-
Write out a string of items followed by a "new line", where the format of the new line separator is determined by the underlying operating system.
- doWrite(Chunk<O>) - Method in class org.springframework.batch.core.step.item.SimpleChunkProcessor
-
Surrounds the actual write call with listener callbacks.
- driverSupportsAbsolute(boolean) - Method in class org.springframework.batch.item.database.builder.JdbcCursorItemReaderBuilder
-
Indicates if the JDBC driver supports setting the absolute row on the
ResultSet
. - driverSupportsAbsolute(boolean) - Method in class org.springframework.batch.item.database.builder.StoredProcedureItemReaderBuilder
-
Indicates if the JDBC driver supports setting the absolute row on the
ResultSet
. - DuplicateJobException - Exception in org.springframework.batch.core.configuration
-
Checked exception that indicates a name clash when registering
Job
instances. - DuplicateJobException(String) - Constructor for exception org.springframework.batch.core.configuration.DuplicateJobException
-
Create an exception with the given message.
- DuplicateJobException(String, Throwable) - Constructor for exception org.springframework.batch.core.configuration.DuplicateJobException
-
Create an exception with the given message and the given exception.
- DynamicMethodInvocationException - Exception in org.springframework.batch.item.adapter
-
Indicates an error has been encountered while trying to dynamically invoke a method e.g. using
MethodInvoker
. - DynamicMethodInvocationException(String, Throwable) - Constructor for exception org.springframework.batch.item.adapter.DynamicMethodInvocationException
- DynamicMethodInvocationException(Throwable) - Constructor for exception org.springframework.batch.item.adapter.DynamicMethodInvocationException
E
- ELSE_KEY - Static variable in class org.springframework.batch.core.step.tasklet.ConfigurableSystemProcessExitCodeMapper
- embeddedSchema(boolean) - Method in class org.springframework.batch.item.avro.builder.AvroItemReaderBuilder
-
Disable or enable reading an embedded Avro schema.
- EnableBatchIntegration - Annotation Interface in org.springframework.batch.integration.config.annotation
-
Enable Spring Batch Integration features and provide a base configuration for setting up remote chunking or partitioning infrastructure beans.
- EnableBatchProcessing - Annotation Interface in org.springframework.batch.core.configuration.annotation
-
Enable Spring Batch features and provide a base configuration for setting up batch jobs in an @Configuration class, roughly equivalent to using the
<batch:*>
XML namespace. - encode(JobParameter<?>) - Method in class org.springframework.batch.core.converter.DefaultJobParametersConverter
-
Encode a job parameter to a string.
- encode(JobParameter<?>) - Method in class org.springframework.batch.core.converter.JsonJobParametersConverter
- encoding(String) - Method in class org.springframework.batch.item.file.builder.FlatFileItemReaderBuilder
-
Configure the encoding used by the reader to read the input source.
- encoding(String) - Method in class org.springframework.batch.item.file.builder.FlatFileItemWriterBuilder
-
Encoding used for output.
- encoding(String) - Method in class org.springframework.batch.item.json.builder.JsonFileItemWriterBuilder
-
Encoding used for output.
- encoding(String) - Method in class org.springframework.batch.item.xml.builder.StaxEventItemReaderBuilder
-
Encoding for the input file.
- encoding(String) - Method in class org.springframework.batch.item.xml.builder.StaxEventItemWriterBuilder
-
Encoding for the file.
- end() - Method in class org.springframework.batch.core.job.builder.FlowBuilder
-
A synonym for
FlowBuilder.build()
which callers might find useful. - end() - Method in class org.springframework.batch.core.job.builder.FlowBuilder.TransitionBuilder
-
Signal the successful end of the flow.
- end(String) - Method in class org.springframework.batch.core.job.builder.FlowBuilder.TransitionBuilder
-
Signal the end of the flow with the status provided.
- END_ELE - Static variable in class org.springframework.batch.core.configuration.xml.AbstractFlowParser
-
Establishes an End element.
- endCounter - Static variable in class org.springframework.batch.core.configuration.xml.AbstractFlowParser
-
Used as a suffix to generate unique state names for end transitions.
- endDocument(XMLEventWriter) - Method in class org.springframework.batch.item.xml.StaxEventItemWriter
-
Writes the EndDocument tag manually.
- EndState - Class in org.springframework.batch.core.job.flow.support.state
-
State
implementation for ending a job if it is in progress and continuing if just starting. - EndState(FlowExecutionStatus, String) - Constructor for class org.springframework.batch.core.job.flow.support.state.EndState
- EndState(FlowExecutionStatus, String, String) - Constructor for class org.springframework.batch.core.job.flow.support.state.EndState
- EndState(FlowExecutionStatus, String, String, boolean) - Constructor for class org.springframework.batch.core.job.flow.support.state.EndState
- enhance(AbstractJob) - Method in class org.springframework.batch.core.job.builder.JobBuilderHelper
- enhance(AbstractStep) - Method in class org.springframework.batch.core.step.builder.StepBuilderHelper
- enhanceCommonStep(StepBuilderHelper<?>) - Method in class org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
-
Enhances a step with attributes from the provided
StepBuilderHelper
. - enhanceTaskletStepBuilder(AbstractTaskletStepBuilder<?>) - Method in class org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
-
Set the state of the
AbstractTaskletStepBuilder
using the values that were established for the factory bean. - Entity - Class in org.springframework.batch.core
-
Batch Domain Entity class.
- Entity() - Constructor for class org.springframework.batch.core.Entity
-
Default constructor for
Entity
. - Entity(Long) - Constructor for class org.springframework.batch.core.Entity
-
The constructor for the
Entity
where the ID is established. - entityManagerFactory(EntityManagerFactory) - Method in class org.springframework.batch.item.database.builder.JpaCursorItemReaderBuilder
-
The
EntityManagerFactory
to be used for executing the configuredJpaCursorItemReaderBuilder.queryString
. - entityManagerFactory(EntityManagerFactory) - Method in class org.springframework.batch.item.database.builder.JpaItemWriterBuilder
-
The JPA
EntityManagerFactory
to obtain an entity manager from. - entityManagerFactory(EntityManagerFactory) - Method in class org.springframework.batch.item.database.builder.JpaPagingItemReaderBuilder
-
The
EntityManagerFactory
to be used for executing the configuredJpaPagingItemReaderBuilder.queryString
. - entrySet() - Method in class org.springframework.batch.item.ExecutionContext
-
Returns the entry set containing the contents of this context.
- ENVIRONMENT - Static variable in class org.springframework.batch.support.SystemPropertyInitializer
-
Name of system property used by default.
- equals(Object) - Method in class org.springframework.batch.core.configuration.support.AbstractApplicationContextFactory
- equals(Object) - Method in class org.springframework.batch.core.configuration.support.GroupAwareJob
- equals(Object) - Method in record class org.springframework.batch.core.converter.JsonJobParametersConverter.JobParameterDefinition
-
Indicates whether some other object is "equal to" this one.
- equals(Object) - Method in class org.springframework.batch.core.Entity
-
Attempt to establish identity based on
id
if both exist. - equals(Object) - Method in class org.springframework.batch.core.ExitStatus
-
Compare the fields, one by one.
- equals(Object) - Method in class org.springframework.batch.core.job.flow.FlowExecutionStatus
-
Check the equality of the statuses.
- equals(Object) - Method in class org.springframework.batch.core.job.flow.support.StateTransition
- equals(Object) - Method in class org.springframework.batch.core.JobParameter
- equals(Object) - Method in class org.springframework.batch.core.JobParameters
- equals(Object) - Method in class org.springframework.batch.core.listener.MethodInvokerMethodInterceptor
- equals(Object) - Method in class org.springframework.batch.core.scope.context.JobContext
-
Extend the base class method to include the job execution itself as a key (i.e. two contexts are only equal if their job executions are the same).
- equals(Object) - Method in class org.springframework.batch.core.scope.context.StepContext
-
Extend the base class method to include the step execution itself as a key (i.e.
- equals(Object) - Method in class org.springframework.batch.core.StepContribution
- equals(Object) - Method in class org.springframework.batch.core.StepExecution
- equals(Object) - Method in class org.springframework.batch.item.Chunk
- equals(Object) - Method in class org.springframework.batch.item.ExecutionContext
- equals(Object) - Method in class org.springframework.batch.item.file.transform.DefaultFieldSet
- equals(Object) - Method in class org.springframework.batch.repeat.context.SynchronizedAttributeAccessor
- equals(Object) - Method in class org.springframework.batch.support.SimpleMethodInvoker
- equals(Object) - Method in class org.springframework.batch.test.context.BatchTestContextCustomizer
- ERROR - Enum constant in enum class org.springframework.batch.repeat.exception.LogOrRethrowExceptionHandler.Level
-
Key for
Classifier
signalling that the throwable should be logged at error level. - ExceptionClassifierSkipPolicy - Class in org.springframework.batch.core.step.skip
-
A
SkipPolicy
that depends on an exception classifier to make its decision, and then delegates to the classifier result. - ExceptionClassifierSkipPolicy() - Constructor for class org.springframework.batch.core.step.skip.ExceptionClassifierSkipPolicy
- ExceptionElementParser - Class in org.springframework.batch.core.configuration.xml
- ExceptionElementParser() - Constructor for class org.springframework.batch.core.configuration.xml.ExceptionElementParser
- exceptionHandler(ExceptionHandler) - Method in class org.springframework.batch.core.step.builder.AbstractTaskletStepBuilder
-
Sets the exception handler to use in the case of tasklet failures.
- exceptionHandler(ExceptionHandler) - Method in class org.springframework.batch.integration.chunk.RemoteChunkingManagerStepBuilder
- ExceptionHandler - Interface in org.springframework.batch.repeat.exception
-
Handler to allow strategies for re-throwing exceptions.
- exec(String[], String[], File) - Method in interface org.springframework.batch.core.step.tasklet.CommandRunner
-
Executes the specified string command in a separate process with the specified environment and working directory.
- exec(String[], String[], File) - Method in class org.springframework.batch.core.step.tasklet.JvmCommandRunner
-
Delegate call to
Runtime.exec(java.lang.String)
with the arguments provided. - execute(JobExecution) - Method in class org.springframework.batch.core.configuration.support.GroupAwareJob
- execute(JobExecution) - Method in class org.springframework.batch.core.job.AbstractJob
-
Run the specified job, handling all listener and repository calls, and delegating the actual processing to
AbstractJob.doExecute(JobExecution)
. - execute(JobExecution) - Method in interface org.springframework.batch.core.Job
-
Run the
JobExecution
and update the meta information, such as status and statistics, as necessary. - execute(Job, JobExecution) - Method in class org.springframework.batch.core.scope.context.JobScopeManager
- execute(StepContribution, ChunkContext) - Method in class org.springframework.batch.core.step.item.ChunkOrientedTasklet
- execute(StepContribution, ChunkContext) - Method in class org.springframework.batch.core.step.tasklet.CallableTaskletAdapter
-
Execute the provided Callable and return its
RepeatStatus
. - execute(StepContribution, ChunkContext) - Method in class org.springframework.batch.core.step.tasklet.MethodInvokingTaskletAdapter
-
Delegate execution to the target object and translate the return value to an
ExitStatus
by invoking a method in the delegate POJO. - execute(StepContribution, ChunkContext) - Method in class org.springframework.batch.core.step.tasklet.SystemCommandTasklet
-
Execute system command and map its exit code to
ExitStatus
usingSystemProcessExitCodeMapper
. - execute(StepContribution, ChunkContext) - Method in interface org.springframework.batch.core.step.tasklet.Tasklet
-
Given the current context in the form of a step contribution, do whatever is necessary to process this unit inside a transaction.
- execute(StepExecution) - Method in class org.springframework.batch.core.step.AbstractStep
-
Template method for step execution logic - calls abstract methods for resource initialization (
AbstractStep.open(ExecutionContext)
), execution logic (AbstractStep.doExecute(StepExecution)
) and resource closing (AbstractStep.close(ExecutionContext)
). - execute(StepExecution) - Method in interface org.springframework.batch.core.Step
-
Process the step and assign progress and status meta information to the
StepExecution
provided. - execute(Step, StepExecution) - Method in class org.springframework.batch.core.scope.context.StepScopeManager
- execute(RetryCallback<T, E>) - Method in class org.springframework.batch.core.step.item.BatchRetryTemplate
- execute(RetryCallback<T, E>, Collection<RetryState>) - Method in class org.springframework.batch.core.step.item.BatchRetryTemplate
- execute(RetryCallback<T, E>, RecoveryCallback<T>) - Method in class org.springframework.batch.core.step.item.BatchRetryTemplate
- execute(RetryCallback<T, E>, RecoveryCallback<T>, Collection<RetryState>) - Method in class org.springframework.batch.core.step.item.BatchRetryTemplate
- execute(RetryCallback<T, E>, RecoveryCallback<T>, RetryState) - Method in class org.springframework.batch.core.step.item.BatchRetryTemplate
- execute(RetryCallback<T, E>, RetryState) - Method in class org.springframework.batch.core.step.item.BatchRetryTemplate
- executeAfterInterceptors(RepeatContext, RepeatStatus) - Method in class org.springframework.batch.repeat.support.RepeatTemplate
-
Convenience method to execute after interceptors on a callback result.
- executeStep(Step) - Method in interface org.springframework.batch.core.job.flow.FlowExecutor
- executeStep(Step) - Method in class org.springframework.batch.core.job.flow.JobFlowExecutor
- EXECUTING - Static variable in class org.springframework.batch.core.ExitStatus
-
Convenient constant value representing continuable state where processing is still taking place, so no further action is required.
- ExecutionContext - Class in org.springframework.batch.item
-
Object representing a context for an
ItemStream
. - ExecutionContext() - Constructor for class org.springframework.batch.item.ExecutionContext
-
Default constructor.
- ExecutionContext(Map<String, Object>) - Constructor for class org.springframework.batch.item.ExecutionContext
-
Initializes a new execution context with the contents of another map.
- ExecutionContext(ExecutionContext) - Constructor for class org.springframework.batch.item.ExecutionContext
-
Initializes a new
ExecutionContext
with the contents of anotherExecutionContext
. - ExecutionContextDao - Interface in org.springframework.batch.core.repository.dao
-
DAO interface for persisting and retrieving
ExecutionContext
s. - ExecutionContextPromotionListener - Class in org.springframework.batch.core.listener
-
This class can be used to automatically promote items from the
Step
ExecutionContext
to theJob
ExecutionContext
at the end of a step. - ExecutionContextPromotionListener() - Constructor for class org.springframework.batch.core.listener.ExecutionContextPromotionListener
- ExecutionContextSerializer - Interface in org.springframework.batch.core.repository
-
A composite interface that combines both serialization and deserialization of an execution context into a single implementation.
- executionContextSerializerRef() - Element in annotation interface org.springframework.batch.core.configuration.annotation.EnableBatchProcessing
-
Set the execution context serializer to use in the job repository and job explorer.
- ExecutionContextTestUtils - Class in org.springframework.batch.test
-
Convenience class for accessing
ExecutionContext
values from job and step executions. - ExecutionContextUserSupport - Class in org.springframework.batch.item.util
-
Facilitates assigning names to objects persisting data in
ExecutionContext
and generating keys forExecutionContext
based on the name. - ExecutionContextUserSupport() - Constructor for class org.springframework.batch.item.util.ExecutionContextUserSupport
- ExecutionContextUserSupport(String) - Constructor for class org.springframework.batch.item.util.ExecutionContextUserSupport
- exit(int) - Method in class org.springframework.batch.core.launch.support.CommandLineJobRunner
-
Delegate to the exiter to (possibly) exit the VM gracefully.
- exit(int) - Method in class org.springframework.batch.core.launch.support.JvmSystemExiter
-
Delegate call to System.exit() with the argument provided.
- exit(int) - Method in interface org.springframework.batch.core.launch.support.SystemExiter
-
Terminate the currently running Java Virtual Machine.
- EXIT_CODE_ATTR - Static variable in class org.springframework.batch.core.configuration.xml.AbstractFlowParser
-
Establishes a Exit Code element.
- ExitCodeMapper - Interface in org.springframework.batch.core.launch.support
-
This interface should be implemented when an environment calling the batch framework has specific requirements regarding the operating system process return status.
- exitStatus - Variable in class org.springframework.batch.core.job.flow.JobFlowExecutor
- ExitStatus - Class in org.springframework.batch.core
-
Value object used to carry information about the status of a job or step execution.
- ExitStatus(String) - Constructor for class org.springframework.batch.core.ExitStatus
-
Constructor that accepts the exit code and sets the exit description to an empty
String
. - ExitStatus(String, String) - Constructor for class org.springframework.batch.core.ExitStatus
-
Constructor that establishes the exit code and the exit description for the
ExitStatus
. - expect() - Method in class org.springframework.batch.repeat.support.ResultHolderResultQueue
-
Deprecated.Tell the queue to expect one more result.
- expect() - Method in class org.springframework.batch.repeat.support.ThrottleLimitResultQueue
-
Deprecated.Tell the queue to expect one more result.
- ExtendedConnectionDataSourceProxy - Class in org.springframework.batch.item.database
-
Implementation of
SmartDataSource
that is capable of keeping a single JDBC Connection which is NOT closed after each use even ifConnection.close()
is called. - ExtendedConnectionDataSourceProxy() - Constructor for class org.springframework.batch.item.database.ExtendedConnectionDataSourceProxy
-
No arg constructor for use when configured using JavaBean style.
- ExtendedConnectionDataSourceProxy(DataSource) - Constructor for class org.springframework.batch.item.database.ExtendedConnectionDataSourceProxy
-
Constructor that takes as a parameter with the
DataSource
to be wrapped. - extract(ChunkResponse, boolean) - Method in class org.springframework.batch.integration.chunk.JmsRedeliveredExtractor
- extract(T) - Method in class org.springframework.batch.item.file.transform.BeanWrapperFieldExtractor
- extract(T) - Method in interface org.springframework.batch.item.file.transform.FieldExtractor
- extract(T) - Method in class org.springframework.batch.item.file.transform.PassThroughFieldExtractor
-
Get an array of fields as close as possible to the input.
- extract(T) - Method in class org.springframework.batch.item.file.transform.RecordFieldExtractor
- ExtractorLineAggregator<T> - Class in org.springframework.batch.item.file.transform
-
An abstract
LineAggregator
implementation that utilizes aFieldExtractor
to convert the incoming object to an array of its parts. - ExtractorLineAggregator() - Constructor for class org.springframework.batch.item.file.transform.ExtractorLineAggregator
- extractTableAlias() - Method in class org.springframework.batch.item.database.support.SqlWindowingPagingQueryProvider
F
- fail() - Method in class org.springframework.batch.core.job.builder.FlowBuilder.TransitionBuilder
-
Signal the end of the flow with an error condition.
- FAIL_ELE - Static variable in class org.springframework.batch.core.configuration.xml.AbstractFlowParser
-
Establishes a Fail element.
- FAILED - Enum constant in enum class org.springframework.batch.core.BatchStatus
-
Status of a batch job that has failed during its execution.
- FAILED - Static variable in class org.springframework.batch.core.ExitStatus
-
Convenient constant value representing finished processing with an error.
- FAILED - Static variable in class org.springframework.batch.core.job.flow.FlowExecutionStatus
-
Special well-known status value.
- FatalStepExecutionException - Exception in org.springframework.batch.core.step
- FatalStepExecutionException(String, Throwable) - Constructor for exception org.springframework.batch.core.step.FatalStepExecutionException
- faultTolerant() - Method in class org.springframework.batch.core.step.builder.FaultTolerantStepBuilder
-
Override parent method to prevent creation of a new FaultTolerantStepBuilder
- faultTolerant() - Method in class org.springframework.batch.core.step.builder.SimpleStepBuilder
- FaultTolerantChunkProcessor<I,
O> - Class in org.springframework.batch.core.step.item -
FaultTolerant implementation of the
ChunkProcessor
interface, that allows for skipping or retry of items that cause exceptions during writing. - FaultTolerantChunkProcessor(ItemProcessor<? super I, ? extends O>, ItemWriter<? super O>, BatchRetryTemplate) - Constructor for class org.springframework.batch.core.step.item.FaultTolerantChunkProcessor
- FaultTolerantChunkProvider<I> - Class in org.springframework.batch.core.step.item
-
FaultTolerant implementation of the
ChunkProvider
interface, that allows for skipping or retry of items that cause exceptions during reading or processing. - FaultTolerantChunkProvider(ItemReader<? extends I>, RepeatOperations) - Constructor for class org.springframework.batch.core.step.item.FaultTolerantChunkProvider
- FaultTolerantStepBuilder<I,
O> - Class in org.springframework.batch.core.step.builder -
A step builder for fully fault tolerant chunk-oriented item processing steps.
- FaultTolerantStepBuilder(SimpleStepBuilder<I, O>) - Constructor for class org.springframework.batch.core.step.builder.FaultTolerantStepBuilder
-
Create a new builder initialized with any properties in the parent.
- FaultTolerantStepBuilder(StepBuilderHelper<?>) - Constructor for class org.springframework.batch.core.step.builder.FaultTolerantStepBuilder
-
Create a new builder initialized with any properties in the parent.
- FaultTolerantStepFactoryBean<T,
S> - Class in org.springframework.batch.core.step.factory -
Factory bean for step that provides options for configuring skip behavior.
- FaultTolerantStepFactoryBean() - Constructor for class org.springframework.batch.core.step.factory.FaultTolerantStepFactoryBean
- fetchSize - Variable in class org.springframework.batch.item.database.builder.JdbcPagingItemReaderBuilder
- fetchSize(int) - Method in class org.springframework.batch.item.database.builder.JdbcCursorItemReaderBuilder
-
A hint to the driver as to how many rows to return with each fetch.
- fetchSize(int) - Method in class org.springframework.batch.item.database.builder.JdbcPagingItemReaderBuilder
-
A hint to the underlying RDBMS as to how many records to return with each fetch.
- fetchSize(int) - Method in class org.springframework.batch.item.database.builder.StoredProcedureItemReaderBuilder
-
A hint to the driver as to how many rows to return with each fetch.
- fieldExtractor(FieldExtractor<T>) - Method in class org.springframework.batch.item.file.builder.FlatFileItemWriterBuilder.DelimitedBuilder
-
Set the
FieldExtractor
to use to extract fields from each item. - fieldExtractor(FieldExtractor<T>) - Method in class org.springframework.batch.item.file.builder.FlatFileItemWriterBuilder.FormattedBuilder
-
Set the
FieldExtractor
to use to extract fields from each item. - FieldExtractor<T> - Interface in org.springframework.batch.item.file.transform
-
This class will convert an object to an array of its parts.
- fields - Variable in class org.springframework.batch.item.data.builder.MongoItemReaderBuilder
-
Deprecated.
- fields - Variable in class org.springframework.batch.item.data.MongoItemReader
-
Deprecated.
- fields(String) - Method in class org.springframework.batch.item.data.builder.MongoCursorItemReaderBuilder
-
JSON defining the fields to be returned from the matching documents by MongoDB.
- fields(String) - Method in class org.springframework.batch.item.data.builder.MongoItemReaderBuilder
-
Deprecated.JSON defining the fields to be returned from the matching documents by MongoDB.
- fields(String) - Method in class org.springframework.batch.item.data.builder.MongoPagingItemReaderBuilder
-
JSON defining the fields to be returned from the matching documents by MongoDB.
- FieldSet - Interface in org.springframework.batch.item.file.transform
-
Interface used by flat file input sources to encapsulate concerns of converting an array of Strings to Java native types.
- fieldSetFactory(FieldSetFactory) - Method in class org.springframework.batch.item.file.builder.FlatFileItemReaderBuilder.DelimitedBuilder
-
A factory for creating the resulting
FieldSet
. - fieldSetFactory(FieldSetFactory) - Method in class org.springframework.batch.item.file.builder.FlatFileItemReaderBuilder.FixedLengthBuilder
-
A factory for creating the resulting
FieldSet
. - FieldSetFactory - Interface in org.springframework.batch.item.file.transform
-
Factory interface for creating
FieldSet
instances. - fieldSetMapper(FieldSetMapper<T>) - Method in class org.springframework.batch.item.file.builder.FlatFileItemReaderBuilder
-
A
FieldSetMapper
implementation to be used. - FieldSetMapper<T> - Interface in org.springframework.batch.item.file.mapping
-
Interface that is used to map data obtained from a
FieldSet
into an object. - FileUtils - Class in org.springframework.batch.item.util
-
Utility methods for files used in batch processing.
- findAllReachableElements(String, Map<String, Set<String>>, Set<String>) - Method in class org.springframework.batch.core.configuration.xml.AbstractFlowParser
-
Find all of the elements that are reachable from the
startElement
. - findBatchStatus(FlowExecutionStatus) - Method in class org.springframework.batch.core.job.flow.JobFlowExecutor
- findJobExecutions(JobInstance) - Method in class org.springframework.batch.core.repository.dao.JdbcJobExecutionDao
- findJobExecutions(JobInstance) - Method in interface org.springframework.batch.core.repository.dao.JobExecutionDao
-
Return all
JobExecution
s for givenJobInstance
, sorted backwards by creation order (so the first element is the most recent). - findJobExecutions(JobInstance) - Method in interface org.springframework.batch.core.repository.JobRepository
-
Return all
JobExecution
s for givenJobInstance
, sorted backwards by creation order (so the first element is the most recent). - findJobExecutions(JobInstance) - Method in class org.springframework.batch.core.repository.support.SimpleJobRepository
- findJobInstancesByJobName(String, int, int) - Method in interface org.springframework.batch.core.explore.JobExplorer
-
Fetch
JobInstance
values in descending order of creation (and, therefore, usually of first execution) with a 'like' or wildcard criteria. - findJobInstancesByJobName(String, int, int) - Method in class org.springframework.batch.core.explore.support.SimpleJobExplorer
- findJobInstancesByName(String, int, int) - Method in class org.springframework.batch.core.repository.dao.JdbcJobInstanceDao
- findJobInstancesByName(String, int, int) - Method in interface org.springframework.batch.core.repository.dao.JobInstanceDao
-
Fetch the last job instances with the provided name, sorted backwards by primary key, using a 'like' criteria
- findJobInstancesByName(String, int, int) - Method in interface org.springframework.batch.core.repository.JobRepository
-
Fetch the last job instances with the provided name, sorted backwards by primary key, using a 'like' criteria
- findJobInstancesByName(String, int, int) - Method in class org.springframework.batch.core.repository.support.SimpleJobRepository
- findMatchingMethod() - Method in class org.springframework.batch.item.adapter.HippyMethodInvoker
- 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(Class<?>) - Method in interface org.springframework.batch.support.MethodResolver
-
Find a single Method on the given Class that matches this resolver's criteria.
- findMethod(Class<?>, Class<? extends Annotation>) - Static method in class org.springframework.batch.support.ReflectionUtils
- 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(Object) - Method in interface org.springframework.batch.support.MethodResolver
-
Find a single Method on the provided Object that matches this resolver's criteria.
- findRunningJobExecutions(String) - Method in interface org.springframework.batch.core.explore.JobExplorer
-
Retrieve running job executions.
- findRunningJobExecutions(String) - Method in class org.springframework.batch.core.explore.support.SimpleJobExplorer
- findRunningJobExecutions(String) - Method in class org.springframework.batch.core.repository.dao.JdbcJobExecutionDao
- findRunningJobExecutions(String) - Method in interface org.springframework.batch.core.repository.dao.JobExecutionDao
- FINISHED - Enum constant in enum class org.springframework.batch.repeat.RepeatStatus
-
Indicates that processing is finished (either successful or unsuccessful)
- fixedLength() - Method in class org.springframework.batch.item.file.builder.FlatFileItemReaderBuilder
-
Returns an instance of a
FlatFileItemReaderBuilder.FixedLengthBuilder
for building aFixedLengthTokenizer
. - FixedLengthBuilder(FlatFileItemReaderBuilder<T>) - Constructor for class org.springframework.batch.item.file.builder.FlatFileItemReaderBuilder.FixedLengthBuilder
- FixedLengthTokenizer - Class in org.springframework.batch.item.file.transform
-
Tokenizer used to process data obtained from files with fixed-length format.
- FixedLengthTokenizer() - Constructor for class org.springframework.batch.item.file.transform.FixedLengthTokenizer
- FlatFileFooterCallback - Interface in org.springframework.batch.item.file
-
Callback interface for writing a footer to a file.
- FlatFileFormatException - Exception in org.springframework.batch.item.file.transform
-
Exception indicating that some type of error has occurred while attempting to parse a line of input into tokens.
- FlatFileFormatException(String) - Constructor for exception org.springframework.batch.item.file.transform.FlatFileFormatException
-
Create a new
FlatFileFormatException
based on a message. - FlatFileFormatException(String, String) - Constructor for exception org.springframework.batch.item.file.transform.FlatFileFormatException
-
Create a new
FlatFileFormatException
based on a message. - FlatFileFormatException(String, Throwable) - Constructor for exception org.springframework.batch.item.file.transform.FlatFileFormatException
-
Create a new
FlatFileFormatException
based on a message and another exception. - FlatFileHeaderCallback - Interface in org.springframework.batch.item.file
-
Callback interface for writing a header to a file.
- FlatFileItemReader<T> - Class in org.springframework.batch.item.file
-
Restartable
ItemReader
that reads lines from inputFlatFileItemReader.setResource(Resource)
. - FlatFileItemReader() - Constructor for class org.springframework.batch.item.file.FlatFileItemReader
- FlatFileItemReaderBuilder<T> - Class in org.springframework.batch.item.file.builder
-
A builder implementation for the
FlatFileItemReader
. - FlatFileItemReaderBuilder() - Constructor for class org.springframework.batch.item.file.builder.FlatFileItemReaderBuilder
- FlatFileItemReaderBuilder.DelimitedBuilder<T> - Class in org.springframework.batch.item.file.builder
-
A builder for constructing a
DelimitedLineTokenizer
- FlatFileItemReaderBuilder.FixedLengthBuilder<T> - Class in org.springframework.batch.item.file.builder
-
A builder for constructing a
FixedLengthTokenizer
- FlatFileItemWriter<T> - Class in org.springframework.batch.item.file
-
This class is an item writer that writes data to a file or stream.
- FlatFileItemWriter() - Constructor for class org.springframework.batch.item.file.FlatFileItemWriter
- FlatFileItemWriterBuilder<T> - Class in org.springframework.batch.item.file.builder
-
A builder implementation for the
FlatFileItemWriter
- FlatFileItemWriterBuilder() - Constructor for class org.springframework.batch.item.file.builder.FlatFileItemWriterBuilder
- FlatFileItemWriterBuilder.DelimitedBuilder<T> - Class in org.springframework.batch.item.file.builder
-
A builder for constructing a
DelimitedLineAggregator
- FlatFileItemWriterBuilder.FormattedBuilder<T> - Class in org.springframework.batch.item.file.builder
-
A builder for constructing a
FormatterLineAggregator
. - FlatFileParseException - Exception in org.springframework.batch.item.file
-
Exception thrown when errors are encountered parsing flat files.
- FlatFileParseException(String, String) - Constructor for exception org.springframework.batch.item.file.FlatFileParseException
- FlatFileParseException(String, String, int) - Constructor for exception org.springframework.batch.item.file.FlatFileParseException
- FlatFileParseException(String, Throwable, String, int) - Constructor for exception org.springframework.batch.item.file.FlatFileParseException
- flow - Variable in class org.springframework.batch.core.job.flow.FlowJob
- flow() - Method in class org.springframework.batch.core.job.builder.FlowBuilder
- flow(Flow) - Method in class org.springframework.batch.core.job.builder.FlowJobBuilder
-
Provide a single flow to execute as the job.
- flow(Flow) - Method in class org.springframework.batch.core.step.builder.FlowStepBuilder
-
Provide a flow to execute during the step.
- flow(Flow) - Method in class org.springframework.batch.core.step.builder.StepBuilder
-
Create a new step builder that will execute a flow.
- flow(Flow) - Method in class org.springframework.batch.integration.partition.RemotePartitioningWorkerStepBuilder
- flow(Step) - Method in class org.springframework.batch.core.job.builder.JobBuilder
-
Create a new job builder that will execute a step or sequence of steps.
- Flow - Interface in org.springframework.batch.core.job.flow
- FLOW_ELE - Static variable in class org.springframework.batch.core.configuration.xml.AbstractFlowParser
-
Establishes a Flow element.
- FlowBuilder<Q> - Class in org.springframework.batch.core.job.builder
-
A builder for a flow of steps that can be executed as a job or as part of a job.
- FlowBuilder(String) - Constructor for class org.springframework.batch.core.job.builder.FlowBuilder
- FlowBuilder.SplitBuilder<Q> - Class in org.springframework.batch.core.job.builder
-
A builder for building a split state.
- FlowBuilder.TransitionBuilder<Q> - Class in org.springframework.batch.core.job.builder
-
A builder for transitions within a flow.
- FlowBuilder.UnterminatedFlowBuilder<Q> - Class in org.springframework.batch.core.job.builder
-
A builder for continuing a flow from a decision state.
- FlowBuilderException - Exception in org.springframework.batch.core.job.builder
- FlowBuilderException(Exception) - Constructor for exception org.springframework.batch.core.job.builder.FlowBuilderException
- FlowBuilderException(String) - Constructor for exception org.springframework.batch.core.job.builder.FlowBuilderException
- FlowBuilderException(String, Exception) - Constructor for exception org.springframework.batch.core.job.builder.FlowBuilderException
- FlowElementParser - Class in org.springframework.batch.core.configuration.xml
-
Internal parser for the <flow/> elements inside a job.
- FlowElementParser() - Constructor for class org.springframework.batch.core.configuration.xml.FlowElementParser
- FlowExecution - Class in org.springframework.batch.core.job.flow
- FlowExecution(String, FlowExecutionStatus) - Constructor for class org.springframework.batch.core.job.flow.FlowExecution
- FlowExecutionAggregator - Interface in org.springframework.batch.core.job.flow.support.state
-
Strategy interface for aggregating
FlowExecution
instances into a single exit status. - FlowExecutionException - Exception in org.springframework.batch.core.job.flow
- FlowExecutionException(String) - Constructor for exception org.springframework.batch.core.job.flow.FlowExecutionException
- FlowExecutionException(String, Throwable) - Constructor for exception org.springframework.batch.core.job.flow.FlowExecutionException
- FlowExecutionStatus - Class in org.springframework.batch.core.job.flow
-
Represents the status of
FlowExecution
. - FlowExecutionStatus(String) - Constructor for class org.springframework.batch.core.job.flow.FlowExecutionStatus
- FlowExecutor - Interface in org.springframework.batch.core.job.flow
-
Context and execution strategy for
FlowJob
to allow it to delegate its execution step by step. - FlowHolder - Interface in org.springframework.batch.core.job.flow
-
Convenient interface for components that contain nested flows.
- FlowJob - Class in org.springframework.batch.core.job.flow
-
Implementation of the
Job
interface that allows for complex flows of steps, rather than requiring sequential execution. - FlowJob() - Constructor for class org.springframework.batch.core.job.flow.FlowJob
-
Create a
FlowJob
with null name and no flow (invalid state). - FlowJob(String) - Constructor for class org.springframework.batch.core.job.flow.FlowJob
-
Create a
FlowJob
with provided name and no flow (invalid state). - FlowJobBuilder - Class in org.springframework.batch.core.job.builder
-
A job builder for
FlowJob
instances. - FlowJobBuilder(JobBuilderHelper<?>) - Constructor for class org.springframework.batch.core.job.builder.FlowJobBuilder
-
Create a new builder initialized with any properties in the parent.
- FlowState - Class in org.springframework.batch.core.job.flow.support.state
-
State that delegates to a Flow
- FlowState(Flow, String) - Constructor for class org.springframework.batch.core.job.flow.support.state.FlowState
- FlowStep - Class in org.springframework.batch.core.job.flow
- FlowStep() - Constructor for class org.springframework.batch.core.job.flow.FlowStep
-
Default constructor convenient for configuration purposes.
- FlowStep(Flow) - Constructor for class org.springframework.batch.core.job.flow.FlowStep
-
Constructor for a
FlowStep
that sets the flow and of the step explicitly. - FlowStepBuilder - Class in org.springframework.batch.core.step.builder
-
A step builder for
FlowStep
instances. - FlowStepBuilder(StepBuilderHelper<?>) - Constructor for class org.springframework.batch.core.step.builder.FlowStepBuilder
-
Create a new builder initialized with any properties in the parent.
- flush() - Method in class org.springframework.batch.item.kafka.KafkaItemWriter
- flush() - Method in class org.springframework.batch.item.KeyValueItemWriter
-
Flush items to the key/value store.
- flush() - Method in class org.springframework.batch.item.xml.stax.NoStartEndDocumentStreamWriter
- 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) - Constructor for exception org.springframework.batch.support.transaction.FlushFailedException
-
Create a new
FlushFailedException
based on a message. - FlushFailedException(String, Throwable) - Constructor for exception org.springframework.batch.support.transaction.FlushFailedException
-
Create a new
FlushFailedException
based on a message and another exception. - footerCallback(FlatFileFooterCallback) - Method in class org.springframework.batch.item.file.builder.FlatFileItemWriterBuilder
-
A callback for footer processing
- footerCallback(FlatFileFooterCallback) - Method in class org.springframework.batch.item.json.builder.JsonFileItemWriterBuilder
-
A callback for footer processing.
- footerCallback(StaxWriterCallback) - Method in class org.springframework.batch.item.xml.builder.StaxEventItemWriterBuilder
-
A
StaxWriterCallback
to provide any footer elements - ForceRollbackForWriteSkipException - Exception in org.springframework.batch.core.step.item
-
Fatal exception to be thrown when a rollback must be forced, typically after catching an exception that otherwise would not cause a rollback.
- ForceRollbackForWriteSkipException(String, Throwable) - Constructor for exception org.springframework.batch.core.step.item.ForceRollbackForWriteSkipException
- forceSync(boolean) - Method in class org.springframework.batch.item.file.builder.FlatFileItemWriterBuilder
-
A flag indicating that changes should be force-synced to disk on flush.
- forceSync(boolean) - Method in class org.springframework.batch.item.json.builder.JsonFileItemWriterBuilder
-
A flag indicating that changes should be force-synced to disk on flush.
- forceSync(boolean) - Method in class org.springframework.batch.item.xml.builder.StaxEventItemWriterBuilder
-
Flag to indicate that changes should be force-synced to disk on flush.
- format(String) - Method in class org.springframework.batch.item.file.builder.FlatFileItemWriterBuilder.FormattedBuilder
-
Set the format string used to aggregate items
- formatDuration(Duration) - Static method in class org.springframework.batch.core.observability.BatchMetrics
-
Format a duration in a human readable format like: 2h32m15s10ms.
- formatted() - Method in class org.springframework.batch.item.file.builder.FlatFileItemWriterBuilder
-
Returns an instance of a
FlatFileItemWriterBuilder.FormattedBuilder
for building aFormatterLineAggregator
. - FormattedBuilder(FlatFileItemWriterBuilder<T>) - Constructor for class org.springframework.batch.item.file.builder.FlatFileItemWriterBuilder.FormattedBuilder
- FormatterLineAggregator<T> - Class in org.springframework.batch.item.file.transform
-
A
LineAggregator
implementation which produces a String by aggregating the provided item via theFormatter
syntax. - FormatterLineAggregator() - Constructor for class org.springframework.batch.item.file.transform.FormatterLineAggregator
- FragmentEventReader - Interface in org.springframework.batch.item.xml.stax
-
Interface for event readers which support treating XML fragments as standalone XML documents by wrapping the fragments with StartDocument and EndDocument events.
- from(Flow) - Method in class org.springframework.batch.core.job.builder.FlowBuilder
-
Start again from a subflow that was already registered.
- from(JobExecutionDecider) - Method in class org.springframework.batch.core.job.builder.FlowBuilder
-
Start again from a decision that was already registered.
- from(Step) - Method in class org.springframework.batch.core.job.builder.FlowBuilder
-
Go back to a previously registered step and start a new path.
- fromClause - Variable in class org.springframework.batch.item.database.builder.JdbcPagingItemReaderBuilder
- fromClause(String) - Method in class org.springframework.batch.item.database.builder.JdbcPagingItemReaderBuilder
-
The SQL
FROM
clause for a db specificPagingQueryProvider
. - fromMetaData(DataSource) - Static method in enum class org.springframework.batch.support.DatabaseType
-
Convenience method that pulls a database product name from the DataSource's metadata.
- fromProductName(String) - Static method in enum class org.springframework.batch.support.DatabaseType
-
Static method to obtain a DatabaseType from the provided product name.
- fromPropertyName(String) - Static method in enum class org.springframework.batch.core.listener.JobListenerMetaData
-
Return the relevant meta data for the provided property name.
- fromPropertyName(String) - Static method in enum class org.springframework.batch.core.listener.StepListenerMetaData
-
Return the relevant meta data for the provided property name.
- function() - Method in class org.springframework.batch.item.database.builder.StoredProcedureItemReaderBuilder
-
Indicates the stored procedure is a function
- FunctionItemProcessor<I,
O> - Class in org.springframework.batch.item.function -
An
ItemProcessor
implementation that delegates to aFunction
- FunctionItemProcessor(Function<I, O>) - Constructor for class org.springframework.batch.item.function.FunctionItemProcessor
G
- generateFirstPageQuery(int) - Method in interface org.springframework.batch.item.database.PagingQueryProvider
-
Generate the query that will provide the first page, limited by the page size.
- generateFirstPageQuery(int) - Method in class org.springframework.batch.item.database.support.AbstractSqlPagingQueryProvider
-
Method generating the query string to be used for retrieving the first page.
- generateFirstPageQuery(int) - Method in class org.springframework.batch.item.database.support.Db2PagingQueryProvider
- generateFirstPageQuery(int) - Method in class org.springframework.batch.item.database.support.H2PagingQueryProvider
- generateFirstPageQuery(int) - Method in class org.springframework.batch.item.database.support.HanaPagingQueryProvider
- generateFirstPageQuery(int) - Method in class org.springframework.batch.item.database.support.HsqlPagingQueryProvider
- generateFirstPageQuery(int) - Method in class org.springframework.batch.item.database.support.MariaDBPagingQueryProvider
- generateFirstPageQuery(int) - Method in class org.springframework.batch.item.database.support.MySqlPagingQueryProvider
- generateFirstPageQuery(int) - Method in class org.springframework.batch.item.database.support.OraclePagingQueryProvider
- generateFirstPageQuery(int) - Method in class org.springframework.batch.item.database.support.PostgresPagingQueryProvider
- generateFirstPageQuery(int) - Method in class org.springframework.batch.item.database.support.SqlitePagingQueryProvider
- generateFirstPageQuery(int) - Method in class org.springframework.batch.item.database.support.SqlServerPagingQueryProvider
- generateFirstPageQuery(int) - Method in class org.springframework.batch.item.database.support.SqlWindowingPagingQueryProvider
- generateFirstPageQuery(int) - Method in class org.springframework.batch.item.database.support.SybasePagingQueryProvider
- generateGroupedTopSqlQuery(AbstractSqlPagingQueryProvider, boolean, String) - Static method in class org.springframework.batch.item.database.support.SqlPagingQueryUtils
-
Deprecated.since v5.2 in favor of
SqlPagingQueryUtils.generateGroupedTopSqlQuery(AbstractSqlPagingQueryProvider, String)
- generateGroupedTopSqlQuery(AbstractSqlPagingQueryProvider, String) - Static method in class org.springframework.batch.item.database.support.SqlPagingQueryUtils
-
Generate SQL query string using a TOP clause
- generateKey(JobParameters) - Method in class org.springframework.batch.core.DefaultJobKeyGenerator
-
Generates the job key to be used based on the
JobParameters
instance provided. - generateKey(T) - Method in interface org.springframework.batch.core.JobKeyGenerator
-
Method to generate the unique key used to identify a job instance.
- generateLimitCypherQuery() - Method in class org.springframework.batch.item.data.Neo4jItemReader
-
Deprecated.
- generateLimitGroupedSqlQuery(AbstractSqlPagingQueryProvider, boolean, String) - Static method in class org.springframework.batch.item.database.support.SqlPagingQueryUtils
-
Deprecated.
- generateLimitGroupedSqlQuery(AbstractSqlPagingQueryProvider, String) - Static method in class org.springframework.batch.item.database.support.SqlPagingQueryUtils
-
Generate SQL query string using a LIMIT clause
- generateLimitSqlQuery(AbstractSqlPagingQueryProvider, boolean, String) - Static method in class org.springframework.batch.item.database.support.SqlPagingQueryUtils
-
Generate SQL query string using a LIMIT clause
- generateRemainingPagesQuery(int) - Method in interface org.springframework.batch.item.database.PagingQueryProvider
-
Generate the query that will provide the first page, limited by the page size.
- generateRemainingPagesQuery(int) - Method in class org.springframework.batch.item.database.support.AbstractSqlPagingQueryProvider
-
Method generating the query string to be used for retrieving the pages following the first page.
- generateRemainingPagesQuery(int) - Method in class org.springframework.batch.item.database.support.Db2PagingQueryProvider
- generateRemainingPagesQuery(int) - Method in class org.springframework.batch.item.database.support.H2PagingQueryProvider
- generateRemainingPagesQuery(int) - Method in class org.springframework.batch.item.database.support.HanaPagingQueryProvider
- generateRemainingPagesQuery(int) - Method in class org.springframework.batch.item.database.support.HsqlPagingQueryProvider
- generateRemainingPagesQuery(int) - Method in class org.springframework.batch.item.database.support.MariaDBPagingQueryProvider
- generateRemainingPagesQuery(int) - Method in class org.springframework.batch.item.database.support.MySqlPagingQueryProvider
- generateRemainingPagesQuery(int) - Method in class org.springframework.batch.item.database.support.OraclePagingQueryProvider
- generateRemainingPagesQuery(int) - Method in class org.springframework.batch.item.database.support.PostgresPagingQueryProvider
- generateRemainingPagesQuery(int) - Method in class org.springframework.batch.item.database.support.SqlitePagingQueryProvider
- generateRemainingPagesQuery(int) - Method in class org.springframework.batch.item.database.support.SqlServerPagingQueryProvider
- generateRemainingPagesQuery(int) - Method in class org.springframework.batch.item.database.support.SqlWindowingPagingQueryProvider
- generateRemainingPagesQuery(int) - Method in class org.springframework.batch.item.database.support.SybasePagingQueryProvider
- generateRowNumSqlQuery(AbstractSqlPagingQueryProvider, boolean, String) - Static method in class org.springframework.batch.item.database.support.SqlPagingQueryUtils
-
Generate SQL query string using a ROW_NUM condition
- generateRowNumSqlQuery(AbstractSqlPagingQueryProvider, String, boolean, String) - Static method in class org.springframework.batch.item.database.support.SqlPagingQueryUtils
-
Generate SQL query string using a ROW_NUM condition
- generateTopSqlQuery(AbstractSqlPagingQueryProvider, boolean, String) - Static method in class org.springframework.batch.item.database.support.SqlPagingQueryUtils
-
Generate SQL query string using a TOP clause
- GenericApplicationContextFactory - Class in org.springframework.batch.core.configuration.support
-
ApplicationContextFactory
implementation that takes a parent context and a path to the context to create. - GenericApplicationContextFactory(Object...) - Constructor for class org.springframework.batch.core.configuration.support.GenericApplicationContextFactory
-
Create an application context factory for the specified resource.
- get() - Method in class org.springframework.batch.core.observability.BatchJobContext
- get() - Method in class org.springframework.batch.core.observability.BatchStepContext
- get(String) - Method in class org.springframework.batch.integration.chunk.RemoteChunkingManagerStepBuilderFactory
-
Creates a
RemoteChunkingManagerStepBuilder
and initializes its job repository and transaction manager. - get(String) - Method in class org.springframework.batch.integration.partition.RemotePartitioningManagerStepBuilderFactory
-
Creates a
RemotePartitioningManagerStepBuilder
and initializes its job repository, job explorer, bean factory and transaction manager. - get(String) - Method in class org.springframework.batch.integration.partition.RemotePartitioningWorkerStepBuilderFactory
-
Creates a
RemotePartitioningWorkerStepBuilder
and initializes its job repository, job explorer, bean factory and transaction manager. - get(String) - Method in class org.springframework.batch.item.ExecutionContext
-
Getter for the value represented by the provided key.
- get(String, Class<V>) - Method in class org.springframework.batch.item.ExecutionContext
-
Typesafe getter for the value represented by the provided key, with cast to given class.
- get(String, Class<V>, V) - Method in class org.springframework.batch.item.ExecutionContext
-
Typesafe getter for the value represented by the provided key, with cast to given class.
- get(String, ObjectFactory<?>) - Method in class org.springframework.batch.core.scope.JobScope
- get(String, ObjectFactory<?>) - Method in class org.springframework.batch.core.scope.StepScope
- getActualCount() - Method in exception org.springframework.batch.item.file.transform.IncorrectTokenCountException
- getActualLength() - Method in exception org.springframework.batch.item.file.transform.IncorrectLineLengthException
-
Retrieves the actual length that was recorded for this exception.
- getAdjustedOutputs(Chunk<I>, Chunk<O>) - Method in class org.springframework.batch.core.step.item.FaultTolerantChunkProcessor
- getAdjustedOutputs(Chunk<I>, Chunk<O>) - Method in class org.springframework.batch.core.step.item.SimpleChunkProcessor
-
Extension point for subclasses that want to adjust the outputs based on additional saved data in the inputs.
- getAggregator() - Method in class org.springframework.batch.core.step.builder.PartitionStepBuilder
- getAllFailureExceptions() - Method in class org.springframework.batch.core.JobExecution
-
Return all failure causing exceptions for this
JobExecution
, including step executions. - getAllowStartIfComplete() - Method in class org.springframework.batch.core.step.builder.StepBuilderHelper.CommonStepProperties
- getAnnotation() - Method in enum class org.springframework.batch.core.listener.JobListenerMetaData
- getAnnotation() - Method in interface org.springframework.batch.core.listener.ListenerMetaData
- getAnnotation() - Method in enum class org.springframework.batch.core.listener.StepListenerMetaData
- getArguments() - Method in class org.springframework.batch.item.adapter.AbstractMethodInvokingDelegator
-
Return arguments.
- getAsText() - Method in class org.springframework.batch.item.file.transform.RangeArrayPropertyEditor
- getAttribute(String) - Method in class org.springframework.batch.repeat.context.SynchronizedAttributeAccessor
- getAttribute(String, String, ConfigurableListableBeanFactory) - Static method in class org.springframework.batch.core.configuration.xml.BeanDefinitionUtils
- getBatchStatusFromEndTransitionName(String) - Static method in class org.springframework.batch.core.configuration.xml.AbstractFlowParser
-
Gets the batch status from the end transition name by the element.
- getBeanClass() - Method in class org.springframework.batch.core.configuration.xml.AbstractListenerParser
-
Gets the bean class.
- getBeanClass() - Method in class org.springframework.batch.core.configuration.xml.JobExecutionListenerParser
- getBeanClass() - Method in class org.springframework.batch.core.configuration.xml.StepListenerParser
- getBeanClass(Element) - Method in class org.springframework.batch.core.configuration.xml.AbstractFlowParser
- getBeanClass(Element) - Method in class org.springframework.batch.core.configuration.xml.JobParser
- getBeanClass(Element) - Method in class org.springframework.batch.core.configuration.xml.TopLevelJobListenerParser
- getBeanClass(Element) - Method in class org.springframework.batch.core.configuration.xml.TopLevelStepListenerParser
- getBeanClassName(Element) - Method in class org.springframework.batch.core.configuration.xml.JobRepositoryParser
- getBeanFactoryPostProcessorClasses() - Method in class org.springframework.batch.core.configuration.support.AbstractApplicationContextFactory
-
Protected access to the list of bean factory post processor classes that should be copied over to the context from the parent.
- getBufferSize() - Method in class org.springframework.batch.support.transaction.TransactionAwareBufferedWriter
-
Convenience method for clients to determine if there is any unflushed data.
- getCharset() - Method in class org.springframework.batch.core.configuration.support.DefaultBatchConfiguration
-
Return the
Charset
to use when serializing/deserializing the execution context. - getChunkCompletionPolicy() - Method in class org.springframework.batch.core.step.builder.SimpleStepBuilder
- getChunkMonitor() - Method in class org.springframework.batch.core.step.builder.FaultTolerantStepBuilder
- getChunkOperations() - Method in class org.springframework.batch.core.step.factory.SimpleStepFactoryBean
-
Protected getter for the chunk operations to make them available in subclasses.
- getChunkSize() - Method in class org.springframework.batch.core.step.builder.SimpleStepBuilder
- getChunkSize() - Method in class org.springframework.batch.repeat.policy.SimpleCompletionPolicy
- getClobType() - Method in class org.springframework.batch.core.configuration.support.DefaultBatchConfiguration
-
Return the value from
Types
class to indicate the type to use for a CLOB - getClobTypeToUse() - Method in class org.springframework.batch.core.repository.dao.AbstractJdbcBatchMetadataDao
- getCloseSuppressingConnectionProxy(Connection) - Method in class org.springframework.batch.item.database.ExtendedConnectionDataSourceProxy
-
Wrap the given Connection with a proxy that delegates every method call to it but suppresses close calls.
- getCode() - Method in class org.springframework.batch.core.job.flow.support.state.EndState
- getCollection() - Method in class org.springframework.batch.item.data.MongoItemWriter
-
Get the Mongo collection name.
- getCommitCount() - Method in class org.springframework.batch.core.StepExecution
-
Returns the current number of commits for this execution.
- getCommitInterval() - Method in class org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
- getCompletionPolicy() - Method in class org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
- getCompositeListener() - Method in class org.springframework.batch.core.step.AbstractStep
- 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.JobSynchronizationManager
-
Getter for the current context if there is one, otherwise returns
null
. - getContext() - Static method in class org.springframework.batch.core.scope.context.StepSynchronizationManager
-
Getter for the current context if there is one, otherwise returns
null
. - getContext() - Method in class org.springframework.batch.core.scope.context.SynchronizationManagerSupport
-
Getter for the current context if there is one, otherwise returns
null
. - getContext() - Static method in class org.springframework.batch.repeat.support.RepeatSynchronizationManager
-
Getter for the current context.
- getConversationId() - Method in class org.springframework.batch.core.scope.JobScope
- getConversationId() - Method in class org.springframework.batch.core.scope.StepScope
- getConversionService() - Method in class org.springframework.batch.core.configuration.support.DefaultBatchConfiguration
-
Return the conversion service to use in the job repository and job explorer.
- getCount() - Method in class org.springframework.batch.repeat.context.RepeatContextCounter
- getCount(RepeatContext) - Method in class org.springframework.batch.repeat.policy.CountingCompletionPolicy
-
Extension point for subclasses.
- getCounter() - Method in class org.springframework.batch.repeat.policy.CountingCompletionPolicy.CountingBatchContext
- getCreateTime() - Method in class org.springframework.batch.core.JobExecution
- getCreateTime() - Method in class org.springframework.batch.core.StepExecution
-
Gets the time this execution was created
- getCurrent() - Method in class org.springframework.batch.core.scope.context.SynchronizationManagerSupport
- getCurrentItemCount() - Method in class org.springframework.batch.item.support.AbstractItemCountingItemStreamItemReader
-
Returns the current item count.
- getDatabaseType() - Method in class org.springframework.batch.core.configuration.support.DefaultBatchConfiguration
-
Return the database type.
- getDataFieldMaxValueIncrementer() - Method in class org.springframework.batch.core.launch.support.DataFieldMaxValueJobParametersIncrementer
-
Get the incrementer.
- getDataSource() - Method in class org.springframework.batch.core.configuration.support.DefaultBatchConfiguration
-
Return the data source to use for Batch meta-data.
- getDataSource() - Method in class org.springframework.batch.item.database.AbstractCursorItemReader
-
Public getter for the data source.
- getDate(String) - Method in class org.springframework.batch.core.JobParameters
-
Typesafe getter for the
Date
represented by the provided key. - getDate(String, Date) - Method in class org.springframework.batch.core.JobParameters
-
Typesafe getter for the
Date
represented by the provided key. - getDefaultExitStatusForFailure(Throwable, JobExecution) - Method in class org.springframework.batch.core.job.AbstractJob
-
Default mapping from throwable to
ExitStatus
. - getDefaultListenerClass() - Method in class org.springframework.batch.core.listener.AbstractListenerFactoryBean
- getDefaultListenerClass() - Method in class org.springframework.batch.core.listener.JobListenerFactoryBean
- getDefaultListenerClass() - Method in class org.springframework.batch.core.listener.StepListenerFactoryBean
- getDouble(String) - Method in class org.springframework.batch.core.JobParameters
-
Typesafe getter for the
Double
represented by the provided key. - getDouble(String) - 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.
- getDouble(String, Double) - Method in class org.springframework.batch.core.JobParameters
-
Typesafe getter for the
Double
represented by the provided key. - getEcDao() - Method in class org.springframework.batch.core.explore.support.SimpleJobExplorer
- getElementText() - Method in class org.springframework.batch.item.xml.stax.DefaultFragmentEventReader
- 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 when this execution ended or
null
if the step is running. - getEntityManager() - Method in class org.springframework.batch.item.database.orm.AbstractJpaQueryProvider
-
Getter for
EntityManager
- getErrorMessage() - Static method in class org.springframework.batch.core.launch.support.CommandLineJobRunner
-
Retrieve the error message set by an instance of
CommandLineJobRunner
as it exits. - getErrors() - Method in class org.springframework.batch.item.Chunk
- getException() - Method in class org.springframework.batch.item.SkipWrapper
-
Public getter for the exception.
- getExceptionHandler() - Method in class org.springframework.batch.core.step.builder.AbstractTaskletStepBuilder
-
Convenience method for subclasses to access the exception handler that was injected by user.
- getExceptionHandler() - Method in class org.springframework.batch.core.step.factory.SimpleStepFactoryBean
-
Protected getter for the
ExceptionHandler
. - getExceptionTranslator() - Method in class org.springframework.batch.item.database.AbstractCursorItemReader
-
Creates a default SQLErrorCodeSQLExceptionTranslator for the specified DataSource if none is set.
- getExecutionContext() - Method in class org.springframework.batch.core.JobExecution
-
Returns the
ExecutionContext
for this execution. - getExecutionContext() - Method in class org.springframework.batch.core.StepExecution
-
Returns the
ExecutionContext
for this execution. - getExecutionContext(JobExecution) - Method in interface org.springframework.batch.core.repository.dao.ExecutionContextDao
- getExecutionContext(JobExecution) - Method in class org.springframework.batch.core.repository.dao.JdbcExecutionContextDao
- getExecutionContext(StepExecution) - Method in interface org.springframework.batch.core.repository.dao.ExecutionContextDao
- getExecutionContext(StepExecution) - Method in class org.springframework.batch.core.repository.dao.JdbcExecutionContextDao
- getExecutionContextKey(String) - Method in class org.springframework.batch.item.ItemStreamSupport
- getExecutionContextSerializer() - Method in class org.springframework.batch.core.configuration.support.DefaultBatchConfiguration
-
A custom implementation of the
ExecutionContextSerializer
. - getExecutions(long) - Method in interface org.springframework.batch.core.launch.JobOperator
-
List the
JobExecutions
associated with a particularJobInstance
, in reverse order of creation (and therefore usually of execution). - getExecutions(long) - Method in class org.springframework.batch.core.launch.support.SimpleJobOperator
- getExitCode() - Method in class org.springframework.batch.core.ExitStatus
-
Getter for the exit code (defaults to blank).
- getExitDescription() - Method in class org.springframework.batch.core.ExitStatus
-
Getter for the exit description (defaults to blank)
- getExitStatus() - Method in class org.springframework.batch.core.JobExecution
- getExitStatus() - Method in class org.springframework.batch.core.StepContribution
-
Public getter for the
ExitStatus
. - getExitStatus() - Method in class org.springframework.batch.core.StepExecution
- getExitStatus(int) - Method in class org.springframework.batch.core.step.tasklet.ConfigurableSystemProcessExitCodeMapper
- getExitStatus(int) - Method in class org.springframework.batch.core.step.tasklet.SimpleSystemProcessExitCodeMapper
- getExitStatus(int) - Method in interface org.springframework.batch.core.step.tasklet.SystemProcessExitCodeMapper
- getExpectedCount() - Method in exception org.springframework.batch.item.file.transform.IncorrectTokenCountException
- getExpectedLength() - Method in exception org.springframework.batch.item.file.transform.IncorrectLineLengthException
-
Retrieves the expected length that was recorded for this exception.
- getExpecting() - Method in class org.springframework.batch.integration.chunk.ChunkMessageChannelItemWriter.LocalState
- getFailureExceptions() - Method in class org.springframework.batch.core.JobExecution
-
Retrieve a list of exceptions.
- getFailureExceptions() - Method in class org.springframework.batch.core.StepExecution
- getFatalExceptionAwareProxy(SkipPolicy) - Method in class org.springframework.batch.core.step.builder.FaultTolerantStepBuilder
-
Wrap a
SkipPolicy
and make it consistent with known fatal exceptions. - getFaultTolerantStepBuilder(String) - Method in class org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
-
Creates a new
FaultTolerantStepBuilder
. - getFieldCount() - Method in class org.springframework.batch.item.file.transform.DefaultFieldSet
- getFieldCount() - Method in interface org.springframework.batch.item.file.transform.FieldSet
-
Return the number of fields in this '
FieldSet
'. - getFilterCount() - Method in class org.springframework.batch.core.StepContribution
-
Public getter for the filter counter.
- getFilterCount() - Method in class org.springframework.batch.core.StepExecution
-
Returns the current number of items filtered out of this execution.
- getFilterCount(Chunk<I>, Chunk<O>) - Method in class org.springframework.batch.core.step.item.FaultTolerantChunkProcessor
- getFilterCount(Chunk<I>, Chunk<O>) - Method in class org.springframework.batch.core.step.item.SimpleChunkProcessor
-
Extension point for subclasses to calculate the filter count.
- getFlows() - Method in class org.springframework.batch.core.configuration.xml.SimpleFlowFactoryBean.DelegateState
- getFlows() - Method in interface org.springframework.batch.core.job.flow.FlowHolder
- getFlows() - Method in class org.springframework.batch.core.job.flow.support.state.FlowState
- getFlows() - Method in class org.springframework.batch.core.job.flow.support.state.SplitState
- getFromClause() - Method in class org.springframework.batch.item.database.support.AbstractSqlPagingQueryProvider
- getGridSize() - Method in class org.springframework.batch.core.partition.support.AbstractPartitionHandler
-
Returns the number of step executions.
- getGridSize() - Method in class org.springframework.batch.core.step.builder.PartitionStepBuilder
- getGroupClause() - Method in class org.springframework.batch.item.database.support.AbstractSqlPagingQueryProvider
-
The getter for the group by clause
- getGroupName(BeanDefinition, Job) - Method in class org.springframework.batch.core.configuration.support.JobRegistryBeanPostProcessor
-
Deprecated.Determine a group name for the job to be registered.
- getGroupName(BeanDefinition, Job) - Method in class org.springframework.batch.core.configuration.support.JobRegistrySmartInitializingSingleton
-
Determine a group name for the job to be registered.
- getHighCardinalityKeyValues(BatchJobContext) - Method in class org.springframework.batch.core.observability.DefaultBatchJobObservationConvention
- getHighCardinalityKeyValues(BatchStepContext) - Method in class org.springframework.batch.core.observability.DefaultBatchStepObservationConvention
- getId() - Method in class org.springframework.batch.core.Entity
- getId() - Method in class org.springframework.batch.core.scope.context.JobContext
- getId() - Method in class org.springframework.batch.core.scope.context.StepContext
- getIdentifyingParameters() - Method in class org.springframework.batch.core.JobParameters
-
Get a map of identifying parameters.
- 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
- getIncrementerFactory() - Method in class org.springframework.batch.core.configuration.support.DefaultBatchConfiguration
-
Return the factory for creating
DataFieldMaxValueIncrementer
implementations used to increment entity IDs in meta-data tables. - getInput() - Method in exception org.springframework.batch.item.file.FlatFileParseException
- getInput() - Method in exception org.springframework.batch.item.file.NonTransientFlatFileException
- getInput() - Method in exception org.springframework.batch.item.file.transform.FlatFileFormatException
-
Retrieve the input that caused this exception.
- getInput() - Method in exception org.springframework.batch.item.file.transform.IncorrectTokenCountException
- getInputChannelAttributeName() - Method in class org.springframework.batch.integration.config.xml.JobLaunchingGatewayParser
- getInstanceId() - Method in class org.springframework.batch.core.JobInstance
- 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.
- getIsolationLevelForCreate() - Method in class org.springframework.batch.core.configuration.support.DefaultBatchConfiguration
-
Return the transaction isolation level when creating job executions.
- getItem() - Method in class org.springframework.batch.item.SkipWrapper
-
Public getter for the item.
- getItemListeners() - Method in class org.springframework.batch.core.step.builder.SimpleStepBuilder
- getItemProcessor() - Method in class org.springframework.batch.core.step.factory.SimpleStepFactoryBean
-
Protected getter for the
ItemProcessor
for subclasses to use - getItemReader() - Method in class org.springframework.batch.core.step.factory.SimpleStepFactoryBean
-
Protected getter for the
ItemReader
for subclasses to use. - getItems() - Method in class org.springframework.batch.integration.chunk.ChunkRequest
- getItems() - Method in class org.springframework.batch.item.Chunk
- getItemWriter() - Method in class org.springframework.batch.core.step.factory.SimpleStepFactoryBean
-
Protected getter for the
ItemWriter
for subclasses to use - getJdbcOperations() - Method in class org.springframework.batch.core.configuration.support.DefaultBatchConfiguration
-
Return the
JdbcOperations
. - getJdbcTemplate() - Method in class org.springframework.batch.core.repository.dao.AbstractJdbcBatchMetadataDao
- getJob() - Method in class org.springframework.batch.integration.launch.JobLaunchRequest
- getJob() - Method in class org.springframework.batch.test.JobLauncherTestUtils
- getJob(String) - Method in interface org.springframework.batch.core.configuration.JobLocator
-
Locates a
Job
at runtime. - getJob(String) - Method in class org.springframework.batch.core.configuration.support.MapJobRegistry
- getJobExecution() - Method in interface org.springframework.batch.core.job.flow.FlowExecutor
- getJobExecution() - Method in class org.springframework.batch.core.job.flow.JobFlowExecutor
- getJobExecution() - Method in class org.springframework.batch.core.observability.BatchJobContext
- getJobExecution() - Method in class org.springframework.batch.core.scope.context.JobContext
-
The current
JobExecution
that is active in this context. - getJobExecution() - Method in class org.springframework.batch.core.StepExecution
-
Accessor for the execution context information of the enclosing job.
- getJobExecution(Long) - Method in interface org.springframework.batch.core.explore.JobExplorer
-
Retrieve a
JobExecution
by its ID. - getJobExecution(Long) - Method in class org.springframework.batch.core.explore.support.SimpleJobExplorer
- getJobExecution(Long) - Method in class org.springframework.batch.core.repository.dao.JdbcJobExecutionDao
- getJobExecution(Long) - Method in interface org.springframework.batch.core.repository.dao.JobExecutionDao
- getJobExecution(TestContext) - Method in class org.springframework.batch.test.JobScopeTestExecutionListener
-
Discover a
JobExecution
as a field in the test case or create one if none is available. - getJobExecutionContext() - Method in class org.springframework.batch.core.scope.context.JobContext
- getJobExecutionContext() - Method in class org.springframework.batch.core.scope.context.StepContext
- getJobExecutionDao() - Method in class org.springframework.batch.core.explore.support.SimpleJobExplorer
- getJobExecutionId() - Method in class org.springframework.batch.core.StepExecution
-
Accessor for the job execution ID.
- getJobExecutionId() - Method in class org.springframework.batch.integration.partition.StepExecutionRequest
- getJobExecutionListeners() - Method in class org.springframework.batch.core.job.builder.JobBuilderHelper.CommonJobProperties
- getJobExecutions(JobInstance) - Method in interface org.springframework.batch.core.explore.JobExplorer
-
Retrieve job executions by their job instance.
- getJobExecutions(JobInstance) - Method in class org.springframework.batch.core.explore.support.SimpleJobExplorer
- getJobId() - Method in class org.springframework.batch.core.JobExecution
-
Convenience getter for the
id
of the enclosing job. - getJobId() - Method in class org.springframework.batch.integration.chunk.ChunkMessageChannelItemWriter.LocalState
- getJobId() - Method in class org.springframework.batch.integration.chunk.ChunkRequest
- getJobId() - Method in class org.springframework.batch.integration.chunk.ChunkResponse
- getJobInstance() - Method in class org.springframework.batch.core.JobExecution
- getJobInstance(Long) - Method in interface org.springframework.batch.core.explore.JobExplorer
- getJobInstance(Long) - Method in class org.springframework.batch.core.explore.support.SimpleJobExplorer
- getJobInstance(Long) - Method in class org.springframework.batch.core.repository.dao.JdbcJobInstanceDao
- getJobInstance(Long) - Method in interface org.springframework.batch.core.repository.dao.JobInstanceDao
-
Fetch the job instance with the provided identifier.
- getJobInstance(String, JobParameters) - Method in interface org.springframework.batch.core.explore.JobExplorer
- getJobInstance(String, JobParameters) - Method in class org.springframework.batch.core.explore.support.SimpleJobExplorer
- getJobInstance(String, JobParameters) - Method in interface org.springframework.batch.core.launch.JobOperator
- getJobInstance(String, JobParameters) - Method in class org.springframework.batch.core.launch.support.SimpleJobOperator
- getJobInstance(String, JobParameters) - Method in class org.springframework.batch.core.repository.dao.JdbcJobInstanceDao
-
The job table is queried for any jobs that match the given identifier, adding them to a list via the RowMapper callback.
- getJobInstance(String, JobParameters) - Method in interface org.springframework.batch.core.repository.dao.JobInstanceDao
-
Find the job instance that matches the given name and parameters.
- getJobInstance(String, JobParameters) - Method in interface org.springframework.batch.core.repository.JobRepository
- getJobInstance(String, JobParameters) - Method in class org.springframework.batch.core.repository.support.SimpleJobRepository
- getJobInstance(JobExecution) - Method in class org.springframework.batch.core.repository.dao.JdbcJobInstanceDao
- getJobInstance(JobExecution) - Method in interface org.springframework.batch.core.repository.dao.JobInstanceDao
-
Fetch the JobInstance for the provided JobExecution.
- getJobInstanceCount(String) - Method in interface org.springframework.batch.core.explore.JobExplorer
-
Query the repository for the number of unique
JobInstance
objects associated with the supplied job name. - getJobInstanceCount(String) - Method in class org.springframework.batch.core.explore.support.SimpleJobExplorer
- getJobInstanceCount(String) - Method in class org.springframework.batch.core.repository.dao.JdbcJobInstanceDao
- getJobInstanceCount(String) - Method in interface org.springframework.batch.core.repository.dao.JobInstanceDao
-
Query the repository for the number of unique
JobInstance
s associated with the supplied job name. - getJobInstanceDao() - Method in class org.springframework.batch.core.explore.support.SimpleJobExplorer
- getJobInstanceId() - Method in class org.springframework.batch.core.scope.context.StepContext
-
Convenient accessor for current
JobInstance
identifier. - getJobInstances(String, int, int) - Method in interface org.springframework.batch.core.explore.JobExplorer
-
Fetch
JobInstance
values in descending order of creation (and, therefore, usually, of first execution). - getJobInstances(String, int, int) - Method in class org.springframework.batch.core.explore.support.SimpleJobExplorer
- getJobInstances(String, int, int) - Method in interface org.springframework.batch.core.launch.JobOperator
-
List the
JobInstances
for a given job name, in reverse order of creation (and therefore usually of first execution). - getJobInstances(String, int, int) - Method in class org.springframework.batch.core.launch.support.SimpleJobOperator
- getJobInstances(String, int, int) - Method in class org.springframework.batch.core.repository.dao.JdbcJobInstanceDao
- getJobInstances(String, int, int) - Method in interface org.springframework.batch.core.repository.dao.JobInstanceDao
-
Fetch the last job instances with the provided name, sorted backwards by primary key.
- getJobKeyGenerator() - Method in class org.springframework.batch.core.configuration.support.DefaultBatchConfiguration
-
A custom implementation of the
JobKeyGenerator
. - getJobLauncher() - Method in class org.springframework.batch.test.JobLauncherTestUtils
- getJobName() - Method in interface org.springframework.batch.core.configuration.JobFactory
- getJobName() - Method in class org.springframework.batch.core.configuration.support.ApplicationContextJobFactory
-
Return the name of the instance passed in on initialization.
- getJobName() - Method in class org.springframework.batch.core.configuration.support.ReferenceJobFactory
-
Return the name of the instance that was passed in on initialization.
- getJobName() - Method in class org.springframework.batch.core.JobInstance
- getJobName() - Method in class org.springframework.batch.core.scope.context.JobContext
-
Convenient accessor for current job name identifier.
- getJobName() - Method in class org.springframework.batch.core.scope.context.StepContext
-
Convenient accessor for current job name identifier.
- getJobNames() - Method in interface org.springframework.batch.core.configuration.ListableJobLocator
-
Provides the currently registered job names.
- getJobNames() - Method in class org.springframework.batch.core.configuration.support.MapJobRegistry
-
Provides an unmodifiable view of the job names.
- getJobNames() - Method in interface org.springframework.batch.core.explore.JobExplorer
-
Query the repository for all unique
JobInstance
names (sorted alphabetically). - getJobNames() - Method in class org.springframework.batch.core.explore.support.SimpleJobExplorer
- getJobNames() - Method in interface org.springframework.batch.core.launch.JobOperator
-
List the available job names that can be launched with
JobOperator.start(String, Properties)
. - getJobNames() - Method in class org.springframework.batch.core.launch.support.SimpleJobOperator
- getJobNames() - Method in class org.springframework.batch.core.repository.dao.JdbcJobInstanceDao
- getJobNames() - Method in interface org.springframework.batch.core.repository.dao.JobInstanceDao
-
Retrieve the names of all job instances sorted alphabetically - i.e. jobs that have ever been executed.
- getJobNames() - Method in interface org.springframework.batch.core.repository.JobRepository
-
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.support.SimpleJobRepository
- getJobParameters() - Method in class org.springframework.batch.core.JobExecution
- getJobParameters() - Method in class org.springframework.batch.core.scope.context.JobContext
- getJobParameters() - Method in class org.springframework.batch.core.scope.context.StepContext
- getJobParameters() - Method in class org.springframework.batch.core.StepExecution
-
Convenience method to get the current job parameters.
- getJobParameters() - Method in class org.springframework.batch.integration.launch.JobLaunchRequest
- getJobParameters(Long) - Method in class org.springframework.batch.core.repository.dao.JdbcJobExecutionDao
- getJobParameters(Properties) - Method in class org.springframework.batch.core.converter.DefaultJobParametersConverter
- getJobParameters(Properties) - Method in interface org.springframework.batch.core.converter.JobParametersConverter
-
Get a new
JobParameters
instance. - getJobParameters(Job, StepExecution) - Method in class org.springframework.batch.core.step.job.DefaultJobParametersExtractor
- getJobParameters(Job, StepExecution) - Method in interface org.springframework.batch.core.step.job.JobParametersExtractor
-
Extract job parameters from the step execution, for example from the execution context or other properties.
- getJobParametersIncrementer() - Method in class org.springframework.batch.core.configuration.support.GroupAwareJob
- getJobParametersIncrementer() - Method in class org.springframework.batch.core.job.AbstractJob
- getJobParametersIncrementer() - Method in class org.springframework.batch.core.job.builder.JobBuilderHelper.CommonJobProperties
- getJobParametersIncrementer() - Method in interface org.springframework.batch.core.Job
-
If clients need to generate new parameters for the next execution in a sequence, they can use this incrementer.
- getJobParametersValidator() - Method in class org.springframework.batch.core.configuration.support.GroupAwareJob
- getJobParametersValidator() - Method in class org.springframework.batch.core.job.AbstractJob
- getJobParametersValidator() - Method in class org.springframework.batch.core.job.builder.JobBuilderHelper.CommonJobProperties
- getJobParametersValidator() - Method in interface org.springframework.batch.core.Job
-
A validator for the job parameters of a
JobExecution
. - getJobRepository() - Method in class org.springframework.batch.core.configuration.xml.JobParserJobFactoryBean
- getJobRepository() - Method in class org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
- getJobRepository() - Method in class org.springframework.batch.core.job.AbstractJob
-
Convenience method for subclasses to access the job repository.
- getJobRepository() - Method in class org.springframework.batch.core.job.builder.JobBuilderHelper.CommonJobProperties
- getJobRepository() - Method in class org.springframework.batch.core.job.builder.JobBuilderHelper
- getJobRepository() - Method in class org.springframework.batch.core.job.SimpleStepHandler
- getJobRepository() - Method in class org.springframework.batch.core.step.AbstractStep
- getJobRepository() - Method in class org.springframework.batch.core.step.builder.StepBuilderHelper.CommonStepProperties
- getJobRepository() - Method in class org.springframework.batch.core.step.builder.StepBuilderHelper
- getJobRepository() - Method in class org.springframework.batch.test.JobLauncherTestUtils
- getKey() - Method in class org.springframework.batch.core.launch.support.DataFieldMaxValueJobParametersIncrementer
-
Get the key.
- getKey(Object) - Method in interface org.springframework.batch.core.step.item.KeyGenerator
- getKey(Object[]) - Method in class org.springframework.batch.item.jms.JmsMethodArgumentsKeyGenerator
-
If the message is a
Message
then returns the JMS message ID. - getKey(String) - Method in class org.springframework.batch.item.util.ExecutionContextUserSupport
-
Prefix the argument with
ExecutionContextUserSupport.getName()
to create a unique key that can be safely used to identify data stored inExecutionContext
. - getLastJobExecution(String, JobParameters) - Method in interface org.springframework.batch.core.repository.JobRepository
- getLastJobExecution(String, JobParameters) - Method in class org.springframework.batch.core.repository.support.SimpleJobRepository
- getLastJobExecution(JobInstance) - Method in interface org.springframework.batch.core.explore.JobExplorer
-
Find the last
JobExecution
that has been created for a givenJobInstance
. - getLastJobExecution(JobInstance) - Method in class org.springframework.batch.core.explore.support.SimpleJobExplorer
- getLastJobExecution(JobInstance) - Method in class org.springframework.batch.core.repository.dao.JdbcJobExecutionDao
- getLastJobExecution(JobInstance) - Method in interface org.springframework.batch.core.repository.dao.JobExecutionDao
-
Find the last
JobExecution
to have been created for a givenJobInstance
. - getLastJobInstance(String) - Method in interface org.springframework.batch.core.explore.JobExplorer
-
Find the last job instance, by ID, for the given job.
- getLastJobInstance(String) - Method in class org.springframework.batch.core.explore.support.SimpleJobExplorer
- getLastJobInstance(String) - Method in class org.springframework.batch.core.repository.dao.JdbcJobInstanceDao
- getLastJobInstance(String) - Method in interface org.springframework.batch.core.repository.dao.JobInstanceDao
-
Fetch the last job instance by Id for the given job.
- getLastStepExecution(JobInstance, String) - Method in class org.springframework.batch.core.repository.dao.JdbcStepExecutionDao
- getLastStepExecution(JobInstance, String) - Method in interface org.springframework.batch.core.repository.dao.StepExecutionDao
-
Retrieve the last
StepExecution
for a givenJobInstance
ordered by creation time and then id. - getLastStepExecution(JobInstance, String) - Method in interface org.springframework.batch.core.repository.JobRepository
- getLastStepExecution(JobInstance, String) - Method in class org.springframework.batch.core.repository.support.SimpleJobRepository
- getLastUpdated() - Method in class org.springframework.batch.core.JobExecution
-
Get the date representing the last time this
JobExecution
was updated in theJobRepository
. - getLastUpdated() - Method in class org.springframework.batch.core.StepExecution
- getLineNumber() - Method in exception org.springframework.batch.item.file.FlatFileParseException
- getLineNumber() - Method in exception org.springframework.batch.item.file.NonTransientFlatFileException
- getLinesWritten() - Method in class org.springframework.batch.item.support.AbstractFileItemWriter.OutputState
- getListener() - Method in class org.springframework.batch.core.step.item.SimpleChunkProcessor
- getListener() - Method in class org.springframework.batch.core.step.item.SimpleChunkProvider
- getListener(Object) - Static method in class org.springframework.batch.core.listener.JobListenerFactoryBean
-
Convenience method to wrap any object and expose the appropriate
JobExecutionListener
interfaces. - getListener(Object) - Static method in class org.springframework.batch.core.listener.StepListenerFactoryBean
-
Convenience method to wrap any object and expose the appropriate
StepListener
interfaces. - getListenerInterface() - Method in enum class org.springframework.batch.core.listener.JobListenerMetaData
- getListenerInterface() - Method in interface org.springframework.batch.core.listener.ListenerMetaData
- getListenerInterface() - Method in enum class org.springframework.batch.core.listener.StepListenerMetaData
- getListeners() - Method in class org.springframework.batch.core.step.factory.SimpleStepFactoryBean
-
Protected getter for the
StepListener
s. - getLobHandler() - Method in class org.springframework.batch.core.configuration.support.DefaultBatchConfiguration
-
A special handler for large objects.
- getLocalDate(String) - Method in class org.springframework.batch.core.JobParameters
-
Typesafe getter for the
LocalDate
represented by the provided key. - getLocalDate(String, LocalDate) - Method in class org.springframework.batch.core.JobParameters
-
Typesafe getter for the
LocalDate
represented by the provided key. - getLocalDateTime(String) - Method in class org.springframework.batch.core.JobParameters
-
Typesafe getter for the
LocalDateTime
represented by the provided key. - getLocalDateTime(String, LocalDateTime) - Method in class org.springframework.batch.core.JobParameters
-
Typesafe getter for the
LocalDateTime
represented by the provided key. - getLocalTime(String) - Method in class org.springframework.batch.core.JobParameters
-
Typesafe getter for the
LocalTime
represented by the provided key. - getLocalTime(String, LocalTime) - Method in class org.springframework.batch.core.JobParameters
-
Typesafe getter for the
LocalTime
represented by the provided key. - 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) - 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.
- getLong(String, Long) - Method in class org.springframework.batch.core.JobParameters
-
Typesafe getter for the
Long
represented by the provided key. - getLowCardinalityKeyValues(BatchJobContext) - Method in class org.springframework.batch.core.observability.DefaultBatchJobObservationConvention
- getLowCardinalityKeyValues(BatchStepContext) - Method in class org.springframework.batch.core.observability.DefaultBatchStepObservationConvention
- getMapping() - Method in class org.springframework.batch.core.launch.support.SimpleJvmExitCodeMapper
- getMax() - Method in class org.springframework.batch.item.file.transform.Range
- getMaxVarCharLength() - Method in class org.springframework.batch.core.configuration.support.DefaultBatchConfiguration
-
Return the length of long string columns in database.
- getMessage() - Method in class org.springframework.batch.integration.chunk.ChunkResponse
- getMetaDataFromPropertyName(String) - Method in class org.springframework.batch.core.listener.AbstractListenerFactoryBean
- getMetaDataFromPropertyName(String) - Method in class org.springframework.batch.core.listener.JobListenerFactoryBean
- getMetaDataFromPropertyName(String) - Method in class org.springframework.batch.core.listener.StepListenerFactoryBean
- getMetaDataValues() - Method in class org.springframework.batch.core.configuration.xml.AbstractListenerParser
-
Gets the metadata values.
- getMetaDataValues() - Method in class org.springframework.batch.core.configuration.xml.JobExecutionListenerParser
- getMetaDataValues() - Method in class org.springframework.batch.core.configuration.xml.StepListenerParser
- getMetaDataValues() - Method in class org.springframework.batch.core.listener.AbstractListenerFactoryBean
- getMetaDataValues() - Method in class org.springframework.batch.core.listener.JobListenerFactoryBean
- getMetaDataValues() - Method in class org.springframework.batch.core.listener.StepListenerFactoryBean
- getMeterRegistry() - Method in class org.springframework.batch.core.job.builder.JobBuilderHelper.CommonJobProperties
- getMeterRegistry() - Method in class org.springframework.batch.core.step.builder.StepBuilderHelper.CommonStepProperties
- 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. - 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.
- getMethodInvokerByName(Object, String, boolean, Class<?>...) - Static method in class org.springframework.batch.support.MethodInvokerUtils
-
Create a
MethodInvoker
using the provided method name to search. - getMethodInvokerByName(String, Object, Class<?>...) - Method in class org.springframework.batch.core.listener.AbstractListenerFactoryBean
- 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 class org.springframework.batch.core.listener.JobListenerMetaData
- getMethodName() - Method in interface org.springframework.batch.core.listener.ListenerMetaData
- getMethodName() - Method in enum class org.springframework.batch.core.listener.StepListenerMetaData
- getMin() - Method in class org.springframework.batch.item.file.transform.Range
- getMode() - Method in class org.springframework.batch.item.data.MongoItemWriter
-
Get the operating
MongoItemWriter.Mode
of the item writer. - getName() - Method in class org.springframework.batch.core.configuration.support.GroupAwareJob
-
Concatenates the group name and the delegate job name (joining with a ".").
- getName() - Method in class org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
- getName() - Method in class org.springframework.batch.core.job.AbstractJob
- getName() - Method in class org.springframework.batch.core.job.builder.JobBuilderHelper.CommonJobProperties
- getName() - Method in class org.springframework.batch.core.job.builder.JobBuilderHelper
- getName() - Method in interface org.springframework.batch.core.job.flow.Flow
- getName() - Method in class org.springframework.batch.core.job.flow.FlowExecution
- getName() - Method in class org.springframework.batch.core.job.flow.FlowExecutionStatus
- getName() - Method in interface org.springframework.batch.core.job.flow.State
-
The name of the state.
- getName() - Method in class org.springframework.batch.core.job.flow.support.SimpleFlow
-
Get the name for this flow.
- getName() - Method in class org.springframework.batch.core.job.flow.support.state.AbstractState
- getName() - Method in interface org.springframework.batch.core.Job
- getName() - Method in class org.springframework.batch.core.scope.BatchScopeSupport
- getName() - Method in class org.springframework.batch.core.step.AbstractStep
- getName() - Method in class org.springframework.batch.core.step.builder.StepBuilderHelper.CommonStepProperties
- getName() - Method in class org.springframework.batch.core.step.builder.StepBuilderHelper
- getName() - Method in class org.springframework.batch.core.step.factory.SimpleStepFactoryBean
-
Public getter for the name of the step.
- getName() - Method in interface org.springframework.batch.core.Step
- getName() - Method in class org.springframework.batch.item.ItemStreamSupport
-
Get the name of the component
- getName() - Method in class org.springframework.batch.item.util.ExecutionContextUserSupport
- getNames() - Method in class org.springframework.batch.item.file.transform.DefaultFieldSet
- getNames() - Method in interface org.springframework.batch.item.file.transform.FieldSet
-
Accessor for the names of the fields.
- getNamespaceContext() - Method in class org.springframework.batch.item.xml.stax.NoStartEndDocumentStreamWriter
- getNext() - Method in class org.springframework.batch.core.job.flow.support.StateTransition
-
Public getter for the next State name.
- getNext(JobParameters) - Method in interface org.springframework.batch.core.JobParametersIncrementer
-
Increments the provided parameters.
- getNext(JobParameters) - Method in class org.springframework.batch.core.launch.support.DataFieldMaxValueJobParametersIncrementer
- getNext(JobParameters) - Method in class org.springframework.batch.core.launch.support.RunIdIncrementer
-
Increment the run.id parameter (starting with 1).
- getNextElements(ParserContext, String, BeanDefinition, Element) - Static method in class org.springframework.batch.core.configuration.xml.AbstractFlowParser
-
Retrieve a list of
StateTransition
instances from aParserContext
. - getNextElements(ParserContext, BeanDefinition, Element) - Static method in class org.springframework.batch.core.configuration.xml.AbstractFlowParser
- getNextJobParameters(Job) - Method in class org.springframework.batch.core.JobParametersBuilder
-
Initializes the
JobParameters
based on the state of theJob
. - getNextResult() - Method in class org.springframework.batch.integration.chunk.ChunkMessageChannelItemWriter
-
Get the next result if it is available (within the timeout specified in the gateway), otherwise do nothing.
- getNextResult(RepeatContext, RepeatCallback, RepeatInternalState) - Method in class org.springframework.batch.repeat.support.RepeatTemplate
-
Get the next completed result, possibly executing several callbacks until one finally finishes.
- getNextResult(RepeatContext, RepeatCallback, RepeatInternalState) - Method in class org.springframework.batch.repeat.support.TaskExecutorRepeatTemplate
-
Use the
TaskExecutorRepeatTemplate.setTaskExecutor(TaskExecutor)
to generate a result. - getObject() - Method in class org.springframework.batch.core.configuration.support.ClasspathXmlApplicationContextsFactoryBean
-
Create an
ApplicationContextFactory
from each resource provided inClasspathXmlApplicationContextsFactoryBean.setResources(Resource[])
. - getObject() - Method in class org.springframework.batch.core.configuration.xml.JobParserJobFactoryBean
- getObject() - Method in class org.springframework.batch.core.configuration.xml.SimpleFlowFactoryBean
- getObject() - Method in class org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
-
Create a
Step
from the configuration provided. - getObject() - Method in class org.springframework.batch.core.explore.support.AbstractJobExplorerFactoryBean
- getObject() - Method in class org.springframework.batch.core.launch.support.JobOperatorFactoryBean
- getObject() - Method in class org.springframework.batch.core.listener.AbstractListenerFactoryBean
- getObject() - Method in class org.springframework.batch.core.repository.support.AbstractJobRepositoryFactoryBean
- getObject() - Method in class org.springframework.batch.core.step.factory.SimpleStepFactoryBean
-
Create a
Step
from the configuration provided. - getObject() - Method in class org.springframework.batch.core.step.StepLocatorStepFactoryBean
- getObject() - Method in class org.springframework.batch.integration.chunk.RemoteChunkHandlerFactoryBean
- getObject() - Method in class org.springframework.batch.item.database.support.SqlPagingQueryProviderFactoryBean
-
Get a
PagingQueryProvider
instance using the provided properties and appropriate for the given database type. - getObjectType() - Method in class org.springframework.batch.core.configuration.support.ClasspathXmlApplicationContextsFactoryBean
-
The type of object returned by this factory as an array of
ApplicationContextFactory
. - getObjectType() - Method in class org.springframework.batch.core.configuration.xml.JobParserJobFactoryBean
- getObjectType() - Method in class org.springframework.batch.core.configuration.xml.SimpleFlowFactoryBean
- getObjectType() - Method in class org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
- getObjectType() - Method in class org.springframework.batch.core.explore.support.AbstractJobExplorerFactoryBean
-
Returns the type of object to be returned from
AbstractJobExplorerFactoryBean.getObject()
. - getObjectType() - Method in class org.springframework.batch.core.launch.support.JobOperatorFactoryBean
- getObjectType() - Method in class org.springframework.batch.core.listener.JobListenerFactoryBean
- getObjectType() - Method in class org.springframework.batch.core.listener.StepListenerFactoryBean
- getObjectType() - Method in class org.springframework.batch.core.repository.support.AbstractJobRepositoryFactoryBean
-
The type of object to be returned from
AbstractJobRepositoryFactoryBean.getObject()
. - getObjectType() - Method in class org.springframework.batch.core.step.factory.SimpleStepFactoryBean
- getObjectType() - Method in class org.springframework.batch.core.step.StepLocatorStepFactoryBean
-
Tell clients that we are a factory for
Step
instances. - getObjectType() - Method in class org.springframework.batch.integration.chunk.RemoteChunkHandlerFactoryBean
-
The type of object created by this factory.
- getObjectType() - Method in class org.springframework.batch.item.database.support.SqlPagingQueryProviderFactoryBean
-
Always returns
PagingQueryProvider
. - getObservationConvention() - Method in class org.springframework.batch.core.job.builder.JobBuilderHelper.CommonJobProperties
- getObservationConvention() - Method in class org.springframework.batch.core.step.builder.StepBuilderHelper.CommonStepProperties
- getObservationRegistry() - Method in class org.springframework.batch.core.job.builder.JobBuilderHelper.CommonJobProperties
- getObservationRegistry() - Method in class org.springframework.batch.core.step.builder.StepBuilderHelper.CommonStepProperties
- getOffset() - Method in class org.springframework.batch.core.step.item.ChunkMonitor
- getOrder() - Method in class org.springframework.batch.core.configuration.support.AutomaticJobRegistrar
- getOrder() - Method in class org.springframework.batch.core.scope.BatchScopeSupport
- getOrderedQueryAlias() - Method in class org.springframework.batch.item.database.support.DerbyPagingQueryProvider
- getOrderedQueryAlias() - Method in class org.springframework.batch.item.database.support.SqlWindowingPagingQueryProvider
- getOutputState() - Method in class org.springframework.batch.item.support.AbstractFileItemWriter
- getOverClause() - Method in class org.springframework.batch.item.database.support.DerbyPagingQueryProvider
- getOverClause() - Method in class org.springframework.batch.item.database.support.SqlWindowingPagingQueryProvider
- getOverSubstituteClauseEnd() - Method in class org.springframework.batch.item.database.support.DerbyPagingQueryProvider
- getOverSubstituteClauseEnd() - Method in class org.springframework.batch.item.database.support.SqlWindowingPagingQueryProvider
- getOverSubstituteClauseStart() - Method in class org.springframework.batch.item.database.support.DerbyPagingQueryProvider
- getOverSubstituteClauseStart() - Method in class org.springframework.batch.item.database.support.SqlWindowingPagingQueryProvider
- getPage() - Method in class org.springframework.batch.item.database.AbstractPagingItemReader
-
The current page number.
- getPageSize() - Method in class org.springframework.batch.item.database.AbstractPagingItemReader
-
The page size configured for this reader.
- getParameter(String) - Method in class org.springframework.batch.core.JobParameters
- 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.
- getParameters(long) - Method in interface org.springframework.batch.core.launch.JobOperator
-
Get the
JobParameters
as a human readable String (new line separated key=value pairs). - getParameters(long) - Method in class org.springframework.batch.core.launch.support.SimpleJobOperator
- getParameterValues() - Method in class org.springframework.batch.item.data.Neo4jItemReader
-
Deprecated.
- getParamTypes() - Method in enum class org.springframework.batch.core.listener.JobListenerMetaData
- getParamTypes() - Method in interface org.springframework.batch.core.listener.ListenerMetaData
- getParamTypes() - Method in enum class org.springframework.batch.core.listener.StepListenerMetaData
- getParamTypesString(Class<?>...) - Static method in class org.springframework.batch.support.MethodInvokerUtils
-
Create a String representation of the array of parameter types.
- getParent() - Method in class org.springframework.batch.repeat.context.RepeatContextSupport
- getParent() - Method in interface org.springframework.batch.repeat.RepeatContext
-
If batches are nested, then the inner batch will be created with the outer one as a parent.
- getParentLogger() - Method in class org.springframework.batch.item.database.ExtendedConnectionDataSourceProxy
-
Added due to JDK 7 compatibility.
- getPartitioner() - Method in class org.springframework.batch.core.step.builder.PartitionStepBuilder
- getPartitionHandler() - Method in class org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
- getPartitionHandler() - Method in class org.springframework.batch.core.partition.support.PartitionStep
- getPartitionHandler() - Method in class org.springframework.batch.core.step.builder.PartitionStepBuilder
- getPartitionNames(int) - Method in interface org.springframework.batch.core.partition.support.PartitionNameProvider
- getPattern() - Method in class org.springframework.batch.core.job.flow.support.StateTransition
- getPhase() - Method in class org.springframework.batch.core.configuration.support.AutomaticJobRegistrar
- getPrefix(String) - Method in class org.springframework.batch.item.xml.stax.NoStartEndDocumentStreamWriter
- getProcessor() - Method in class org.springframework.batch.core.step.builder.SimpleStepBuilder
- getProcessSkipCount() - Method in class org.springframework.batch.core.StepContribution
-
Public getter for the process skip count.
- getProcessSkipCount() - Method in class org.springframework.batch.core.StepExecution
- getProductName() - Method in enum class org.springframework.batch.support.DatabaseType
- 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.
- getProperties(JobParameters) - Method in class org.springframework.batch.core.converter.DefaultJobParametersConverter
- getProperties(JobParameters) - Method in interface org.springframework.batch.core.converter.JobParametersConverter
-
The inverse operation: get a
Properties
instance. - getProperty(String) - Method in class org.springframework.batch.item.xml.stax.DefaultFragmentEventReader
- getPropertyName() - Method in enum class org.springframework.batch.core.listener.JobListenerMetaData
- getPropertyName() - Method in interface org.springframework.batch.core.listener.ListenerMetaData
- getPropertyName() - Method in enum class org.springframework.batch.core.listener.StepListenerMetaData
- getPropertyValue(String, String, ConfigurableListableBeanFactory) - Static method in class org.springframework.batch.core.configuration.xml.BeanDefinitionUtils
- getQuery(String) - Method in class org.springframework.batch.core.repository.dao.AbstractJdbcBatchMetadataDao
- getReadCount() - Method in class org.springframework.batch.core.StepContribution
-
Public access to the read counter.
- getReadCount() - Method in class org.springframework.batch.core.StepExecution
-
Returns the current number of items read for this execution.
- getReader() - Method in class org.springframework.batch.core.step.builder.SimpleStepBuilder
- getReadSkipCount() - Method in class org.springframework.batch.core.StepContribution
-
Public getter for the read skip count.
- getReadSkipCount() - Method in class org.springframework.batch.core.StepExecution
- getRequest(Chunk<? extends T>) - Method in class org.springframework.batch.integration.chunk.ChunkMessageChannelItemWriter.LocalState
- getRestartable() - Method in class org.springframework.batch.core.job.builder.JobBuilderHelper.CommonJobProperties
- getRollbackClassifier() - Method in class org.springframework.batch.core.step.builder.FaultTolerantStepBuilder
-
Convenience method to get an exception classifier based on the provided transaction attributes.
- getRollbackCount() - Method in class org.springframework.batch.core.StepExecution
-
Returns the current number of rollbacks for this execution.
- getRootElementAttributes() - Method in class org.springframework.batch.item.xml.StaxEventItemWriter
-
Get attributes of the root element.
- getRootTagName() - Method in class org.springframework.batch.item.xml.StaxEventItemWriter
-
Get the tag name of the root element.
- getRootTagNamespace() - Method in class org.springframework.batch.item.xml.StaxEventItemWriter
-
Get the namespace of the root element.
- getRootTagNamespacePrefix() - Method in class org.springframework.batch.item.xml.StaxEventItemWriter
-
Get the namespace prefix of the root element.
- getRunningExecutions(String) - Method in interface org.springframework.batch.core.launch.JobOperator
-
Get the id values of all the running
JobExecutions
with the given job name. - getRunningExecutions(String) - Method in class org.springframework.batch.core.launch.support.SimpleJobOperator
- getSelectClause() - Method in class org.springframework.batch.item.database.support.AbstractSqlPagingQueryProvider
- getSequence() - Method in class org.springframework.batch.integration.chunk.ChunkRequest
- getSequence() - Method in class org.springframework.batch.integration.chunk.ChunkResponse
- getSessionFactory() - Method in class org.springframework.batch.item.data.Neo4jItemReader
-
Deprecated.
- getSimpleStepBuilder(String) - Method in class org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
- getSkipCount() - Method in class org.springframework.batch.core.StepContribution
- getSkipCount() - Method in class org.springframework.batch.core.StepExecution
- getSkipLimit() - Method in exception org.springframework.batch.core.step.skip.SkipLimitExceededException
- getSkipListeners() - Method in class org.springframework.batch.core.step.builder.FaultTolerantStepBuilder
- getSkips() - Method in class org.springframework.batch.item.Chunk
- getSortKeyPlaceHolder(String) - Method in interface org.springframework.batch.item.database.PagingQueryProvider
-
Returns either a String to be used as the named placeholder for a sort key value (based on the column name) or a ?
- getSortKeyPlaceHolder(String) - Method in class org.springframework.batch.item.database.support.AbstractSqlPagingQueryProvider
-
The sort key placeholder will vary depending on whether named parameters or traditional placeholders are used in query strings.
- getSortKeys() - Method in interface org.springframework.batch.item.database.PagingQueryProvider
-
The sort keys.
- getSortKeys() - Method in class org.springframework.batch.item.database.support.AbstractSqlPagingQueryProvider
-
A Map<String, Boolean> of sort columns as the key and boolean for ascending/descending (ascending = true).
- getSortKeysWithoutAliases() - Method in interface org.springframework.batch.item.database.PagingQueryProvider
-
The sort key (unique single column name) without alias.
- getSortKeysWithoutAliases() - Method in class org.springframework.batch.item.database.support.AbstractSqlPagingQueryProvider
- getSplitter() - Method in class org.springframework.batch.core.step.builder.PartitionStepBuilder
- getSql() - Method in class org.springframework.batch.item.database.AbstractCursorItemReader
- getSql() - Method in class org.springframework.batch.item.database.JdbcCursorItemReader
- getSql() - Method in class org.springframework.batch.item.database.StoredProcedureItemReader
- getStandalone() - Method in class org.springframework.batch.item.xml.StaxEventItemWriter
-
Get used standalone document declaration.
- getStartedCount() - Method in class org.springframework.batch.repeat.context.RepeatContextSupport
- getStartedCount() - Method in interface org.springframework.batch.repeat.RepeatContext
-
Public access to a counter for the number of operations attempted.
- getStartLimit() - Method in class org.springframework.batch.core.step.AbstractStep
- getStartLimit() - Method in class org.springframework.batch.core.step.builder.StepBuilderHelper.CommonStepProperties
- getStartLimit() - Method in interface org.springframework.batch.core.Step
- getStartState() - Method in class org.springframework.batch.core.job.flow.support.SimpleFlow
- getStartTime() - Method in class org.springframework.batch.core.JobExecution
- getStartTime() - Method in class org.springframework.batch.core.StepExecution
-
Gets the time when this execution started.
- getState() - Method in class org.springframework.batch.core.configuration.xml.SimpleFlowFactoryBean.DelegateState
-
Gets the current state.
- getState() - Method in class org.springframework.batch.core.job.flow.support.StateTransition
-
Public getter for the State.
- getState(String) - Method in interface org.springframework.batch.core.job.flow.Flow
-
Retrieve the State with the given name.
- getState(String) - Method in class org.springframework.batch.core.job.flow.support.SimpleFlow
-
Retrieve the State with the given name.
- getStateMap() - Method in class org.springframework.batch.core.job.flow.support.SimpleFlow
- getStates() - Method in interface org.springframework.batch.core.job.flow.Flow
-
Convenient accessor for clients needing to explore the states of this flow.
- getStates() - Method in class org.springframework.batch.core.job.flow.support.SimpleFlow
-
Convenient accessor for clients needing to explore the states of this flow.
- getStateTransitionReference(ParserContext, BeanDefinition, String, String) - Static method in class org.springframework.batch.core.configuration.xml.AbstractFlowParser
-
Gets a reference to the state transition.
- getStatus() - Method in class org.springframework.batch.core.job.flow.FlowExecution
- getStatus() - Method in class org.springframework.batch.core.job.flow.support.state.EndState
- getStatus() - Method in class org.springframework.batch.core.JobExecution
- getStatus() - Method in exception org.springframework.batch.core.JobInterruptedException
-
The desired status of the surrounding execution after the interruption.
- getStatus() - Method in class org.springframework.batch.core.StepExecution
-
Returns the current status of this step.
- getStep() - Method in class org.springframework.batch.core.job.flow.support.state.StepState
- getStep() - Method in class org.springframework.batch.core.partition.support.TaskExecutorPartitionHandler
-
The step instance that will be executed in parallel by this handler.
- getStep() - Method in class org.springframework.batch.core.step.builder.PartitionStepBuilder
- getStep() - Method in interface org.springframework.batch.core.step.StepHolder
- getStep(String) - Method in class org.springframework.batch.core.job.AbstractJob
-
Retrieve the step with the given name.
- getStep(String) - Method in class org.springframework.batch.core.job.flow.FlowJob
-
Retrieve the step with the given name.
- getStep(String) - Method in class org.springframework.batch.core.job.flow.support.state.StepState
- getStep(String) - Method in class org.springframework.batch.core.job.SimpleJob
- getStep(String) - Method in interface org.springframework.batch.core.step.StepLocator
- getStep(String) - Method in class org.springframework.batch.integration.partition.BeanFactoryStepLocator
-
Look up a bean with the provided name of type
Step
. - getStep(String, String) - Method in interface org.springframework.batch.core.configuration.StepRegistry
-
Returns the
Step
of the specified job based on its name. - getStep(String, String) - Method in class org.springframework.batch.core.configuration.support.MapStepRegistry
- getStepContext() - Method in class org.springframework.batch.core.scope.context.ChunkContext
- getStepContribution() - Method in class org.springframework.batch.integration.chunk.ChunkRequest
- getStepContribution() - Method in class org.springframework.batch.integration.chunk.ChunkResponse
- getStepContributions() - Method in class org.springframework.batch.integration.chunk.ChunkMessageChannelItemWriter
- getStepContributions() - Method in interface org.springframework.batch.integration.chunk.StepContributionSource
-
Get the currently available contributions and drain the source.
- getStepExecution() - Method in interface org.springframework.batch.core.job.flow.FlowExecutor
- getStepExecution() - Method in class org.springframework.batch.core.job.flow.JobFlowExecutor
- getStepExecution() - Method in class org.springframework.batch.core.observability.BatchStepContext
- getStepExecution() - Method in class org.springframework.batch.core.scope.context.StepContext
-
The current
StepExecution
that is active in this context. - getStepExecution() - Method in class org.springframework.batch.core.StepContribution
-
Public getter for the parent step execution of this contribution.
- getStepExecution(Long, Long) - Method in interface org.springframework.batch.core.explore.JobExplorer
-
Retrieve a
StepExecution
by its ID and parentJobExecution
ID. - getStepExecution(Long, Long) - Method in class org.springframework.batch.core.explore.support.SimpleJobExplorer
- getStepExecution(JobExecution, Long) - Method in class org.springframework.batch.core.repository.dao.JdbcStepExecutionDao
- getStepExecution(JobExecution, Long) - Method in interface org.springframework.batch.core.repository.dao.StepExecutionDao
-
Retrieve a
StepExecution
from its id. - getStepExecution(TestContext) - Method in class org.springframework.batch.test.StepScopeTestExecutionListener
-
Discover a
StepExecution
as a field in the test case or create one if none is available. - getStepExecutionAggergator() - Method in class org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
- getStepExecutionContext() - Method in class org.springframework.batch.core.scope.context.StepContext
- getStepExecutionCount(JobInstance, String) - Method in interface org.springframework.batch.core.repository.JobRepository
- getStepExecutionCount(JobInstance, String) - Method in class org.springframework.batch.core.repository.support.SimpleJobRepository
- getStepExecutionDao() - Method in class org.springframework.batch.core.explore.support.SimpleJobExplorer
- getStepExecutionId() - Method in class org.springframework.batch.integration.partition.StepExecutionRequest
- getStepExecutionListeners() - Method in class org.springframework.batch.core.step.builder.StepBuilderHelper.CommonStepProperties
- getStepExecutions() - Method in class org.springframework.batch.core.JobExecution
-
Accessor for the step executions.
- getStepExecutionSplitter() - Method in class org.springframework.batch.core.partition.support.PartitionStep
- getStepExecutionSummaries(long) - Method in interface org.springframework.batch.core.launch.JobOperator
-
Summarise the
StepExecution
instances belonging to theJobExecution
with the supplied id, giving details of status, start and end times etc. - getStepExecutionSummaries(long) - Method in class org.springframework.batch.core.launch.support.SimpleJobOperator
- getStepName() - Method in interface org.springframework.batch.core.partition.StepExecutionSplitter
-
The name of the step configuration that will be executed remotely.
- getStepName() - Method in class org.springframework.batch.core.partition.support.SimpleStepExecutionSplitter
- getStepName() - Method in class org.springframework.batch.core.scope.context.StepContext
-
Convenient accessor for current step name identifier.
- getStepName() - Method in class org.springframework.batch.core.step.builder.PartitionStepBuilder
- getStepName() - Method in class org.springframework.batch.core.StepExecution
- getStepName() - Method in class org.springframework.batch.integration.partition.StepExecutionRequest
- getStepNames() - Method in class org.springframework.batch.core.job.AbstractJob
-
Retrieve the step names.
- getStepNames() - Method in class org.springframework.batch.core.job.flow.FlowJob
-
Retrieve the step names.
- getStepNames() - Method in class org.springframework.batch.core.job.flow.support.state.StepState
- getStepNames() - Method in class org.springframework.batch.core.job.SimpleJob
-
Convenience method for clients to inspect the steps for this job.
- getStepNames() - Method in interface org.springframework.batch.core.step.StepLocator
- getStepNames() - Method in class org.springframework.batch.integration.partition.BeanFactoryStepLocator
-
Look in the bean factory for all beans of type
Step
. - getStepOperations() - Method in class org.springframework.batch.core.step.builder.AbstractTaskletStepBuilder
-
Convenience method for subclasses to access the step operations that were injected by user.
- getStepOperations() - Method in class org.springframework.batch.core.step.factory.SimpleStepFactoryBean
-
Protected getter for the step operations to make them available in subclasses.
- getStepRunner() - Method in class org.springframework.batch.test.JobLauncherTestUtils
-
Convenient method for subclasses to grab a
StepRunner
for running steps by name. - getStepSkipCount() - Method in class org.springframework.batch.core.StepContribution
- getStreams() - Method in class org.springframework.batch.core.step.builder.AbstractTaskletStepBuilder
- getString(String) - Method in class org.springframework.batch.core.JobParameters
-
Typesafe getter for the
String
represented by the provided key. - getString(String) - 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.core.JobParameters
-
Typesafe getter for the
String
represented by the provided key. - getString(String, String) - Method in class org.springframework.batch.item.ExecutionContext
-
Typesafe Getter for the String represented by the provided key with default value to return if key is not represented.
- getSubQueryAlias() - Method in class org.springframework.batch.item.database.support.Db2PagingQueryProvider
- getSubQueryAlias() - Method in class org.springframework.batch.item.database.support.SqlServerPagingQueryProvider
- getSubQueryAlias() - Method in class org.springframework.batch.item.database.support.SqlWindowingPagingQueryProvider
- getSubQueryAlias() - Method in class org.springframework.batch.item.database.support.SybasePagingQueryProvider
- getSuffix(int) - Method in interface org.springframework.batch.item.file.ResourceSuffixCreator
- getSuffix(int) - Method in class org.springframework.batch.item.file.SimpleResourceSuffixCreator
- getSummary() - Method in class org.springframework.batch.core.StepExecution
- getSummary(long) - Method in interface org.springframework.batch.core.launch.JobOperator
-
Summarise the
JobExecution
with the supplied id, giving details of status, start and end times etc. - getSummary(long) - Method in class org.springframework.batch.core.launch.support.SimpleJobOperator
- getSupportedIncrementerTypes() - Method in interface org.springframework.batch.item.database.support.DataFieldMaxValueIncrementerFactory
-
Returns the list of supported database incrementer types
- getSupportedIncrementerTypes() - Method in class org.springframework.batch.item.database.support.DefaultDataFieldMaxValueIncrementerFactory
- getSystemProperties() - Method in class org.springframework.batch.core.scope.context.JobContext
-
Convenient accessor for System properties to make it easy to access them from placeholder expressions.
- getSystemProperties() - Method in class org.springframework.batch.core.scope.context.StepContext
-
Convenient accessor for System properties to make it easy to access them from placeholder expressions.
- getTablePrefix() - Method in class org.springframework.batch.core.configuration.support.DefaultBatchConfiguration
-
Return the prefix of Batch meta-data tables.
- getTablePrefix() - Method in class org.springframework.batch.core.repository.dao.AbstractJdbcBatchMetadataDao
- getTargetMethod() - Method in class org.springframework.batch.item.adapter.AbstractMethodInvokingDelegator
- getTargetNamePrefix() - Method in class org.springframework.batch.core.scope.BatchScopeSupport
- getTargetNamePrefix() - Method in class org.springframework.batch.core.scope.JobScope
- getTargetNamePrefix() - Method in class org.springframework.batch.core.scope.StepScope
- getTargetObject() - Method in class org.springframework.batch.item.adapter.AbstractMethodInvokingDelegator
- getTargetType() - Method in class org.springframework.batch.item.data.Neo4jItemReader
-
Deprecated.
- getTaskExecutor() - Method in class org.springframework.batch.core.configuration.support.DefaultBatchConfiguration
-
Return the
TaskExecutor
to use in the the job launcher. - getTaskExecutor() - Method in class org.springframework.batch.core.step.builder.AbstractTaskletStepBuilder
- getTaskExecutor() - Method in class org.springframework.batch.core.step.builder.PartitionStepBuilder
- getTaskExecutor() - Method in class org.springframework.batch.core.step.factory.SimpleStepFactoryBean
-
Make the
TaskExecutor
available to subclasses - getTasklet() - Method in class org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
- getTasklet() - Method in class org.springframework.batch.core.step.tasklet.TaskletStep
-
retrieve the tasklet - helper method for JobOperator
- getTemplate() - Method in class org.springframework.batch.item.data.MongoItemWriter
-
Get the
MongoOperations
to be used to save items to be written. - getThrottleLimit() - Method in class org.springframework.batch.core.step.builder.AbstractTaskletStepBuilder
-
Deprecated, for removal: This API element is subject to removal in a future version.
- getThrowables() - Method in interface org.springframework.batch.repeat.support.RepeatInternalState
-
Returns a mutable collection of exceptions that have occurred in the current repeat context.
- getThrowables() - Method in class org.springframework.batch.repeat.support.RepeatInternalStateSupport
- getTransactionAttribute() - Method in class org.springframework.batch.core.step.builder.AbstractTaskletStepBuilder
- getTransactionAttribute() - Method in class org.springframework.batch.core.step.factory.SimpleStepFactoryBean
-
Getter for the
TransactionAttribute
for subclasses only. - getTransactionManager() - Method in class org.springframework.batch.core.configuration.support.DefaultBatchConfiguration
-
Return the transaction manager to use for the job repository.
- getTransactionManager() - Method in class org.springframework.batch.core.configuration.xml.StepParserStepFactoryBean
- getTransactionManager() - Method in class org.springframework.batch.core.explore.support.AbstractJobExplorerFactoryBean
-
The transaction manager used in this factory.
- getTransactionManager() - Method in class org.springframework.batch.core.repository.support.AbstractJobRepositoryFactoryBean
-
The transaction manager used in this factory.
- getTransactionManager() - Method in class org.springframework.batch.core.step.builder.AbstractTaskletStepBuilder
- getTransitionMap() - Method in class org.springframework.batch.core.job.flow.support.SimpleFlow
- getType() - Method in class org.springframework.batch.core.JobParameter
-
Return the type of the parameter.
- getUnclosedElements() - Method in class org.springframework.batch.item.xml.stax.UnclosedElementCollectingEventWriter
- getUniqueJobParameters() - Method in class org.springframework.batch.test.JobLauncherTestUtils
- getUniqueJobParametersBuilder() - Method in class org.springframework.batch.test.JobLauncherTestUtils
- getUserData() - Method in class org.springframework.batch.item.Chunk
- getValidateTransactionState() - Method in class org.springframework.batch.core.configuration.support.DefaultBatchConfiguration
-
Return the value of the
validateTransactionState
parameter. - getValue() - Method in class org.springframework.batch.core.JobParameter
- getValueFromJob(JobExecution, String) - Static method in class org.springframework.batch.test.ExecutionContextTestUtils
- getValueFromStep(StepExecution, String) - Static method in class org.springframework.batch.test.ExecutionContextTestUtils
- getValueFromStepInJob(JobExecution, String, String) - Static method in class org.springframework.batch.test.ExecutionContextTestUtils
- getValues() - Method in class org.springframework.batch.item.file.transform.DefaultFieldSet
- getValues() - Method in interface org.springframework.batch.item.file.transform.FieldSet
- getVersion() - Method in class org.springframework.batch.core.Entity
- getVersion() - Static method in class org.springframework.batch.core.SpringBatchVersion
-
Return the full version string of the present Spring Batch codebase, or
"N/A"
if it cannot be determined. - getVersion() - Method in class org.springframework.batch.item.xml.StaxEventItemWriter
-
Get XML version.
- getWhereClause() - Method in class org.springframework.batch.item.database.support.AbstractSqlPagingQueryProvider
- getWriteCount() - Method in class org.springframework.batch.core.StepContribution
-
Public access to the write counter.
- getWriteCount() - Method in class org.springframework.batch.core.StepExecution
-
Returns the current number of items written for this execution.
- getWriter() - Method in class org.springframework.batch.core.step.builder.SimpleStepBuilder
- getWriteSkipCount() - Method in class org.springframework.batch.core.StepContribution
-
Public getter for the write skip count.
- getWriteSkipCount() - Method in class org.springframework.batch.core.StepExecution
- getWrittenItems() - Method in class org.springframework.batch.item.support.ListItemWriter
StepBuilder.chunk(int, PlatformTransactionManager)